Uses of Interface
org.apache.druid.query.DataSource
-
-
Uses of DataSource in org.apache.druid.query
Classes in org.apache.druid.query that implement DataSource Modifier and Type Class Description classFilteredDataSourceThis class models a data source to be unnested which is present along with a filter.classFrameBasedInlineDataSourceRepresents an inline datasource where the rows are embedded within the DataSource object itself.classGlobalTableDataSourceTableDataSourcevariant for globally available 'broadcast' segments.classInlineDataSourceRepresents an inline datasource, where the rows are embedded within the DataSource object itself.classJoinDataSourceRepresents a join of two datasources.classLookupDataSourceRepresents a lookup.classQueryDataSourceclassTableDataSourceclassUnionDataSourceReperesents a UNION ALL of two or more datasources.classUnnestDataSourceThe data source for representing an unnest operation.Methods in org.apache.druid.query that return DataSource Modifier and Type Method Description DataSourceFilteredDataSource. getBase()DataSourceUnnestDataSource. getBase()DataSourceBaseQuery. getDataSource()DataSourceQuery. getDataSource()DataSourceJoinDataSource. getLeft()DataSourceJoinDataSource. getRight()DataSourceDataSource. withChildren(List<DataSource> children)Return a new DataSource, identical to this one, with different children.DataSourceFilteredDataSource. withChildren(List<DataSource> children)DataSourceFrameBasedInlineDataSource. withChildren(List<DataSource> children)DataSourceInlineDataSource. withChildren(List<DataSource> children)DataSourceJoinDataSource. withChildren(List<DataSource> children)DataSourceLookupDataSource. withChildren(List<DataSource> children)DataSourceQueryDataSource. withChildren(List<DataSource> children)DataSourceTableDataSource. withChildren(List<DataSource> children)DataSourceUnionDataSource. withChildren(List<DataSource> children)DataSourceUnnestDataSource. withChildren(List<DataSource> children)DataSourceDataSource. withUpdatedDataSource(DataSource newSource)Returns an updated datasource based on the specified new source.DataSourceFilteredDataSource. withUpdatedDataSource(DataSource newSource)DataSourceFrameBasedInlineDataSource. withUpdatedDataSource(DataSource newSource)DataSourceInlineDataSource. withUpdatedDataSource(DataSource newSource)DataSourceJoinDataSource. withUpdatedDataSource(DataSource newSource)DataSourceLookupDataSource. withUpdatedDataSource(DataSource newSource)DataSourceQueryDataSource. withUpdatedDataSource(DataSource newSource)DataSourceTableDataSource. withUpdatedDataSource(DataSource newSource)DataSourceUnionDataSource. withUpdatedDataSource(DataSource newSource)DataSourceUnnestDataSource. withUpdatedDataSource(DataSource newSource)Methods in org.apache.druid.query that return types with arguments of type DataSource Modifier and Type Method Description List<DataSource>DataSource. getChildren()Returns datasources that this datasource depends on.List<DataSource>FilteredDataSource. getChildren()List<DataSource>FrameBasedInlineDataSource. getChildren()List<DataSource>InlineDataSource. getChildren()List<DataSource>JoinDataSource. getChildren()List<DataSource>LookupDataSource. getChildren()List<DataSource>QueryDataSource. getChildren()List<DataSource>TableDataSource. getChildren()List<DataSource>UnionDataSource. getChildren()List<DataSource>UnnestDataSource. getChildren()List<DataSource>UnionDataSource. getDataSources()Methods in org.apache.druid.query with parameters of type DataSource Modifier and Type Method Description static FilteredDataSourceFilteredDataSource. create(DataSource base, DimFilter f)static JoinDataSourceJoinDataSource. create(DataSource left, DataSource right, String rightPrefix, String condition, JoinType joinType, DimFilter leftFilter, ExprMacroTable macroTable, JoinableFactoryWrapper joinableFactoryWrapper)Create a join dataSource from a string condition.static JoinDataSourceJoinDataSource. create(DataSource left, DataSource right, String rightPrefix, JoinConditionAnalysis conditionAnalysis, JoinType joinType, DimFilter leftFilter, JoinableFactoryWrapper joinableFactoryWrapper)Create a join dataSource from an existingJoinConditionAnalysis.static UnnestDataSourceUnnestDataSource. create(DataSource base, VirtualColumn virtualColumn, DimFilter unnestFilter)Druids.DataSourceMetadataQueryBuilderDruids.DataSourceMetadataQueryBuilder. dataSource(DataSource ds)Druids.ScanQueryBuilderDruids.ScanQueryBuilder. dataSource(DataSource ds)Druids.SearchQueryBuilderDruids.SearchQueryBuilder. dataSource(DataSource d)Druids.SegmentMetadataQueryBuilderDruids.SegmentMetadataQueryBuilder. dataSource(DataSource ds)Druids.TimeBoundaryQueryBuilderDruids.TimeBoundaryQueryBuilder. dataSource(DataSource ds)Druids.TimeseriesQueryBuilderDruids.TimeseriesQueryBuilder. dataSource(DataSource ds)static <T> Query<T>Queries. withBaseDataSource(Query<T> query, DataSource newBaseDataSource)Rewrite "query" to refer to some specific base datasource, instead of the one it currently refers to.Query<T>Query. withDataSource(DataSource dataSource)DataSourceDataSource. withUpdatedDataSource(DataSource newSource)Returns an updated datasource based on the specified new source.DataSourceFilteredDataSource. withUpdatedDataSource(DataSource newSource)DataSourceFrameBasedInlineDataSource. withUpdatedDataSource(DataSource newSource)DataSourceInlineDataSource. withUpdatedDataSource(DataSource newSource)DataSourceJoinDataSource. withUpdatedDataSource(DataSource newSource)DataSourceLookupDataSource. withUpdatedDataSource(DataSource newSource)DataSourceQueryDataSource. withUpdatedDataSource(DataSource newSource)DataSourceTableDataSource. withUpdatedDataSource(DataSource newSource)DataSourceUnionDataSource. withUpdatedDataSource(DataSource newSource)DataSourceUnnestDataSource. withUpdatedDataSource(DataSource newSource)Method parameters in org.apache.druid.query with type arguments of type DataSource Modifier and Type Method Description DataSourceDataSource. withChildren(List<DataSource> children)Return a new DataSource, identical to this one, with different children.DataSourceFilteredDataSource. withChildren(List<DataSource> children)DataSourceFrameBasedInlineDataSource. withChildren(List<DataSource> children)DataSourceInlineDataSource. withChildren(List<DataSource> children)DataSourceJoinDataSource. withChildren(List<DataSource> children)DataSourceLookupDataSource. withChildren(List<DataSource> children)DataSourceQueryDataSource. withChildren(List<DataSource> children)DataSourceTableDataSource. withChildren(List<DataSource> children)DataSourceUnionDataSource. withChildren(List<DataSource> children)DataSourceUnnestDataSource. withChildren(List<DataSource> children)Constructors in org.apache.druid.query with parameters of type DataSource Constructor Description BaseQuery(DataSource dataSource, QuerySegmentSpec querySegmentSpec, boolean descending, Map<String,Object> context)BaseQuery(DataSource dataSource, QuerySegmentSpec querySegmentSpec, boolean descending, Map<String,Object> context, Granularity granularity)Constructor parameters in org.apache.druid.query with type arguments of type DataSource Constructor Description UnionDataSource(List<DataSource> dataSources) -
Uses of DataSource in org.apache.druid.query.datasourcemetadata
Methods in org.apache.druid.query.datasourcemetadata with parameters of type DataSource Modifier and Type Method Description Query<Result<DataSourceMetadataResultValue>>DataSourceMetadataQuery. withDataSource(DataSource dataSource)Constructors in org.apache.druid.query.datasourcemetadata with parameters of type DataSource Constructor Description DataSourceMetadataQuery(DataSource dataSource, QuerySegmentSpec querySegmentSpec, Map<String,Object> context) -
Uses of DataSource in org.apache.druid.query.groupby
Methods in org.apache.druid.query.groupby with parameters of type DataSource Modifier and Type Method Description GroupByQuery.BuilderGroupByQuery.Builder. setDataSource(DataSource dataSource)Query<ResultRow>GroupByQuery. withDataSource(DataSource dataSource)Constructors in org.apache.druid.query.groupby with parameters of type DataSource Constructor Description GroupByQuery(DataSource dataSource, QuerySegmentSpec querySegmentSpec, VirtualColumns virtualColumns, DimFilter dimFilter, Granularity granularity, List<DimensionSpec> dimensions, List<AggregatorFactory> aggregatorSpecs, List<PostAggregator> postAggregatorSpecs, HavingSpec havingSpec, LimitSpec limitSpec, List<List<String>> subtotalsSpec, Map<String,Object> context) -
Uses of DataSource in org.apache.druid.query.metadata.metadata
Methods in org.apache.druid.query.metadata.metadata with parameters of type DataSource Modifier and Type Method Description Query<SegmentAnalysis>SegmentMetadataQuery. withDataSource(DataSource dataSource)Constructors in org.apache.druid.query.metadata.metadata with parameters of type DataSource Constructor Description SegmentMetadataQuery(DataSource dataSource, QuerySegmentSpec querySegmentSpec, ColumnIncluderator toInclude, Boolean merge, Map<String,Object> context, EnumSet<SegmentMetadataQuery.AnalysisType> analysisTypes, Boolean useDefaultInterval, Boolean lenientAggregatorMerge, AggregatorMergeStrategy aggregatorMergeStrategy) -
Uses of DataSource in org.apache.druid.query.operator
Methods in org.apache.druid.query.operator with parameters of type DataSource Modifier and Type Method Description Query<RowsAndColumns>WindowOperatorQuery. withDataSource(DataSource dataSource)Constructors in org.apache.druid.query.operator with parameters of type DataSource Constructor Description WindowOperatorQuery(DataSource dataSource, QuerySegmentSpec intervals, Map<String,Object> context, RowSignature rowSignature, List<OperatorFactory> operators, List<OperatorFactory> leafOperators) -
Uses of DataSource in org.apache.druid.query.planning
Methods in org.apache.druid.query.planning that return DataSource Modifier and Type Method Description DataSourceDataSourceAnalysis. getBaseDataSource()Returns the base (bottom-leftmost) datasource.DataSourcePreJoinableClause. getDataSource()Constructors in org.apache.druid.query.planning with parameters of type DataSource Constructor Description DataSourceAnalysis(DataSource baseDataSource, Query<?> baseQuery, DimFilter joinBaseTableFilter, List<PreJoinableClause> preJoinableClauses)PreJoinableClause(String prefix, DataSource dataSource, JoinType joinType, JoinConditionAnalysis condition) -
Uses of DataSource in org.apache.druid.query.scan
Methods in org.apache.druid.query.scan with parameters of type DataSource Modifier and Type Method Description ScanQueryScanQuery. withDataSource(DataSource dataSource)Constructors in org.apache.druid.query.scan with parameters of type DataSource Constructor Description ScanQuery(DataSource dataSource, QuerySegmentSpec querySegmentSpec, VirtualColumns virtualColumns, ScanQuery.ResultFormat resultFormat, int batchSize, long scanRowsOffset, long scanRowsLimit, ScanQuery.Order orderFromUser, List<ScanQuery.OrderBy> orderBysFromUser, DimFilter dimFilter, List<String> columns, Boolean legacy, Map<String,Object> context) -
Uses of DataSource in org.apache.druid.query.search
Methods in org.apache.druid.query.search with parameters of type DataSource Modifier and Type Method Description Query<Result<SearchResultValue>>SearchQuery. withDataSource(DataSource dataSource)Constructors in org.apache.druid.query.search with parameters of type DataSource Constructor Description SearchQuery(DataSource dataSource, DimFilter dimFilter, Granularity granularity, int limit, QuerySegmentSpec querySegmentSpec, List<DimensionSpec> dimensions, VirtualColumns virtualColumns, SearchQuerySpec querySpec, SearchSortSpec sortSpec, Map<String,Object> context) -
Uses of DataSource in org.apache.druid.query.select
Methods in org.apache.druid.query.select that return DataSource Modifier and Type Method Description DataSourceSelectQuery. getDataSource()Deprecated.Methods in org.apache.druid.query.select with parameters of type DataSource Modifier and Type Method Description Query<Object>SelectQuery. withDataSource(DataSource dataSource)Deprecated. -
Uses of DataSource in org.apache.druid.query.timeboundary
Methods in org.apache.druid.query.timeboundary with parameters of type DataSource Modifier and Type Method Description Query<Result<TimeBoundaryResultValue>>TimeBoundaryQuery. withDataSource(DataSource dataSource)Constructors in org.apache.druid.query.timeboundary with parameters of type DataSource Constructor Description TimeBoundaryQuery(DataSource dataSource, QuerySegmentSpec querySegmentSpec, String bound, DimFilter dimFilter, Map<String,Object> context) -
Uses of DataSource in org.apache.druid.query.timeseries
Methods in org.apache.druid.query.timeseries with parameters of type DataSource Modifier and Type Method Description Query<Result<TimeseriesResultValue>>TimeseriesQuery. withDataSource(DataSource dataSource)Constructors in org.apache.druid.query.timeseries with parameters of type DataSource Constructor Description TimeseriesQuery(DataSource dataSource, QuerySegmentSpec querySegmentSpec, boolean descending, VirtualColumns virtualColumns, DimFilter dimFilter, Granularity granularity, List<AggregatorFactory> aggregatorSpecs, List<PostAggregator> postAggregatorSpecs, int limit, Map<String,Object> context) -
Uses of DataSource in org.apache.druid.query.topn
Methods in org.apache.druid.query.topn with parameters of type DataSource Modifier and Type Method Description TopNQueryBuilderTopNQueryBuilder. dataSource(DataSource d)Query<Result<TopNResultValue>>TopNQuery. withDataSource(DataSource dataSource)Constructors in org.apache.druid.query.topn with parameters of type DataSource Constructor Description TopNQuery(DataSource dataSource, VirtualColumns virtualColumns, DimensionSpec dimensionSpec, TopNMetricSpec topNMetricSpec, int threshold, QuerySegmentSpec querySegmentSpec, DimFilter dimFilter, Granularity granularity, List<AggregatorFactory> aggregatorSpecs, List<PostAggregator> postAggregatorSpecs, Map<String,Object> context) -
Uses of DataSource in org.apache.druid.segment
Methods in org.apache.druid.segment with parameters of type DataSource Modifier and Type Method Description Iterable<Segment>SegmentWrangler. getSegmentsForIntervals(DataSource dataSource, Iterable<org.joda.time.Interval> intervals)Gets Segments for a particular datasource and set of intervals. -
Uses of DataSource in org.apache.druid.segment.join
Methods in org.apache.druid.segment.join with parameters of type DataSource Modifier and Type Method Description Optional<Joinable>FrameBasedInlineJoinableFactory. build(DataSource dataSource, JoinConditionAnalysis condition)Optional<Joinable>InlineJoinableFactory. build(DataSource dataSource, JoinConditionAnalysis condition)Optional<Joinable>JoinableFactory. build(DataSource dataSource, JoinConditionAnalysis condition)Create a Joinable object.Optional<Joinable>MapJoinableFactory. build(DataSource dataSource, JoinConditionAnalysis condition)Optional<Joinable>NoopJoinableFactory. build(DataSource dataSource, JoinConditionAnalysis condition)default Optional<byte[]>JoinableFactory. computeJoinCacheKey(DataSource dataSource, JoinConditionAnalysis condition)Compute the cache key for a data source participating in join operation.Optional<byte[]>MapJoinableFactory. computeJoinCacheKey(DataSource dataSource, JoinConditionAnalysis condition)booleanFrameBasedInlineJoinableFactory. isDirectlyJoinable(DataSource dataSource)booleanInlineJoinableFactory. isDirectlyJoinable(DataSource dataSource)booleanJoinableFactory. isDirectlyJoinable(DataSource dataSource)Returns true if aJoinable**may** be created for a givenDataSource, but is not a guarantee thatJoinableFactory.build(org.apache.druid.query.DataSource, org.apache.druid.segment.join.JoinConditionAnalysis)will return a non-empty result.booleanMapJoinableFactory. isDirectlyJoinable(DataSource dataSource)booleanNoopJoinableFactory. isDirectlyJoinable(DataSource dataSource)Constructor parameters in org.apache.druid.segment.join with type arguments of type DataSource Constructor Description MapJoinableFactory(Set<JoinableFactory> factories, Map<Class<? extends JoinableFactory>,Class<? extends DataSource>> factoryToDataSource)
-