All Downloads are FREE. Search and download functionalities are using the official Maven repository.

org.elasticsearch.search.aggregations.AggregationPhase Maven / Gradle / Ivy

/*
 * Copyright Elasticsearch B.V. and/or licensed to Elasticsearch B.V. under one
 * or more contributor license agreements. Licensed under the Elastic License
 * 2.0 and the Server Side Public License, v 1; you may not use this file except
 * in compliance with, at your election, the Elastic License 2.0 or the Server
 * Side Public License, v 1.
 */
package org.elasticsearch.search.aggregations;

import org.apache.lucene.search.Collector;
import org.apache.lucene.search.CollectorManager;
import org.elasticsearch.action.search.SearchShardTask;
import org.elasticsearch.search.aggregations.support.TimeSeriesIndexSearcher;
import org.elasticsearch.search.internal.SearchContext;
import org.elasticsearch.search.query.QueryPhase;

import java.io.IOException;
import java.util.ArrayList;
import java.util.Collection;
import java.util.List;
import java.util.function.Supplier;

/**
 * Aggregation phase of a search request, used to collect aggregations
 */
public class AggregationPhase {

    private AggregationPhase() {}

    public static void preProcess(SearchContext context) {
        if (context.aggregations() == null) {
            return;
        }
        final Supplier collectorSupplier;
        if (context.aggregations().isInSortOrderExecutionRequired()) {
            executeInSortOrder(context, newBucketCollector(context));
            collectorSupplier = () -> BucketCollector.NO_OP_COLLECTOR;
        } else {
            collectorSupplier = () -> newBucketCollector(context).asCollector();
        }
        context.aggregations().registerAggsCollectorManager(new CollectorManager<>() {
            @Override
            public Collector newCollector() {
                return collectorSupplier.get();
            }

            @Override
            public Void reduce(Collection collectors) {
                // we cannot run post-collection method here because we need to do it after the optional timeout
                // has been removed from the index searcher. Therefore, we delay this processing to the
                // AggregationPhase#execute method.
                return null;
            }
        });
    }

    private static BucketCollector newBucketCollector(SearchContext context) {
        try {
            Aggregator[] aggregators = context.aggregations().factories().createTopLevelAggregators();
            context.aggregations().aggregators(aggregators);
            BucketCollector bucketCollector = MultiBucketCollector.wrap(true, List.of(aggregators));
            bucketCollector.preCollection();
            return bucketCollector;
        } catch (IOException e) {
            throw new AggregationInitializationException("Could not initialize aggregators", e);
        }
    }

    private static void executeInSortOrder(SearchContext context, BucketCollector collector) {
        TimeSeriesIndexSearcher searcher = new TimeSeriesIndexSearcher(context.searcher(), getCancellationChecks(context));
        searcher.setMinimumScore(context.minimumScore());
        searcher.setProfiler(context);
        try {
            searcher.search(context.rewrittenQuery(), collector);
        } catch (IOException e) {
            throw new AggregationExecutionException("Could not perform time series aggregation", e);
        }
    }

    private static List getCancellationChecks(SearchContext context) {
        List cancellationChecks = new ArrayList<>();
        if (context.lowLevelCancellation()) {
            // This searching doesn't live beyond this phase, so we don't need to remove query cancellation
            cancellationChecks.add(() -> {
                final SearchShardTask task = context.getTask();
                if (task != null) {
                    task.ensureNotCancelled();
                }
            });
        }

        final Runnable timeoutRunnable = QueryPhase.getTimeoutCheck(context);
        if (timeoutRunnable != null) {
            cancellationChecks.add(timeoutRunnable);
        }

        return cancellationChecks;
    }

    public static void execute(SearchContext context) {
        if (context.aggregations() == null) {
            context.queryResult().aggregations(null);
            return;
        }

        if (context.queryResult().hasAggs()) {
            // no need to compute the aggs twice, they should be computed on a per context basis
            return;
        }

        final List internalAggregations = new ArrayList<>(context.aggregations().aggregators().size());
        for (Aggregator[] aggregators : context.aggregations().aggregators()) {
            final List aggregations = new ArrayList<>(aggregators.length);
            for (Aggregator aggregator : aggregators) {
                try {
                    aggregations.add(aggregator.buildTopLevel());
                } catch (IOException e) {
                    throw new AggregationExecutionException("Failed to build aggregation [" + aggregator.name() + "]", e);
                }
                // release the aggregator to claim the used bytes as we don't need it anymore
                aggregator.releaseAggregations();
            }
            internalAggregations.add(InternalAggregations.from(aggregations));
        }

        if (internalAggregations.size() > 1) {
            // we execute this search using more than one slice. In order to keep memory requirements
            // low, we do a partial reduction here.
            context.queryResult()
                .aggregations(
                    InternalAggregations.topLevelReduce(
                        internalAggregations,
                        context.aggregations().getAggregationReduceContextBuilder().forPartialReduction()
                    )
                );
        } else {
            context.queryResult().aggregations(internalAggregations.get(0));
        }

        // disable aggregations so that they don't run on next pages in case of scrolling
        context.aggregations(null);
    }
}




© 2015 - 2025 Weber Informatics LLC | Privacy Policy