LCOV - code coverage report
Current view: top level - src/backend/executor - nodeAgg.c (source / functions) Coverage Total Hit
Test: Code coverage Lines: 95.4 % 1970 1879
Test Date: 2026-01-26 10:56:24 Functions: 98.3 % 58 57
Legend: Lines:     hit not hit
Branches: + taken - not taken # not executed
Branches: 79.0 % 1011 799

             Branch data     Line data    Source code
       1                 :             : /*-------------------------------------------------------------------------
       2                 :             :  *
       3                 :             :  * nodeAgg.c
       4                 :             :  *        Routines to handle aggregate nodes.
       5                 :             :  *
       6                 :             :  *        ExecAgg normally evaluates each aggregate in the following steps:
       7                 :             :  *
       8                 :             :  *               transvalue = initcond
       9                 :             :  *               foreach input_tuple do
      10                 :             :  *                      transvalue = transfunc(transvalue, input_value(s))
      11                 :             :  *               result = finalfunc(transvalue, direct_argument(s))
      12                 :             :  *
      13                 :             :  *        If a finalfunc is not supplied then the result is just the ending
      14                 :             :  *        value of transvalue.
      15                 :             :  *
      16                 :             :  *        Other behaviors can be selected by the "aggsplit" mode, which exists
      17                 :             :  *        to support partial aggregation.  It is possible to:
      18                 :             :  *        * Skip running the finalfunc, so that the output is always the
      19                 :             :  *        final transvalue state.
      20                 :             :  *        * Substitute the combinefunc for the transfunc, so that transvalue
      21                 :             :  *        states (propagated up from a child partial-aggregation step) are merged
      22                 :             :  *        rather than processing raw input rows.  (The statements below about
      23                 :             :  *        the transfunc apply equally to the combinefunc, when it's selected.)
      24                 :             :  *        * Apply the serializefunc to the output values (this only makes sense
      25                 :             :  *        when skipping the finalfunc, since the serializefunc works on the
      26                 :             :  *        transvalue data type).
      27                 :             :  *        * Apply the deserializefunc to the input values (this only makes sense
      28                 :             :  *        when using the combinefunc, for similar reasons).
      29                 :             :  *        It is the planner's responsibility to connect up Agg nodes using these
      30                 :             :  *        alternate behaviors in a way that makes sense, with partial aggregation
      31                 :             :  *        results being fed to nodes that expect them.
      32                 :             :  *
      33                 :             :  *        If a normal aggregate call specifies DISTINCT or ORDER BY, we sort the
      34                 :             :  *        input tuples and eliminate duplicates (if required) before performing
      35                 :             :  *        the above-depicted process.  (However, we don't do that for ordered-set
      36                 :             :  *        aggregates; their "ORDER BY" inputs are ordinary aggregate arguments
      37                 :             :  *        so far as this module is concerned.)  Note that partial aggregation
      38                 :             :  *        is not supported in these cases, since we couldn't ensure global
      39                 :             :  *        ordering or distinctness of the inputs.
      40                 :             :  *
      41                 :             :  *        If transfunc is marked "strict" in pg_proc and initcond is NULL,
      42                 :             :  *        then the first non-NULL input_value is assigned directly to transvalue,
      43                 :             :  *        and transfunc isn't applied until the second non-NULL input_value.
      44                 :             :  *        The agg's first input type and transtype must be the same in this case!
      45                 :             :  *
      46                 :             :  *        If transfunc is marked "strict" then NULL input_values are skipped,
      47                 :             :  *        keeping the previous transvalue.  If transfunc is not strict then it
      48                 :             :  *        is called for every input tuple and must deal with NULL initcond
      49                 :             :  *        or NULL input_values for itself.
      50                 :             :  *
      51                 :             :  *        If finalfunc is marked "strict" then it is not called when the
      52                 :             :  *        ending transvalue is NULL, instead a NULL result is created
      53                 :             :  *        automatically (this is just the usual handling of strict functions,
      54                 :             :  *        of course).  A non-strict finalfunc can make its own choice of
      55                 :             :  *        what to return for a NULL ending transvalue.
      56                 :             :  *
      57                 :             :  *        Ordered-set aggregates are treated specially in one other way: we
      58                 :             :  *        evaluate any "direct" arguments and pass them to the finalfunc along
      59                 :             :  *        with the transition value.
      60                 :             :  *
      61                 :             :  *        A finalfunc can have additional arguments beyond the transvalue and
      62                 :             :  *        any "direct" arguments, corresponding to the input arguments of the
      63                 :             :  *        aggregate.  These are always just passed as NULL.  Such arguments may be
      64                 :             :  *        needed to allow resolution of a polymorphic aggregate's result type.
      65                 :             :  *
      66                 :             :  *        We compute aggregate input expressions and run the transition functions
      67                 :             :  *        in a temporary econtext (aggstate->tmpcontext).  This is reset at least
      68                 :             :  *        once per input tuple, so when the transvalue datatype is
      69                 :             :  *        pass-by-reference, we have to be careful to copy it into a longer-lived
      70                 :             :  *        memory context, and free the prior value to avoid memory leakage.  We
      71                 :             :  *        store transvalues in another set of econtexts, aggstate->aggcontexts
      72                 :             :  *        (one per grouping set, see below), which are also used for the hashtable
      73                 :             :  *        structures in AGG_HASHED mode.  These econtexts are rescanned, not just
      74                 :             :  *        reset, at group boundaries so that aggregate transition functions can
      75                 :             :  *        register shutdown callbacks via AggRegisterCallback.
      76                 :             :  *
      77                 :             :  *        The node's regular econtext (aggstate->ss.ps.ps_ExprContext) is used to
      78                 :             :  *        run finalize functions and compute the output tuple; this context can be
      79                 :             :  *        reset once per output tuple.
      80                 :             :  *
      81                 :             :  *        The executor's AggState node is passed as the fmgr "context" value in
      82                 :             :  *        all transfunc and finalfunc calls.  It is not recommended that the
      83                 :             :  *        transition functions look at the AggState node directly, but they can
      84                 :             :  *        use AggCheckCallContext() to verify that they are being called by
      85                 :             :  *        nodeAgg.c (and not as ordinary SQL functions).  The main reason a
      86                 :             :  *        transition function might want to know this is so that it can avoid
      87                 :             :  *        palloc'ing a fixed-size pass-by-ref transition value on every call:
      88                 :             :  *        it can instead just scribble on and return its left input.  Ordinarily
      89                 :             :  *        it is completely forbidden for functions to modify pass-by-ref inputs,
      90                 :             :  *        but in the aggregate case we know the left input is either the initial
      91                 :             :  *        transition value or a previous function result, and in either case its
      92                 :             :  *        value need not be preserved.  See int8inc() for an example.  Notice that
      93                 :             :  *        the EEOP_AGG_PLAIN_TRANS step is coded to avoid a data copy step when
      94                 :             :  *        the previous transition value pointer is returned.  It is also possible
      95                 :             :  *        to avoid repeated data copying when the transition value is an expanded
      96                 :             :  *        object: to do that, the transition function must take care to return
      97                 :             :  *        an expanded object that is in a child context of the memory context
      98                 :             :  *        returned by AggCheckCallContext().  Also, some transition functions want
      99                 :             :  *        to store working state in addition to the nominal transition value; they
     100                 :             :  *        can use the memory context returned by AggCheckCallContext() to do that.
     101                 :             :  *
     102                 :             :  *        Note: AggCheckCallContext() is available as of PostgreSQL 9.0.  The
     103                 :             :  *        AggState is available as context in earlier releases (back to 8.1),
     104                 :             :  *        but direct examination of the node is needed to use it before 9.0.
     105                 :             :  *
     106                 :             :  *        As of 9.4, aggregate transition functions can also use AggGetAggref()
     107                 :             :  *        to get hold of the Aggref expression node for their aggregate call.
     108                 :             :  *        This is mainly intended for ordered-set aggregates, which are not
     109                 :             :  *        supported as window functions.  (A regular aggregate function would
     110                 :             :  *        need some fallback logic to use this, since there's no Aggref node
     111                 :             :  *        for a window function.)
     112                 :             :  *
     113                 :             :  *        Grouping sets:
     114                 :             :  *
     115                 :             :  *        A list of grouping sets which is structurally equivalent to a ROLLUP
     116                 :             :  *        clause (e.g. (a,b,c), (a,b), (a)) can be processed in a single pass over
     117                 :             :  *        ordered data.  We do this by keeping a separate set of transition values
     118                 :             :  *        for each grouping set being concurrently processed; for each input tuple
     119                 :             :  *        we update them all, and on group boundaries we reset those states
     120                 :             :  *        (starting at the front of the list) whose grouping values have changed
     121                 :             :  *        (the list of grouping sets is ordered from most specific to least
     122                 :             :  *        specific).
     123                 :             :  *
     124                 :             :  *        Where more complex grouping sets are used, we break them down into
     125                 :             :  *        "phases", where each phase has a different sort order (except phase 0
     126                 :             :  *        which is reserved for hashing).  During each phase but the last, the
     127                 :             :  *        input tuples are additionally stored in a tuplesort which is keyed to the
     128                 :             :  *        next phase's sort order; during each phase but the first, the input
     129                 :             :  *        tuples are drawn from the previously sorted data.  (The sorting of the
     130                 :             :  *        data for the first phase is handled by the planner, as it might be
     131                 :             :  *        satisfied by underlying nodes.)
     132                 :             :  *
     133                 :             :  *        Hashing can be mixed with sorted grouping.  To do this, we have an
     134                 :             :  *        AGG_MIXED strategy that populates the hashtables during the first sorted
     135                 :             :  *        phase, and switches to reading them out after completing all sort phases.
     136                 :             :  *        We can also support AGG_HASHED with multiple hash tables and no sorting
     137                 :             :  *        at all.
     138                 :             :  *
     139                 :             :  *        From the perspective of aggregate transition and final functions, the
     140                 :             :  *        only issue regarding grouping sets is this: a single call site (flinfo)
     141                 :             :  *        of an aggregate function may be used for updating several different
     142                 :             :  *        transition values in turn. So the function must not cache in the flinfo
     143                 :             :  *        anything which logically belongs as part of the transition value (most
     144                 :             :  *        importantly, the memory context in which the transition value exists).
     145                 :             :  *        The support API functions (AggCheckCallContext, AggRegisterCallback) are
     146                 :             :  *        sensitive to the grouping set for which the aggregate function is
     147                 :             :  *        currently being called.
     148                 :             :  *
     149                 :             :  *        Plan structure:
     150                 :             :  *
     151                 :             :  *        What we get from the planner is actually one "real" Agg node which is
     152                 :             :  *        part of the plan tree proper, but which optionally has an additional list
     153                 :             :  *        of Agg nodes hung off the side via the "chain" field.  This is because an
     154                 :             :  *        Agg node happens to be a convenient representation of all the data we
     155                 :             :  *        need for grouping sets.
     156                 :             :  *
     157                 :             :  *        For many purposes, we treat the "real" node as if it were just the first
     158                 :             :  *        node in the chain.  The chain must be ordered such that hashed entries
     159                 :             :  *        come before sorted/plain entries; the real node is marked AGG_MIXED if
     160                 :             :  *        there are both types present (in which case the real node describes one
     161                 :             :  *        of the hashed groupings, other AGG_HASHED nodes may optionally follow in
     162                 :             :  *        the chain, followed in turn by AGG_SORTED or (one) AGG_PLAIN node).  If
     163                 :             :  *        the real node is marked AGG_HASHED or AGG_SORTED, then all the chained
     164                 :             :  *        nodes must be of the same type; if it is AGG_PLAIN, there can be no
     165                 :             :  *        chained nodes.
     166                 :             :  *
     167                 :             :  *        We collect all hashed nodes into a single "phase", numbered 0, and create
     168                 :             :  *        a sorted phase (numbered 1..n) for each AGG_SORTED or AGG_PLAIN node.
     169                 :             :  *        Phase 0 is allocated even if there are no hashes, but remains unused in
     170                 :             :  *        that case.
     171                 :             :  *
     172                 :             :  *        AGG_HASHED nodes actually refer to only a single grouping set each,
     173                 :             :  *        because for each hashed grouping we need a separate grpColIdx and
     174                 :             :  *        numGroups estimate.  AGG_SORTED nodes represent a "rollup", a list of
     175                 :             :  *        grouping sets that share a sort order.  Each AGG_SORTED node other than
     176                 :             :  *        the first one has an associated Sort node which describes the sort order
     177                 :             :  *        to be used; the first sorted node takes its input from the outer subtree,
     178                 :             :  *        which the planner has already arranged to provide ordered data.
     179                 :             :  *
     180                 :             :  *        Memory and ExprContext usage:
     181                 :             :  *
     182                 :             :  *        Because we're accumulating aggregate values across input rows, we need to
     183                 :             :  *        use more memory contexts than just simple input/output tuple contexts.
     184                 :             :  *        In fact, for a rollup, we need a separate context for each grouping set
     185                 :             :  *        so that we can reset the inner (finer-grained) aggregates on their group
     186                 :             :  *        boundaries while continuing to accumulate values for outer
     187                 :             :  *        (coarser-grained) groupings.  On top of this, we might be simultaneously
     188                 :             :  *        populating hashtables; however, we only need one context for all the
     189                 :             :  *        hashtables.
     190                 :             :  *
     191                 :             :  *        So we create an array, aggcontexts, with an ExprContext for each grouping
     192                 :             :  *        set in the largest rollup that we're going to process, and use the
     193                 :             :  *        per-tuple memory context of those ExprContexts to store the aggregate
     194                 :             :  *        transition values.  hashcontext is the single context created to support
     195                 :             :  *        all hash tables.
     196                 :             :  *
     197                 :             :  *        Spilling To Disk
     198                 :             :  *
     199                 :             :  *        When performing hash aggregation, if the hash table memory exceeds the
     200                 :             :  *        limit (see hash_agg_check_limits()), we enter "spill mode". In spill
     201                 :             :  *        mode, we advance the transition states only for groups already in the
     202                 :             :  *        hash table. For tuples that would need to create a new hash table
     203                 :             :  *        entries (and initialize new transition states), we instead spill them to
     204                 :             :  *        disk to be processed later. The tuples are spilled in a partitioned
     205                 :             :  *        manner, so that subsequent batches are smaller and less likely to exceed
     206                 :             :  *        hash_mem (if a batch does exceed hash_mem, it must be spilled
     207                 :             :  *        recursively).
     208                 :             :  *
     209                 :             :  *        Spilled data is written to logical tapes. These provide better control
     210                 :             :  *        over memory usage, disk space, and the number of files than if we were
     211                 :             :  *        to use a BufFile for each spill.  We don't know the number of tapes needed
     212                 :             :  *        at the start of the algorithm (because it can recurse), so a tape set is
     213                 :             :  *        allocated at the beginning, and individual tapes are created as needed.
     214                 :             :  *        As a particular tape is read, logtape.c recycles its disk space. When a
     215                 :             :  *        tape is read to completion, it is destroyed entirely.
     216                 :             :  *
     217                 :             :  *        Tapes' buffers can take up substantial memory when many tapes are open at
     218                 :             :  *        once. We only need one tape open at a time in read mode (using a buffer
     219                 :             :  *        that's a multiple of BLCKSZ); but we need one tape open in write mode (each
     220                 :             :  *        requiring a buffer of size BLCKSZ) for each partition.
     221                 :             :  *
     222                 :             :  *        Note that it's possible for transition states to start small but then
     223                 :             :  *        grow very large; for instance in the case of ARRAY_AGG. In such cases,
     224                 :             :  *        it's still possible to significantly exceed hash_mem. We try to avoid
     225                 :             :  *        this situation by estimating what will fit in the available memory, and
     226                 :             :  *        imposing a limit on the number of groups separately from the amount of
     227                 :             :  *        memory consumed.
     228                 :             :  *
     229                 :             :  *    Transition / Combine function invocation:
     230                 :             :  *
     231                 :             :  *    For performance reasons transition functions, including combine
     232                 :             :  *    functions, aren't invoked one-by-one from nodeAgg.c after computing
     233                 :             :  *    arguments using the expression evaluation engine. Instead
     234                 :             :  *    ExecBuildAggTrans() builds one large expression that does both argument
     235                 :             :  *    evaluation and transition function invocation. That avoids performance
     236                 :             :  *    issues due to repeated uses of expression evaluation, complications due
     237                 :             :  *    to filter expressions having to be evaluated early, and allows to JIT
     238                 :             :  *    the entire expression into one native function.
     239                 :             :  *
     240                 :             :  * Portions Copyright (c) 1996-2026, PostgreSQL Global Development Group
     241                 :             :  * Portions Copyright (c) 1994, Regents of the University of California
     242                 :             :  *
     243                 :             :  * IDENTIFICATION
     244                 :             :  *        src/backend/executor/nodeAgg.c
     245                 :             :  *
     246                 :             :  *-------------------------------------------------------------------------
     247                 :             :  */
     248                 :             : 
     249                 :             : #include "postgres.h"
     250                 :             : 
     251                 :             : #include "access/htup_details.h"
     252                 :             : #include "access/parallel.h"
     253                 :             : #include "catalog/objectaccess.h"
     254                 :             : #include "catalog/pg_aggregate.h"
     255                 :             : #include "catalog/pg_proc.h"
     256                 :             : #include "catalog/pg_type.h"
     257                 :             : #include "common/hashfn.h"
     258                 :             : #include "executor/execExpr.h"
     259                 :             : #include "executor/executor.h"
     260                 :             : #include "executor/nodeAgg.h"
     261                 :             : #include "lib/hyperloglog.h"
     262                 :             : #include "miscadmin.h"
     263                 :             : #include "nodes/nodeFuncs.h"
     264                 :             : #include "optimizer/optimizer.h"
     265                 :             : #include "parser/parse_agg.h"
     266                 :             : #include "parser/parse_coerce.h"
     267                 :             : #include "utils/acl.h"
     268                 :             : #include "utils/builtins.h"
     269                 :             : #include "utils/datum.h"
     270                 :             : #include "utils/expandeddatum.h"
     271                 :             : #include "utils/injection_point.h"
     272                 :             : #include "utils/logtape.h"
     273                 :             : #include "utils/lsyscache.h"
     274                 :             : #include "utils/memutils.h"
     275                 :             : #include "utils/memutils_memorychunk.h"
     276                 :             : #include "utils/syscache.h"
     277                 :             : #include "utils/tuplesort.h"
     278                 :             : 
     279                 :             : /*
     280                 :             :  * Control how many partitions are created when spilling HashAgg to
     281                 :             :  * disk.
     282                 :             :  *
     283                 :             :  * HASHAGG_PARTITION_FACTOR is multiplied by the estimated number of
     284                 :             :  * partitions needed such that each partition will fit in memory. The factor
     285                 :             :  * is set higher than one because there's not a high cost to having a few too
     286                 :             :  * many partitions, and it makes it less likely that a partition will need to
     287                 :             :  * be spilled recursively. Another benefit of having more, smaller partitions
     288                 :             :  * is that small hash tables may perform better than large ones due to memory
     289                 :             :  * caching effects.
     290                 :             :  *
     291                 :             :  * We also specify a min and max number of partitions per spill. Too few might
     292                 :             :  * mean a lot of wasted I/O from repeated spilling of the same tuples. Too
     293                 :             :  * many will result in lots of memory wasted buffering the spill files (which
     294                 :             :  * could instead be spent on a larger hash table).
     295                 :             :  */
     296                 :             : #define HASHAGG_PARTITION_FACTOR 1.50
     297                 :             : #define HASHAGG_MIN_PARTITIONS 4
     298                 :             : #define HASHAGG_MAX_PARTITIONS 1024
     299                 :             : 
     300                 :             : /*
     301                 :             :  * For reading from tapes, the buffer size must be a multiple of
     302                 :             :  * BLCKSZ. Larger values help when reading from multiple tapes concurrently,
     303                 :             :  * but that doesn't happen in HashAgg, so we simply use BLCKSZ. Writing to a
     304                 :             :  * tape always uses a buffer of size BLCKSZ.
     305                 :             :  */
     306                 :             : #define HASHAGG_READ_BUFFER_SIZE BLCKSZ
     307                 :             : #define HASHAGG_WRITE_BUFFER_SIZE BLCKSZ
     308                 :             : 
     309                 :             : /*
     310                 :             :  * HyperLogLog is used for estimating the cardinality of the spilled tuples in
     311                 :             :  * a given partition. 5 bits corresponds to a size of about 32 bytes and a
     312                 :             :  * worst-case error of around 18%. That's effective enough to choose a
     313                 :             :  * reasonable number of partitions when recursing.
     314                 :             :  */
     315                 :             : #define HASHAGG_HLL_BIT_WIDTH 5
     316                 :             : 
     317                 :             : /*
     318                 :             :  * Assume the palloc overhead always uses sizeof(MemoryChunk) bytes.
     319                 :             :  */
     320                 :             : #define CHUNKHDRSZ sizeof(MemoryChunk)
     321                 :             : 
     322                 :             : /*
     323                 :             :  * Represents partitioned spill data for a single hashtable. Contains the
     324                 :             :  * necessary information to route tuples to the correct partition, and to
     325                 :             :  * transform the spilled data into new batches.
     326                 :             :  *
     327                 :             :  * The high bits are used for partition selection (when recursing, we ignore
     328                 :             :  * the bits that have already been used for partition selection at an earlier
     329                 :             :  * level).
     330                 :             :  */
     331                 :             : typedef struct HashAggSpill
     332                 :             : {
     333                 :             :         int                     npartitions;    /* number of partitions */
     334                 :             :         LogicalTape **partitions;       /* spill partition tapes */
     335                 :             :         int64      *ntuples;            /* number of tuples in each partition */
     336                 :             :         uint32          mask;                   /* mask to find partition from hash value */
     337                 :             :         int                     shift;                  /* after masking, shift by this amount */
     338                 :             :         hyperLogLogState *hll_card; /* cardinality estimate for contents */
     339                 :             : } HashAggSpill;
     340                 :             : 
     341                 :             : /*
     342                 :             :  * Represents work to be done for one pass of hash aggregation (with only one
     343                 :             :  * grouping set).
     344                 :             :  *
     345                 :             :  * Also tracks the bits of the hash already used for partition selection by
     346                 :             :  * earlier iterations, so that this batch can use new bits. If all bits have
     347                 :             :  * already been used, no partitioning will be done (any spilled data will go
     348                 :             :  * to a single output tape).
     349                 :             :  */
     350                 :             : typedef struct HashAggBatch
     351                 :             : {
     352                 :             :         int                     setno;                  /* grouping set */
     353                 :             :         int                     used_bits;              /* number of bits of hash already used */
     354                 :             :         LogicalTape *input_tape;        /* input partition tape */
     355                 :             :         int64           input_tuples;   /* number of tuples in this batch */
     356                 :             :         double          input_card;             /* estimated group cardinality */
     357                 :             : } HashAggBatch;
     358                 :             : 
     359                 :             : /* used to find referenced colnos */
     360                 :             : typedef struct FindColsContext
     361                 :             : {
     362                 :             :         bool            is_aggref;              /* is under an aggref */
     363                 :             :         Bitmapset  *aggregated;         /* column references under an aggref */
     364                 :             :         Bitmapset  *unaggregated;       /* other column references */
     365                 :             : } FindColsContext;
     366                 :             : 
     367                 :             : static void select_current_set(AggState *aggstate, int setno, bool is_hash);
     368                 :             : static void initialize_phase(AggState *aggstate, int newphase);
     369                 :             : static TupleTableSlot *fetch_input_tuple(AggState *aggstate);
     370                 :             : static void initialize_aggregates(AggState *aggstate,
     371                 :             :                                                                   AggStatePerGroup *pergroups,
     372                 :             :                                                                   int numReset);
     373                 :             : static void advance_transition_function(AggState *aggstate,
     374                 :             :                                                                                 AggStatePerTrans pertrans,
     375                 :             :                                                                                 AggStatePerGroup pergroupstate);
     376                 :             : static void advance_aggregates(AggState *aggstate);
     377                 :             : static void process_ordered_aggregate_single(AggState *aggstate,
     378                 :             :                                                                                          AggStatePerTrans pertrans,
     379                 :             :                                                                                          AggStatePerGroup pergroupstate);
     380                 :             : static void process_ordered_aggregate_multi(AggState *aggstate,
     381                 :             :                                                                                         AggStatePerTrans pertrans,
     382                 :             :                                                                                         AggStatePerGroup pergroupstate);
     383                 :             : static void finalize_aggregate(AggState *aggstate,
     384                 :             :                                                            AggStatePerAgg peragg,
     385                 :             :                                                            AggStatePerGroup pergroupstate,
     386                 :             :                                                            Datum *resultVal, bool *resultIsNull);
     387                 :             : static void finalize_partialaggregate(AggState *aggstate,
     388                 :             :                                                                           AggStatePerAgg peragg,
     389                 :             :                                                                           AggStatePerGroup pergroupstate,
     390                 :             :                                                                           Datum *resultVal, bool *resultIsNull);
     391                 :             : static inline void prepare_hash_slot(AggStatePerHash perhash,
     392                 :             :                                                                          TupleTableSlot *inputslot,
     393                 :             :                                                                          TupleTableSlot *hashslot);
     394                 :             : static void prepare_projection_slot(AggState *aggstate,
     395                 :             :                                                                         TupleTableSlot *slot,
     396                 :             :                                                                         int currentSet);
     397                 :             : static void finalize_aggregates(AggState *aggstate,
     398                 :             :                                                                 AggStatePerAgg peraggs,
     399                 :             :                                                                 AggStatePerGroup pergroup);
     400                 :             : static TupleTableSlot *project_aggregates(AggState *aggstate);
     401                 :             : static void find_cols(AggState *aggstate, Bitmapset **aggregated,
     402                 :             :                                           Bitmapset **unaggregated);
     403                 :             : static bool find_cols_walker(Node *node, FindColsContext *context);
     404                 :             : static void build_hash_tables(AggState *aggstate);
     405                 :             : static void build_hash_table(AggState *aggstate, int setno, double nbuckets);
     406                 :             : static void hashagg_recompile_expressions(AggState *aggstate, bool minslot,
     407                 :             :                                                                                   bool nullcheck);
     408                 :             : static void hash_create_memory(AggState *aggstate);
     409                 :             : static double hash_choose_num_buckets(double hashentrysize,
     410                 :             :                                                                           double ngroups, Size memory);
     411                 :             : static int      hash_choose_num_partitions(double input_groups,
     412                 :             :                                                                            double hashentrysize,
     413                 :             :                                                                            int used_bits,
     414                 :             :                                                                            int *log2_npartitions);
     415                 :             : static void initialize_hash_entry(AggState *aggstate,
     416                 :             :                                                                   TupleHashTable hashtable,
     417                 :             :                                                                   TupleHashEntry entry);
     418                 :             : static void lookup_hash_entries(AggState *aggstate);
     419                 :             : static TupleTableSlot *agg_retrieve_direct(AggState *aggstate);
     420                 :             : static void agg_fill_hash_table(AggState *aggstate);
     421                 :             : static bool agg_refill_hash_table(AggState *aggstate);
     422                 :             : static TupleTableSlot *agg_retrieve_hash_table(AggState *aggstate);
     423                 :             : static TupleTableSlot *agg_retrieve_hash_table_in_memory(AggState *aggstate);
     424                 :             : static void hash_agg_check_limits(AggState *aggstate);
     425                 :             : static void hash_agg_enter_spill_mode(AggState *aggstate);
     426                 :             : static void hash_agg_update_metrics(AggState *aggstate, bool from_tape,
     427                 :             :                                                                         int npartitions);
     428                 :             : static void hashagg_finish_initial_spills(AggState *aggstate);
     429                 :             : static void hashagg_reset_spill_state(AggState *aggstate);
     430                 :             : static HashAggBatch *hashagg_batch_new(LogicalTape *input_tape, int setno,
     431                 :             :                                                                            int64 input_tuples, double input_card,
     432                 :             :                                                                            int used_bits);
     433                 :             : static MinimalTuple hashagg_batch_read(HashAggBatch *batch, uint32 *hashp);
     434                 :             : static void hashagg_spill_init(HashAggSpill *spill, LogicalTapeSet *tapeset,
     435                 :             :                                                            int used_bits, double input_groups,
     436                 :             :                                                            double hashentrysize);
     437                 :             : static Size hashagg_spill_tuple(AggState *aggstate, HashAggSpill *spill,
     438                 :             :                                                                 TupleTableSlot *inputslot, uint32 hash);
     439                 :             : static void hashagg_spill_finish(AggState *aggstate, HashAggSpill *spill,
     440                 :             :                                                                  int setno);
     441                 :             : static Datum GetAggInitVal(Datum textInitVal, Oid transtype);
     442                 :             : static void build_pertrans_for_aggref(AggStatePerTrans pertrans,
     443                 :             :                                                                           AggState *aggstate, EState *estate,
     444                 :             :                                                                           Aggref *aggref, Oid transfn_oid,
     445                 :             :                                                                           Oid aggtranstype, Oid aggserialfn,
     446                 :             :                                                                           Oid aggdeserialfn, Datum initValue,
     447                 :             :                                                                           bool initValueIsNull, Oid *inputTypes,
     448                 :             :                                                                           int numArguments);
     449                 :             : 
     450                 :             : 
     451                 :             : /*
     452                 :             :  * Select the current grouping set; affects current_set and
     453                 :             :  * curaggcontext.
     454                 :             :  */
     455                 :             : static void
     456                 :     1188554 : select_current_set(AggState *aggstate, int setno, bool is_hash)
     457                 :             : {
     458                 :             :         /*
     459                 :             :          * When changing this, also adapt ExecAggPlainTransByVal() and
     460                 :             :          * ExecAggPlainTransByRef().
     461                 :             :          */
     462         [ +  + ]:     1188554 :         if (is_hash)
     463                 :     1113400 :                 aggstate->curaggcontext = aggstate->hashcontext;
     464                 :             :         else
     465                 :       75154 :                 aggstate->curaggcontext = aggstate->aggcontexts[setno];
     466                 :             : 
     467                 :     1188554 :         aggstate->current_set = setno;
     468                 :     1188554 : }
     469                 :             : 
     470                 :             : /*
     471                 :             :  * Switch to phase "newphase", which must either be 0 or 1 (to reset) or
     472                 :             :  * current_phase + 1. Juggle the tuplesorts accordingly.
     473                 :             :  *
     474                 :             :  * Phase 0 is for hashing, which we currently handle last in the AGG_MIXED
     475                 :             :  * case, so when entering phase 0, all we need to do is drop open sorts.
     476                 :             :  */
     477                 :             : static void
     478                 :        6856 : initialize_phase(AggState *aggstate, int newphase)
     479                 :             : {
     480   [ +  +  +  - ]:        6856 :         Assert(newphase <= 1 || newphase == aggstate->current_phase + 1);
     481                 :             : 
     482                 :             :         /*
     483                 :             :          * Whatever the previous state, we're now done with whatever input
     484                 :             :          * tuplesort was in use.
     485                 :             :          */
     486         [ +  + ]:        6856 :         if (aggstate->sort_in)
     487                 :             :         {
     488                 :           7 :                 tuplesort_end(aggstate->sort_in);
     489                 :           7 :                 aggstate->sort_in = NULL;
     490                 :           7 :         }
     491                 :             : 
     492         [ +  + ]:        6856 :         if (newphase <= 1)
     493                 :             :         {
     494                 :             :                 /*
     495                 :             :                  * Discard any existing output tuplesort.
     496                 :             :                  */
     497         [ +  + ]:        6819 :                 if (aggstate->sort_out)
     498                 :             :                 {
     499                 :           1 :                         tuplesort_end(aggstate->sort_out);
     500                 :           1 :                         aggstate->sort_out = NULL;
     501                 :           1 :                 }
     502                 :        6819 :         }
     503                 :             :         else
     504                 :             :         {
     505                 :             :                 /*
     506                 :             :                  * The old output tuplesort becomes the new input one, and this is the
     507                 :             :                  * right time to actually sort it.
     508                 :             :                  */
     509                 :          37 :                 aggstate->sort_in = aggstate->sort_out;
     510                 :          37 :                 aggstate->sort_out = NULL;
     511         [ +  - ]:          37 :                 Assert(aggstate->sort_in);
     512                 :          37 :                 tuplesort_performsort(aggstate->sort_in);
     513                 :             :         }
     514                 :             : 
     515                 :             :         /*
     516                 :             :          * If this isn't the last phase, we need to sort appropriately for the
     517                 :             :          * next phase in sequence.
     518                 :             :          */
     519   [ +  +  +  + ]:        6856 :         if (newphase > 0 && newphase < aggstate->numphases - 1)
     520                 :             :         {
     521                 :          49 :                 Sort       *sortnode = aggstate->phases[newphase + 1].sortnode;
     522                 :          49 :                 PlanState  *outerNode = outerPlanState(aggstate);
     523                 :          49 :                 TupleDesc       tupDesc = ExecGetResultType(outerNode);
     524                 :             : 
     525                 :          98 :                 aggstate->sort_out = tuplesort_begin_heap(tupDesc,
     526                 :          49 :                                                                                                   sortnode->numCols,
     527                 :          49 :                                                                                                   sortnode->sortColIdx,
     528                 :          49 :                                                                                                   sortnode->sortOperators,
     529                 :          49 :                                                                                                   sortnode->collations,
     530                 :          49 :                                                                                                   sortnode->nullsFirst,
     531                 :          49 :                                                                                                   work_mem,
     532                 :             :                                                                                                   NULL, TUPLESORT_NONE);
     533                 :          49 :         }
     534                 :             : 
     535                 :        6856 :         aggstate->current_phase = newphase;
     536                 :        6856 :         aggstate->phase = &aggstate->phases[newphase];
     537                 :        6856 : }
     538                 :             : 
     539                 :             : /*
     540                 :             :  * Fetch a tuple from either the outer plan (for phase 1) or from the sorter
     541                 :             :  * populated by the previous phase.  Copy it to the sorter for the next phase
     542                 :             :  * if any.
     543                 :             :  *
     544                 :             :  * Callers cannot rely on memory for tuple in returned slot remaining valid
     545                 :             :  * past any subsequently fetched tuple.
     546                 :             :  */
     547                 :             : static TupleTableSlot *
     548                 :     4305659 : fetch_input_tuple(AggState *aggstate)
     549                 :             : {
     550                 :     4305659 :         TupleTableSlot *slot;
     551                 :             : 
     552         [ +  + ]:     4305659 :         if (aggstate->sort_in)
     553                 :             :         {
     554                 :             :                 /* make sure we check for interrupts in either path through here */
     555         [ +  - ]:       59155 :                 CHECK_FOR_INTERRUPTS();
     556   [ +  +  +  + ]:      118310 :                 if (!tuplesort_gettupleslot(aggstate->sort_in, true, false,
     557                 :       59155 :                                                                         aggstate->sort_slot, NULL))
     558                 :          37 :                         return NULL;
     559                 :       59118 :                 slot = aggstate->sort_slot;
     560                 :       59118 :         }
     561                 :             :         else
     562                 :     4246504 :                 slot = ExecProcNode(outerPlanState(aggstate));
     563                 :             : 
     564   [ +  +  +  +  :     4305622 :         if (!TupIsNull(slot) && aggstate->sort_out)
                   +  + ]
     565                 :       59118 :                 tuplesort_puttupleslot(aggstate->sort_out, slot);
     566                 :             : 
     567                 :     4305622 :         return slot;
     568                 :     4305659 : }
     569                 :             : 
     570                 :             : /*
     571                 :             :  * (Re)Initialize an individual aggregate.
     572                 :             :  *
     573                 :             :  * This function handles only one grouping set, already set in
     574                 :             :  * aggstate->current_set.
     575                 :             :  *
     576                 :             :  * When called, CurrentMemoryContext should be the per-query context.
     577                 :             :  */
     578                 :             : static void
     579                 :      155686 : initialize_aggregate(AggState *aggstate, AggStatePerTrans pertrans,
     580                 :             :                                          AggStatePerGroup pergroupstate)
     581                 :             : {
     582                 :             :         /*
     583                 :             :          * Start a fresh sort operation for each DISTINCT/ORDER BY aggregate.
     584                 :             :          */
     585         [ +  + ]:      155686 :         if (pertrans->aggsortrequired)
     586                 :             :         {
     587                 :             :                 /*
     588                 :             :                  * In case of rescan, maybe there could be an uncompleted sort
     589                 :             :                  * operation?  Clean it up if so.
     590                 :             :                  */
     591         [ +  - ]:        8939 :                 if (pertrans->sortstates[aggstate->current_set])
     592                 :           0 :                         tuplesort_end(pertrans->sortstates[aggstate->current_set]);
     593                 :             : 
     594                 :             : 
     595                 :             :                 /*
     596                 :             :                  * We use a plain Datum sorter when there's a single input column;
     597                 :             :                  * otherwise sort the full tuple.  (See comments for
     598                 :             :                  * process_ordered_aggregate_single.)
     599                 :             :                  */
     600         [ +  + ]:        8939 :                 if (pertrans->numInputs == 1)
     601                 :             :                 {
     602                 :        8925 :                         Form_pg_attribute attr = TupleDescAttr(pertrans->sortdesc, 0);
     603                 :             : 
     604                 :        8925 :                         pertrans->sortstates[aggstate->current_set] =
     605                 :       17850 :                                 tuplesort_begin_datum(attr->atttypid,
     606                 :        8925 :                                                                           pertrans->sortOperators[0],
     607                 :        8925 :                                                                           pertrans->sortCollations[0],
     608                 :        8925 :                                                                           pertrans->sortNullsFirst[0],
     609                 :        8925 :                                                                           work_mem, NULL, TUPLESORT_NONE);
     610                 :        8925 :                 }
     611                 :             :                 else
     612                 :          14 :                         pertrans->sortstates[aggstate->current_set] =
     613                 :          28 :                                 tuplesort_begin_heap(pertrans->sortdesc,
     614                 :          14 :                                                                          pertrans->numSortCols,
     615                 :          14 :                                                                          pertrans->sortColIdx,
     616                 :          14 :                                                                          pertrans->sortOperators,
     617                 :          14 :                                                                          pertrans->sortCollations,
     618                 :          14 :                                                                          pertrans->sortNullsFirst,
     619                 :          14 :                                                                          work_mem, NULL, TUPLESORT_NONE);
     620                 :        8939 :         }
     621                 :             : 
     622                 :             :         /*
     623                 :             :          * (Re)set transValue to the initial value.
     624                 :             :          *
     625                 :             :          * Note that when the initial value is pass-by-ref, we must copy it (into
     626                 :             :          * the aggcontext) since we will pfree the transValue later.
     627                 :             :          */
     628         [ +  + ]:      155686 :         if (pertrans->initValueIsNull)
     629                 :       67840 :                 pergroupstate->transValue = pertrans->initValue;
     630                 :             :         else
     631                 :             :         {
     632                 :       87846 :                 MemoryContext oldContext;
     633                 :             : 
     634                 :       87846 :                 oldContext = MemoryContextSwitchTo(aggstate->curaggcontext->ecxt_per_tuple_memory);
     635                 :      175692 :                 pergroupstate->transValue = datumCopy(pertrans->initValue,
     636                 :       87846 :                                                                                           pertrans->transtypeByVal,
     637                 :       87846 :                                                                                           pertrans->transtypeLen);
     638                 :       87846 :                 MemoryContextSwitchTo(oldContext);
     639                 :       87846 :         }
     640                 :      155686 :         pergroupstate->transValueIsNull = pertrans->initValueIsNull;
     641                 :             : 
     642                 :             :         /*
     643                 :             :          * If the initial value for the transition state doesn't exist in the
     644                 :             :          * pg_aggregate table then we will let the first non-NULL value returned
     645                 :             :          * from the outer procNode become the initial value. (This is useful for
     646                 :             :          * aggregates like max() and min().) The noTransValue flag signals that we
     647                 :             :          * still need to do this.
     648                 :             :          */
     649                 :      155686 :         pergroupstate->noTransValue = pertrans->initValueIsNull;
     650                 :      155686 : }
     651                 :             : 
     652                 :             : /*
     653                 :             :  * Initialize all aggregate transition states for a new group of input values.
     654                 :             :  *
     655                 :             :  * If there are multiple grouping sets, we initialize only the first numReset
     656                 :             :  * of them (the grouping sets are ordered so that the most specific one, which
     657                 :             :  * is reset most often, is first). As a convenience, if numReset is 0, we
     658                 :             :  * reinitialize all sets.
     659                 :             :  *
     660                 :             :  * NB: This cannot be used for hash aggregates, as for those the grouping set
     661                 :             :  * number has to be specified from further up.
     662                 :             :  *
     663                 :             :  * When called, CurrentMemoryContext should be the per-query context.
     664                 :             :  */
     665                 :             : static void
     666                 :       32684 : initialize_aggregates(AggState *aggstate,
     667                 :             :                                           AggStatePerGroup *pergroups,
     668                 :             :                                           int numReset)
     669                 :             : {
     670                 :       32684 :         int                     transno;
     671         [ +  + ]:       32684 :         int                     numGroupingSets = Max(aggstate->phase->numsets, 1);
     672                 :       32684 :         int                     setno = 0;
     673                 :       32684 :         int                     numTrans = aggstate->numtrans;
     674                 :       32684 :         AggStatePerTrans transstates = aggstate->pertrans;
     675                 :             : 
     676         [ +  - ]:       32684 :         if (numReset == 0)
     677                 :           0 :                 numReset = numGroupingSets;
     678                 :             : 
     679         [ +  + ]:       67725 :         for (setno = 0; setno < numReset; setno++)
     680                 :             :         {
     681                 :       35041 :                 AggStatePerGroup pergroup = pergroups[setno];
     682                 :             : 
     683                 :       35041 :                 select_current_set(aggstate, setno, false);
     684                 :             : 
     685         [ +  + ]:      124141 :                 for (transno = 0; transno < numTrans; transno++)
     686                 :             :                 {
     687                 :       89100 :                         AggStatePerTrans pertrans = &transstates[transno];
     688                 :       89100 :                         AggStatePerGroup pergroupstate = &pergroup[transno];
     689                 :             : 
     690                 :       89100 :                         initialize_aggregate(aggstate, pertrans, pergroupstate);
     691                 :       89100 :                 }
     692                 :       35041 :         }
     693                 :       32684 : }
     694                 :             : 
     695                 :             : /*
     696                 :             :  * Given new input value(s), advance the transition function of one aggregate
     697                 :             :  * state within one grouping set only (already set in aggstate->current_set)
     698                 :             :  *
     699                 :             :  * The new values (and null flags) have been preloaded into argument positions
     700                 :             :  * 1 and up in pertrans->transfn_fcinfo, so that we needn't copy them again to
     701                 :             :  * pass to the transition function.  We also expect that the static fields of
     702                 :             :  * the fcinfo are already initialized; that was done by ExecInitAgg().
     703                 :             :  *
     704                 :             :  * It doesn't matter which memory context this is called in.
     705                 :             :  */
     706                 :             : static void
     707                 :      117654 : advance_transition_function(AggState *aggstate,
     708                 :             :                                                         AggStatePerTrans pertrans,
     709                 :             :                                                         AggStatePerGroup pergroupstate)
     710                 :             : {
     711                 :      117654 :         FunctionCallInfo fcinfo = pertrans->transfn_fcinfo;
     712                 :      117654 :         MemoryContext oldContext;
     713                 :      117654 :         Datum           newVal;
     714                 :             : 
     715         [ +  + ]:      117654 :         if (pertrans->transfn.fn_strict)
     716                 :             :         {
     717                 :             :                 /*
     718                 :             :                  * For a strict transfn, nothing happens when there's a NULL input; we
     719                 :             :                  * just keep the prior transValue.
     720                 :             :                  */
     721                 :       37500 :                 int                     numTransInputs = pertrans->numTransInputs;
     722                 :       37500 :                 int                     i;
     723                 :             : 
     724         [ +  + ]:       75000 :                 for (i = 1; i <= numTransInputs; i++)
     725                 :             :                 {
     726         [ -  + ]:       37500 :                         if (fcinfo->args[i].isnull)
     727                 :           0 :                                 return;
     728                 :       37500 :                 }
     729         [ -  + ]:       37500 :                 if (pergroupstate->noTransValue)
     730                 :             :                 {
     731                 :             :                         /*
     732                 :             :                          * transValue has not been initialized. This is the first non-NULL
     733                 :             :                          * input value. We use it as the initial value for transValue. (We
     734                 :             :                          * already checked that the agg's input type is binary-compatible
     735                 :             :                          * with its transtype, so straight copy here is OK.)
     736                 :             :                          *
     737                 :             :                          * We must copy the datum into aggcontext if it is pass-by-ref. We
     738                 :             :                          * do not need to pfree the old transValue, since it's NULL.
     739                 :             :                          */
     740                 :           0 :                         oldContext = MemoryContextSwitchTo(aggstate->curaggcontext->ecxt_per_tuple_memory);
     741                 :           0 :                         pergroupstate->transValue = datumCopy(fcinfo->args[1].value,
     742                 :           0 :                                                                                                   pertrans->transtypeByVal,
     743                 :           0 :                                                                                                   pertrans->transtypeLen);
     744                 :           0 :                         pergroupstate->transValueIsNull = false;
     745                 :           0 :                         pergroupstate->noTransValue = false;
     746                 :           0 :                         MemoryContextSwitchTo(oldContext);
     747                 :           0 :                         return;
     748                 :             :                 }
     749         [ -  + ]:       37500 :                 if (pergroupstate->transValueIsNull)
     750                 :             :                 {
     751                 :             :                         /*
     752                 :             :                          * Don't call a strict function with NULL inputs.  Note it is
     753                 :             :                          * possible to get here despite the above tests, if the transfn is
     754                 :             :                          * strict *and* returned a NULL on a prior cycle. If that happens
     755                 :             :                          * we will propagate the NULL all the way to the end.
     756                 :             :                          */
     757                 :           0 :                         return;
     758                 :             :                 }
     759         [ -  + ]:       37500 :         }
     760                 :             : 
     761                 :             :         /* We run the transition functions in per-input-tuple memory context */
     762                 :      117654 :         oldContext = MemoryContextSwitchTo(aggstate->tmpcontext->ecxt_per_tuple_memory);
     763                 :             : 
     764                 :             :         /* set up aggstate->curpertrans for AggGetAggref() */
     765                 :      117654 :         aggstate->curpertrans = pertrans;
     766                 :             : 
     767                 :             :         /*
     768                 :             :          * OK to call the transition function
     769                 :             :          */
     770                 :      117654 :         fcinfo->args[0].value = pergroupstate->transValue;
     771                 :      117654 :         fcinfo->args[0].isnull = pergroupstate->transValueIsNull;
     772                 :      117654 :         fcinfo->isnull = false;              /* just in case transfn doesn't set it */
     773                 :             : 
     774                 :      117654 :         newVal = FunctionCallInvoke(fcinfo);
     775                 :             : 
     776                 :      117654 :         aggstate->curpertrans = NULL;
     777                 :             : 
     778                 :             :         /*
     779                 :             :          * If pass-by-ref datatype, must copy the new value into aggcontext and
     780                 :             :          * free the prior transValue.  But if transfn returned a pointer to its
     781                 :             :          * first input, we don't need to do anything.
     782                 :             :          *
     783                 :             :          * It's safe to compare newVal with pergroup->transValue without regard
     784                 :             :          * for either being NULL, because ExecAggCopyTransValue takes care to set
     785                 :             :          * transValue to 0 when NULL. Otherwise we could end up accidentally not
     786                 :             :          * reparenting, when the transValue has the same numerical value as
     787                 :             :          * newValue, despite being NULL.  This is a somewhat hot path, making it
     788                 :             :          * undesirable to instead solve this with another branch for the common
     789                 :             :          * case of the transition function returning its (modified) input
     790                 :             :          * argument.
     791                 :             :          */
     792   [ -  +  #  # ]:      117654 :         if (!pertrans->transtypeByVal &&
     793                 :           0 :                 DatumGetPointer(newVal) != DatumGetPointer(pergroupstate->transValue))
     794                 :           0 :                 newVal = ExecAggCopyTransValue(aggstate, pertrans,
     795                 :           0 :                                                                            newVal, fcinfo->isnull,
     796                 :           0 :                                                                            pergroupstate->transValue,
     797                 :           0 :                                                                            pergroupstate->transValueIsNull);
     798                 :             : 
     799                 :      117654 :         pergroupstate->transValue = newVal;
     800                 :      117654 :         pergroupstate->transValueIsNull = fcinfo->isnull;
     801                 :             : 
     802                 :      117654 :         MemoryContextSwitchTo(oldContext);
     803         [ -  + ]:      117654 : }
     804                 :             : 
     805                 :             : /*
     806                 :             :  * Advance each aggregate transition state for one input tuple.  The input
     807                 :             :  * tuple has been stored in tmpcontext->ecxt_outertuple, so that it is
     808                 :             :  * accessible to ExecEvalExpr.
     809                 :             :  *
     810                 :             :  * We have two sets of transition states to handle: one for sorted aggregation
     811                 :             :  * and one for hashed; we do them both here, to avoid multiple evaluation of
     812                 :             :  * the inputs.
     813                 :             :  *
     814                 :             :  * When called, CurrentMemoryContext should be the per-query context.
     815                 :             :  */
     816                 :             : static void
     817                 :     4337877 : advance_aggregates(AggState *aggstate)
     818                 :             : {
     819                 :     8675754 :         ExecEvalExprNoReturnSwitchContext(aggstate->phase->evaltrans,
     820                 :     4337877 :                                                                           aggstate->tmpcontext);
     821                 :     4337877 : }
     822                 :             : 
     823                 :             : /*
     824                 :             :  * Run the transition function for a DISTINCT or ORDER BY aggregate
     825                 :             :  * with only one input.  This is called after we have completed
     826                 :             :  * entering all the input values into the sort object.  We complete the
     827                 :             :  * sort, read out the values in sorted order, and run the transition
     828                 :             :  * function on each value (applying DISTINCT if appropriate).
     829                 :             :  *
     830                 :             :  * Note that the strictness of the transition function was checked when
     831                 :             :  * entering the values into the sort, so we don't check it again here;
     832                 :             :  * we just apply standard SQL DISTINCT logic.
     833                 :             :  *
     834                 :             :  * The one-input case is handled separately from the multi-input case
     835                 :             :  * for performance reasons: for single by-value inputs, such as the
     836                 :             :  * common case of count(distinct id), the tuplesort_getdatum code path
     837                 :             :  * is around 300% faster.  (The speedup for by-reference types is less
     838                 :             :  * but still noticeable.)
     839                 :             :  *
     840                 :             :  * This function handles only one grouping set (already set in
     841                 :             :  * aggstate->current_set).
     842                 :             :  *
     843                 :             :  * When called, CurrentMemoryContext should be the per-query context.
     844                 :             :  */
     845                 :             : static void
     846                 :        8925 : process_ordered_aggregate_single(AggState *aggstate,
     847                 :             :                                                                  AggStatePerTrans pertrans,
     848                 :             :                                                                  AggStatePerGroup pergroupstate)
     849                 :             : {
     850                 :        8925 :         Datum           oldVal = (Datum) 0;
     851                 :        8925 :         bool            oldIsNull = true;
     852                 :        8925 :         bool            haveOldVal = false;
     853                 :        8925 :         MemoryContext workcontext = aggstate->tmpcontext->ecxt_per_tuple_memory;
     854                 :        8925 :         MemoryContext oldContext;
     855                 :        8925 :         bool            isDistinct = (pertrans->numDistinctCols > 0);
     856                 :        8925 :         Datum           newAbbrevVal = (Datum) 0;
     857                 :        8925 :         Datum           oldAbbrevVal = (Datum) 0;
     858                 :        8925 :         FunctionCallInfo fcinfo = pertrans->transfn_fcinfo;
     859                 :        8925 :         Datum      *newVal;
     860                 :        8925 :         bool       *isNull;
     861                 :             : 
     862         [ +  - ]:        8925 :         Assert(pertrans->numDistinctCols < 2);
     863                 :             : 
     864                 :        8925 :         tuplesort_performsort(pertrans->sortstates[aggstate->current_set]);
     865                 :             : 
     866                 :             :         /* Load the column into argument 1 (arg 0 will be transition value) */
     867                 :        8925 :         newVal = &fcinfo->args[1].value;
     868                 :        8925 :         isNull = &fcinfo->args[1].isnull;
     869                 :             : 
     870                 :             :         /*
     871                 :             :          * Note: if input type is pass-by-ref, the datums returned by the sort are
     872                 :             :          * freshly palloc'd in the per-query context, so we must be careful to
     873                 :             :          * pfree them when they are no longer needed.
     874                 :             :          */
     875                 :             : 
     876   [ +  +  +  + ]:      166031 :         while (tuplesort_getdatum(pertrans->sortstates[aggstate->current_set],
     877                 :      146287 :                                                           true, false, newVal, isNull, &newAbbrevVal))
     878                 :             :         {
     879                 :             :                 /*
     880                 :             :                  * Clear and select the working context for evaluation of the equality
     881                 :             :                  * function and transition function.
     882                 :             :                  */
     883                 :      137362 :                 MemoryContextReset(workcontext);
     884                 :      137362 :                 oldContext = MemoryContextSwitchTo(workcontext);
     885                 :             : 
     886                 :             :                 /*
     887                 :             :                  * If DISTINCT mode, and not distinct from prior, skip it.
     888                 :             :                  */
     889         [ +  + ]:      137362 :                 if (isDistinct &&
     890         [ +  + ]:      105670 :                         haveOldVal &&
     891   [ -  +  +  + ]:       48386 :                         ((oldIsNull && *isNull) ||
     892   [ +  +  +  - ]:       77028 :                          (!oldIsNull && !*isNull &&
     893         [ +  - ]:       48386 :                           oldAbbrevVal == newAbbrevVal &&
     894                 :       96772 :                           DatumGetBool(FunctionCall2Coll(&pertrans->equalfnOne,
     895                 :       48386 :                                                                                          pertrans->aggCollation,
     896                 :       48386 :                                                                                          oldVal, *newVal)))))
     897                 :             :                 {
     898                 :       77028 :                         MemoryContextSwitchTo(oldContext);
     899                 :       77028 :                         continue;
     900                 :             :                 }
     901                 :             :                 else
     902                 :             :                 {
     903                 :      117618 :                         advance_transition_function(aggstate, pertrans, pergroupstate);
     904                 :             : 
     905                 :      117618 :                         MemoryContextSwitchTo(oldContext);
     906                 :             : 
     907                 :             :                         /*
     908                 :             :                          * Forget the old value, if any, and remember the new one for
     909                 :             :                          * subsequent equality checks.
     910                 :             :                          */
     911         [ +  + ]:      117618 :                         if (!pertrans->inputtypeByVal)
     912                 :             :                         {
     913         [ +  + ]:       87548 :                                 if (!oldIsNull)
     914                 :       87518 :                                         pfree(DatumGetPointer(oldVal));
     915         [ +  + ]:       87548 :                                 if (!*isNull)
     916                 :      175076 :                                         oldVal = datumCopy(*newVal, pertrans->inputtypeByVal,
     917                 :       87538 :                                                                            pertrans->inputtypeLen);
     918                 :       87548 :                         }
     919                 :             :                         else
     920                 :       30070 :                                 oldVal = *newVal;
     921                 :      117618 :                         oldAbbrevVal = newAbbrevVal;
     922                 :      117618 :                         oldIsNull = *isNull;
     923                 :      117618 :                         haveOldVal = true;
     924                 :             :                 }
     925                 :             :         }
     926                 :             : 
     927   [ +  +  +  + ]:        8925 :         if (!oldIsNull && !pertrans->inputtypeByVal)
     928                 :          20 :                 pfree(DatumGetPointer(oldVal));
     929                 :             : 
     930                 :        8925 :         tuplesort_end(pertrans->sortstates[aggstate->current_set]);
     931                 :        8925 :         pertrans->sortstates[aggstate->current_set] = NULL;
     932                 :        8925 : }
     933                 :             : 
     934                 :             : /*
     935                 :             :  * Run the transition function for a DISTINCT or ORDER BY aggregate
     936                 :             :  * with more than one input.  This is called after we have completed
     937                 :             :  * entering all the input values into the sort object.  We complete the
     938                 :             :  * sort, read out the values in sorted order, and run the transition
     939                 :             :  * function on each value (applying DISTINCT if appropriate).
     940                 :             :  *
     941                 :             :  * This function handles only one grouping set (already set in
     942                 :             :  * aggstate->current_set).
     943                 :             :  *
     944                 :             :  * When called, CurrentMemoryContext should be the per-query context.
     945                 :             :  */
     946                 :             : static void
     947                 :          14 : process_ordered_aggregate_multi(AggState *aggstate,
     948                 :             :                                                                 AggStatePerTrans pertrans,
     949                 :             :                                                                 AggStatePerGroup pergroupstate)
     950                 :             : {
     951                 :          14 :         ExprContext *tmpcontext = aggstate->tmpcontext;
     952                 :          14 :         FunctionCallInfo fcinfo = pertrans->transfn_fcinfo;
     953                 :          14 :         TupleTableSlot *slot1 = pertrans->sortslot;
     954                 :          14 :         TupleTableSlot *slot2 = pertrans->uniqslot;
     955                 :          14 :         int                     numTransInputs = pertrans->numTransInputs;
     956                 :          14 :         int                     numDistinctCols = pertrans->numDistinctCols;
     957                 :          14 :         Datum           newAbbrevVal = (Datum) 0;
     958                 :          14 :         Datum           oldAbbrevVal = (Datum) 0;
     959                 :          14 :         bool            haveOldValue = false;
     960                 :          14 :         TupleTableSlot *save = aggstate->tmpcontext->ecxt_outertuple;
     961                 :          14 :         int                     i;
     962                 :             : 
     963                 :          14 :         tuplesort_performsort(pertrans->sortstates[aggstate->current_set]);
     964                 :             : 
     965                 :          14 :         ExecClearTuple(slot1);
     966         [ -  + ]:          14 :         if (slot2)
     967                 :           0 :                 ExecClearTuple(slot2);
     968                 :             : 
     969   [ +  +  +  + ]:          50 :         while (tuplesort_gettupleslot(pertrans->sortstates[aggstate->current_set],
     970                 :          50 :                                                                   true, true, slot1, &newAbbrevVal))
     971                 :             :         {
     972         [ -  + ]:          36 :                 CHECK_FOR_INTERRUPTS();
     973                 :             : 
     974                 :          36 :                 tmpcontext->ecxt_outertuple = slot1;
     975                 :          36 :                 tmpcontext->ecxt_innertuple = slot2;
     976                 :             : 
     977         [ -  + ]:          36 :                 if (numDistinctCols == 0 ||
     978         [ #  # ]:           0 :                         !haveOldValue ||
     979   [ #  #  #  # ]:           0 :                         newAbbrevVal != oldAbbrevVal ||
     980                 :           0 :                         !ExecQual(pertrans->equalfnMulti, tmpcontext))
     981                 :             :                 {
     982                 :             :                         /*
     983                 :             :                          * Extract the first numTransInputs columns as datums to pass to
     984                 :             :                          * the transfn.
     985                 :             :                          */
     986                 :          36 :                         slot_getsomeattrs(slot1, numTransInputs);
     987                 :             : 
     988                 :             :                         /* Load values into fcinfo */
     989                 :             :                         /* Start from 1, since the 0th arg will be the transition value */
     990         [ +  + ]:         102 :                         for (i = 0; i < numTransInputs; i++)
     991                 :             :                         {
     992                 :          66 :                                 fcinfo->args[i + 1].value = slot1->tts_values[i];
     993                 :          66 :                                 fcinfo->args[i + 1].isnull = slot1->tts_isnull[i];
     994                 :          66 :                         }
     995                 :             : 
     996                 :          36 :                         advance_transition_function(aggstate, pertrans, pergroupstate);
     997                 :             : 
     998         [ +  - ]:          36 :                         if (numDistinctCols > 0)
     999                 :             :                         {
    1000                 :             :                                 /* swap the slot pointers to retain the current tuple */
    1001                 :           0 :                                 TupleTableSlot *tmpslot = slot2;
    1002                 :             : 
    1003                 :           0 :                                 slot2 = slot1;
    1004                 :           0 :                                 slot1 = tmpslot;
    1005                 :             :                                 /* avoid ExecQual() calls by reusing abbreviated keys */
    1006                 :           0 :                                 oldAbbrevVal = newAbbrevVal;
    1007                 :           0 :                                 haveOldValue = true;
    1008                 :           0 :                         }
    1009                 :          36 :                 }
    1010                 :             : 
    1011                 :             :                 /* Reset context each time */
    1012                 :          36 :                 ResetExprContext(tmpcontext);
    1013                 :             : 
    1014                 :          36 :                 ExecClearTuple(slot1);
    1015                 :             :         }
    1016                 :             : 
    1017         [ -  + ]:          14 :         if (slot2)
    1018                 :           0 :                 ExecClearTuple(slot2);
    1019                 :             : 
    1020                 :          14 :         tuplesort_end(pertrans->sortstates[aggstate->current_set]);
    1021                 :          14 :         pertrans->sortstates[aggstate->current_set] = NULL;
    1022                 :             : 
    1023                 :             :         /* restore previous slot, potentially in use for grouping sets */
    1024                 :          14 :         tmpcontext->ecxt_outertuple = save;
    1025                 :          14 : }
    1026                 :             : 
    1027                 :             : /*
    1028                 :             :  * Compute the final value of one aggregate.
    1029                 :             :  *
    1030                 :             :  * This function handles only one grouping set (already set in
    1031                 :             :  * aggstate->current_set).
    1032                 :             :  *
    1033                 :             :  * The finalfn will be run, and the result delivered, in the
    1034                 :             :  * output-tuple context; caller's CurrentMemoryContext does not matter.
    1035                 :             :  * (But note that in some cases, such as when there is no finalfn, the
    1036                 :             :  * result might be a pointer to or into the agg's transition value.)
    1037                 :             :  *
    1038                 :             :  * The finalfn uses the state as set in the transno.  This also might be
    1039                 :             :  * being used by another aggregate function, so it's important that we do
    1040                 :             :  * nothing destructive here.  Moreover, the aggregate's final value might
    1041                 :             :  * get used in multiple places, so we mustn't return a R/W expanded datum.
    1042                 :             :  */
    1043                 :             : static void
    1044                 :      153608 : finalize_aggregate(AggState *aggstate,
    1045                 :             :                                    AggStatePerAgg peragg,
    1046                 :             :                                    AggStatePerGroup pergroupstate,
    1047                 :             :                                    Datum *resultVal, bool *resultIsNull)
    1048                 :             : {
    1049                 :      153608 :         LOCAL_FCINFO(fcinfo, FUNC_MAX_ARGS);
    1050                 :      153608 :         bool            anynull = false;
    1051                 :      153608 :         MemoryContext oldContext;
    1052                 :      153608 :         int                     i;
    1053                 :      153608 :         ListCell   *lc;
    1054                 :      153608 :         AggStatePerTrans pertrans = &aggstate->pertrans[peragg->transno];
    1055                 :             : 
    1056                 :      153608 :         oldContext = MemoryContextSwitchTo(aggstate->ss.ps.ps_ExprContext->ecxt_per_tuple_memory);
    1057                 :             : 
    1058                 :             :         /*
    1059                 :             :          * Evaluate any direct arguments.  We do this even if there's no finalfn
    1060                 :             :          * (which is unlikely anyway), so that side-effects happen as expected.
    1061                 :             :          * The direct arguments go into arg positions 1 and up, leaving position 0
    1062                 :             :          * for the transition state value.
    1063                 :             :          */
    1064                 :      153608 :         i = 1;
    1065   [ +  +  +  +  :      153765 :         foreach(lc, peragg->aggdirectargs)
                   +  + ]
    1066                 :             :         {
    1067                 :         157 :                 ExprState  *expr = (ExprState *) lfirst(lc);
    1068                 :             : 
    1069                 :         314 :                 fcinfo->args[i].value = ExecEvalExpr(expr,
    1070                 :         157 :                                                                                          aggstate->ss.ps.ps_ExprContext,
    1071                 :         157 :                                                                                          &fcinfo->args[i].isnull);
    1072                 :         157 :                 anynull |= fcinfo->args[i].isnull;
    1073                 :         157 :                 i++;
    1074                 :         157 :         }
    1075                 :             : 
    1076                 :             :         /*
    1077                 :             :          * Apply the agg's finalfn if one is provided, else return transValue.
    1078                 :             :          */
    1079         [ +  + ]:      153608 :         if (OidIsValid(peragg->finalfn_oid))
    1080                 :             :         {
    1081                 :       34985 :                 int                     numFinalArgs = peragg->numFinalArgs;
    1082                 :             : 
    1083                 :             :                 /* set up aggstate->curperagg for AggGetAggref() */
    1084                 :       34985 :                 aggstate->curperagg = peragg;
    1085                 :             : 
    1086                 :       34985 :                 InitFunctionCallInfoData(*fcinfo, &peragg->finalfn,
    1087                 :             :                                                                  numFinalArgs,
    1088                 :             :                                                                  pertrans->aggCollation,
    1089                 :             :                                                                  (Node *) aggstate, NULL);
    1090                 :             : 
    1091                 :             :                 /* Fill in the transition state value */
    1092                 :       34985 :                 fcinfo->args[0].value =
    1093   [ +  +  +  + ]:       34985 :                         MakeExpandedObjectReadOnly(pergroupstate->transValue,
    1094                 :             :                                                                            pergroupstate->transValueIsNull,
    1095                 :             :                                                                            pertrans->transtypeLen);
    1096                 :       34985 :                 fcinfo->args[0].isnull = pergroupstate->transValueIsNull;
    1097                 :       34985 :                 anynull |= pergroupstate->transValueIsNull;
    1098                 :             : 
    1099                 :             :                 /* Fill any remaining argument positions with nulls */
    1100         [ +  + ]:       39425 :                 for (; i < numFinalArgs; i++)
    1101                 :             :                 {
    1102                 :        4440 :                         fcinfo->args[i].value = (Datum) 0;
    1103                 :        4440 :                         fcinfo->args[i].isnull = true;
    1104                 :        4440 :                         anynull = true;
    1105                 :        4440 :                 }
    1106                 :             : 
    1107   [ +  +  +  - ]:       34985 :                 if (fcinfo->flinfo->fn_strict && anynull)
    1108                 :             :                 {
    1109                 :             :                         /* don't call a strict function with NULL inputs */
    1110                 :           0 :                         *resultVal = (Datum) 0;
    1111                 :           0 :                         *resultIsNull = true;
    1112                 :           0 :                 }
    1113                 :             :                 else
    1114                 :             :                 {
    1115                 :       34985 :                         Datum           result;
    1116                 :             : 
    1117                 :       34985 :                         result = FunctionCallInvoke(fcinfo);
    1118                 :       34985 :                         *resultIsNull = fcinfo->isnull;
    1119   [ +  +  +  + ]:       34985 :                         *resultVal = MakeExpandedObjectReadOnly(result,
    1120                 :             :                                                                                                         fcinfo->isnull,
    1121                 :             :                                                                                                         peragg->resulttypeLen);
    1122                 :       34985 :                 }
    1123                 :       34985 :                 aggstate->curperagg = NULL;
    1124                 :       34985 :         }
    1125                 :             :         else
    1126                 :             :         {
    1127                 :      118623 :                 *resultVal =
    1128   [ +  +  +  + ]:      118623 :                         MakeExpandedObjectReadOnly(pergroupstate->transValue,
    1129                 :             :                                                                            pergroupstate->transValueIsNull,
    1130                 :             :                                                                            pertrans->transtypeLen);
    1131                 :      118623 :                 *resultIsNull = pergroupstate->transValueIsNull;
    1132                 :             :         }
    1133                 :             : 
    1134                 :      153608 :         MemoryContextSwitchTo(oldContext);
    1135                 :      153608 : }
    1136                 :             : 
    1137                 :             : /*
    1138                 :             :  * Compute the output value of one partial aggregate.
    1139                 :             :  *
    1140                 :             :  * The serialization function will be run, and the result delivered, in the
    1141                 :             :  * output-tuple context; caller's CurrentMemoryContext does not matter.
    1142                 :             :  */
    1143                 :             : static void
    1144                 :        2673 : finalize_partialaggregate(AggState *aggstate,
    1145                 :             :                                                   AggStatePerAgg peragg,
    1146                 :             :                                                   AggStatePerGroup pergroupstate,
    1147                 :             :                                                   Datum *resultVal, bool *resultIsNull)
    1148                 :             : {
    1149                 :        2673 :         AggStatePerTrans pertrans = &aggstate->pertrans[peragg->transno];
    1150                 :        2673 :         MemoryContext oldContext;
    1151                 :             : 
    1152                 :        2673 :         oldContext = MemoryContextSwitchTo(aggstate->ss.ps.ps_ExprContext->ecxt_per_tuple_memory);
    1153                 :             : 
    1154                 :             :         /*
    1155                 :             :          * serialfn_oid will be set if we must serialize the transvalue before
    1156                 :             :          * returning it
    1157                 :             :          */
    1158         [ +  + ]:        2673 :         if (OidIsValid(pertrans->serialfn_oid))
    1159                 :             :         {
    1160                 :             :                 /* Don't call a strict serialization function with NULL input. */
    1161   [ +  -  +  + ]:         111 :                 if (pertrans->serialfn.fn_strict && pergroupstate->transValueIsNull)
    1162                 :             :                 {
    1163                 :          12 :                         *resultVal = (Datum) 0;
    1164                 :          12 :                         *resultIsNull = true;
    1165                 :          12 :                 }
    1166                 :             :                 else
    1167                 :             :                 {
    1168                 :          99 :                         FunctionCallInfo fcinfo = pertrans->serialfn_fcinfo;
    1169                 :          99 :                         Datum           result;
    1170                 :             : 
    1171                 :          99 :                         fcinfo->args[0].value =
    1172   [ +  -  +  - ]:          99 :                                 MakeExpandedObjectReadOnly(pergroupstate->transValue,
    1173                 :             :                                                                                    pergroupstate->transValueIsNull,
    1174                 :             :                                                                                    pertrans->transtypeLen);
    1175                 :          99 :                         fcinfo->args[0].isnull = pergroupstate->transValueIsNull;
    1176                 :          99 :                         fcinfo->isnull = false;
    1177                 :             : 
    1178                 :          99 :                         result = FunctionCallInvoke(fcinfo);
    1179                 :          99 :                         *resultIsNull = fcinfo->isnull;
    1180   [ +  -  -  + ]:          99 :                         *resultVal = MakeExpandedObjectReadOnly(result,
    1181                 :             :                                                                                                         fcinfo->isnull,
    1182                 :             :                                                                                                         peragg->resulttypeLen);
    1183                 :          99 :                 }
    1184                 :         111 :         }
    1185                 :             :         else
    1186                 :             :         {
    1187                 :        2562 :                 *resultVal =
    1188   [ +  +  +  + ]:        2562 :                         MakeExpandedObjectReadOnly(pergroupstate->transValue,
    1189                 :             :                                                                            pergroupstate->transValueIsNull,
    1190                 :             :                                                                            pertrans->transtypeLen);
    1191                 :        2562 :                 *resultIsNull = pergroupstate->transValueIsNull;
    1192                 :             :         }
    1193                 :             : 
    1194                 :        2673 :         MemoryContextSwitchTo(oldContext);
    1195                 :        2673 : }
    1196                 :             : 
    1197                 :             : /*
    1198                 :             :  * Extract the attributes that make up the grouping key into the
    1199                 :             :  * hashslot. This is necessary to compute the hash or perform a lookup.
    1200                 :             :  */
    1201                 :             : static inline void
    1202                 :     1193671 : prepare_hash_slot(AggStatePerHash perhash,
    1203                 :             :                                   TupleTableSlot *inputslot,
    1204                 :             :                                   TupleTableSlot *hashslot)
    1205                 :             : {
    1206                 :     1193671 :         int                     i;
    1207                 :             : 
    1208                 :             :         /* transfer just the needed columns into hashslot */
    1209                 :     1193671 :         slot_getsomeattrs(inputslot, perhash->largestGrpColIdx);
    1210                 :     1193671 :         ExecClearTuple(hashslot);
    1211                 :             : 
    1212         [ +  + ]:     3020766 :         for (i = 0; i < perhash->numhashGrpCols; i++)
    1213                 :             :         {
    1214                 :     1827095 :                 int                     varNumber = perhash->hashGrpColIdxInput[i] - 1;
    1215                 :             : 
    1216                 :     1827095 :                 hashslot->tts_values[i] = inputslot->tts_values[varNumber];
    1217                 :     1827095 :                 hashslot->tts_isnull[i] = inputslot->tts_isnull[varNumber];
    1218                 :     1827095 :         }
    1219                 :     1193671 :         ExecStoreVirtualTuple(hashslot);
    1220                 :     1193671 : }
    1221                 :             : 
    1222                 :             : /*
    1223                 :             :  * Prepare to finalize and project based on the specified representative tuple
    1224                 :             :  * slot and grouping set.
    1225                 :             :  *
    1226                 :             :  * In the specified tuple slot, force to null all attributes that should be
    1227                 :             :  * read as null in the context of the current grouping set.  Also stash the
    1228                 :             :  * current group bitmap where GroupingExpr can get at it.
    1229                 :             :  *
    1230                 :             :  * This relies on three conditions:
    1231                 :             :  *
    1232                 :             :  * 1) Nothing is ever going to try and extract the whole tuple from this slot,
    1233                 :             :  * only reference it in evaluations, which will only access individual
    1234                 :             :  * attributes.
    1235                 :             :  *
    1236                 :             :  * 2) No system columns are going to need to be nulled. (If a system column is
    1237                 :             :  * referenced in a group clause, it is actually projected in the outer plan
    1238                 :             :  * tlist.)
    1239                 :             :  *
    1240                 :             :  * 3) Within a given phase, we never need to recover the value of an attribute
    1241                 :             :  * once it has been set to null.
    1242                 :             :  *
    1243                 :             :  * Poking into the slot this way is a bit ugly, but the consensus is that the
    1244                 :             :  * alternative was worse.
    1245                 :             :  */
    1246                 :             : static void
    1247                 :      100661 : prepare_projection_slot(AggState *aggstate, TupleTableSlot *slot, int currentSet)
    1248                 :             : {
    1249         [ +  + ]:      100661 :         if (aggstate->phase->grouped_cols)
    1250                 :             :         {
    1251                 :       70545 :                 Bitmapset  *grouped_cols = aggstate->phase->grouped_cols[currentSet];
    1252                 :             : 
    1253                 :       70545 :                 aggstate->grouped_cols = grouped_cols;
    1254                 :             : 
    1255         [ +  + ]:       70545 :                 if (TTS_EMPTY(slot))
    1256                 :             :                 {
    1257                 :             :                         /*
    1258                 :             :                          * Force all values to be NULL if working on an empty input tuple
    1259                 :             :                          * (i.e. an empty grouping set for which no input rows were
    1260                 :             :                          * supplied).
    1261                 :             :                          */
    1262                 :          10 :                         ExecStoreAllNullTuple(slot);
    1263                 :          10 :                 }
    1264         [ +  + ]:       70535 :                 else if (aggstate->all_grouped_cols)
    1265                 :             :                 {
    1266                 :       70527 :                         ListCell   *lc;
    1267                 :             : 
    1268                 :             :                         /* all_grouped_cols is arranged in desc order */
    1269                 :       70527 :                         slot_getsomeattrs(slot, linitial_int(aggstate->all_grouped_cols));
    1270                 :             : 
    1271   [ +  -  +  +  :      198317 :                         foreach(lc, aggstate->all_grouped_cols)
                   +  + ]
    1272                 :             :                         {
    1273                 :      127790 :                                 int                     attnum = lfirst_int(lc);
    1274                 :             : 
    1275         [ +  + ]:      127790 :                                 if (!bms_is_member(attnum, grouped_cols))
    1276                 :        9647 :                                         slot->tts_isnull[attnum - 1] = true;
    1277                 :      127790 :                         }
    1278                 :       70527 :                 }
    1279                 :       70545 :         }
    1280                 :      100661 : }
    1281                 :             : 
    1282                 :             : /*
    1283                 :             :  * Compute the final value of all aggregates for one group.
    1284                 :             :  *
    1285                 :             :  * This function handles only one grouping set at a time, which the caller must
    1286                 :             :  * have selected.  It's also the caller's responsibility to adjust the supplied
    1287                 :             :  * pergroup parameter to point to the current set's transvalues.
    1288                 :             :  *
    1289                 :             :  * Results are stored in the output econtext aggvalues/aggnulls.
    1290                 :             :  */
    1291                 :             : static void
    1292                 :      100661 : finalize_aggregates(AggState *aggstate,
    1293                 :             :                                         AggStatePerAgg peraggs,
    1294                 :             :                                         AggStatePerGroup pergroup)
    1295                 :             : {
    1296                 :      100661 :         ExprContext *econtext = aggstate->ss.ps.ps_ExprContext;
    1297                 :      100661 :         Datum      *aggvalues = econtext->ecxt_aggvalues;
    1298                 :      100661 :         bool       *aggnulls = econtext->ecxt_aggnulls;
    1299                 :      100661 :         int                     aggno;
    1300                 :             : 
    1301                 :             :         /*
    1302                 :             :          * If there were any DISTINCT and/or ORDER BY aggregates, sort their
    1303                 :             :          * inputs and run the transition functions.
    1304                 :             :          */
    1305         [ +  + ]:      256897 :         for (int transno = 0; transno < aggstate->numtrans; transno++)
    1306                 :             :         {
    1307                 :      156236 :                 AggStatePerTrans pertrans = &aggstate->pertrans[transno];
    1308                 :      156236 :                 AggStatePerGroup pergroupstate;
    1309                 :             : 
    1310                 :      156236 :                 pergroupstate = &pergroup[transno];
    1311                 :             : 
    1312         [ +  + ]:      156236 :                 if (pertrans->aggsortrequired)
    1313                 :             :                 {
    1314         [ +  - ]:        8939 :                         Assert(aggstate->aggstrategy != AGG_HASHED &&
    1315                 :             :                                    aggstate->aggstrategy != AGG_MIXED);
    1316                 :             : 
    1317         [ +  + ]:        8939 :                         if (pertrans->numInputs == 1)
    1318                 :       17850 :                                 process_ordered_aggregate_single(aggstate,
    1319                 :        8925 :                                                                                                  pertrans,
    1320                 :        8925 :                                                                                                  pergroupstate);
    1321                 :             :                         else
    1322                 :          28 :                                 process_ordered_aggregate_multi(aggstate,
    1323                 :          14 :                                                                                                 pertrans,
    1324                 :          14 :                                                                                                 pergroupstate);
    1325                 :        8939 :                 }
    1326   [ +  +  +  + ]:      147297 :                 else if (pertrans->numDistinctCols > 0 && pertrans->haslast)
    1327                 :             :                 {
    1328                 :        3057 :                         pertrans->haslast = false;
    1329                 :             : 
    1330         [ +  + ]:        3057 :                         if (pertrans->numDistinctCols == 1)
    1331                 :             :                         {
    1332   [ +  +  +  + ]:        3041 :                                 if (!pertrans->inputtypeByVal && !pertrans->lastisnull)
    1333                 :          43 :                                         pfree(DatumGetPointer(pertrans->lastdatum));
    1334                 :             : 
    1335                 :        3041 :                                 pertrans->lastisnull = false;
    1336                 :        3041 :                                 pertrans->lastdatum = (Datum) 0;
    1337                 :        3041 :                         }
    1338                 :             :                         else
    1339                 :          16 :                                 ExecClearTuple(pertrans->uniqslot);
    1340                 :        3057 :                 }
    1341                 :      156236 :         }
    1342                 :             : 
    1343                 :             :         /*
    1344                 :             :          * Run the final functions.
    1345                 :             :          */
    1346         [ +  + ]:      256944 :         for (aggno = 0; aggno < aggstate->numaggs; aggno++)
    1347                 :             :         {
    1348                 :      156283 :                 AggStatePerAgg peragg = &peraggs[aggno];
    1349                 :      156283 :                 int                     transno = peragg->transno;
    1350                 :      156283 :                 AggStatePerGroup pergroupstate;
    1351                 :             : 
    1352                 :      156283 :                 pergroupstate = &pergroup[transno];
    1353                 :             : 
    1354         [ +  + ]:      156283 :                 if (DO_AGGSPLIT_SKIPFINAL(aggstate->aggsplit))
    1355                 :        5346 :                         finalize_partialaggregate(aggstate, peragg, pergroupstate,
    1356                 :        2673 :                                                                           &aggvalues[aggno], &aggnulls[aggno]);
    1357                 :             :                 else
    1358                 :      307220 :                         finalize_aggregate(aggstate, peragg, pergroupstate,
    1359                 :      153610 :                                                            &aggvalues[aggno], &aggnulls[aggno]);
    1360                 :      156283 :         }
    1361                 :      100661 : }
    1362                 :             : 
    1363                 :             : /*
    1364                 :             :  * Project the result of a group (whose aggs have already been calculated by
    1365                 :             :  * finalize_aggregates). Returns the result slot, or NULL if no row is
    1366                 :             :  * projected (suppressed by qual).
    1367                 :             :  */
    1368                 :             : static TupleTableSlot *
    1369                 :      100659 : project_aggregates(AggState *aggstate)
    1370                 :             : {
    1371                 :      100659 :         ExprContext *econtext = aggstate->ss.ps.ps_ExprContext;
    1372                 :             : 
    1373                 :             :         /*
    1374                 :             :          * Check the qual (HAVING clause); if the group does not match, ignore it.
    1375                 :             :          */
    1376         [ +  + ]:      100659 :         if (ExecQual(aggstate->ss.ps.qual, econtext))
    1377                 :             :         {
    1378                 :             :                 /*
    1379                 :             :                  * Form and return projection tuple using the aggregate results and
    1380                 :             :                  * the representative input tuple.
    1381                 :             :                  */
    1382                 :       82971 :                 return ExecProject(aggstate->ss.ps.ps_ProjInfo);
    1383                 :             :         }
    1384                 :             :         else
    1385         [ +  - ]:       17688 :                 InstrCountFiltered1(aggstate, 1);
    1386                 :             : 
    1387                 :       17688 :         return NULL;
    1388                 :      100659 : }
    1389                 :             : 
    1390                 :             : /*
    1391                 :             :  * Find input-tuple columns that are needed, dividing them into
    1392                 :             :  * aggregated and unaggregated sets.
    1393                 :             :  */
    1394                 :             : static void
    1395                 :         950 : find_cols(AggState *aggstate, Bitmapset **aggregated, Bitmapset **unaggregated)
    1396                 :             : {
    1397                 :         950 :         Agg                *agg = (Agg *) aggstate->ss.ps.plan;
    1398                 :         950 :         FindColsContext context;
    1399                 :             : 
    1400                 :         950 :         context.is_aggref = false;
    1401                 :         950 :         context.aggregated = NULL;
    1402                 :         950 :         context.unaggregated = NULL;
    1403                 :             : 
    1404                 :             :         /* Examine tlist and quals */
    1405                 :         950 :         (void) find_cols_walker((Node *) agg->plan.targetlist, &context);
    1406                 :         950 :         (void) find_cols_walker((Node *) agg->plan.qual, &context);
    1407                 :             : 
    1408                 :             :         /* In some cases, grouping columns will not appear in the tlist */
    1409         [ +  + ]:        2287 :         for (int i = 0; i < agg->numCols; i++)
    1410                 :        2674 :                 context.unaggregated = bms_add_member(context.unaggregated,
    1411                 :        1337 :                                                                                           agg->grpColIdx[i]);
    1412                 :             : 
    1413                 :         950 :         *aggregated = context.aggregated;
    1414                 :         950 :         *unaggregated = context.unaggregated;
    1415                 :         950 : }
    1416                 :             : 
    1417                 :             : static bool
    1418                 :       12088 : find_cols_walker(Node *node, FindColsContext *context)
    1419                 :             : {
    1420         [ +  + ]:       12088 :         if (node == NULL)
    1421                 :        2262 :                 return false;
    1422         [ +  + ]:        9826 :         if (IsA(node, Var))
    1423                 :             :         {
    1424                 :        2530 :                 Var                *var = (Var *) node;
    1425                 :             : 
    1426                 :             :                 /* setrefs.c should have set the varno to OUTER_VAR */
    1427         [ +  - ]:        2530 :                 Assert(var->varno == OUTER_VAR);
    1428         [ +  - ]:        2530 :                 Assert(var->varlevelsup == 0);
    1429         [ +  + ]:        2530 :                 if (context->is_aggref)
    1430                 :        1958 :                         context->aggregated = bms_add_member(context->aggregated,
    1431                 :         979 :                                                                                                  var->varattno);
    1432                 :             :                 else
    1433                 :        3102 :                         context->unaggregated = bms_add_member(context->unaggregated,
    1434                 :        1551 :                                                                                                    var->varattno);
    1435                 :        2530 :                 return false;
    1436                 :        2530 :         }
    1437         [ +  + ]:        7296 :         if (IsA(node, Aggref))
    1438                 :             :         {
    1439         [ +  - ]:        1380 :                 Assert(!context->is_aggref);
    1440                 :        1380 :                 context->is_aggref = true;
    1441                 :        1380 :                 expression_tree_walker(node, find_cols_walker, context);
    1442                 :        1380 :                 context->is_aggref = false;
    1443                 :        1380 :                 return false;
    1444                 :             :         }
    1445                 :        5916 :         return expression_tree_walker(node, find_cols_walker, context);
    1446                 :       12088 : }
    1447                 :             : 
    1448                 :             : /*
    1449                 :             :  * (Re-)initialize the hash table(s) to empty.
    1450                 :             :  *
    1451                 :             :  * To implement hashed aggregation, we need a hashtable that stores a
    1452                 :             :  * representative tuple and an array of AggStatePerGroup structs for each
    1453                 :             :  * distinct set of GROUP BY column values.  We compute the hash key from the
    1454                 :             :  * GROUP BY columns.  The per-group data is allocated in initialize_hash_entry(),
    1455                 :             :  * for each entry.
    1456                 :             :  *
    1457                 :             :  * We have a separate hashtable and associated perhash data structure for each
    1458                 :             :  * grouping set for which we're doing hashing.
    1459                 :             :  *
    1460                 :             :  * The contents of the hash tables live in the aggstate's hash_tuplescxt
    1461                 :             :  * memory context (there is only one of these for all tables together, since
    1462                 :             :  * they are all reset at the same time).
    1463                 :             :  */
    1464                 :             : static void
    1465                 :         798 : build_hash_tables(AggState *aggstate)
    1466                 :             : {
    1467                 :         798 :         int                     setno;
    1468                 :             : 
    1469         [ +  + ]:        1653 :         for (setno = 0; setno < aggstate->num_hashes; ++setno)
    1470                 :             :         {
    1471                 :         855 :                 AggStatePerHash perhash = &aggstate->perhash[setno];
    1472                 :         855 :                 double          nbuckets;
    1473                 :         855 :                 Size            memory;
    1474                 :             : 
    1475         [ +  + ]:         855 :                 if (perhash->hashtable != NULL)
    1476                 :             :                 {
    1477                 :         155 :                         ResetTupleHashTable(perhash->hashtable);
    1478                 :         155 :                         continue;
    1479                 :             :                 }
    1480                 :             : 
    1481                 :         700 :                 memory = aggstate->hash_mem_limit / aggstate->num_hashes;
    1482                 :             : 
    1483                 :             :                 /* choose reasonable number of buckets per hashtable */
    1484                 :        1400 :                 nbuckets = hash_choose_num_buckets(aggstate->hashentrysize,
    1485                 :         700 :                                                                                    perhash->aggnode->numGroups,
    1486                 :         700 :                                                                                    memory);
    1487                 :             : 
    1488                 :             : #ifdef USE_INJECTION_POINTS
    1489                 :             :                 if (IS_INJECTION_POINT_ATTACHED("hash-aggregate-oversize-table"))
    1490                 :             :                 {
    1491                 :             :                         nbuckets = memory / TupleHashEntrySize();
    1492                 :             :                         INJECTION_POINT_CACHED("hash-aggregate-oversize-table", NULL);
    1493                 :             :                 }
    1494                 :             : #endif
    1495                 :             : 
    1496                 :         700 :                 build_hash_table(aggstate, setno, nbuckets);
    1497      [ -  +  + ]:         855 :         }
    1498                 :             : 
    1499                 :         798 :         aggstate->hash_ngroups_current = 0;
    1500                 :         798 : }
    1501                 :             : 
    1502                 :             : /*
    1503                 :             :  * Build a single hashtable for this grouping set.
    1504                 :             :  */
    1505                 :             : static void
    1506                 :         700 : build_hash_table(AggState *aggstate, int setno, double nbuckets)
    1507                 :             : {
    1508                 :         700 :         AggStatePerHash perhash = &aggstate->perhash[setno];
    1509                 :         700 :         MemoryContext metacxt = aggstate->hash_metacxt;
    1510                 :         700 :         MemoryContext tuplescxt = aggstate->hash_tuplescxt;
    1511                 :         700 :         MemoryContext tmpcxt = aggstate->tmpcontext->ecxt_per_tuple_memory;
    1512                 :         700 :         Size            additionalsize;
    1513                 :             : 
    1514   [ +  +  +  - ]:         700 :         Assert(aggstate->aggstrategy == AGG_HASHED ||
    1515                 :             :                    aggstate->aggstrategy == AGG_MIXED);
    1516                 :             : 
    1517                 :             :         /*
    1518                 :             :          * Used to make sure initial hash table allocation does not exceed
    1519                 :             :          * hash_mem. Note that the estimate does not include space for
    1520                 :             :          * pass-by-reference transition data values, nor for the representative
    1521                 :             :          * tuple of each group.
    1522                 :             :          */
    1523                 :         700 :         additionalsize = aggstate->numtrans * sizeof(AggStatePerGroupData);
    1524                 :             : 
    1525                 :        1400 :         perhash->hashtable = BuildTupleHashTable(&aggstate->ss.ps,
    1526                 :         700 :                                                                                          perhash->hashslot->tts_tupleDescriptor,
    1527                 :         700 :                                                                                          perhash->hashslot->tts_ops,
    1528                 :         700 :                                                                                          perhash->numCols,
    1529                 :         700 :                                                                                          perhash->hashGrpColIdxHash,
    1530                 :         700 :                                                                                          perhash->eqfuncoids,
    1531                 :         700 :                                                                                          perhash->hashfunctions,
    1532                 :         700 :                                                                                          perhash->aggnode->grpCollations,
    1533                 :         700 :                                                                                          nbuckets,
    1534                 :         700 :                                                                                          additionalsize,
    1535                 :         700 :                                                                                          metacxt,
    1536                 :         700 :                                                                                          tuplescxt,
    1537                 :         700 :                                                                                          tmpcxt,
    1538                 :         700 :                                                                                          DO_AGGSPLIT_SKIPFINAL(aggstate->aggsplit));
    1539                 :         700 : }
    1540                 :             : 
    1541                 :             : /*
    1542                 :             :  * Compute columns that actually need to be stored in hashtable entries.  The
    1543                 :             :  * incoming tuples from the child plan node will contain grouping columns,
    1544                 :             :  * other columns referenced in our targetlist and qual, columns used to
    1545                 :             :  * compute the aggregate functions, and perhaps just junk columns we don't use
    1546                 :             :  * at all.  Only columns of the first two types need to be stored in the
    1547                 :             :  * hashtable, and getting rid of the others can make the table entries
    1548                 :             :  * significantly smaller.  The hashtable only contains the relevant columns,
    1549                 :             :  * and is packed/unpacked in lookup_hash_entries() / agg_retrieve_hash_table()
    1550                 :             :  * into the format of the normal input descriptor.
    1551                 :             :  *
    1552                 :             :  * Additional columns, in addition to the columns grouped by, come from two
    1553                 :             :  * sources: Firstly functionally dependent columns that we don't need to group
    1554                 :             :  * by themselves, and secondly ctids for row-marks.
    1555                 :             :  *
    1556                 :             :  * To eliminate duplicates, we build a bitmapset of the needed columns, and
    1557                 :             :  * then build an array of the columns included in the hashtable. We might
    1558                 :             :  * still have duplicates if the passed-in grpColIdx has them, which can happen
    1559                 :             :  * in edge cases from semijoins/distinct; these can't always be removed,
    1560                 :             :  * because it's not certain that the duplicate cols will be using the same
    1561                 :             :  * hash function.
    1562                 :             :  *
    1563                 :             :  * Note that the array is preserved over ExecReScanAgg, so we allocate it in
    1564                 :             :  * the per-query context (unlike the hash table itself).
    1565                 :             :  */
    1566                 :             : static void
    1567                 :         950 : find_hash_columns(AggState *aggstate)
    1568                 :             : {
    1569                 :         950 :         Bitmapset  *base_colnos;
    1570                 :         950 :         Bitmapset  *aggregated_colnos;
    1571                 :         950 :         TupleDesc       scanDesc = aggstate->ss.ss_ScanTupleSlot->tts_tupleDescriptor;
    1572                 :         950 :         List       *outerTlist = outerPlanState(aggstate)->plan->targetlist;
    1573                 :         950 :         int                     numHashes = aggstate->num_hashes;
    1574                 :         950 :         EState     *estate = aggstate->ss.ps.state;
    1575                 :         950 :         int                     j;
    1576                 :             : 
    1577                 :             :         /* Find Vars that will be needed in tlist and qual */
    1578                 :         950 :         find_cols(aggstate, &aggregated_colnos, &base_colnos);
    1579                 :         950 :         aggstate->colnos_needed = bms_union(base_colnos, aggregated_colnos);
    1580                 :         950 :         aggstate->max_colno_needed = 0;
    1581                 :         950 :         aggstate->all_cols_needed = true;
    1582                 :             : 
    1583         [ +  + ]:        3909 :         for (int i = 0; i < scanDesc->natts; i++)
    1584                 :             :         {
    1585                 :        2959 :                 int                     colno = i + 1;
    1586                 :             : 
    1587         [ +  + ]:        2959 :                 if (bms_is_member(colno, aggstate->colnos_needed))
    1588                 :        2102 :                         aggstate->max_colno_needed = colno;
    1589                 :             :                 else
    1590                 :         857 :                         aggstate->all_cols_needed = false;
    1591                 :        2959 :         }
    1592                 :             : 
    1593         [ +  + ]:        1987 :         for (j = 0; j < numHashes; ++j)
    1594                 :             :         {
    1595                 :        1037 :                 AggStatePerHash perhash = &aggstate->perhash[j];
    1596                 :        1037 :                 Bitmapset  *colnos = bms_copy(base_colnos);
    1597                 :        1037 :                 AttrNumber *grpColIdx = perhash->aggnode->grpColIdx;
    1598                 :        1037 :                 List       *hashTlist = NIL;
    1599                 :        1037 :                 TupleDesc       hashDesc;
    1600                 :        1037 :                 int                     maxCols;
    1601                 :        1037 :                 int                     i;
    1602                 :             : 
    1603                 :        1037 :                 perhash->largestGrpColIdx = 0;
    1604                 :             : 
    1605                 :             :                 /*
    1606                 :             :                  * If we're doing grouping sets, then some Vars might be referenced in
    1607                 :             :                  * tlist/qual for the benefit of other grouping sets, but not needed
    1608                 :             :                  * when hashing; i.e. prepare_projection_slot will null them out, so
    1609                 :             :                  * there'd be no point storing them.  Use prepare_projection_slot's
    1610                 :             :                  * logic to determine which.
    1611                 :             :                  */
    1612         [ -  + ]:        1037 :                 if (aggstate->phases[0].grouped_cols)
    1613                 :             :                 {
    1614                 :        1037 :                         Bitmapset  *grouped_cols = aggstate->phases[0].grouped_cols[j];
    1615                 :        1037 :                         ListCell   *lc;
    1616                 :             : 
    1617   [ +  -  +  +  :        2720 :                         foreach(lc, aggstate->all_grouped_cols)
                   +  + ]
    1618                 :             :                         {
    1619                 :        1683 :                                 int                     attnum = lfirst_int(lc);
    1620                 :             : 
    1621         [ +  + ]:        1683 :                                 if (!bms_is_member(attnum, grouped_cols))
    1622                 :         242 :                                         colnos = bms_del_member(colnos, attnum);
    1623                 :        1683 :                         }
    1624                 :        1037 :                 }
    1625                 :             : 
    1626                 :             :                 /*
    1627                 :             :                  * Compute maximum number of input columns accounting for possible
    1628                 :             :                  * duplications in the grpColIdx array, which can happen in some edge
    1629                 :             :                  * cases where HashAggregate was generated as part of a semijoin or a
    1630                 :             :                  * DISTINCT.
    1631                 :             :                  */
    1632                 :        1037 :                 maxCols = bms_num_members(colnos) + perhash->numCols;
    1633                 :             : 
    1634                 :        1037 :                 perhash->hashGrpColIdxInput =
    1635                 :        1037 :                         palloc(maxCols * sizeof(AttrNumber));
    1636                 :        1037 :                 perhash->hashGrpColIdxHash =
    1637                 :        1037 :                         palloc(perhash->numCols * sizeof(AttrNumber));
    1638                 :             : 
    1639                 :             :                 /* Add all the grouping columns to colnos */
    1640         [ +  + ]:        2478 :                 for (i = 0; i < perhash->numCols; i++)
    1641                 :        1441 :                         colnos = bms_add_member(colnos, grpColIdx[i]);
    1642                 :             : 
    1643                 :             :                 /*
    1644                 :             :                  * First build mapping for columns directly hashed. These are the
    1645                 :             :                  * first, because they'll be accessed when computing hash values and
    1646                 :             :                  * comparing tuples for exact matches. We also build simple mapping
    1647                 :             :                  * for execGrouping, so it knows where to find the to-be-hashed /
    1648                 :             :                  * compared columns in the input.
    1649                 :             :                  */
    1650         [ +  + ]:        2478 :                 for (i = 0; i < perhash->numCols; i++)
    1651                 :             :                 {
    1652                 :        1441 :                         perhash->hashGrpColIdxInput[i] = grpColIdx[i];
    1653                 :        1441 :                         perhash->hashGrpColIdxHash[i] = i + 1;
    1654                 :        1441 :                         perhash->numhashGrpCols++;
    1655                 :             :                         /* delete already mapped columns */
    1656                 :        1441 :                         colnos = bms_del_member(colnos, grpColIdx[i]);
    1657                 :        1441 :                 }
    1658                 :             : 
    1659                 :             :                 /* and add the remaining columns */
    1660                 :        1037 :                 i = -1;
    1661         [ +  + ]:        1134 :                 while ((i = bms_next_member(colnos, i)) >= 0)
    1662                 :             :                 {
    1663                 :          97 :                         perhash->hashGrpColIdxInput[perhash->numhashGrpCols] = i;
    1664                 :          97 :                         perhash->numhashGrpCols++;
    1665                 :             :                 }
    1666                 :             : 
    1667                 :             :                 /* and build a tuple descriptor for the hashtable */
    1668         [ +  + ]:        2575 :                 for (i = 0; i < perhash->numhashGrpCols; i++)
    1669                 :             :                 {
    1670                 :        1538 :                         int                     varNumber = perhash->hashGrpColIdxInput[i] - 1;
    1671                 :             : 
    1672                 :        1538 :                         hashTlist = lappend(hashTlist, list_nth(outerTlist, varNumber));
    1673                 :        1538 :                         perhash->largestGrpColIdx =
    1674         [ +  + ]:        1538 :                                 Max(varNumber + 1, perhash->largestGrpColIdx);
    1675                 :        1538 :                 }
    1676                 :             : 
    1677                 :        1037 :                 hashDesc = ExecTypeFromTL(hashTlist);
    1678                 :             : 
    1679                 :        2074 :                 execTuplesHashPrepare(perhash->numCols,
    1680                 :        1037 :                                                           perhash->aggnode->grpOperators,
    1681                 :        1037 :                                                           &perhash->eqfuncoids,
    1682                 :        1037 :                                                           &perhash->hashfunctions);
    1683                 :        1037 :                 perhash->hashslot =
    1684                 :        1037 :                         ExecAllocTableSlot(&estate->es_tupleTable, hashDesc,
    1685                 :             :                                                            &TTSOpsMinimalTuple);
    1686                 :             : 
    1687                 :        1037 :                 list_free(hashTlist);
    1688                 :        1037 :                 bms_free(colnos);
    1689                 :        1037 :         }
    1690                 :             : 
    1691                 :         950 :         bms_free(base_colnos);
    1692                 :         950 : }
    1693                 :             : 
    1694                 :             : /*
    1695                 :             :  * Estimate per-hash-table-entry overhead.
    1696                 :             :  */
    1697                 :             : Size
    1698                 :        6224 : hash_agg_entry_size(int numTrans, Size tupleWidth, Size transitionSpace)
    1699                 :             : {
    1700                 :        6224 :         Size            tupleChunkSize;
    1701                 :        6224 :         Size            pergroupChunkSize;
    1702                 :        6224 :         Size            transitionChunkSize;
    1703                 :       12448 :         Size            tupleSize = (MAXALIGN(SizeofMinimalTupleHeader) +
    1704                 :        6224 :                                                          tupleWidth);
    1705                 :        6224 :         Size            pergroupSize = numTrans * sizeof(AggStatePerGroupData);
    1706                 :             : 
    1707                 :             :         /*
    1708                 :             :          * Entries use the Bump allocator, so the chunk sizes are the same as the
    1709                 :             :          * requested sizes.
    1710                 :             :          */
    1711                 :        6224 :         tupleChunkSize = MAXALIGN(tupleSize);
    1712                 :        6224 :         pergroupChunkSize = pergroupSize;
    1713                 :             : 
    1714                 :             :         /*
    1715                 :             :          * Transition values use AllocSet, which has a chunk header and also uses
    1716                 :             :          * power-of-two allocations.
    1717                 :             :          */
    1718         [ +  + ]:        6224 :         if (transitionSpace > 0)
    1719                 :         868 :                 transitionChunkSize = CHUNKHDRSZ + pg_nextpower2_size_t(transitionSpace);
    1720                 :             :         else
    1721                 :        5356 :                 transitionChunkSize = 0;
    1722                 :             : 
    1723                 :        6224 :         return
    1724                 :       12448 :                 TupleHashEntrySize() +
    1725                 :       12448 :                 tupleChunkSize +
    1726                 :       12448 :                 pergroupChunkSize +
    1727                 :        6224 :                 transitionChunkSize;
    1728                 :        6224 : }
    1729                 :             : 
    1730                 :             : /*
    1731                 :             :  * hashagg_recompile_expressions()
    1732                 :             :  *
    1733                 :             :  * Identifies the right phase, compiles the right expression given the
    1734                 :             :  * arguments, and then sets phase->evalfunc to that expression.
    1735                 :             :  *
    1736                 :             :  * Different versions of the compiled expression are needed depending on
    1737                 :             :  * whether hash aggregation has spilled or not, and whether it's reading from
    1738                 :             :  * the outer plan or a tape. Before spilling to disk, the expression reads
    1739                 :             :  * from the outer plan and does not need to perform a NULL check. After
    1740                 :             :  * HashAgg begins to spill, new groups will not be created in the hash table,
    1741                 :             :  * and the AggStatePerGroup array may be NULL; therefore we need to add a null
    1742                 :             :  * pointer check to the expression. Then, when reading spilled data from a
    1743                 :             :  * tape, we change the outer slot type to be a fixed minimal tuple slot.
    1744                 :             :  *
    1745                 :             :  * It would be wasteful to recompile every time, so cache the compiled
    1746                 :             :  * expressions in the AggStatePerPhase, and reuse when appropriate.
    1747                 :             :  */
    1748                 :             : static void
    1749                 :        9037 : hashagg_recompile_expressions(AggState *aggstate, bool minslot, bool nullcheck)
    1750                 :             : {
    1751                 :        9037 :         AggStatePerPhase phase;
    1752                 :        9037 :         int                     i = minslot ? 1 : 0;
    1753                 :        9037 :         int                     j = nullcheck ? 1 : 0;
    1754                 :             : 
    1755   [ +  +  +  - ]:        9037 :         Assert(aggstate->aggstrategy == AGG_HASHED ||
    1756                 :             :                    aggstate->aggstrategy == AGG_MIXED);
    1757                 :             : 
    1758         [ +  + ]:        9037 :         if (aggstate->aggstrategy == AGG_HASHED)
    1759                 :         275 :                 phase = &aggstate->phases[0];
    1760                 :             :         else                                            /* AGG_MIXED */
    1761                 :        8762 :                 phase = &aggstate->phases[1];
    1762                 :             : 
    1763         [ +  + ]:        9037 :         if (phase->evaltrans_cache[i][j] == NULL)
    1764                 :             :         {
    1765                 :          12 :                 const TupleTableSlotOps *outerops = aggstate->ss.ps.outerops;
    1766                 :          12 :                 bool            outerfixed = aggstate->ss.ps.outeropsfixed;
    1767                 :          12 :                 bool            dohash = true;
    1768                 :          12 :                 bool            dosort = false;
    1769                 :             : 
    1770                 :             :                 /*
    1771                 :             :                  * If minslot is true, that means we are processing a spilled batch
    1772                 :             :                  * (inside agg_refill_hash_table()), and we must not advance the
    1773                 :             :                  * sorted grouping sets.
    1774                 :             :                  */
    1775   [ +  +  +  + ]:          12 :                 if (aggstate->aggstrategy == AGG_MIXED && !minslot)
    1776                 :           2 :                         dosort = true;
    1777                 :             : 
    1778                 :             :                 /* temporarily change the outerops while compiling the expression */
    1779         [ +  + ]:          12 :                 if (minslot)
    1780                 :             :                 {
    1781                 :           6 :                         aggstate->ss.ps.outerops = &TTSOpsMinimalTuple;
    1782                 :           6 :                         aggstate->ss.ps.outeropsfixed = true;
    1783                 :           6 :                 }
    1784                 :             : 
    1785                 :          24 :                 phase->evaltrans_cache[i][j] = ExecBuildAggTrans(aggstate, phase,
    1786                 :          12 :                                                                                                                  dosort, dohash,
    1787                 :          12 :                                                                                                                  nullcheck);
    1788                 :             : 
    1789                 :             :                 /* change back */
    1790                 :          12 :                 aggstate->ss.ps.outerops = outerops;
    1791                 :          12 :                 aggstate->ss.ps.outeropsfixed = outerfixed;
    1792                 :          12 :         }
    1793                 :             : 
    1794                 :        9037 :         phase->evaltrans = phase->evaltrans_cache[i][j];
    1795                 :        9037 : }
    1796                 :             : 
    1797                 :             : /*
    1798                 :             :  * Set limits that trigger spilling to avoid exceeding hash_mem. Consider the
    1799                 :             :  * number of partitions we expect to create (if we do spill).
    1800                 :             :  *
    1801                 :             :  * There are two limits: a memory limit, and also an ngroups limit. The
    1802                 :             :  * ngroups limit becomes important when we expect transition values to grow
    1803                 :             :  * substantially larger than the initial value.
    1804                 :             :  */
    1805                 :             : void
    1806                 :       10284 : hash_agg_set_limits(double hashentrysize, double input_groups, int used_bits,
    1807                 :             :                                         Size *mem_limit, uint64 *ngroups_limit,
    1808                 :             :                                         int *num_partitions)
    1809                 :             : {
    1810                 :       10284 :         int                     npartitions;
    1811                 :       10284 :         Size            partition_mem;
    1812                 :       10284 :         Size            hash_mem_limit = get_hash_memory_limit();
    1813                 :             : 
    1814                 :             :         /* if not expected to spill, use all of hash_mem */
    1815         [ +  + ]:       10284 :         if (input_groups * hashentrysize <= hash_mem_limit)
    1816                 :             :         {
    1817         [ +  + ]:        9879 :                 if (num_partitions != NULL)
    1818                 :        5783 :                         *num_partitions = 0;
    1819                 :        9879 :                 *mem_limit = hash_mem_limit;
    1820                 :        9879 :                 *ngroups_limit = hash_mem_limit / hashentrysize;
    1821                 :        9879 :                 return;
    1822                 :             :         }
    1823                 :             : 
    1824                 :             :         /*
    1825                 :             :          * Calculate expected memory requirements for spilling, which is the size
    1826                 :             :          * of the buffers needed for all the tapes that need to be open at once.
    1827                 :             :          * Then, subtract that from the memory available for holding hash tables.
    1828                 :             :          */
    1829                 :         810 :         npartitions = hash_choose_num_partitions(input_groups,
    1830                 :         405 :                                                                                          hashentrysize,
    1831                 :         405 :                                                                                          used_bits,
    1832                 :             :                                                                                          NULL);
    1833         [ +  + ]:         405 :         if (num_partitions != NULL)
    1834                 :          16 :                 *num_partitions = npartitions;
    1835                 :             : 
    1836                 :         405 :         partition_mem =
    1837                 :         405 :                 HASHAGG_READ_BUFFER_SIZE +
    1838                 :         405 :                 HASHAGG_WRITE_BUFFER_SIZE * npartitions;
    1839                 :             : 
    1840                 :             :         /*
    1841                 :             :          * Don't set the limit below 3/4 of hash_mem. In that case, we are at the
    1842                 :             :          * minimum number of partitions, so we aren't going to dramatically exceed
    1843                 :             :          * work mem anyway.
    1844                 :             :          */
    1845         [ -  + ]:         405 :         if (hash_mem_limit > 4 * partition_mem)
    1846                 :           0 :                 *mem_limit = hash_mem_limit - partition_mem;
    1847                 :             :         else
    1848                 :         405 :                 *mem_limit = hash_mem_limit * 0.75;
    1849                 :             : 
    1850         [ +  - ]:         405 :         if (*mem_limit > hashentrysize)
    1851                 :         405 :                 *ngroups_limit = *mem_limit / hashentrysize;
    1852                 :             :         else
    1853                 :           0 :                 *ngroups_limit = 1;
    1854         [ -  + ]:       10284 : }
    1855                 :             : 
    1856                 :             : /*
    1857                 :             :  * hash_agg_check_limits
    1858                 :             :  *
    1859                 :             :  * After adding a new group to the hash table, check whether we need to enter
    1860                 :             :  * spill mode. Allocations may happen without adding new groups (for instance,
    1861                 :             :  * if the transition state size grows), so this check is imperfect.
    1862                 :             :  */
    1863                 :             : static void
    1864                 :       65299 : hash_agg_check_limits(AggState *aggstate)
    1865                 :             : {
    1866                 :       65299 :         uint64          ngroups = aggstate->hash_ngroups_current;
    1867                 :       65299 :         Size            meta_mem = MemoryContextMemAllocated(aggstate->hash_metacxt,
    1868                 :             :                                                                                                          true);
    1869                 :       65299 :         Size            entry_mem = MemoryContextMemAllocated(aggstate->hash_tuplescxt,
    1870                 :             :                                                                                                           true);
    1871                 :       65299 :         Size            tval_mem = MemoryContextMemAllocated(aggstate->hashcontext->ecxt_per_tuple_memory,
    1872                 :             :                                                                                                          true);
    1873                 :       65299 :         Size            total_mem = meta_mem + entry_mem + tval_mem;
    1874                 :       65299 :         bool            do_spill = false;
    1875                 :             : 
    1876                 :             : #ifdef USE_INJECTION_POINTS
    1877                 :             :         if (ngroups >= 1000)
    1878                 :             :         {
    1879                 :             :                 if (IS_INJECTION_POINT_ATTACHED("hash-aggregate-spill-1000"))
    1880                 :             :                 {
    1881                 :             :                         do_spill = true;
    1882                 :             :                         INJECTION_POINT_CACHED("hash-aggregate-spill-1000", NULL);
    1883                 :             :                 }
    1884                 :             :         }
    1885                 :             : #endif
    1886                 :             : 
    1887                 :             :         /*
    1888                 :             :          * Don't spill unless there's at least one group in the hash table so we
    1889                 :             :          * can be sure to make progress even in edge cases.
    1890                 :             :          */
    1891   [ +  -  +  + ]:      126199 :         if (aggstate->hash_ngroups_current > 0 &&
    1892         [ +  + ]:       65299 :                 (total_mem > aggstate->hash_mem_limit ||
    1893                 :       60900 :                  ngroups > aggstate->hash_ngroups_limit))
    1894                 :             :         {
    1895                 :        4407 :                 do_spill = true;
    1896                 :        4407 :         }
    1897                 :             : 
    1898         [ +  + ]:       65299 :         if (do_spill)
    1899                 :        4407 :                 hash_agg_enter_spill_mode(aggstate);
    1900                 :       65299 : }
    1901                 :             : 
    1902                 :             : /*
    1903                 :             :  * Enter "spill mode", meaning that no new groups are added to any of the hash
    1904                 :             :  * tables. Tuples that would create a new group are instead spilled, and
    1905                 :             :  * processed later.
    1906                 :             :  */
    1907                 :             : static void
    1908                 :        4407 : hash_agg_enter_spill_mode(AggState *aggstate)
    1909                 :             : {
    1910                 :             :         INJECTION_POINT("hash-aggregate-enter-spill-mode", NULL);
    1911                 :        4407 :         aggstate->hash_spill_mode = true;
    1912                 :        4407 :         hashagg_recompile_expressions(aggstate, aggstate->table_filled, true);
    1913                 :             : 
    1914         [ +  + ]:        4407 :         if (!aggstate->hash_ever_spilled)
    1915                 :             :         {
    1916         [ +  - ]:           9 :                 Assert(aggstate->hash_tapeset == NULL);
    1917         [ +  - ]:           9 :                 Assert(aggstate->hash_spills == NULL);
    1918                 :             : 
    1919                 :           9 :                 aggstate->hash_ever_spilled = true;
    1920                 :             : 
    1921                 :           9 :                 aggstate->hash_tapeset = LogicalTapeSetCreate(true, NULL, -1);
    1922                 :             : 
    1923                 :           9 :                 aggstate->hash_spills = palloc_array(HashAggSpill, aggstate->num_hashes);
    1924                 :             : 
    1925         [ +  + ]:          28 :                 for (int setno = 0; setno < aggstate->num_hashes; setno++)
    1926                 :             :                 {
    1927                 :          19 :                         AggStatePerHash perhash = &aggstate->perhash[setno];
    1928                 :          19 :                         HashAggSpill *spill = &aggstate->hash_spills[setno];
    1929                 :             : 
    1930                 :          38 :                         hashagg_spill_init(spill, aggstate->hash_tapeset, 0,
    1931                 :          19 :                                                            perhash->aggnode->numGroups,
    1932                 :          19 :                                                            aggstate->hashentrysize);
    1933                 :          19 :                 }
    1934                 :           9 :         }
    1935                 :        4407 : }
    1936                 :             : 
    1937                 :             : /*
    1938                 :             :  * Update metrics after filling the hash table.
    1939                 :             :  *
    1940                 :             :  * If reading from the outer plan, from_tape should be false; if reading from
    1941                 :             :  * another tape, from_tape should be true.
    1942                 :             :  */
    1943                 :             : static void
    1944                 :        5237 : hash_agg_update_metrics(AggState *aggstate, bool from_tape, int npartitions)
    1945                 :             : {
    1946                 :        5237 :         Size            meta_mem;
    1947                 :        5237 :         Size            entry_mem;
    1948                 :        5237 :         Size            hashkey_mem;
    1949                 :        5237 :         Size            buffer_mem;
    1950                 :        5237 :         Size            total_mem;
    1951                 :             : 
    1952   [ +  +  +  - ]:        5237 :         if (aggstate->aggstrategy != AGG_MIXED &&
    1953                 :         836 :                 aggstate->aggstrategy != AGG_HASHED)
    1954                 :           0 :                 return;
    1955                 :             : 
    1956                 :             :         /* memory for the hash table itself */
    1957                 :        5237 :         meta_mem = MemoryContextMemAllocated(aggstate->hash_metacxt, true);
    1958                 :             : 
    1959                 :             :         /* memory for hash entries */
    1960                 :        5237 :         entry_mem = MemoryContextMemAllocated(aggstate->hash_tuplescxt, true);
    1961                 :             : 
    1962                 :             :         /* memory for byref transition states */
    1963                 :        5237 :         hashkey_mem = MemoryContextMemAllocated(aggstate->hashcontext->ecxt_per_tuple_memory, true);
    1964                 :             : 
    1965                 :             :         /* memory for read/write tape buffers, if spilled */
    1966                 :        5237 :         buffer_mem = npartitions * HASHAGG_WRITE_BUFFER_SIZE;
    1967         [ +  + ]:        5237 :         if (from_tape)
    1968                 :        4485 :                 buffer_mem += HASHAGG_READ_BUFFER_SIZE;
    1969                 :             : 
    1970                 :             :         /* update peak mem */
    1971                 :        5237 :         total_mem = meta_mem + entry_mem + hashkey_mem + buffer_mem;
    1972         [ +  + ]:        5237 :         if (total_mem > aggstate->hash_mem_peak)
    1973                 :         614 :                 aggstate->hash_mem_peak = total_mem;
    1974                 :             : 
    1975                 :             :         /* update disk usage */
    1976         [ +  + ]:        5237 :         if (aggstate->hash_tapeset != NULL)
    1977                 :             :         {
    1978                 :        4494 :                 uint64          disk_used = LogicalTapeSetBlocks(aggstate->hash_tapeset) * (BLCKSZ / 1024);
    1979                 :             : 
    1980         [ +  + ]:        4494 :                 if (aggstate->hash_disk_used < disk_used)
    1981                 :           7 :                         aggstate->hash_disk_used = disk_used;
    1982                 :        4494 :         }
    1983                 :             : 
    1984                 :             :         /* update hashentrysize estimate based on contents */
    1985         [ +  + ]:        5237 :         if (aggstate->hash_ngroups_current > 0)
    1986                 :             :         {
    1987                 :        5200 :                 aggstate->hashentrysize =
    1988                 :       10400 :                         TupleHashEntrySize() +
    1989                 :        5200 :                         (hashkey_mem / (double) aggstate->hash_ngroups_current);
    1990                 :        5200 :         }
    1991         [ -  + ]:        5237 : }
    1992                 :             : 
    1993                 :             : /*
    1994                 :             :  * Create memory contexts used for hash aggregation.
    1995                 :             :  */
    1996                 :             : static void
    1997                 :         950 : hash_create_memory(AggState *aggstate)
    1998                 :             : {
    1999                 :         950 :         Size            maxBlockSize = ALLOCSET_DEFAULT_MAXSIZE;
    2000                 :             : 
    2001                 :             :         /*
    2002                 :             :          * The hashcontext's per-tuple memory will be used for byref transition
    2003                 :             :          * values and returned by AggCheckCallContext().
    2004                 :             :          */
    2005                 :         950 :         aggstate->hashcontext = CreateWorkExprContext(aggstate->ss.ps.state);
    2006                 :             : 
    2007                 :             :         /*
    2008                 :             :          * The meta context will be used for the bucket array of
    2009                 :             :          * TupleHashEntryData (or arrays, in the case of grouping sets). As the
    2010                 :             :          * hash table grows, the bucket array will double in size and the old one
    2011                 :             :          * will be freed, so an AllocSet is appropriate. For large bucket arrays,
    2012                 :             :          * the large allocation path will be used, so it's not worth worrying
    2013                 :             :          * about wasting space due to power-of-two allocations.
    2014                 :             :          */
    2015                 :         950 :         aggstate->hash_metacxt = AllocSetContextCreate(aggstate->ss.ps.state->es_query_cxt,
    2016                 :             :                                                                                                    "HashAgg meta context",
    2017                 :             :                                                                                                    ALLOCSET_DEFAULT_SIZES);
    2018                 :             : 
    2019                 :             :         /*
    2020                 :             :          * The hash entries themselves, which include the grouping key
    2021                 :             :          * (firstTuple) and pergroup data, are stored in the table context. The
    2022                 :             :          * bump allocator can be used because the entries are not freed until the
    2023                 :             :          * entire hash table is reset. The bump allocator is faster for
    2024                 :             :          * allocations and avoids wasting space on the chunk header or
    2025                 :             :          * power-of-two allocations.
    2026                 :             :          *
    2027                 :             :          * Like CreateWorkExprContext(), use smaller sizings for smaller work_mem,
    2028                 :             :          * to avoid large jumps in memory usage.
    2029                 :             :          */
    2030                 :             : 
    2031                 :             :         /*
    2032                 :             :          * Like CreateWorkExprContext(), use smaller sizings for smaller work_mem,
    2033                 :             :          * to avoid large jumps in memory usage.
    2034                 :             :          */
    2035                 :         950 :         maxBlockSize = pg_prevpower2_size_t(work_mem * (Size) 1024 / 16);
    2036                 :             : 
    2037                 :             :         /* But no bigger than ALLOCSET_DEFAULT_MAXSIZE */
    2038         [ +  - ]:         950 :         maxBlockSize = Min(maxBlockSize, ALLOCSET_DEFAULT_MAXSIZE);
    2039                 :             : 
    2040                 :             :         /* and no smaller than ALLOCSET_DEFAULT_INITSIZE */
    2041         [ +  + ]:         950 :         maxBlockSize = Max(maxBlockSize, ALLOCSET_DEFAULT_INITSIZE);
    2042                 :             : 
    2043                 :        1900 :         aggstate->hash_tuplescxt = BumpContextCreate(aggstate->ss.ps.state->es_query_cxt,
    2044                 :             :                                                                                                  "HashAgg hashed tuples",
    2045                 :             :                                                                                                  ALLOCSET_DEFAULT_MINSIZE,
    2046                 :             :                                                                                                  ALLOCSET_DEFAULT_INITSIZE,
    2047                 :         950 :                                                                                                  maxBlockSize);
    2048                 :             : 
    2049                 :         950 : }
    2050                 :             : 
    2051                 :             : /*
    2052                 :             :  * Choose a reasonable number of buckets for the initial hash table size.
    2053                 :             :  */
    2054                 :             : static double
    2055                 :         700 : hash_choose_num_buckets(double hashentrysize, double ngroups, Size memory)
    2056                 :             : {
    2057                 :         700 :         double          max_nbuckets;
    2058                 :         700 :         double          nbuckets = ngroups;
    2059                 :             : 
    2060                 :         700 :         max_nbuckets = memory / hashentrysize;
    2061                 :             : 
    2062                 :             :         /*
    2063                 :             :          * Underestimating is better than overestimating. Too many buckets crowd
    2064                 :             :          * out space for group keys and transition state values.
    2065                 :             :          */
    2066                 :         700 :         max_nbuckets /= 2;
    2067                 :             : 
    2068         [ +  + ]:         700 :         if (nbuckets > max_nbuckets)
    2069                 :          12 :                 nbuckets = max_nbuckets;
    2070                 :             : 
    2071                 :             :         /*
    2072                 :             :          * BuildTupleHashTable will clamp any obviously-insane result, so we don't
    2073                 :             :          * need to be too careful here.
    2074                 :             :          */
    2075                 :        1400 :         return nbuckets;
    2076                 :         700 : }
    2077                 :             : 
    2078                 :             : /*
    2079                 :             :  * Determine the number of partitions to create when spilling, which will
    2080                 :             :  * always be a power of two. If log2_npartitions is non-NULL, set
    2081                 :             :  * *log2_npartitions to the log2() of the number of partitions.
    2082                 :             :  */
    2083                 :             : static int
    2084                 :        2506 : hash_choose_num_partitions(double input_groups, double hashentrysize,
    2085                 :             :                                                    int used_bits, int *log2_npartitions)
    2086                 :             : {
    2087                 :        2506 :         Size            hash_mem_limit = get_hash_memory_limit();
    2088                 :        2506 :         double          partition_limit;
    2089                 :        2506 :         double          mem_wanted;
    2090                 :        2506 :         double          dpartitions;
    2091                 :        2506 :         int                     npartitions;
    2092                 :        2506 :         int                     partition_bits;
    2093                 :             : 
    2094                 :             :         /*
    2095                 :             :          * Avoid creating so many partitions that the memory requirements of the
    2096                 :             :          * open partition files are greater than 1/4 of hash_mem.
    2097                 :             :          */
    2098                 :        2506 :         partition_limit =
    2099                 :        2506 :                 (hash_mem_limit * 0.25 - HASHAGG_READ_BUFFER_SIZE) /
    2100                 :             :                 HASHAGG_WRITE_BUFFER_SIZE;
    2101                 :             : 
    2102                 :        2506 :         mem_wanted = HASHAGG_PARTITION_FACTOR * input_groups * hashentrysize;
    2103                 :             : 
    2104                 :             :         /* make enough partitions so that each one is likely to fit in memory */
    2105                 :        2506 :         dpartitions = 1 + (mem_wanted / hash_mem_limit);
    2106                 :             : 
    2107         [ +  + ]:        2506 :         if (dpartitions > partition_limit)
    2108                 :        2496 :                 dpartitions = partition_limit;
    2109                 :             : 
    2110         [ -  + ]:        2506 :         if (dpartitions < HASHAGG_MIN_PARTITIONS)
    2111                 :        2506 :                 dpartitions = HASHAGG_MIN_PARTITIONS;
    2112         [ +  - ]:        2506 :         if (dpartitions > HASHAGG_MAX_PARTITIONS)
    2113                 :           0 :                 dpartitions = HASHAGG_MAX_PARTITIONS;
    2114                 :             : 
    2115                 :             :         /* HASHAGG_MAX_PARTITIONS limit makes this safe */
    2116                 :        2506 :         npartitions = (int) dpartitions;
    2117                 :             : 
    2118                 :             :         /* ceil(log2(npartitions)) */
    2119                 :        2506 :         partition_bits = pg_ceil_log2_32(npartitions);
    2120                 :             : 
    2121                 :             :         /* make sure that we don't exhaust the hash bits */
    2122         [ +  - ]:        2506 :         if (partition_bits + used_bits >= 32)
    2123                 :           0 :                 partition_bits = 32 - used_bits;
    2124                 :             : 
    2125         [ +  + ]:        2506 :         if (log2_npartitions != NULL)
    2126                 :        2101 :                 *log2_npartitions = partition_bits;
    2127                 :             : 
    2128                 :             :         /* number of partitions will be a power of two */
    2129                 :        2506 :         npartitions = 1 << partition_bits;
    2130                 :             : 
    2131                 :        5012 :         return npartitions;
    2132                 :        2506 : }
    2133                 :             : 
    2134                 :             : /*
    2135                 :             :  * Initialize a freshly-created TupleHashEntry.
    2136                 :             :  */
    2137                 :             : static void
    2138                 :       65299 : initialize_hash_entry(AggState *aggstate, TupleHashTable hashtable,
    2139                 :             :                                           TupleHashEntry entry)
    2140                 :             : {
    2141                 :       65299 :         AggStatePerGroup pergroup;
    2142                 :       65299 :         int                     transno;
    2143                 :             : 
    2144                 :       65299 :         aggstate->hash_ngroups_current++;
    2145                 :       65299 :         hash_agg_check_limits(aggstate);
    2146                 :             : 
    2147                 :             :         /* no need to allocate or initialize per-group state */
    2148         [ +  + ]:       65299 :         if (aggstate->numtrans == 0)
    2149                 :       23403 :                 return;
    2150                 :             : 
    2151                 :       41896 :         pergroup = (AggStatePerGroup) TupleHashEntryGetAdditional(hashtable, entry);
    2152                 :             : 
    2153                 :             :         /*
    2154                 :             :          * Initialize aggregates for new tuple group, lookup_hash_entries()
    2155                 :             :          * already has selected the relevant grouping set.
    2156                 :             :          */
    2157         [ +  + ]:      108482 :         for (transno = 0; transno < aggstate->numtrans; transno++)
    2158                 :             :         {
    2159                 :       66586 :                 AggStatePerTrans pertrans = &aggstate->pertrans[transno];
    2160                 :       66586 :                 AggStatePerGroup pergroupstate = &pergroup[transno];
    2161                 :             : 
    2162                 :       66586 :                 initialize_aggregate(aggstate, pertrans, pergroupstate);
    2163                 :       66586 :         }
    2164         [ -  + ]:       65299 : }
    2165                 :             : 
    2166                 :             : /*
    2167                 :             :  * Look up hash entries for the current tuple in all hashed grouping sets.
    2168                 :             :  *
    2169                 :             :  * Some entries may be left NULL if we are in "spill mode". The same tuple
    2170                 :             :  * will belong to different groups for each grouping set, so may match a group
    2171                 :             :  * already in memory for one set and match a group not in memory for another
    2172                 :             :  * set. When in "spill mode", the tuple will be spilled for each grouping set
    2173                 :             :  * where it doesn't match a group in memory.
    2174                 :             :  *
    2175                 :             :  * NB: It's possible to spill the same tuple for several different grouping
    2176                 :             :  * sets. This may seem wasteful, but it's actually a trade-off: if we spill
    2177                 :             :  * the tuple multiple times for multiple grouping sets, it can be partitioned
    2178                 :             :  * for each grouping set, making the refilling of the hash table very
    2179                 :             :  * efficient.
    2180                 :             :  */
    2181                 :             : static void
    2182                 :     1063599 : lookup_hash_entries(AggState *aggstate)
    2183                 :             : {
    2184                 :     1063599 :         AggStatePerGroup *pergroup = aggstate->hash_pergroup;
    2185                 :     1063599 :         TupleTableSlot *outerslot = aggstate->tmpcontext->ecxt_outertuple;
    2186                 :     1063599 :         int                     setno;
    2187                 :             : 
    2188         [ +  + ]:     2149506 :         for (setno = 0; setno < aggstate->num_hashes; setno++)
    2189                 :             :         {
    2190                 :     1085907 :                 AggStatePerHash perhash = &aggstate->perhash[setno];
    2191                 :     1085907 :                 TupleHashTable hashtable = perhash->hashtable;
    2192                 :     1085907 :                 TupleTableSlot *hashslot = perhash->hashslot;
    2193                 :     1085907 :                 TupleHashEntry entry;
    2194                 :     1085907 :                 uint32          hash;
    2195                 :     1085907 :                 bool            isnew = false;
    2196                 :     1085907 :                 bool       *p_isnew;
    2197                 :             : 
    2198                 :             :                 /* if hash table already spilled, don't create new entries */
    2199         [ +  + ]:     1085907 :                 p_isnew = aggstate->hash_spill_mode ? NULL : &isnew;
    2200                 :             : 
    2201                 :     1085907 :                 select_current_set(aggstate, setno, true);
    2202                 :     2171814 :                 prepare_hash_slot(perhash,
    2203                 :     1085907 :                                                   outerslot,
    2204                 :     1085907 :                                                   hashslot);
    2205                 :             : 
    2206                 :     2171814 :                 entry = LookupTupleHashEntry(hashtable, hashslot,
    2207                 :     1085907 :                                                                          p_isnew, &hash);
    2208                 :             : 
    2209         [ +  + ]:     1085907 :                 if (entry != NULL)
    2210                 :             :                 {
    2211         [ +  + ]:     1048925 :                         if (isnew)
    2212                 :       49549 :                                 initialize_hash_entry(aggstate, hashtable, entry);
    2213                 :     1048925 :                         pergroup[setno] = TupleHashEntryGetAdditional(hashtable, entry);
    2214                 :     1048925 :                 }
    2215                 :             :                 else
    2216                 :             :                 {
    2217                 :       36982 :                         HashAggSpill *spill = &aggstate->hash_spills[setno];
    2218                 :       36982 :                         TupleTableSlot *slot = aggstate->tmpcontext->ecxt_outertuple;
    2219                 :             : 
    2220         [ +  - ]:       36982 :                         if (spill->partitions == NULL)
    2221                 :           0 :                                 hashagg_spill_init(spill, aggstate->hash_tapeset, 0,
    2222                 :           0 :                                                                    perhash->aggnode->numGroups,
    2223                 :           0 :                                                                    aggstate->hashentrysize);
    2224                 :             : 
    2225                 :       36982 :                         hashagg_spill_tuple(aggstate, spill, slot, hash);
    2226                 :       36982 :                         pergroup[setno] = NULL;
    2227                 :       36982 :                 }
    2228                 :     1085907 :         }
    2229                 :     1063599 : }
    2230                 :             : 
    2231                 :             : /*
    2232                 :             :  * ExecAgg -
    2233                 :             :  *
    2234                 :             :  *        ExecAgg receives tuples from its outer subplan and aggregates over
    2235                 :             :  *        the appropriate attribute for each aggregate function use (Aggref
    2236                 :             :  *        node) appearing in the targetlist or qual of the node.  The number
    2237                 :             :  *        of tuples to aggregate over depends on whether grouped or plain
    2238                 :             :  *        aggregation is selected.  In grouped aggregation, we produce a result
    2239                 :             :  *        row for each group; in plain aggregation there's a single result row
    2240                 :             :  *        for the whole query.  In either case, the value of each aggregate is
    2241                 :             :  *        stored in the expression context to be used when ExecProject evaluates
    2242                 :             :  *        the result tuple.
    2243                 :             :  */
    2244                 :             : static TupleTableSlot *
    2245                 :       87715 : ExecAgg(PlanState *pstate)
    2246                 :             : {
    2247                 :       87715 :         AggState   *node = castNode(AggState, pstate);
    2248                 :       87715 :         TupleTableSlot *result = NULL;
    2249                 :             : 
    2250         [ +  + ]:       87715 :         CHECK_FOR_INTERRUPTS();
    2251                 :             : 
    2252         [ +  + ]:       87715 :         if (!node->agg_done)
    2253                 :             :         {
    2254                 :             :                 /* Dispatch based on strategy */
    2255   [ +  +  +  + ]:       84024 :                 switch (node->phase->aggstrategy)
    2256                 :             :                 {
    2257                 :             :                         case AGG_HASHED:
    2258         [ +  + ]:       56771 :                                 if (!node->table_filled)
    2259                 :         728 :                                         agg_fill_hash_table(node);
    2260                 :             :                                 /* FALLTHROUGH */
    2261                 :             :                         case AGG_MIXED:
    2262                 :       60600 :                                 result = agg_retrieve_hash_table(node);
    2263                 :       60600 :                                 break;
    2264                 :             :                         case AGG_PLAIN:
    2265                 :             :                         case AGG_SORTED:
    2266                 :       23406 :                                 result = agg_retrieve_direct(node);
    2267                 :       23406 :                                 break;
    2268                 :             :                 }
    2269                 :             : 
    2270   [ +  +  -  + ]:       84024 :                 if (!TupIsNull(result))
    2271                 :       82969 :                         return result;
    2272                 :        1019 :         }
    2273                 :             : 
    2274                 :        4710 :         return NULL;
    2275                 :       87679 : }
    2276                 :             : 
    2277                 :             : /*
    2278                 :             :  * ExecAgg for non-hashed case
    2279                 :             :  */
    2280                 :             : static TupleTableSlot *
    2281                 :       23406 : agg_retrieve_direct(AggState *aggstate)
    2282                 :             : {
    2283                 :       23406 :         Agg                *node = aggstate->phase->aggnode;
    2284                 :       23406 :         ExprContext *econtext;
    2285                 :       23406 :         ExprContext *tmpcontext;
    2286                 :       23406 :         AggStatePerAgg peragg;
    2287                 :       23406 :         AggStatePerGroup *pergroups;
    2288                 :       23406 :         TupleTableSlot *outerslot;
    2289                 :       23406 :         TupleTableSlot *firstSlot;
    2290                 :       23406 :         TupleTableSlot *result;
    2291                 :       23406 :         bool            hasGroupingSets = aggstate->phase->numsets > 0;
    2292         [ +  + ]:       23406 :         int                     numGroupingSets = Max(aggstate->phase->numsets, 1);
    2293                 :       23406 :         int                     currentSet;
    2294                 :       23406 :         int                     nextSetSize;
    2295                 :       23406 :         int                     numReset;
    2296                 :       23406 :         int                     i;
    2297                 :             : 
    2298                 :             :         /*
    2299                 :             :          * get state info from node
    2300                 :             :          *
    2301                 :             :          * econtext is the per-output-tuple expression context
    2302                 :             :          *
    2303                 :             :          * tmpcontext is the per-input-tuple expression context
    2304                 :             :          */
    2305                 :       23406 :         econtext = aggstate->ss.ps.ps_ExprContext;
    2306                 :       23406 :         tmpcontext = aggstate->tmpcontext;
    2307                 :             : 
    2308                 :       23406 :         peragg = aggstate->peragg;
    2309                 :       23406 :         pergroups = aggstate->pergroups;
    2310                 :       23406 :         firstSlot = aggstate->ss.ss_ScanTupleSlot;
    2311                 :             : 
    2312                 :             :         /*
    2313                 :             :          * We loop retrieving groups until we find one matching
    2314                 :             :          * aggstate->ss.ps.qual
    2315                 :             :          *
    2316                 :             :          * For grouping sets, we have the invariant that aggstate->projected_set
    2317                 :             :          * is either -1 (initial call) or the index (starting from 0) in
    2318                 :             :          * gset_lengths for the group we just completed (either by projecting a
    2319                 :             :          * row or by discarding it in the qual).
    2320                 :             :          */
    2321         [ +  + ]:       35204 :         while (!aggstate->agg_done)
    2322                 :             :         {
    2323                 :             :                 /*
    2324                 :             :                  * Clear the per-output-tuple context for each group, as well as
    2325                 :             :                  * aggcontext (which contains any pass-by-ref transvalues of the old
    2326                 :             :                  * group).  Some aggregate functions store working state in child
    2327                 :             :                  * contexts; those now get reset automatically without us needing to
    2328                 :             :                  * do anything special.
    2329                 :             :                  *
    2330                 :             :                  * We use ReScanExprContext not just ResetExprContext because we want
    2331                 :             :                  * any registered shutdown callbacks to be called.  That allows
    2332                 :             :                  * aggregate functions to ensure they've cleaned up any non-memory
    2333                 :             :                  * resources.
    2334                 :             :                  */
    2335                 :       35154 :                 ReScanExprContext(econtext);
    2336                 :             : 
    2337                 :             :                 /*
    2338                 :             :                  * Determine how many grouping sets need to be reset at this boundary.
    2339                 :             :                  */
    2340   [ +  +  +  + ]:       35154 :                 if (aggstate->projected_set >= 0 &&
    2341                 :       31156 :                         aggstate->projected_set < numGroupingSets)
    2342                 :       31153 :                         numReset = aggstate->projected_set + 1;
    2343                 :             :                 else
    2344                 :        4001 :                         numReset = numGroupingSets;
    2345                 :             : 
    2346                 :             :                 /*
    2347                 :             :                  * numReset can change on a phase boundary, but that's OK; we want to
    2348                 :             :                  * reset the contexts used in _this_ phase, and later, after possibly
    2349                 :             :                  * changing phase, initialize the right number of aggregates for the
    2350                 :             :                  * _new_ phase.
    2351                 :             :                  */
    2352                 :             : 
    2353         [ +  + ]:       74016 :                 for (i = 0; i < numReset; i++)
    2354                 :             :                 {
    2355                 :       38862 :                         ReScanExprContext(aggstate->aggcontexts[i]);
    2356                 :       38862 :                 }
    2357                 :             : 
    2358                 :             :                 /*
    2359                 :             :                  * Check if input is complete and there are no more groups to project
    2360                 :             :                  * in this phase; move to next phase or mark as done.
    2361                 :             :                  */
    2362   [ +  +  +  + ]:       35154 :                 if (aggstate->input_done == true &&
    2363                 :         273 :                         aggstate->projected_set >= (numGroupingSets - 1))
    2364                 :             :                 {
    2365         [ +  + ]:         139 :                         if (aggstate->current_phase < aggstate->numphases - 1)
    2366                 :             :                         {
    2367                 :          37 :                                 initialize_phase(aggstate, aggstate->current_phase + 1);
    2368                 :          37 :                                 aggstate->input_done = false;
    2369                 :          37 :                                 aggstate->projected_set = -1;
    2370         [ +  + ]:          37 :                                 numGroupingSets = Max(aggstate->phase->numsets, 1);
    2371                 :          37 :                                 node = aggstate->phase->aggnode;
    2372                 :          37 :                                 numReset = numGroupingSets;
    2373                 :          37 :                         }
    2374         [ +  + ]:         102 :                         else if (aggstate->aggstrategy == AGG_MIXED)
    2375                 :             :                         {
    2376                 :             :                                 /*
    2377                 :             :                                  * Mixed mode; we've output all the grouped stuff and have
    2378                 :             :                                  * full hashtables, so switch to outputting those.
    2379                 :             :                                  */
    2380                 :          26 :                                 initialize_phase(aggstate, 0);
    2381                 :          26 :                                 aggstate->table_filled = true;
    2382                 :          26 :                                 ResetTupleHashIterator(aggstate->perhash[0].hashtable,
    2383                 :             :                                                                            &aggstate->perhash[0].hashiter);
    2384                 :          26 :                                 select_current_set(aggstate, 0, true);
    2385                 :          26 :                                 return agg_retrieve_hash_table(aggstate);
    2386                 :             :                         }
    2387                 :             :                         else
    2388                 :             :                         {
    2389                 :          76 :                                 aggstate->agg_done = true;
    2390                 :          76 :                                 break;
    2391                 :             :                         }
    2392                 :          37 :                 }
    2393                 :             : 
    2394                 :             :                 /*
    2395                 :             :                  * Get the number of columns in the next grouping set after the last
    2396                 :             :                  * projected one (if any). This is the number of columns to compare to
    2397                 :             :                  * see if we reached the boundary of that set too.
    2398                 :             :                  */
    2399   [ +  +  +  + ]:       35052 :                 if (aggstate->projected_set >= 0 &&
    2400                 :       31017 :                         aggstate->projected_set < (numGroupingSets - 1))
    2401                 :        4543 :                         nextSetSize = aggstate->phase->gset_lengths[aggstate->projected_set + 1];
    2402                 :             :                 else
    2403                 :       30509 :                         nextSetSize = 0;
    2404                 :             : 
    2405                 :             :                 /*----------
    2406                 :             :                  * If a subgroup for the current grouping set is present, project it.
    2407                 :             :                  *
    2408                 :             :                  * We have a new group if:
    2409                 :             :                  *      - we're out of input but haven't projected all grouping sets
    2410                 :             :                  *        (checked above)
    2411                 :             :                  * OR
    2412                 :             :                  *        - we already projected a row that wasn't from the last grouping
    2413                 :             :                  *              set
    2414                 :             :                  *        AND
    2415                 :             :                  *        - the next grouping set has at least one grouping column (since
    2416                 :             :                  *              empty grouping sets project only once input is exhausted)
    2417                 :             :                  *        AND
    2418                 :             :                  *        - the previous and pending rows differ on the grouping columns
    2419                 :             :                  *              of the next grouping set
    2420                 :             :                  *----------
    2421                 :             :                  */
    2422                 :       35052 :                 tmpcontext->ecxt_innertuple = econtext->ecxt_outertuple;
    2423   [ +  +  +  + ]:       38373 :                 if (aggstate->input_done ||
    2424         [ +  + ]:       34932 :                         (node->aggstrategy != AGG_PLAIN &&
    2425         [ +  + ]:       31198 :                          aggstate->projected_set != -1 &&
    2426         [ +  + ]:       30883 :                          aggstate->projected_set < (numGroupingSets - 1) &&
    2427         [ +  + ]:        4409 :                          nextSetSize > 0 &&
    2428                 :        6642 :                          !ExecQualAndReset(aggstate->phase->eqfunctions[nextSetSize - 1],
    2429                 :        3321 :                                                            tmpcontext)))
    2430                 :             :                 {
    2431                 :        2353 :                         aggstate->projected_set += 1;
    2432                 :             : 
    2433         [ -  + ]:        2353 :                         Assert(aggstate->projected_set < numGroupingSets);
    2434   [ +  +  -  + ]:        2353 :                         Assert(nextSetSize > 0 || aggstate->input_done);
    2435                 :        2353 :                 }
    2436                 :             :                 else
    2437                 :             :                 {
    2438                 :             :                         /*
    2439                 :             :                          * We no longer care what group we just projected, the next
    2440                 :             :                          * projection will always be the first (or only) grouping set
    2441                 :             :                          * (unless the input proves to be empty).
    2442                 :             :                          */
    2443                 :       32699 :                         aggstate->projected_set = 0;
    2444                 :             : 
    2445                 :             :                         /*
    2446                 :             :                          * If we don't already have the first tuple of the new group,
    2447                 :             :                          * fetch it from the outer plan.
    2448                 :             :                          */
    2449         [ +  + ]:       32699 :                         if (aggstate->grp_firstTuple == NULL)
    2450                 :             :                         {
    2451                 :        4048 :                                 outerslot = fetch_input_tuple(aggstate);
    2452   [ +  +  +  + ]:        4048 :                                 if (!TupIsNull(outerslot))
    2453                 :             :                                 {
    2454                 :             :                                         /*
    2455                 :             :                                          * Make a copy of the first input tuple; we will use this
    2456                 :             :                                          * for comparisons (in group mode) and for projection.
    2457                 :             :                                          */
    2458                 :        3708 :                                         aggstate->grp_firstTuple = ExecCopySlotHeapTuple(outerslot);
    2459                 :        3708 :                                 }
    2460                 :             :                                 else
    2461                 :             :                                 {
    2462                 :             :                                         /* outer plan produced no tuples at all */
    2463         [ +  + ]:         340 :                                         if (hasGroupingSets)
    2464                 :             :                                         {
    2465                 :             :                                                 /*
    2466                 :             :                                                  * If there was no input at all, we need to project
    2467                 :             :                                                  * rows only if there are grouping sets of size 0.
    2468                 :             :                                                  * Note that this implies that there can't be any
    2469                 :             :                                                  * references to ungrouped Vars, which would otherwise
    2470                 :             :                                                  * cause issues with the empty output slot.
    2471                 :             :                                                  *
    2472                 :             :                                                  * XXX: This is no longer true, we currently deal with
    2473                 :             :                                                  * this in finalize_aggregates().
    2474                 :             :                                                  */
    2475                 :          13 :                                                 aggstate->input_done = true;
    2476                 :             : 
    2477         [ +  + ]:          18 :                                                 while (aggstate->phase->gset_lengths[aggstate->projected_set] > 0)
    2478                 :             :                                                 {
    2479                 :           8 :                                                         aggstate->projected_set += 1;
    2480         [ +  + ]:           8 :                                                         if (aggstate->projected_set >= numGroupingSets)
    2481                 :             :                                                         {
    2482                 :             :                                                                 /*
    2483                 :             :                                                                  * We can't set agg_done here because we might
    2484                 :             :                                                                  * have more phases to do, even though the
    2485                 :             :                                                                  * input is empty. So we need to restart the
    2486                 :             :                                                                  * whole outer loop.
    2487                 :             :                                                                  */
    2488                 :           3 :                                                                 break;
    2489                 :             :                                                         }
    2490                 :             :                                                 }
    2491                 :             : 
    2492         [ +  + ]:          13 :                                                 if (aggstate->projected_set >= numGroupingSets)
    2493                 :           3 :                                                         continue;
    2494                 :          10 :                                         }
    2495                 :             :                                         else
    2496                 :             :                                         {
    2497                 :         327 :                                                 aggstate->agg_done = true;
    2498                 :             :                                                 /* If we are grouping, we should produce no tuples too */
    2499         [ +  + ]:         327 :                                                 if (node->aggstrategy != AGG_PLAIN)
    2500                 :          25 :                                                         return NULL;
    2501                 :             :                                         }
    2502                 :             :                                 }
    2503                 :        4020 :                         }
    2504                 :             : 
    2505                 :             :                         /*
    2506                 :             :                          * Initialize working state for a new input tuple group.
    2507                 :             :                          */
    2508                 :       32671 :                         initialize_aggregates(aggstate, pergroups, numReset);
    2509                 :             : 
    2510         [ +  + ]:       32671 :                         if (aggstate->grp_firstTuple != NULL)
    2511                 :             :                         {
    2512                 :             :                                 /*
    2513                 :             :                                  * Store the copied first input tuple in the tuple table slot
    2514                 :             :                                  * reserved for it.  The tuple will be deleted when it is
    2515                 :             :                                  * cleared from the slot.
    2516                 :             :                                  */
    2517                 :       64718 :                                 ExecForceStoreHeapTuple(aggstate->grp_firstTuple,
    2518                 :       32359 :                                                                                 firstSlot, true);
    2519                 :       32359 :                                 aggstate->grp_firstTuple = NULL;     /* don't keep two pointers */
    2520                 :             : 
    2521                 :             :                                 /* set up for first advance_aggregates call */
    2522                 :       32359 :                                 tmpcontext->ecxt_outertuple = firstSlot;
    2523                 :             : 
    2524                 :             :                                 /*
    2525                 :             :                                  * Process each outer-plan tuple, and then fetch the next one,
    2526                 :             :                                  * until we exhaust the outer plan or cross a group boundary.
    2527                 :             :                                  */
    2528                 :     3243429 :                                 for (;;)
    2529                 :             :                                 {
    2530                 :             :                                         /*
    2531                 :             :                                          * During phase 1 only of a mixed agg, we need to update
    2532                 :             :                                          * hashtables as well in advance_aggregates.
    2533                 :             :                                          */
    2534   [ +  +  -  + ]:     3243429 :                                         if (aggstate->aggstrategy == AGG_MIXED &&
    2535                 :        6146 :                                                 aggstate->current_phase == 1)
    2536                 :             :                                         {
    2537                 :        6146 :                                                 lookup_hash_entries(aggstate);
    2538                 :        6146 :                                         }
    2539                 :             : 
    2540                 :             :                                         /* Advance the aggregates (or combine functions) */
    2541                 :     3243429 :                                         advance_aggregates(aggstate);
    2542                 :             : 
    2543                 :             :                                         /* Reset per-input-tuple context after each tuple */
    2544                 :     3243429 :                                         ResetExprContext(tmpcontext);
    2545                 :             : 
    2546                 :     3243429 :                                         outerslot = fetch_input_tuple(aggstate);
    2547   [ +  +  +  + ]:     3243429 :                                         if (TupIsNull(outerslot))
    2548                 :             :                                         {
    2549                 :             :                                                 /* no more outer-plan tuples available */
    2550                 :             : 
    2551                 :             :                                                 /* if we built hash tables, finalize any spills */
    2552   [ +  +  -  + ]:        3691 :                                                 if (aggstate->aggstrategy == AGG_MIXED &&
    2553                 :          24 :                                                         aggstate->current_phase == 1)
    2554                 :          24 :                                                         hashagg_finish_initial_spills(aggstate);
    2555                 :             : 
    2556         [ +  + ]:        3691 :                                                 if (hasGroupingSets)
    2557                 :             :                                                 {
    2558                 :         126 :                                                         aggstate->input_done = true;
    2559                 :         126 :                                                         break;
    2560                 :             :                                                 }
    2561                 :             :                                                 else
    2562                 :             :                                                 {
    2563                 :        3565 :                                                         aggstate->agg_done = true;
    2564                 :        3565 :                                                         break;
    2565                 :             :                                                 }
    2566                 :             :                                         }
    2567                 :             :                                         /* set up for next advance_aggregates call */
    2568                 :     3239738 :                                         tmpcontext->ecxt_outertuple = outerslot;
    2569                 :             : 
    2570                 :             :                                         /*
    2571                 :             :                                          * If we are grouping, check whether we've crossed a group
    2572                 :             :                                          * boundary.
    2573                 :             :                                          */
    2574   [ +  +  +  + ]:     3239738 :                                         if (node->aggstrategy != AGG_PLAIN && node->numCols > 0)
    2575                 :             :                                         {
    2576                 :      377875 :                                                 tmpcontext->ecxt_innertuple = firstSlot;
    2577   [ +  +  +  + ]:      755750 :                                                 if (!ExecQual(aggstate->phase->eqfunctions[node->numCols - 1],
    2578                 :      377875 :                                                                           tmpcontext))
    2579                 :             :                                                 {
    2580                 :       28668 :                                                         aggstate->grp_firstTuple = ExecCopySlotHeapTuple(outerslot);
    2581                 :       28668 :                                                         break;
    2582                 :             :                                                 }
    2583                 :      349207 :                                         }
    2584                 :             :                                 }
    2585                 :       32359 :                         }
    2586                 :             : 
    2587                 :             :                         /*
    2588                 :             :                          * Use the representative input tuple for any references to
    2589                 :             :                          * non-aggregated input columns in aggregate direct args, the node
    2590                 :             :                          * qual, and the tlist.  (If we are not grouping, and there are no
    2591                 :             :                          * input rows at all, we will come here with an empty firstSlot
    2592                 :             :                          * ... but if not grouping, there can't be any references to
    2593                 :             :                          * non-aggregated input columns, so no problem.)
    2594                 :             :                          */
    2595                 :       32671 :                         econtext->ecxt_outertuple = firstSlot;
    2596                 :             :                 }
    2597                 :             : 
    2598         [ -  + ]:       35024 :                 Assert(aggstate->projected_set >= 0);
    2599                 :             : 
    2600                 :       35024 :                 currentSet = aggstate->projected_set;
    2601                 :             : 
    2602                 :       35024 :                 prepare_projection_slot(aggstate, econtext->ecxt_outertuple, currentSet);
    2603                 :             : 
    2604                 :       35024 :                 select_current_set(aggstate, currentSet, false);
    2605                 :             : 
    2606                 :       70048 :                 finalize_aggregates(aggstate,
    2607                 :       35024 :                                                         peragg,
    2608                 :       35024 :                                                         pergroups[currentSet]);
    2609                 :             : 
    2610                 :             :                 /*
    2611                 :             :                  * If there's no row to project right now, we must continue rather
    2612                 :             :                  * than returning a null since there might be more groups.
    2613                 :             :                  */
    2614                 :       35024 :                 result = project_aggregates(aggstate);
    2615         [ +  + ]:       35024 :                 if (result)
    2616                 :       23229 :                         return result;
    2617                 :             :         }
    2618                 :             : 
    2619                 :             :         /* No more groups */
    2620                 :         126 :         return NULL;
    2621                 :       23406 : }
    2622                 :             : 
    2623                 :             : /*
    2624                 :             :  * ExecAgg for hashed case: read input and build hash table
    2625                 :             :  */
    2626                 :             : static void
    2627                 :         728 : agg_fill_hash_table(AggState *aggstate)
    2628                 :             : {
    2629                 :         728 :         TupleTableSlot *outerslot;
    2630                 :         728 :         ExprContext *tmpcontext = aggstate->tmpcontext;
    2631                 :             : 
    2632                 :             :         /*
    2633                 :             :          * Process each outer-plan tuple, and then fetch the next one, until we
    2634                 :             :          * exhaust the outer plan.
    2635                 :             :          */
    2636                 :     1058181 :         for (;;)
    2637                 :             :         {
    2638                 :     1058181 :                 outerslot = fetch_input_tuple(aggstate);
    2639   [ +  +  +  + ]:     1058181 :                 if (TupIsNull(outerslot))
    2640                 :         728 :                         break;
    2641                 :             : 
    2642                 :             :                 /* set up for lookup_hash_entries and advance_aggregates */
    2643                 :     1057453 :                 tmpcontext->ecxt_outertuple = outerslot;
    2644                 :             : 
    2645                 :             :                 /* Find or build hashtable entries */
    2646                 :     1057453 :                 lookup_hash_entries(aggstate);
    2647                 :             : 
    2648                 :             :                 /* Advance the aggregates (or combine functions) */
    2649                 :     1057453 :                 advance_aggregates(aggstate);
    2650                 :             : 
    2651                 :             :                 /*
    2652                 :             :                  * Reset per-input-tuple context after each tuple, but note that the
    2653                 :             :                  * hash lookups do this too
    2654                 :             :                  */
    2655                 :     1057453 :                 ResetExprContext(aggstate->tmpcontext);
    2656                 :             :         }
    2657                 :             : 
    2658                 :             :         /* finalize spills, if any */
    2659                 :         728 :         hashagg_finish_initial_spills(aggstate);
    2660                 :             : 
    2661                 :         728 :         aggstate->table_filled = true;
    2662                 :             :         /* Initialize to walk the first hash table */
    2663                 :         728 :         select_current_set(aggstate, 0, true);
    2664                 :         728 :         ResetTupleHashIterator(aggstate->perhash[0].hashtable,
    2665                 :             :                                                    &aggstate->perhash[0].hashiter);
    2666                 :         728 : }
    2667                 :             : 
    2668                 :             : /*
    2669                 :             :  * If any data was spilled during hash aggregation, reset the hash table and
    2670                 :             :  * reprocess one batch of spilled data. After reprocessing a batch, the hash
    2671                 :             :  * table will again contain data, ready to be consumed by
    2672                 :             :  * agg_retrieve_hash_table_in_memory().
    2673                 :             :  *
    2674                 :             :  * Should only be called after all in memory hash table entries have been
    2675                 :             :  * finalized and emitted.
    2676                 :             :  *
    2677                 :             :  * Return false when input is exhausted and there's no more work to be done;
    2678                 :             :  * otherwise return true.
    2679                 :             :  */
    2680                 :             : static bool
    2681                 :        5371 : agg_refill_hash_table(AggState *aggstate)
    2682                 :             : {
    2683                 :        5371 :         HashAggBatch *batch;
    2684                 :        5371 :         AggStatePerHash perhash;
    2685                 :        5371 :         HashAggSpill spill;
    2686                 :        5371 :         LogicalTapeSet *tapeset = aggstate->hash_tapeset;
    2687                 :        5371 :         bool            spill_initialized = false;
    2688                 :             : 
    2689         [ +  + ]:        5371 :         if (aggstate->hash_batches == NIL)
    2690                 :         886 :                 return false;
    2691                 :             : 
    2692                 :             :         /* hash_batches is a stack, with the top item at the end of the list */
    2693                 :        4485 :         batch = llast(aggstate->hash_batches);
    2694                 :        4485 :         aggstate->hash_batches = list_delete_last(aggstate->hash_batches);
    2695                 :             : 
    2696                 :        8970 :         hash_agg_set_limits(aggstate->hashentrysize, batch->input_card,
    2697                 :        4485 :                                                 batch->used_bits, &aggstate->hash_mem_limit,
    2698                 :        4485 :                                                 &aggstate->hash_ngroups_limit, NULL);
    2699                 :             : 
    2700                 :             :         /*
    2701                 :             :          * Each batch only processes one grouping set; set the rest to NULL so
    2702                 :             :          * that advance_aggregates() knows to ignore them. We don't touch
    2703                 :             :          * pergroups for sorted grouping sets here, because they will be needed if
    2704                 :             :          * we rescan later. The expressions for sorted grouping sets will not be
    2705                 :             :          * evaluated after we recompile anyway.
    2706                 :             :          */
    2707   [ +  -  +  -  :       34560 :         MemSet(aggstate->hash_pergroup, 0,
          +  -  -  +  +  
                      + ]
    2708                 :             :                    sizeof(AggStatePerGroup) * aggstate->num_hashes);
    2709                 :             : 
    2710                 :             :         /* free memory and reset hash tables */
    2711                 :        4485 :         ReScanExprContext(aggstate->hashcontext);
    2712         [ +  + ]:       34560 :         for (int setno = 0; setno < aggstate->num_hashes; setno++)
    2713                 :       30075 :                 ResetTupleHashTable(aggstate->perhash[setno].hashtable);
    2714                 :             : 
    2715                 :        4485 :         aggstate->hash_ngroups_current = 0;
    2716                 :             : 
    2717                 :             :         /*
    2718                 :             :          * In AGG_MIXED mode, hash aggregation happens in phase 1 and the output
    2719                 :             :          * happens in phase 0. So, we switch to phase 1 when processing a batch,
    2720                 :             :          * and back to phase 0 after the batch is done.
    2721                 :             :          */
    2722         [ +  - ]:        4485 :         Assert(aggstate->current_phase == 0);
    2723         [ +  + ]:        4485 :         if (aggstate->phase->aggstrategy == AGG_MIXED)
    2724                 :             :         {
    2725                 :        4377 :                 aggstate->current_phase = 1;
    2726                 :        4377 :                 aggstate->phase = &aggstate->phases[aggstate->current_phase];
    2727                 :        4377 :         }
    2728                 :             : 
    2729                 :        4485 :         select_current_set(aggstate, batch->setno, true);
    2730                 :             : 
    2731                 :        4485 :         perhash = &aggstate->perhash[aggstate->current_set];
    2732                 :             : 
    2733                 :             :         /*
    2734                 :             :          * Spilled tuples are always read back as MinimalTuples, which may be
    2735                 :             :          * different from the outer plan, so recompile the aggregate expressions.
    2736                 :             :          *
    2737                 :             :          * We still need the NULL check, because we are only processing one
    2738                 :             :          * grouping set at a time and the rest will be NULL.
    2739                 :             :          */
    2740                 :        4485 :         hashagg_recompile_expressions(aggstate, true, true);
    2741                 :             : 
    2742                 :             :         INJECTION_POINT("hash-aggregate-process-batch", NULL);
    2743                 :      112249 :         for (;;)
    2744                 :             :         {
    2745                 :      112249 :                 TupleTableSlot *spillslot = aggstate->hash_spill_rslot;
    2746                 :      112249 :                 TupleTableSlot *hashslot = perhash->hashslot;
    2747                 :      112249 :                 TupleHashTable hashtable = perhash->hashtable;
    2748                 :      112249 :                 TupleHashEntry entry;
    2749                 :      112249 :                 MinimalTuple tuple;
    2750                 :      112249 :                 uint32          hash;
    2751                 :      112249 :                 bool            isnew = false;
    2752         [ +  + ]:      112249 :                 bool       *p_isnew = aggstate->hash_spill_mode ? NULL : &isnew;
    2753                 :             : 
    2754         [ -  + ]:      112249 :                 CHECK_FOR_INTERRUPTS();
    2755                 :             : 
    2756                 :      112249 :                 tuple = hashagg_batch_read(batch, &hash);
    2757         [ +  + ]:      112249 :                 if (tuple == NULL)
    2758                 :        4485 :                         break;
    2759                 :             : 
    2760                 :      107764 :                 ExecStoreMinimalTuple(tuple, spillslot, true);
    2761                 :      107764 :                 aggstate->tmpcontext->ecxt_outertuple = spillslot;
    2762                 :             : 
    2763                 :      215528 :                 prepare_hash_slot(perhash,
    2764                 :      107764 :                                                   aggstate->tmpcontext->ecxt_outertuple,
    2765                 :      107764 :                                                   hashslot);
    2766                 :      215528 :                 entry = LookupTupleHashEntryHash(hashtable, hashslot,
    2767                 :      107764 :                                                                                  p_isnew, hash);
    2768                 :             : 
    2769         [ +  + ]:      107764 :                 if (entry != NULL)
    2770                 :             :                 {
    2771         [ +  + ]:       36982 :                         if (isnew)
    2772                 :       15750 :                                 initialize_hash_entry(aggstate, hashtable, entry);
    2773                 :       36982 :                         aggstate->hash_pergroup[batch->setno] = TupleHashEntryGetAdditional(hashtable, entry);
    2774                 :       36982 :                         advance_aggregates(aggstate);
    2775                 :       36982 :                 }
    2776                 :             :                 else
    2777                 :             :                 {
    2778         [ +  + ]:       70782 :                         if (!spill_initialized)
    2779                 :             :                         {
    2780                 :             :                                 /*
    2781                 :             :                                  * Avoid initializing the spill until we actually need it so
    2782                 :             :                                  * that we don't assign tapes that will never be used.
    2783                 :             :                                  */
    2784                 :        2082 :                                 spill_initialized = true;
    2785                 :        4164 :                                 hashagg_spill_init(&spill, tapeset, batch->used_bits,
    2786                 :        2082 :                                                                    batch->input_card, aggstate->hashentrysize);
    2787                 :        2082 :                         }
    2788                 :             :                         /* no memory for a new group, spill */
    2789                 :       70782 :                         hashagg_spill_tuple(aggstate, &spill, spillslot, hash);
    2790                 :             : 
    2791                 :       70782 :                         aggstate->hash_pergroup[batch->setno] = NULL;
    2792                 :             :                 }
    2793                 :             : 
    2794                 :             :                 /*
    2795                 :             :                  * Reset per-input-tuple context after each tuple, but note that the
    2796                 :             :                  * hash lookups do this too
    2797                 :             :                  */
    2798                 :      107764 :                 ResetExprContext(aggstate->tmpcontext);
    2799      [ -  +  + ]:      112249 :         }
    2800                 :             : 
    2801                 :        4485 :         LogicalTapeClose(batch->input_tape);
    2802                 :             : 
    2803                 :             :         /* change back to phase 0 */
    2804                 :        4485 :         aggstate->current_phase = 0;
    2805                 :        4485 :         aggstate->phase = &aggstate->phases[aggstate->current_phase];
    2806                 :             : 
    2807         [ +  + ]:        4485 :         if (spill_initialized)
    2808                 :             :         {
    2809                 :        2082 :                 hashagg_spill_finish(aggstate, &spill, batch->setno);
    2810                 :        2082 :                 hash_agg_update_metrics(aggstate, true, spill.npartitions);
    2811                 :        2082 :         }
    2812                 :             :         else
    2813                 :        2403 :                 hash_agg_update_metrics(aggstate, true, 0);
    2814                 :             : 
    2815                 :        4485 :         aggstate->hash_spill_mode = false;
    2816                 :             : 
    2817                 :             :         /* prepare to walk the first hash table */
    2818                 :        4485 :         select_current_set(aggstate, batch->setno, true);
    2819                 :        4485 :         ResetTupleHashIterator(aggstate->perhash[batch->setno].hashtable,
    2820                 :             :                                                    &aggstate->perhash[batch->setno].hashiter);
    2821                 :             : 
    2822                 :        4485 :         pfree(batch);
    2823                 :             : 
    2824                 :        4485 :         return true;
    2825                 :        5371 : }
    2826                 :             : 
    2827                 :             : /*
    2828                 :             :  * ExecAgg for hashed case: retrieving groups from hash table
    2829                 :             :  *
    2830                 :             :  * After exhausting in-memory tuples, also try refilling the hash table using
    2831                 :             :  * previously-spilled tuples. Only returns NULL after all in-memory and
    2832                 :             :  * spilled tuples are exhausted.
    2833                 :             :  */
    2834                 :             : static TupleTableSlot *
    2835                 :       60626 : agg_retrieve_hash_table(AggState *aggstate)
    2836                 :             : {
    2837                 :       60626 :         TupleTableSlot *result = NULL;
    2838                 :             : 
    2839         [ +  + ]:      124851 :         while (result == NULL)
    2840                 :             :         {
    2841                 :       65111 :                 result = agg_retrieve_hash_table_in_memory(aggstate);
    2842         [ +  + ]:       65111 :                 if (result == NULL)
    2843                 :             :                 {
    2844         [ +  + ]:        5371 :                         if (!agg_refill_hash_table(aggstate))
    2845                 :             :                         {
    2846                 :         886 :                                 aggstate->agg_done = true;
    2847                 :         886 :                                 break;
    2848                 :             :                         }
    2849                 :        4485 :                 }
    2850                 :             :         }
    2851                 :             : 
    2852                 :      121252 :         return result;
    2853                 :       60626 : }
    2854                 :             : 
    2855                 :             : /*
    2856                 :             :  * Retrieve the groups from the in-memory hash tables without considering any
    2857                 :             :  * spilled tuples.
    2858                 :             :  */
    2859                 :             : static TupleTableSlot *
    2860                 :       65111 : agg_retrieve_hash_table_in_memory(AggState *aggstate)
    2861                 :             : {
    2862                 :       65111 :         ExprContext *econtext;
    2863                 :       65111 :         AggStatePerAgg peragg;
    2864                 :       65111 :         AggStatePerGroup pergroup;
    2865                 :       65111 :         TupleHashEntry entry;
    2866                 :       65111 :         TupleTableSlot *firstSlot;
    2867                 :       65111 :         TupleTableSlot *result;
    2868                 :       65111 :         AggStatePerHash perhash;
    2869                 :             : 
    2870                 :             :         /*
    2871                 :             :          * get state info from node.
    2872                 :             :          *
    2873                 :             :          * econtext is the per-output-tuple expression context.
    2874                 :             :          */
    2875                 :       65111 :         econtext = aggstate->ss.ps.ps_ExprContext;
    2876                 :       65111 :         peragg = aggstate->peragg;
    2877                 :       65111 :         firstSlot = aggstate->ss.ss_ScanTupleSlot;
    2878                 :             : 
    2879                 :             :         /*
    2880                 :             :          * Note that perhash (and therefore anything accessed through it) can
    2881                 :             :          * change inside the loop, as we change between grouping sets.
    2882                 :             :          */
    2883                 :       65111 :         perhash = &aggstate->perhash[aggstate->current_set];
    2884                 :             : 
    2885                 :             :         /*
    2886                 :             :          * We loop retrieving groups until we find one satisfying
    2887                 :             :          * aggstate->ss.ps.qual
    2888                 :             :          */
    2889                 :       71008 :         for (;;)
    2890                 :             :         {
    2891                 :       87723 :                 TupleTableSlot *hashslot = perhash->hashslot;
    2892                 :       87723 :                 TupleHashTable hashtable = perhash->hashtable;
    2893                 :       87723 :                 int                     i;
    2894                 :             : 
    2895         [ -  + ]:       87723 :                 CHECK_FOR_INTERRUPTS();
    2896                 :             : 
    2897                 :             :                 /*
    2898                 :             :                  * Find the next entry in the hash table
    2899                 :             :                  */
    2900                 :       87723 :                 entry = ScanTupleHashTable(hashtable, &perhash->hashiter);
    2901         [ +  + ]:       87723 :                 if (entry == NULL)
    2902                 :             :                 {
    2903                 :       22086 :                         int                     nextset = aggstate->current_set + 1;
    2904                 :             : 
    2905         [ +  + ]:       22086 :                         if (nextset < aggstate->num_hashes)
    2906                 :             :                         {
    2907                 :             :                                 /*
    2908                 :             :                                  * Switch to next grouping set, reinitialize, and restart the
    2909                 :             :                                  * loop.
    2910                 :             :                                  */
    2911                 :       16715 :                                 select_current_set(aggstate, nextset, true);
    2912                 :             : 
    2913                 :       16715 :                                 perhash = &aggstate->perhash[aggstate->current_set];
    2914                 :             : 
    2915                 :       16715 :                                 ResetTupleHashIterator(perhash->hashtable, &perhash->hashiter);
    2916                 :             : 
    2917                 :       16715 :                                 continue;
    2918                 :             :                         }
    2919                 :             :                         else
    2920                 :             :                         {
    2921                 :        5371 :                                 return NULL;
    2922                 :             :                         }
    2923                 :       22086 :                 }
    2924                 :             : 
    2925                 :             :                 /*
    2926                 :             :                  * Clear the per-output-tuple context for each group
    2927                 :             :                  *
    2928                 :             :                  * We intentionally don't use ReScanExprContext here; if any aggs have
    2929                 :             :                  * registered shutdown callbacks, they mustn't be called yet, since we
    2930                 :             :                  * might not be done with that agg.
    2931                 :             :                  */
    2932                 :       65637 :                 ResetExprContext(econtext);
    2933                 :             : 
    2934                 :             :                 /*
    2935                 :             :                  * Transform representative tuple back into one with the right
    2936                 :             :                  * columns.
    2937                 :             :                  */
    2938                 :       65637 :                 ExecStoreMinimalTuple(TupleHashEntryGetTuple(entry), hashslot, false);
    2939                 :       65637 :                 slot_getallattrs(hashslot);
    2940                 :             : 
    2941                 :       65637 :                 ExecClearTuple(firstSlot);
    2942                 :       65637 :                 memset(firstSlot->tts_isnull, true,
    2943                 :             :                            firstSlot->tts_tupleDescriptor->natts * sizeof(bool));
    2944                 :             : 
    2945         [ +  + ]:      176067 :                 for (i = 0; i < perhash->numhashGrpCols; i++)
    2946                 :             :                 {
    2947                 :      110430 :                         int                     varNumber = perhash->hashGrpColIdxInput[i] - 1;
    2948                 :             : 
    2949                 :      110430 :                         firstSlot->tts_values[varNumber] = hashslot->tts_values[i];
    2950                 :      110430 :                         firstSlot->tts_isnull[varNumber] = hashslot->tts_isnull[i];
    2951                 :      110430 :                 }
    2952                 :       65637 :                 ExecStoreVirtualTuple(firstSlot);
    2953                 :             : 
    2954                 :       65637 :                 pergroup = (AggStatePerGroup) TupleHashEntryGetAdditional(hashtable, entry);
    2955                 :             : 
    2956                 :             :                 /*
    2957                 :             :                  * Use the representative input tuple for any references to
    2958                 :             :                  * non-aggregated input columns in the qual and tlist.
    2959                 :             :                  */
    2960                 :       65637 :                 econtext->ecxt_outertuple = firstSlot;
    2961                 :             : 
    2962                 :      131274 :                 prepare_projection_slot(aggstate,
    2963                 :       65637 :                                                                 econtext->ecxt_outertuple,
    2964                 :       65637 :                                                                 aggstate->current_set);
    2965                 :             : 
    2966                 :       65637 :                 finalize_aggregates(aggstate, peragg, pergroup);
    2967                 :             : 
    2968                 :       65637 :                 result = project_aggregates(aggstate);
    2969         [ +  + ]:       65637 :                 if (result)
    2970                 :       59740 :                         return result;
    2971      [ +  +  + ]:       87723 :         }
    2972                 :             : 
    2973                 :             :         /* No more groups */
    2974                 :             :         return NULL;
    2975                 :       65111 : }
    2976                 :             : 
    2977                 :             : /*
    2978                 :             :  * hashagg_spill_init
    2979                 :             :  *
    2980                 :             :  * Called after we determined that spilling is necessary. Chooses the number
    2981                 :             :  * of partitions to create, and initializes them.
    2982                 :             :  */
    2983                 :             : static void
    2984                 :        2101 : hashagg_spill_init(HashAggSpill *spill, LogicalTapeSet *tapeset, int used_bits,
    2985                 :             :                                    double input_groups, double hashentrysize)
    2986                 :             : {
    2987                 :        2101 :         int                     npartitions;
    2988                 :        2101 :         int                     partition_bits;
    2989                 :             : 
    2990                 :        4202 :         npartitions = hash_choose_num_partitions(input_groups, hashentrysize,
    2991                 :        2101 :                                                                                          used_bits, &partition_bits);
    2992                 :             : 
    2993                 :             : #ifdef USE_INJECTION_POINTS
    2994                 :             :         if (IS_INJECTION_POINT_ATTACHED("hash-aggregate-single-partition"))
    2995                 :             :         {
    2996                 :             :                 npartitions = 1;
    2997                 :             :                 partition_bits = 0;
    2998                 :             :                 INJECTION_POINT_CACHED("hash-aggregate-single-partition", NULL);
    2999                 :             :         }
    3000                 :             : #endif
    3001                 :             : 
    3002                 :        2101 :         spill->partitions = palloc0_array(LogicalTape *, npartitions);
    3003                 :        2101 :         spill->ntuples = palloc0_array(int64, npartitions);
    3004                 :        2101 :         spill->hll_card = palloc0_array(hyperLogLogState, npartitions);
    3005                 :             : 
    3006         [ +  + ]:       10505 :         for (int i = 0; i < npartitions; i++)
    3007                 :        8404 :                 spill->partitions[i] = LogicalTapeCreate(tapeset);
    3008                 :             : 
    3009                 :        2101 :         spill->shift = 32 - used_bits - partition_bits;
    3010         [ +  - ]:        2101 :         if (spill->shift < 32)
    3011                 :        2101 :                 spill->mask = (npartitions - 1) << spill->shift;
    3012                 :             :         else
    3013                 :           0 :                 spill->mask = 0;
    3014                 :        2101 :         spill->npartitions = npartitions;
    3015                 :             : 
    3016         [ +  + ]:       10505 :         for (int i = 0; i < npartitions; i++)
    3017                 :        8404 :                 initHyperLogLog(&spill->hll_card[i], HASHAGG_HLL_BIT_WIDTH);
    3018                 :        2101 : }
    3019                 :             : 
    3020                 :             : /*
    3021                 :             :  * hashagg_spill_tuple
    3022                 :             :  *
    3023                 :             :  * No room for new groups in the hash table. Save for later in the appropriate
    3024                 :             :  * partition.
    3025                 :             :  */
    3026                 :             : static Size
    3027                 :      107764 : hashagg_spill_tuple(AggState *aggstate, HashAggSpill *spill,
    3028                 :             :                                         TupleTableSlot *inputslot, uint32 hash)
    3029                 :             : {
    3030                 :      107764 :         TupleTableSlot *spillslot;
    3031                 :      107764 :         int                     partition;
    3032                 :      107764 :         MinimalTuple tuple;
    3033                 :      107764 :         LogicalTape *tape;
    3034                 :      107764 :         int                     total_written = 0;
    3035                 :      107764 :         bool            shouldFree;
    3036                 :             : 
    3037         [ +  - ]:      107764 :         Assert(spill->partitions != NULL);
    3038                 :             : 
    3039                 :             :         /* spill only attributes that we actually need */
    3040         [ +  + ]:      107764 :         if (!aggstate->all_cols_needed)
    3041                 :             :         {
    3042                 :         646 :                 spillslot = aggstate->hash_spill_wslot;
    3043                 :         646 :                 slot_getsomeattrs(inputslot, aggstate->max_colno_needed);
    3044                 :         646 :                 ExecClearTuple(spillslot);
    3045         [ +  + ]:        1938 :                 for (int i = 0; i < spillslot->tts_tupleDescriptor->natts; i++)
    3046                 :             :                 {
    3047         [ +  + ]:        1292 :                         if (bms_is_member(i + 1, aggstate->colnos_needed))
    3048                 :             :                         {
    3049                 :         646 :                                 spillslot->tts_values[i] = inputslot->tts_values[i];
    3050                 :         646 :                                 spillslot->tts_isnull[i] = inputslot->tts_isnull[i];
    3051                 :         646 :                         }
    3052                 :             :                         else
    3053                 :         646 :                                 spillslot->tts_isnull[i] = true;
    3054                 :        1292 :                 }
    3055                 :         646 :                 ExecStoreVirtualTuple(spillslot);
    3056                 :         646 :         }
    3057                 :             :         else
    3058                 :      107118 :                 spillslot = inputslot;
    3059                 :             : 
    3060                 :      107764 :         tuple = ExecFetchSlotMinimalTuple(spillslot, &shouldFree);
    3061                 :             : 
    3062         [ +  - ]:      107764 :         if (spill->shift < 32)
    3063                 :      107764 :                 partition = (hash & spill->mask) >> spill->shift;
    3064                 :             :         else
    3065                 :           0 :                 partition = 0;
    3066                 :             : 
    3067                 :      107764 :         spill->ntuples[partition]++;
    3068                 :             : 
    3069                 :             :         /*
    3070                 :             :          * All hash values destined for a given partition have some bits in
    3071                 :             :          * common, which causes bad HLL cardinality estimates. Hash the hash to
    3072                 :             :          * get a more uniform distribution.
    3073                 :             :          */
    3074                 :      107764 :         addHyperLogLog(&spill->hll_card[partition], hash_bytes_uint32(hash));
    3075                 :             : 
    3076                 :      107764 :         tape = spill->partitions[partition];
    3077                 :             : 
    3078                 :      107764 :         LogicalTapeWrite(tape, &hash, sizeof(uint32));
    3079                 :      107764 :         total_written += sizeof(uint32);
    3080                 :             : 
    3081                 :      107764 :         LogicalTapeWrite(tape, tuple, tuple->t_len);
    3082                 :      107764 :         total_written += tuple->t_len;
    3083                 :             : 
    3084         [ +  + ]:      107764 :         if (shouldFree)
    3085                 :       36982 :                 pfree(tuple);
    3086                 :             : 
    3087                 :      215528 :         return total_written;
    3088                 :      107764 : }
    3089                 :             : 
    3090                 :             : /*
    3091                 :             :  * hashagg_batch_new
    3092                 :             :  *
    3093                 :             :  * Construct a HashAggBatch item, which represents one iteration of HashAgg to
    3094                 :             :  * be done.
    3095                 :             :  */
    3096                 :             : static HashAggBatch *
    3097                 :        4485 : hashagg_batch_new(LogicalTape *input_tape, int setno,
    3098                 :             :                                   int64 input_tuples, double input_card, int used_bits)
    3099                 :             : {
    3100                 :        4485 :         HashAggBatch *batch = palloc0_object(HashAggBatch);
    3101                 :             : 
    3102                 :        4485 :         batch->setno = setno;
    3103                 :        4485 :         batch->used_bits = used_bits;
    3104                 :        4485 :         batch->input_tape = input_tape;
    3105                 :        4485 :         batch->input_tuples = input_tuples;
    3106                 :        4485 :         batch->input_card = input_card;
    3107                 :             : 
    3108                 :        8970 :         return batch;
    3109                 :        4485 : }
    3110                 :             : 
    3111                 :             : /*
    3112                 :             :  * hashagg_batch_read
    3113                 :             :  *              read the next tuple from a batch's tape.  Return NULL if no more.
    3114                 :             :  */
    3115                 :             : static MinimalTuple
    3116                 :      112249 : hashagg_batch_read(HashAggBatch *batch, uint32 *hashp)
    3117                 :             : {
    3118                 :      112249 :         LogicalTape *tape = batch->input_tape;
    3119                 :      112249 :         MinimalTuple tuple;
    3120                 :      112249 :         uint32          t_len;
    3121                 :      112249 :         size_t          nread;
    3122                 :      112249 :         uint32          hash;
    3123                 :             : 
    3124                 :      112249 :         nread = LogicalTapeRead(tape, &hash, sizeof(uint32));
    3125         [ +  + ]:      112249 :         if (nread == 0)
    3126                 :        4485 :                 return NULL;
    3127         [ +  - ]:      107764 :         if (nread != sizeof(uint32))
    3128   [ #  #  #  # ]:           0 :                 ereport(ERROR,
    3129                 :             :                                 (errcode_for_file_access(),
    3130                 :             :                                  errmsg_internal("unexpected EOF for tape %p: requested %zu bytes, read %zu bytes",
    3131                 :             :                                                                  tape, sizeof(uint32), nread)));
    3132         [ -  + ]:      107764 :         if (hashp != NULL)
    3133                 :      107764 :                 *hashp = hash;
    3134                 :             : 
    3135                 :      107764 :         nread = LogicalTapeRead(tape, &t_len, sizeof(t_len));
    3136         [ +  - ]:      107764 :         if (nread != sizeof(uint32))
    3137   [ #  #  #  # ]:           0 :                 ereport(ERROR,
    3138                 :             :                                 (errcode_for_file_access(),
    3139                 :             :                                  errmsg_internal("unexpected EOF for tape %p: requested %zu bytes, read %zu bytes",
    3140                 :             :                                                                  tape, sizeof(uint32), nread)));
    3141                 :             : 
    3142                 :      107764 :         tuple = (MinimalTuple) palloc(t_len);
    3143                 :      107764 :         tuple->t_len = t_len;
    3144                 :             : 
    3145                 :      215528 :         nread = LogicalTapeRead(tape,
    3146                 :      107764 :                                                         (char *) tuple + sizeof(uint32),
    3147                 :      107764 :                                                         t_len - sizeof(uint32));
    3148         [ +  - ]:      107764 :         if (nread != t_len - sizeof(uint32))
    3149   [ #  #  #  # ]:           0 :                 ereport(ERROR,
    3150                 :             :                                 (errcode_for_file_access(),
    3151                 :             :                                  errmsg_internal("unexpected EOF for tape %p: requested %zu bytes, read %zu bytes",
    3152                 :             :                                                                  tape, t_len - sizeof(uint32), nread)));
    3153                 :             : 
    3154                 :      107764 :         return tuple;
    3155                 :      112249 : }
    3156                 :             : 
    3157                 :             : /*
    3158                 :             :  * hashagg_finish_initial_spills
    3159                 :             :  *
    3160                 :             :  * After a HashAggBatch has been processed, it may have spilled tuples to
    3161                 :             :  * disk. If so, turn the spilled partitions into new batches that must later
    3162                 :             :  * be executed.
    3163                 :             :  */
    3164                 :             : static void
    3165                 :         752 : hashagg_finish_initial_spills(AggState *aggstate)
    3166                 :             : {
    3167                 :         752 :         int                     setno;
    3168                 :         752 :         int                     total_npartitions = 0;
    3169                 :             : 
    3170         [ +  + ]:         752 :         if (aggstate->hash_spills != NULL)
    3171                 :             :         {
    3172         [ +  + ]:          28 :                 for (setno = 0; setno < aggstate->num_hashes; setno++)
    3173                 :             :                 {
    3174                 :          19 :                         HashAggSpill *spill = &aggstate->hash_spills[setno];
    3175                 :             : 
    3176                 :          19 :                         total_npartitions += spill->npartitions;
    3177                 :          19 :                         hashagg_spill_finish(aggstate, spill, setno);
    3178                 :          19 :                 }
    3179                 :             : 
    3180                 :             :                 /*
    3181                 :             :                  * We're not processing tuples from outer plan any more; only
    3182                 :             :                  * processing batches of spilled tuples. The initial spill structures
    3183                 :             :                  * are no longer needed.
    3184                 :             :                  */
    3185                 :           9 :                 pfree(aggstate->hash_spills);
    3186                 :           9 :                 aggstate->hash_spills = NULL;
    3187                 :           9 :         }
    3188                 :             : 
    3189                 :         752 :         hash_agg_update_metrics(aggstate, false, total_npartitions);
    3190                 :         752 :         aggstate->hash_spill_mode = false;
    3191                 :         752 : }
    3192                 :             : 
    3193                 :             : /*
    3194                 :             :  * hashagg_spill_finish
    3195                 :             :  *
    3196                 :             :  * Transform spill partitions into new batches.
    3197                 :             :  */
    3198                 :             : static void
    3199                 :        2101 : hashagg_spill_finish(AggState *aggstate, HashAggSpill *spill, int setno)
    3200                 :             : {
    3201                 :        2101 :         int                     i;
    3202                 :        2101 :         int                     used_bits = 32 - spill->shift;
    3203                 :             : 
    3204         [ +  - ]:        2101 :         if (spill->npartitions == 0)
    3205                 :           0 :                 return;                                 /* didn't spill */
    3206                 :             : 
    3207         [ +  + ]:       10505 :         for (i = 0; i < spill->npartitions; i++)
    3208                 :             :         {
    3209                 :        8404 :                 LogicalTape *tape = spill->partitions[i];
    3210                 :        8404 :                 HashAggBatch *new_batch;
    3211                 :        8404 :                 double          cardinality;
    3212                 :             : 
    3213                 :             :                 /* if the partition is empty, don't create a new batch of work */
    3214         [ +  + ]:        8404 :                 if (spill->ntuples[i] == 0)
    3215                 :        3919 :                         continue;
    3216                 :             : 
    3217                 :        4485 :                 cardinality = estimateHyperLogLog(&spill->hll_card[i]);
    3218                 :        4485 :                 freeHyperLogLog(&spill->hll_card[i]);
    3219                 :             : 
    3220                 :             :                 /* rewinding frees the buffer while not in use */
    3221                 :        4485 :                 LogicalTapeRewindForRead(tape, HASHAGG_READ_BUFFER_SIZE);
    3222                 :             : 
    3223                 :        8970 :                 new_batch = hashagg_batch_new(tape, setno,
    3224                 :        4485 :                                                                           spill->ntuples[i], cardinality,
    3225                 :        4485 :                                                                           used_bits);
    3226                 :        4485 :                 aggstate->hash_batches = lappend(aggstate->hash_batches, new_batch);
    3227                 :        4485 :                 aggstate->hash_batches_used++;
    3228         [ +  + ]:        8404 :         }
    3229                 :             : 
    3230                 :        2101 :         pfree(spill->ntuples);
    3231                 :        2101 :         pfree(spill->hll_card);
    3232                 :        2101 :         pfree(spill->partitions);
    3233                 :        2101 : }
    3234                 :             : 
    3235                 :             : /*
    3236                 :             :  * Free resources related to a spilled HashAgg.
    3237                 :             :  */
    3238                 :             : static void
    3239                 :        6123 : hashagg_reset_spill_state(AggState *aggstate)
    3240                 :             : {
    3241                 :             :         /* free spills from initial pass */
    3242         [ -  + ]:        6123 :         if (aggstate->hash_spills != NULL)
    3243                 :             :         {
    3244                 :           0 :                 int                     setno;
    3245                 :             : 
    3246         [ #  # ]:           0 :                 for (setno = 0; setno < aggstate->num_hashes; setno++)
    3247                 :             :                 {
    3248                 :           0 :                         HashAggSpill *spill = &aggstate->hash_spills[setno];
    3249                 :             : 
    3250                 :           0 :                         pfree(spill->ntuples);
    3251                 :           0 :                         pfree(spill->partitions);
    3252                 :           0 :                 }
    3253                 :           0 :                 pfree(aggstate->hash_spills);
    3254                 :           0 :                 aggstate->hash_spills = NULL;
    3255                 :           0 :         }
    3256                 :             : 
    3257                 :             :         /* free batches */
    3258                 :        6123 :         list_free_deep(aggstate->hash_batches);
    3259                 :        6123 :         aggstate->hash_batches = NIL;
    3260                 :             : 
    3261                 :             :         /* close tape set */
    3262         [ +  + ]:        6123 :         if (aggstate->hash_tapeset != NULL)
    3263                 :             :         {
    3264                 :           9 :                 LogicalTapeSetClose(aggstate->hash_tapeset);
    3265                 :           9 :                 aggstate->hash_tapeset = NULL;
    3266                 :           9 :         }
    3267                 :        6123 : }
    3268                 :             : 
    3269                 :             : 
    3270                 :             : /* -----------------
    3271                 :             :  * ExecInitAgg
    3272                 :             :  *
    3273                 :             :  *      Creates the run-time information for the agg node produced by the
    3274                 :             :  *      planner and initializes its outer subtree.
    3275                 :             :  *
    3276                 :             :  * -----------------
    3277                 :             :  */
    3278                 :             : AggState *
    3279                 :        5998 : ExecInitAgg(Agg *node, EState *estate, int eflags)
    3280                 :             : {
    3281                 :        5998 :         AggState   *aggstate;
    3282                 :        5998 :         AggStatePerAgg peraggs;
    3283                 :        5998 :         AggStatePerTrans pertransstates;
    3284                 :        5998 :         AggStatePerGroup *pergroups;
    3285                 :        5998 :         Plan       *outerPlan;
    3286                 :        5998 :         ExprContext *econtext;
    3287                 :        5998 :         TupleDesc       scanDesc;
    3288                 :        5998 :         int                     max_aggno;
    3289                 :        5998 :         int                     max_transno;
    3290                 :        5998 :         int                     numaggrefs;
    3291                 :        5998 :         int                     numaggs;
    3292                 :        5998 :         int                     numtrans;
    3293                 :        5998 :         int                     phase;
    3294                 :        5998 :         int                     phaseidx;
    3295                 :        5998 :         ListCell   *l;
    3296                 :        5998 :         Bitmapset  *all_grouped_cols = NULL;
    3297                 :        5998 :         int                     numGroupingSets = 1;
    3298                 :        5998 :         int                     numPhases;
    3299                 :        5998 :         int                     numHashes;
    3300                 :        5998 :         int                     i = 0;
    3301                 :        5998 :         int                     j = 0;
    3302         [ +  + ]:        5998 :         bool            use_hashing = (node->aggstrategy == AGG_HASHED ||
    3303                 :        5089 :                                                            node->aggstrategy == AGG_MIXED);
    3304                 :             : 
    3305                 :             :         /* check for unsupported flags */
    3306         [ +  - ]:        5998 :         Assert(!(eflags & (EXEC_FLAG_BACKWARD | EXEC_FLAG_MARK)));
    3307                 :             : 
    3308                 :             :         /*
    3309                 :             :          * create state structure
    3310                 :             :          */
    3311                 :        5998 :         aggstate = makeNode(AggState);
    3312                 :        5998 :         aggstate->ss.ps.plan = (Plan *) node;
    3313                 :        5998 :         aggstate->ss.ps.state = estate;
    3314                 :        5998 :         aggstate->ss.ps.ExecProcNode = ExecAgg;
    3315                 :             : 
    3316                 :        5998 :         aggstate->aggs = NIL;
    3317                 :        5998 :         aggstate->numaggs = 0;
    3318                 :        5998 :         aggstate->numtrans = 0;
    3319                 :        5998 :         aggstate->aggstrategy = node->aggstrategy;
    3320                 :        5998 :         aggstate->aggsplit = node->aggsplit;
    3321                 :        5998 :         aggstate->maxsets = 0;
    3322                 :        5998 :         aggstate->projected_set = -1;
    3323                 :        5998 :         aggstate->current_set = 0;
    3324                 :        5998 :         aggstate->peragg = NULL;
    3325                 :        5998 :         aggstate->pertrans = NULL;
    3326                 :        5998 :         aggstate->curperagg = NULL;
    3327                 :        5998 :         aggstate->curpertrans = NULL;
    3328                 :        5998 :         aggstate->input_done = false;
    3329                 :        5998 :         aggstate->agg_done = false;
    3330                 :        5998 :         aggstate->pergroups = NULL;
    3331                 :        5998 :         aggstate->grp_firstTuple = NULL;
    3332                 :        5998 :         aggstate->sort_in = NULL;
    3333                 :        5998 :         aggstate->sort_out = NULL;
    3334                 :             : 
    3335                 :             :         /*
    3336                 :             :          * phases[0] always exists, but is dummy in sorted/plain mode
    3337                 :             :          */
    3338                 :        5998 :         numPhases = (use_hashing ? 1 : 2);
    3339                 :        5998 :         numHashes = (use_hashing ? 1 : 0);
    3340                 :             : 
    3341                 :             :         /*
    3342                 :             :          * Calculate the maximum number of grouping sets in any phase; this
    3343                 :             :          * determines the size of some allocations.  Also calculate the number of
    3344                 :             :          * phases, since all hashed/mixed nodes contribute to only a single phase.
    3345                 :             :          */
    3346         [ +  + ]:        5998 :         if (node->groupingSets)
    3347                 :             :         {
    3348                 :         160 :                 numGroupingSets = list_length(node->groupingSets);
    3349                 :             : 
    3350   [ +  +  +  +  :         336 :                 foreach(l, node->chain)
                   +  + ]
    3351                 :             :                 {
    3352                 :         176 :                         Agg                *agg = lfirst(l);
    3353                 :             : 
    3354         [ +  + ]:         176 :                         numGroupingSets = Max(numGroupingSets,
    3355                 :             :                                                                   list_length(agg->groupingSets));
    3356                 :             : 
    3357                 :             :                         /*
    3358                 :             :                          * additional AGG_HASHED aggs become part of phase 0, but all
    3359                 :             :                          * others add an extra phase.
    3360                 :             :                          */
    3361         [ +  + ]:         176 :                         if (agg->aggstrategy != AGG_HASHED)
    3362                 :          89 :                                 ++numPhases;
    3363                 :             :                         else
    3364                 :          87 :                                 ++numHashes;
    3365                 :         176 :                 }
    3366                 :         160 :         }
    3367                 :             : 
    3368                 :        5998 :         aggstate->maxsets = numGroupingSets;
    3369                 :        5998 :         aggstate->numphases = numPhases;
    3370                 :             : 
    3371                 :        5998 :         aggstate->aggcontexts = palloc0_array(ExprContext *, numGroupingSets);
    3372                 :             : 
    3373                 :             :         /*
    3374                 :             :          * Create expression contexts.  We need three or more, one for
    3375                 :             :          * per-input-tuple processing, one for per-output-tuple processing, one
    3376                 :             :          * for all the hashtables, and one for each grouping set.  The per-tuple
    3377                 :             :          * memory context of the per-grouping-set ExprContexts (aggcontexts)
    3378                 :             :          * replaces the standalone memory context formerly used to hold transition
    3379                 :             :          * values.  We cheat a little by using ExecAssignExprContext() to build
    3380                 :             :          * all of them.
    3381                 :             :          *
    3382                 :             :          * NOTE: the details of what is stored in aggcontexts and what is stored
    3383                 :             :          * in the regular per-query memory context are driven by a simple
    3384                 :             :          * decision: we want to reset the aggcontext at group boundaries (if not
    3385                 :             :          * hashing) and in ExecReScanAgg to recover no-longer-wanted space.
    3386                 :             :          */
    3387                 :        5998 :         ExecAssignExprContext(estate, &aggstate->ss.ps);
    3388                 :        5998 :         aggstate->tmpcontext = aggstate->ss.ps.ps_ExprContext;
    3389                 :             : 
    3390         [ +  + ]:       12138 :         for (i = 0; i < numGroupingSets; ++i)
    3391                 :             :         {
    3392                 :        6140 :                 ExecAssignExprContext(estate, &aggstate->ss.ps);
    3393                 :        6140 :                 aggstate->aggcontexts[i] = aggstate->ss.ps.ps_ExprContext;
    3394                 :        6140 :         }
    3395                 :             : 
    3396         [ +  + ]:        5998 :         if (use_hashing)
    3397                 :         950 :                 hash_create_memory(aggstate);
    3398                 :             : 
    3399                 :        5998 :         ExecAssignExprContext(estate, &aggstate->ss.ps);
    3400                 :             : 
    3401                 :             :         /*
    3402                 :             :          * Initialize child nodes.
    3403                 :             :          *
    3404                 :             :          * If we are doing a hashed aggregation then the child plan does not need
    3405                 :             :          * to handle REWIND efficiently; see ExecReScanAgg.
    3406                 :             :          */
    3407         [ +  + ]:        5998 :         if (node->aggstrategy == AGG_HASHED)
    3408                 :         909 :                 eflags &= ~EXEC_FLAG_REWIND;
    3409                 :        5998 :         outerPlan = outerPlan(node);
    3410                 :        5998 :         outerPlanState(aggstate) = ExecInitNode(outerPlan, estate, eflags);
    3411                 :             : 
    3412                 :             :         /*
    3413                 :             :          * initialize source tuple type.
    3414                 :             :          */
    3415                 :        5998 :         aggstate->ss.ps.outerops =
    3416                 :       11996 :                 ExecGetResultSlotOps(outerPlanState(&aggstate->ss),
    3417                 :        5998 :                                                          &aggstate->ss.ps.outeropsfixed);
    3418                 :        5998 :         aggstate->ss.ps.outeropsset = true;
    3419                 :             : 
    3420                 :       11996 :         ExecCreateScanSlotFromOuterPlan(estate, &aggstate->ss,
    3421                 :        5998 :                                                                         aggstate->ss.ps.outerops);
    3422                 :        5998 :         scanDesc = aggstate->ss.ss_ScanTupleSlot->tts_tupleDescriptor;
    3423                 :             : 
    3424                 :             :         /*
    3425                 :             :          * If there are more than two phases (including a potential dummy phase
    3426                 :             :          * 0), input will be resorted using tuplesort. Need a slot for that.
    3427                 :             :          */
    3428         [ +  + ]:        5998 :         if (numPhases > 2)
    3429                 :             :         {
    3430                 :          41 :                 aggstate->sort_slot = ExecInitExtraTupleSlot(estate, scanDesc,
    3431                 :             :                                                                                                          &TTSOpsMinimalTuple);
    3432                 :             : 
    3433                 :             :                 /*
    3434                 :             :                  * The output of the tuplesort, and the output from the outer child
    3435                 :             :                  * might not use the same type of slot. In most cases the child will
    3436                 :             :                  * be a Sort, and thus return a TTSOpsMinimalTuple type slot - but the
    3437                 :             :                  * input can also be presorted due an index, in which case it could be
    3438                 :             :                  * a different type of slot.
    3439                 :             :                  *
    3440                 :             :                  * XXX: For efficiency it would be good to instead/additionally
    3441                 :             :                  * generate expressions with corresponding settings of outerops* for
    3442                 :             :                  * the individual phases - deforming is often a bottleneck for
    3443                 :             :                  * aggregations with lots of rows per group. If there's multiple
    3444                 :             :                  * sorts, we know that all but the first use TTSOpsMinimalTuple (via
    3445                 :             :                  * the nodeAgg.c internal tuplesort).
    3446                 :             :                  */
    3447   [ +  -  +  + ]:          41 :                 if (aggstate->ss.ps.outeropsfixed &&
    3448                 :          41 :                         aggstate->ss.ps.outerops != &TTSOpsMinimalTuple)
    3449                 :           6 :                         aggstate->ss.ps.outeropsfixed = false;
    3450                 :          41 :         }
    3451                 :             : 
    3452                 :             :         /*
    3453                 :             :          * Initialize result type, slot and projection.
    3454                 :             :          */
    3455                 :        5998 :         ExecInitResultTupleSlotTL(&aggstate->ss.ps, &TTSOpsVirtual);
    3456                 :        5998 :         ExecAssignProjectionInfo(&aggstate->ss.ps, NULL);
    3457                 :             : 
    3458                 :             :         /*
    3459                 :             :          * initialize child expressions
    3460                 :             :          *
    3461                 :             :          * We expect the parser to have checked that no aggs contain other agg
    3462                 :             :          * calls in their arguments (and just to be sure, we verify it again while
    3463                 :             :          * initializing the plan node).  This would make no sense under SQL
    3464                 :             :          * semantics, and it's forbidden by the spec.  Because it is true, we
    3465                 :             :          * don't need to worry about evaluating the aggs in any particular order.
    3466                 :             :          *
    3467                 :             :          * Note: execExpr.c finds Aggrefs for us, and adds them to aggstate->aggs.
    3468                 :             :          * Aggrefs in the qual are found here; Aggrefs in the targetlist are found
    3469                 :             :          * during ExecAssignProjectionInfo, above.
    3470                 :             :          */
    3471                 :        5998 :         aggstate->ss.ps.qual =
    3472                 :        5998 :                 ExecInitQual(node->plan.qual, (PlanState *) aggstate);
    3473                 :             : 
    3474                 :             :         /*
    3475                 :             :          * We should now have found all Aggrefs in the targetlist and quals.
    3476                 :             :          */
    3477                 :        5998 :         numaggrefs = list_length(aggstate->aggs);
    3478                 :        5998 :         max_aggno = -1;
    3479                 :        5998 :         max_transno = -1;
    3480   [ +  +  +  +  :       13060 :         foreach(l, aggstate->aggs)
                   +  + ]
    3481                 :             :         {
    3482                 :        7062 :                 Aggref     *aggref = (Aggref *) lfirst(l);
    3483                 :             : 
    3484         [ +  + ]:        7062 :                 max_aggno = Max(max_aggno, aggref->aggno);
    3485         [ +  + ]:        7062 :                 max_transno = Max(max_transno, aggref->aggtransno);
    3486                 :        7062 :         }
    3487                 :        5998 :         aggstate->numaggs = numaggs = max_aggno + 1;
    3488                 :        5998 :         aggstate->numtrans = numtrans = max_transno + 1;
    3489                 :             : 
    3490                 :             :         /*
    3491                 :             :          * For each phase, prepare grouping set data and fmgr lookup data for
    3492                 :             :          * compare functions.  Accumulate all_grouped_cols in passing.
    3493                 :             :          */
    3494                 :        5998 :         aggstate->phases = palloc0_array(AggStatePerPhaseData, numPhases);
    3495                 :             : 
    3496                 :        5998 :         aggstate->num_hashes = numHashes;
    3497         [ +  + ]:        5998 :         if (numHashes)
    3498                 :             :         {
    3499                 :         950 :                 aggstate->perhash = palloc0_array(AggStatePerHashData, numHashes);
    3500                 :         950 :                 aggstate->phases[0].numsets = 0;
    3501                 :         950 :                 aggstate->phases[0].gset_lengths = palloc_array(int, numHashes);
    3502                 :         950 :                 aggstate->phases[0].grouped_cols = palloc_array(Bitmapset *, numHashes);
    3503                 :         950 :         }
    3504                 :             : 
    3505                 :        5998 :         phase = 0;
    3506         [ +  + ]:       12172 :         for (phaseidx = 0; phaseidx <= list_length(node->chain); ++phaseidx)
    3507                 :             :         {
    3508                 :        6174 :                 Agg                *aggnode;
    3509                 :        6174 :                 Sort       *sortnode;
    3510                 :             : 
    3511         [ +  + ]:        6174 :                 if (phaseidx > 0)
    3512                 :             :                 {
    3513                 :         176 :                         aggnode = list_nth_node(Agg, node->chain, phaseidx - 1);
    3514                 :         176 :                         sortnode = castNode(Sort, outerPlan(aggnode));
    3515                 :         176 :                 }
    3516                 :             :                 else
    3517                 :             :                 {
    3518                 :        5998 :                         aggnode = node;
    3519                 :        5998 :                         sortnode = NULL;
    3520                 :             :                 }
    3521                 :             : 
    3522   [ +  +  -  + ]:        6174 :                 Assert(phase <= 1 || sortnode);
    3523                 :             : 
    3524                 :        6174 :                 if (aggnode->aggstrategy == AGG_HASHED
    3525   [ +  +  +  + ]:        6174 :                         || aggnode->aggstrategy == AGG_MIXED)
    3526                 :             :                 {
    3527                 :        1037 :                         AggStatePerPhase phasedata = &aggstate->phases[0];
    3528                 :        1037 :                         AggStatePerHash perhash;
    3529                 :        1037 :                         Bitmapset  *cols = NULL;
    3530                 :             : 
    3531         [ -  + ]:        1037 :                         Assert(phase == 0);
    3532                 :        1037 :                         i = phasedata->numsets++;
    3533                 :        1037 :                         perhash = &aggstate->perhash[i];
    3534                 :             : 
    3535                 :             :                         /* phase 0 always points to the "real" Agg in the hash case */
    3536                 :        1037 :                         phasedata->aggnode = node;
    3537                 :        1037 :                         phasedata->aggstrategy = node->aggstrategy;
    3538                 :             : 
    3539                 :             :                         /* but the actual Agg node representing this hash is saved here */
    3540                 :        1037 :                         perhash->aggnode = aggnode;
    3541                 :             : 
    3542                 :        1037 :                         phasedata->gset_lengths[i] = perhash->numCols = aggnode->numCols;
    3543                 :             : 
    3544         [ +  + ]:        2478 :                         for (j = 0; j < aggnode->numCols; ++j)
    3545                 :        1441 :                                 cols = bms_add_member(cols, aggnode->grpColIdx[j]);
    3546                 :             : 
    3547                 :        1037 :                         phasedata->grouped_cols[i] = cols;
    3548                 :             : 
    3549                 :        1037 :                         all_grouped_cols = bms_add_members(all_grouped_cols, cols);
    3550                 :             :                         continue;
    3551                 :        1037 :                 }
    3552                 :             :                 else
    3553                 :             :                 {
    3554                 :        5137 :                         AggStatePerPhase phasedata = &aggstate->phases[++phase];
    3555                 :        5137 :                         int                     num_sets;
    3556                 :             : 
    3557                 :        5137 :                         phasedata->numsets = num_sets = list_length(aggnode->groupingSets);
    3558                 :             : 
    3559         [ +  + ]:        5137 :                         if (num_sets)
    3560                 :             :                         {
    3561                 :         181 :                                 phasedata->gset_lengths = palloc(num_sets * sizeof(int));
    3562                 :         181 :                                 phasedata->grouped_cols = palloc(num_sets * sizeof(Bitmapset *));
    3563                 :             : 
    3564                 :         181 :                                 i = 0;
    3565   [ +  -  +  +  :         516 :                                 foreach(l, aggnode->groupingSets)
                   +  + ]
    3566                 :             :                                 {
    3567                 :         335 :                                         int                     current_length = list_length(lfirst(l));
    3568                 :         335 :                                         Bitmapset  *cols = NULL;
    3569                 :             : 
    3570                 :             :                                         /* planner forces this to be correct */
    3571         [ +  + ]:         655 :                                         for (j = 0; j < current_length; ++j)
    3572                 :         320 :                                                 cols = bms_add_member(cols, aggnode->grpColIdx[j]);
    3573                 :             : 
    3574                 :         335 :                                         phasedata->grouped_cols[i] = cols;
    3575                 :         335 :                                         phasedata->gset_lengths[i] = current_length;
    3576                 :             : 
    3577                 :         335 :                                         ++i;
    3578                 :         335 :                                 }
    3579                 :             : 
    3580                 :         362 :                                 all_grouped_cols = bms_add_members(all_grouped_cols,
    3581                 :         181 :                                                                                                    phasedata->grouped_cols[0]);
    3582                 :         181 :                         }
    3583                 :             :                         else
    3584                 :             :                         {
    3585         [ -  + ]:        4956 :                                 Assert(phaseidx == 0);
    3586                 :             : 
    3587                 :        4956 :                                 phasedata->gset_lengths = NULL;
    3588                 :        4956 :                                 phasedata->grouped_cols = NULL;
    3589                 :             :                         }
    3590                 :             : 
    3591                 :             :                         /*
    3592                 :             :                          * If we are grouping, precompute fmgr lookup data for inner loop.
    3593                 :             :                          */
    3594         [ +  + ]:        5137 :                         if (aggnode->aggstrategy == AGG_SORTED)
    3595                 :             :                         {
    3596                 :             :                                 /*
    3597                 :             :                                  * Build a separate function for each subset of columns that
    3598                 :             :                                  * need to be compared.
    3599                 :             :                                  */
    3600                 :         432 :                                 phasedata->eqfunctions = palloc0_array(ExprState *, aggnode->numCols);
    3601                 :             : 
    3602                 :             :                                 /* for each grouping set */
    3603         [ +  + ]:         715 :                                 for (int k = 0; k < phasedata->numsets; k++)
    3604                 :             :                                 {
    3605                 :         283 :                                         int                     length = phasedata->gset_lengths[k];
    3606                 :             : 
    3607                 :             :                                         /* nothing to do for empty grouping set */
    3608         [ +  + ]:         283 :                                         if (length == 0)
    3609                 :          56 :                                                 continue;
    3610                 :             : 
    3611                 :             :                                         /* if we already had one of this length, it'll do */
    3612         [ +  + ]:         227 :                                         if (phasedata->eqfunctions[length - 1] != NULL)
    3613                 :          22 :                                                 continue;
    3614                 :             : 
    3615                 :         205 :                                         phasedata->eqfunctions[length - 1] =
    3616                 :         410 :                                                 execTuplesMatchPrepare(scanDesc,
    3617                 :         205 :                                                                                            length,
    3618                 :         205 :                                                                                            aggnode->grpColIdx,
    3619                 :         205 :                                                                                            aggnode->grpOperators,
    3620                 :         205 :                                                                                            aggnode->grpCollations,
    3621                 :         205 :                                                                                            (PlanState *) aggstate);
    3622         [ +  + ]:         283 :                                 }
    3623                 :             : 
    3624                 :             :                                 /* and for all grouped columns, unless already computed */
    3625   [ +  +  +  + ]:         432 :                                 if (aggnode->numCols > 0 &&
    3626                 :         421 :                                         phasedata->eqfunctions[aggnode->numCols - 1] == NULL)
    3627                 :             :                                 {
    3628                 :         280 :                                         phasedata->eqfunctions[aggnode->numCols - 1] =
    3629                 :         560 :                                                 execTuplesMatchPrepare(scanDesc,
    3630                 :         280 :                                                                                            aggnode->numCols,
    3631                 :         280 :                                                                                            aggnode->grpColIdx,
    3632                 :         280 :                                                                                            aggnode->grpOperators,
    3633                 :         280 :                                                                                            aggnode->grpCollations,
    3634                 :         280 :                                                                                            (PlanState *) aggstate);
    3635                 :         280 :                                 }
    3636                 :         432 :                         }
    3637                 :             : 
    3638                 :        5137 :                         phasedata->aggnode = aggnode;
    3639                 :        5137 :                         phasedata->aggstrategy = aggnode->aggstrategy;
    3640                 :        5137 :                         phasedata->sortnode = sortnode;
    3641                 :        5137 :                 }
    3642         [ +  + ]:        6174 :         }
    3643                 :             : 
    3644                 :             :         /*
    3645                 :             :          * Convert all_grouped_cols to a descending-order list.
    3646                 :             :          */
    3647                 :        5998 :         i = -1;
    3648         [ +  + ]:        7555 :         while ((i = bms_next_member(all_grouped_cols, i)) >= 0)
    3649                 :        1557 :                 aggstate->all_grouped_cols = lcons_int(i, aggstate->all_grouped_cols);
    3650                 :             : 
    3651                 :             :         /*
    3652                 :             :          * Set up aggregate-result storage in the output expr context, and also
    3653                 :             :          * allocate my private per-agg working storage
    3654                 :             :          */
    3655                 :        5998 :         econtext = aggstate->ss.ps.ps_ExprContext;
    3656                 :        5998 :         econtext->ecxt_aggvalues = palloc0_array(Datum, numaggs);
    3657                 :        5998 :         econtext->ecxt_aggnulls = palloc0_array(bool, numaggs);
    3658                 :             : 
    3659                 :        5998 :         peraggs = palloc0_array(AggStatePerAggData, numaggs);
    3660                 :        5998 :         pertransstates = palloc0_array(AggStatePerTransData, numtrans);
    3661                 :             : 
    3662                 :        5998 :         aggstate->peragg = peraggs;
    3663                 :        5998 :         aggstate->pertrans = pertransstates;
    3664                 :             : 
    3665                 :             : 
    3666                 :        5998 :         aggstate->all_pergroups = palloc0_array(AggStatePerGroup, numGroupingSets + numHashes);
    3667                 :        5998 :         pergroups = aggstate->all_pergroups;
    3668                 :             : 
    3669         [ +  + ]:        5998 :         if (node->aggstrategy != AGG_HASHED)
    3670                 :             :         {
    3671         [ +  + ]:       10320 :                 for (i = 0; i < numGroupingSets; i++)
    3672                 :             :                 {
    3673                 :        5231 :                         pergroups[i] = palloc0_array(AggStatePerGroupData, numaggs);
    3674                 :        5231 :                 }
    3675                 :             : 
    3676                 :        5089 :                 aggstate->pergroups = pergroups;
    3677                 :        5089 :                 pergroups += numGroupingSets;
    3678                 :        5089 :         }
    3679                 :             : 
    3680                 :             :         /*
    3681                 :             :          * Hashing can only appear in the initial phase.
    3682                 :             :          */
    3683         [ +  + ]:        5998 :         if (use_hashing)
    3684                 :             :         {
    3685                 :         950 :                 Plan       *outerplan = outerPlan(node);
    3686                 :         950 :                 double          totalGroups = 0;
    3687                 :             : 
    3688                 :         950 :                 aggstate->hash_spill_rslot = ExecInitExtraTupleSlot(estate, scanDesc,
    3689                 :             :                                                                                                                         &TTSOpsMinimalTuple);
    3690                 :         950 :                 aggstate->hash_spill_wslot = ExecInitExtraTupleSlot(estate, scanDesc,
    3691                 :             :                                                                                                                         &TTSOpsVirtual);
    3692                 :             : 
    3693                 :             :                 /* this is an array of pointers, not structures */
    3694                 :         950 :                 aggstate->hash_pergroup = pergroups;
    3695                 :             : 
    3696                 :        1900 :                 aggstate->hashentrysize = hash_agg_entry_size(aggstate->numtrans,
    3697                 :         950 :                                                                                                           outerplan->plan_width,
    3698                 :         950 :                                                                                                           node->transitionSpace);
    3699                 :             : 
    3700                 :             :                 /*
    3701                 :             :                  * Consider all of the grouping sets together when setting the limits
    3702                 :             :                  * and estimating the number of partitions. This can be inaccurate
    3703                 :             :                  * when there is more than one grouping set, but should still be
    3704                 :             :                  * reasonable.
    3705                 :             :                  */
    3706         [ +  + ]:        1987 :                 for (int k = 0; k < aggstate->num_hashes; k++)
    3707                 :        1037 :                         totalGroups += aggstate->perhash[k].aggnode->numGroups;
    3708                 :             : 
    3709                 :        1900 :                 hash_agg_set_limits(aggstate->hashentrysize, totalGroups, 0,
    3710                 :         950 :                                                         &aggstate->hash_mem_limit,
    3711                 :         950 :                                                         &aggstate->hash_ngroups_limit,
    3712                 :         950 :                                                         &aggstate->hash_planned_partitions);
    3713                 :         950 :                 find_hash_columns(aggstate);
    3714                 :             : 
    3715                 :             :                 /* Skip massive memory allocation if we are just doing EXPLAIN */
    3716         [ +  + ]:         950 :                 if (!(eflags & EXEC_FLAG_EXPLAIN_ONLY))
    3717                 :         653 :                         build_hash_tables(aggstate);
    3718                 :             : 
    3719                 :         950 :                 aggstate->table_filled = false;
    3720                 :             : 
    3721                 :             :                 /* Initialize this to 1, meaning nothing spilled, yet */
    3722                 :         950 :                 aggstate->hash_batches_used = 1;
    3723                 :         950 :         }
    3724                 :             : 
    3725                 :             :         /*
    3726                 :             :          * Initialize current phase-dependent values to initial phase. The initial
    3727                 :             :          * phase is 1 (first sort pass) for all strategies that use sorting (if
    3728                 :             :          * hashing is being done too, then phase 0 is processed last); but if only
    3729                 :             :          * hashing is being done, then phase 0 is all there is.
    3730                 :             :          */
    3731         [ +  + ]:        5998 :         if (node->aggstrategy == AGG_HASHED)
    3732                 :             :         {
    3733                 :         909 :                 aggstate->current_phase = 0;
    3734                 :         909 :                 initialize_phase(aggstate, 0);
    3735                 :         909 :                 select_current_set(aggstate, 0, true);
    3736                 :         909 :         }
    3737                 :             :         else
    3738                 :             :         {
    3739                 :        5089 :                 aggstate->current_phase = 1;
    3740                 :        5089 :                 initialize_phase(aggstate, 1);
    3741                 :        5089 :                 select_current_set(aggstate, 0, false);
    3742                 :             :         }
    3743                 :             : 
    3744                 :             :         /*
    3745                 :             :          * Perform lookups of aggregate function info, and initialize the
    3746                 :             :          * unchanging fields of the per-agg and per-trans data.
    3747                 :             :          */
    3748   [ +  +  +  +  :       13059 :         foreach(l, aggstate->aggs)
                   +  + ]
    3749                 :             :         {
    3750                 :        7061 :                 Aggref     *aggref = lfirst(l);
    3751                 :        7061 :                 AggStatePerAgg peragg;
    3752                 :        7061 :                 AggStatePerTrans pertrans;
    3753                 :        7061 :                 Oid                     aggTransFnInputTypes[FUNC_MAX_ARGS];
    3754                 :        7061 :                 int                     numAggTransFnArgs;
    3755                 :        7061 :                 int                     numDirectArgs;
    3756                 :        7061 :                 HeapTuple       aggTuple;
    3757                 :        7061 :                 Form_pg_aggregate aggform;
    3758                 :        7061 :                 AclResult       aclresult;
    3759                 :        7061 :                 Oid                     finalfn_oid;
    3760                 :        7061 :                 Oid                     serialfn_oid,
    3761                 :             :                                         deserialfn_oid;
    3762                 :        7061 :                 Oid                     aggOwner;
    3763                 :        7061 :                 Expr       *finalfnexpr;
    3764                 :        7061 :                 Oid                     aggtranstype;
    3765                 :             : 
    3766                 :             :                 /* Planner should have assigned aggregate to correct level */
    3767         [ +  - ]:        7061 :                 Assert(aggref->agglevelsup == 0);
    3768                 :             :                 /* ... and the split mode should match */
    3769         [ -  + ]:        7061 :                 Assert(aggref->aggsplit == aggstate->aggsplit);
    3770                 :             : 
    3771                 :        7061 :                 peragg = &peraggs[aggref->aggno];
    3772                 :             : 
    3773                 :             :                 /* Check if we initialized the state for this aggregate already. */
    3774         [ +  + ]:        7061 :                 if (peragg->aggref != NULL)
    3775                 :          68 :                         continue;
    3776                 :             : 
    3777                 :        6993 :                 peragg->aggref = aggref;
    3778                 :        6993 :                 peragg->transno = aggref->aggtransno;
    3779                 :             : 
    3780                 :             :                 /* Fetch the pg_aggregate row */
    3781                 :        6993 :                 aggTuple = SearchSysCache1(AGGFNOID,
    3782                 :        6993 :                                                                    ObjectIdGetDatum(aggref->aggfnoid));
    3783         [ +  - ]:        6993 :                 if (!HeapTupleIsValid(aggTuple))
    3784   [ #  #  #  # ]:           0 :                         elog(ERROR, "cache lookup failed for aggregate %u",
    3785                 :             :                                  aggref->aggfnoid);
    3786                 :        6993 :                 aggform = (Form_pg_aggregate) GETSTRUCT(aggTuple);
    3787                 :             : 
    3788                 :             :                 /* Check permission to call aggregate function */
    3789                 :        6993 :                 aclresult = object_aclcheck(ProcedureRelationId, aggref->aggfnoid, GetUserId(),
    3790                 :             :                                                                         ACL_EXECUTE);
    3791         [ +  + ]:        6993 :                 if (aclresult != ACLCHECK_OK)
    3792                 :           2 :                         aclcheck_error(aclresult, OBJECT_AGGREGATE,
    3793                 :           1 :                                                    get_func_name(aggref->aggfnoid));
    3794         [ +  - ]:        6993 :                 InvokeFunctionExecuteHook(aggref->aggfnoid);
    3795                 :             : 
    3796                 :             :                 /* planner recorded transition state type in the Aggref itself */
    3797                 :        6993 :                 aggtranstype = aggref->aggtranstype;
    3798         [ -  + ]:        6993 :                 Assert(OidIsValid(aggtranstype));
    3799                 :             : 
    3800                 :             :                 /* Final function only required if we're finalizing the aggregates */
    3801         [ +  + ]:        6993 :                 if (DO_AGGSPLIT_SKIPFINAL(aggstate->aggsplit))
    3802                 :         914 :                         peragg->finalfn_oid = finalfn_oid = InvalidOid;
    3803                 :             :                 else
    3804                 :        6079 :                         peragg->finalfn_oid = finalfn_oid = aggform->aggfinalfn;
    3805                 :             : 
    3806                 :        6993 :                 serialfn_oid = InvalidOid;
    3807                 :        6993 :                 deserialfn_oid = InvalidOid;
    3808                 :             : 
    3809                 :             :                 /*
    3810                 :             :                  * Check if serialization/deserialization is required.  We only do it
    3811                 :             :                  * for aggregates that have transtype INTERNAL.
    3812                 :             :                  */
    3813         [ +  + ]:        6993 :                 if (aggtranstype == INTERNALOID)
    3814                 :             :                 {
    3815                 :             :                         /*
    3816                 :             :                          * The planner should only have generated a serialize agg node if
    3817                 :             :                          * every aggregate with an INTERNAL state has a serialization
    3818                 :             :                          * function.  Verify that.
    3819                 :             :                          */
    3820         [ +  + ]:        3038 :                         if (DO_AGGSPLIT_SERIALIZE(aggstate->aggsplit))
    3821                 :             :                         {
    3822                 :             :                                 /* serialization only valid when not running finalfn */
    3823         [ -  + ]:          56 :                                 Assert(DO_AGGSPLIT_SKIPFINAL(aggstate->aggsplit));
    3824                 :             : 
    3825         [ +  - ]:          56 :                                 if (!OidIsValid(aggform->aggserialfn))
    3826   [ #  #  #  # ]:           0 :                                         elog(ERROR, "serialfunc not provided for serialization aggregation");
    3827                 :          56 :                                 serialfn_oid = aggform->aggserialfn;
    3828                 :          56 :                         }
    3829                 :             : 
    3830                 :             :                         /* Likewise for deserialization functions */
    3831         [ +  + ]:        3038 :                         if (DO_AGGSPLIT_DESERIALIZE(aggstate->aggsplit))
    3832                 :             :                         {
    3833                 :             :                                 /* deserialization only valid when combining states */
    3834         [ -  + ]:          20 :                                 Assert(DO_AGGSPLIT_COMBINE(aggstate->aggsplit));
    3835                 :             : 
    3836         [ +  - ]:          20 :                                 if (!OidIsValid(aggform->aggdeserialfn))
    3837   [ #  #  #  # ]:           0 :                                         elog(ERROR, "deserialfunc not provided for deserialization aggregation");
    3838                 :          20 :                                 deserialfn_oid = aggform->aggdeserialfn;
    3839                 :          20 :                         }
    3840                 :        3038 :                 }
    3841                 :             : 
    3842                 :             :                 /* Check that aggregate owner has permission to call component fns */
    3843                 :             :                 {
    3844                 :        6993 :                         HeapTuple       procTuple;
    3845                 :             : 
    3846                 :        6993 :                         procTuple = SearchSysCache1(PROCOID,
    3847                 :        6993 :                                                                                 ObjectIdGetDatum(aggref->aggfnoid));
    3848         [ +  - ]:        6993 :                         if (!HeapTupleIsValid(procTuple))
    3849   [ #  #  #  # ]:           0 :                                 elog(ERROR, "cache lookup failed for function %u",
    3850                 :             :                                          aggref->aggfnoid);
    3851                 :        6993 :                         aggOwner = ((Form_pg_proc) GETSTRUCT(procTuple))->proowner;
    3852                 :        6993 :                         ReleaseSysCache(procTuple);
    3853                 :             : 
    3854         [ +  + ]:        6993 :                         if (OidIsValid(finalfn_oid))
    3855                 :             :                         {
    3856                 :        3297 :                                 aclresult = object_aclcheck(ProcedureRelationId, finalfn_oid, aggOwner,
    3857                 :             :                                                                                         ACL_EXECUTE);
    3858         [ +  - ]:        3297 :                                 if (aclresult != ACLCHECK_OK)
    3859                 :           0 :                                         aclcheck_error(aclresult, OBJECT_FUNCTION,
    3860                 :           0 :                                                                    get_func_name(finalfn_oid));
    3861         [ +  - ]:        3297 :                                 InvokeFunctionExecuteHook(finalfn_oid);
    3862                 :        3297 :                         }
    3863         [ +  + ]:        6993 :                         if (OidIsValid(serialfn_oid))
    3864                 :             :                         {
    3865                 :          56 :                                 aclresult = object_aclcheck(ProcedureRelationId, serialfn_oid, aggOwner,
    3866                 :             :                                                                                         ACL_EXECUTE);
    3867         [ +  - ]:          56 :                                 if (aclresult != ACLCHECK_OK)
    3868                 :           0 :                                         aclcheck_error(aclresult, OBJECT_FUNCTION,
    3869                 :           0 :                                                                    get_func_name(serialfn_oid));
    3870         [ +  - ]:          56 :                                 InvokeFunctionExecuteHook(serialfn_oid);
    3871                 :          56 :                         }
    3872         [ +  + ]:        6993 :                         if (OidIsValid(deserialfn_oid))
    3873                 :             :                         {
    3874                 :          20 :                                 aclresult = object_aclcheck(ProcedureRelationId, deserialfn_oid, aggOwner,
    3875                 :             :                                                                                         ACL_EXECUTE);
    3876         [ +  - ]:          20 :                                 if (aclresult != ACLCHECK_OK)
    3877                 :           0 :                                         aclcheck_error(aclresult, OBJECT_FUNCTION,
    3878                 :           0 :                                                                    get_func_name(deserialfn_oid));
    3879         [ +  - ]:          20 :                                 InvokeFunctionExecuteHook(deserialfn_oid);
    3880                 :          20 :                         }
    3881                 :        6993 :                 }
    3882                 :             : 
    3883                 :             :                 /*
    3884                 :             :                  * Get actual datatypes of the (nominal) aggregate inputs.  These
    3885                 :             :                  * could be different from the agg's declared input types, when the
    3886                 :             :                  * agg accepts ANY or a polymorphic type.
    3887                 :             :                  */
    3888                 :       13986 :                 numAggTransFnArgs = get_aggregate_argtypes(aggref,
    3889                 :        6993 :                                                                                                    aggTransFnInputTypes);
    3890                 :             : 
    3891                 :             :                 /* Count the "direct" arguments, if any */
    3892                 :        6993 :                 numDirectArgs = list_length(aggref->aggdirectargs);
    3893                 :             : 
    3894                 :             :                 /* Detect how many arguments to pass to the finalfn */
    3895         [ +  + ]:        6993 :                 if (aggform->aggfinalextra)
    3896                 :        2056 :                         peragg->numFinalArgs = numAggTransFnArgs + 1;
    3897                 :             :                 else
    3898                 :        4937 :                         peragg->numFinalArgs = numDirectArgs + 1;
    3899                 :             : 
    3900                 :             :                 /* Initialize any direct-argument expressions */
    3901                 :       13986 :                 peragg->aggdirectargs = ExecInitExprList(aggref->aggdirectargs,
    3902                 :        6993 :                                                                                                  (PlanState *) aggstate);
    3903                 :             : 
    3904                 :             :                 /*
    3905                 :             :                  * build expression trees using actual argument & result types for the
    3906                 :             :                  * finalfn, if it exists and is required.
    3907                 :             :                  */
    3908         [ +  + ]:        6993 :                 if (OidIsValid(finalfn_oid))
    3909                 :             :                 {
    3910                 :        6594 :                         build_aggregate_finalfn_expr(aggTransFnInputTypes,
    3911                 :        3297 :                                                                                  peragg->numFinalArgs,
    3912                 :        3297 :                                                                                  aggtranstype,
    3913                 :        3297 :                                                                                  aggref->aggtype,
    3914                 :        3297 :                                                                                  aggref->inputcollid,
    3915                 :        3297 :                                                                                  finalfn_oid,
    3916                 :             :                                                                                  &finalfnexpr);
    3917                 :        3297 :                         fmgr_info(finalfn_oid, &peragg->finalfn);
    3918                 :        3297 :                         fmgr_info_set_expr((Node *) finalfnexpr, &peragg->finalfn);
    3919                 :        3297 :                 }
    3920                 :             : 
    3921                 :             :                 /* get info about the output value's datatype */
    3922                 :       13986 :                 get_typlenbyval(aggref->aggtype,
    3923                 :        6993 :                                                 &peragg->resulttypeLen,
    3924                 :        6993 :                                                 &peragg->resulttypeByVal);
    3925                 :             : 
    3926                 :             :                 /*
    3927                 :             :                  * Build working state for invoking the transition function, if we
    3928                 :             :                  * haven't done it already.
    3929                 :             :                  */
    3930                 :        6993 :                 pertrans = &pertransstates[aggref->aggtransno];
    3931         [ +  + ]:        6993 :                 if (pertrans->aggref == NULL)
    3932                 :             :                 {
    3933                 :        6946 :                         Datum           textInitVal;
    3934                 :        6946 :                         Datum           initValue;
    3935                 :        6946 :                         bool            initValueIsNull;
    3936                 :        6946 :                         Oid                     transfn_oid;
    3937                 :             : 
    3938                 :             :                         /*
    3939                 :             :                          * If this aggregation is performing state combines, then instead
    3940                 :             :                          * of using the transition function, we'll use the combine
    3941                 :             :                          * function.
    3942                 :             :                          */
    3943         [ +  + ]:        6946 :                         if (DO_AGGSPLIT_COMBINE(aggstate->aggsplit))
    3944                 :             :                         {
    3945                 :         369 :                                 transfn_oid = aggform->aggcombinefn;
    3946                 :             : 
    3947                 :             :                                 /* If not set then the planner messed up */
    3948         [ +  - ]:         369 :                                 if (!OidIsValid(transfn_oid))
    3949   [ #  #  #  # ]:           0 :                                         elog(ERROR, "combinefn not set for aggregate function");
    3950                 :         369 :                         }
    3951                 :             :                         else
    3952                 :        6577 :                                 transfn_oid = aggform->aggtransfn;
    3953                 :             : 
    3954                 :        6946 :                         aclresult = object_aclcheck(ProcedureRelationId, transfn_oid, aggOwner, ACL_EXECUTE);
    3955         [ +  - ]:        6946 :                         if (aclresult != ACLCHECK_OK)
    3956                 :           0 :                                 aclcheck_error(aclresult, OBJECT_FUNCTION,
    3957                 :           0 :                                                            get_func_name(transfn_oid));
    3958         [ +  - ]:        6946 :                         InvokeFunctionExecuteHook(transfn_oid);
    3959                 :             : 
    3960                 :             :                         /*
    3961                 :             :                          * initval is potentially null, so don't try to access it as a
    3962                 :             :                          * struct field. Must do it the hard way with SysCacheGetAttr.
    3963                 :             :                          */
    3964                 :        6946 :                         textInitVal = SysCacheGetAttr(AGGFNOID, aggTuple,
    3965                 :             :                                                                                   Anum_pg_aggregate_agginitval,
    3966                 :             :                                                                                   &initValueIsNull);
    3967         [ +  + ]:        6946 :                         if (initValueIsNull)
    3968                 :        4091 :                                 initValue = (Datum) 0;
    3969                 :             :                         else
    3970                 :        2855 :                                 initValue = GetAggInitVal(textInitVal, aggtranstype);
    3971                 :             : 
    3972         [ +  + ]:        6946 :                         if (DO_AGGSPLIT_COMBINE(aggstate->aggsplit))
    3973                 :             :                         {
    3974                 :         738 :                                 Oid                     combineFnInputTypes[] = {aggtranstype,
    3975                 :         369 :                                 aggtranstype};
    3976                 :             : 
    3977                 :             :                                 /*
    3978                 :             :                                  * When combining there's only one input, the to-be-combined
    3979                 :             :                                  * transition value.  The transition value is not counted
    3980                 :             :                                  * here.
    3981                 :             :                                  */
    3982                 :         369 :                                 pertrans->numTransInputs = 1;
    3983                 :             : 
    3984                 :             :                                 /* aggcombinefn always has two arguments of aggtranstype */
    3985                 :         738 :                                 build_pertrans_for_aggref(pertrans, aggstate, estate,
    3986                 :         369 :                                                                                   aggref, transfn_oid, aggtranstype,
    3987                 :         369 :                                                                                   serialfn_oid, deserialfn_oid,
    3988                 :         369 :                                                                                   initValue, initValueIsNull,
    3989                 :         369 :                                                                                   combineFnInputTypes, 2);
    3990                 :             : 
    3991                 :             :                                 /*
    3992                 :             :                                  * Ensure that a combine function to combine INTERNAL states
    3993                 :             :                                  * is not strict. This should have been checked during CREATE
    3994                 :             :                                  * AGGREGATE, but the strict property could have been changed
    3995                 :             :                                  * since then.
    3996                 :             :                                  */
    3997   [ +  +  +  - ]:         369 :                                 if (pertrans->transfn.fn_strict && aggtranstype == INTERNALOID)
    3998   [ #  #  #  # ]:           0 :                                         ereport(ERROR,
    3999                 :             :                                                         (errcode(ERRCODE_INVALID_FUNCTION_DEFINITION),
    4000                 :             :                                                          errmsg("combine function with transition type %s must not be declared STRICT",
    4001                 :             :                                                                         format_type_be(aggtranstype))));
    4002                 :         369 :                         }
    4003                 :             :                         else
    4004                 :             :                         {
    4005                 :             :                                 /* Detect how many arguments to pass to the transfn */
    4006         [ +  + ]:        6577 :                                 if (AGGKIND_IS_ORDERED_SET(aggref->aggkind))
    4007                 :          41 :                                         pertrans->numTransInputs = list_length(aggref->args);
    4008                 :             :                                 else
    4009                 :        6536 :                                         pertrans->numTransInputs = numAggTransFnArgs;
    4010                 :             : 
    4011                 :       13154 :                                 build_pertrans_for_aggref(pertrans, aggstate, estate,
    4012                 :        6577 :                                                                                   aggref, transfn_oid, aggtranstype,
    4013                 :        6577 :                                                                                   serialfn_oid, deserialfn_oid,
    4014                 :        6577 :                                                                                   initValue, initValueIsNull,
    4015                 :        6577 :                                                                                   aggTransFnInputTypes,
    4016                 :        6577 :                                                                                   numAggTransFnArgs);
    4017                 :             : 
    4018                 :             :                                 /*
    4019                 :             :                                  * If the transfn is strict and the initval is NULL, make sure
    4020                 :             :                                  * input type and transtype are the same (or at least
    4021                 :             :                                  * binary-compatible), so that it's OK to use the first
    4022                 :             :                                  * aggregated input value as the initial transValue.  This
    4023                 :             :                                  * should have been checked at agg definition time, but we
    4024                 :             :                                  * must check again in case the transfn's strictness property
    4025                 :             :                                  * has been changed.
    4026                 :             :                                  */
    4027   [ +  +  +  + ]:        6577 :                                 if (pertrans->transfn.fn_strict && pertrans->initValueIsNull)
    4028                 :             :                                 {
    4029         [ +  - ]:         435 :                                         if (numAggTransFnArgs <= numDirectArgs ||
    4030                 :         870 :                                                 !IsBinaryCoercible(aggTransFnInputTypes[numDirectArgs],
    4031                 :         435 :                                                                                    aggtranstype))
    4032   [ #  #  #  # ]:           0 :                                                 ereport(ERROR,
    4033                 :             :                                                                 (errcode(ERRCODE_INVALID_FUNCTION_DEFINITION),
    4034                 :             :                                                                  errmsg("aggregate %u needs to have compatible input type and transition type",
    4035                 :             :                                                                                 aggref->aggfnoid)));
    4036                 :         435 :                                 }
    4037                 :             :                         }
    4038                 :        6946 :                 }
    4039                 :             :                 else
    4040                 :          47 :                         pertrans->aggshared = true;
    4041                 :        6993 :                 ReleaseSysCache(aggTuple);
    4042         [ +  + ]:        7061 :         }
    4043                 :             : 
    4044                 :             :         /*
    4045                 :             :          * Last, check whether any more aggregates got added onto the node while
    4046                 :             :          * we processed the expressions for the aggregate arguments (including not
    4047                 :             :          * only the regular arguments and FILTER expressions handled immediately
    4048                 :             :          * above, but any direct arguments we might've handled earlier).  If so,
    4049                 :             :          * we have nested aggregate functions, which is semantically nonsensical,
    4050                 :             :          * so complain.  (This should have been caught by the parser, so we don't
    4051                 :             :          * need to work hard on a helpful error message; but we defend against it
    4052                 :             :          * here anyway, just to be sure.)
    4053                 :             :          */
    4054         [ +  - ]:        5998 :         if (numaggrefs != list_length(aggstate->aggs))
    4055   [ #  #  #  # ]:           0 :                 ereport(ERROR,
    4056                 :             :                                 (errcode(ERRCODE_GROUPING_ERROR),
    4057                 :             :                                  errmsg("aggregate function calls cannot be nested")));
    4058                 :             : 
    4059                 :             :         /*
    4060                 :             :          * Build expressions doing all the transition work at once. We build a
    4061                 :             :          * different one for each phase, as the number of transition function
    4062                 :             :          * invocation can differ between phases. Note this'll work both for
    4063                 :             :          * transition and combination functions (although there'll only be one
    4064                 :             :          * phase in the latter case).
    4065                 :             :          */
    4066         [ +  + ]:       17131 :         for (phaseidx = 0; phaseidx < aggstate->numphases; phaseidx++)
    4067                 :             :         {
    4068                 :       11133 :                 AggStatePerPhase phase = &aggstate->phases[phaseidx];
    4069                 :       11133 :                 bool            dohash = false;
    4070                 :       11133 :                 bool            dosort = false;
    4071                 :             : 
    4072                 :             :                 /* phase 0 doesn't necessarily exist */
    4073         [ +  + ]:       11133 :                 if (!phase->aggnode)
    4074                 :        5047 :                         continue;
    4075                 :             : 
    4076   [ +  +  +  + ]:        6086 :                 if (aggstate->aggstrategy == AGG_MIXED && phaseidx == 1)
    4077                 :             :                 {
    4078                 :             :                         /*
    4079                 :             :                          * Phase one, and only phase one, in a mixed agg performs both
    4080                 :             :                          * sorting and aggregation.
    4081                 :             :                          */
    4082                 :          41 :                         dohash = true;
    4083                 :          41 :                         dosort = true;
    4084                 :          41 :                 }
    4085   [ +  +  +  + ]:        6045 :                 else if (aggstate->aggstrategy == AGG_MIXED && phaseidx == 0)
    4086                 :             :                 {
    4087                 :             :                         /*
    4088                 :             :                          * No need to compute a transition function for an AGG_MIXED phase
    4089                 :             :                          * 0 - the contents of the hashtables will have been computed
    4090                 :             :                          * during phase 1.
    4091                 :             :                          */
    4092                 :          41 :                         continue;
    4093                 :             :                 }
    4094   [ +  +  +  + ]:        6004 :                 else if (phase->aggstrategy == AGG_PLAIN ||
    4095                 :        1331 :                                  phase->aggstrategy == AGG_SORTED)
    4096                 :             :                 {
    4097                 :        5095 :                         dohash = false;
    4098                 :        5095 :                         dosort = true;
    4099                 :        5095 :                 }
    4100         [ +  - ]:         909 :                 else if (phase->aggstrategy == AGG_HASHED)
    4101                 :             :                 {
    4102                 :         909 :                         dohash = true;
    4103                 :         909 :                         dosort = false;
    4104                 :         909 :                 }
    4105                 :             :                 else
    4106                 :           0 :                         Assert(false);
    4107                 :             : 
    4108                 :        6045 :                 phase->evaltrans = ExecBuildAggTrans(aggstate, phase, dosort, dohash,
    4109                 :             :                                                                                          false);
    4110                 :             : 
    4111                 :             :                 /* cache compiled expression for outer slot without NULL check */
    4112                 :        6045 :                 phase->evaltrans_cache[0][0] = phase->evaltrans;
    4113         [ +  + ]:       11133 :         }
    4114                 :             : 
    4115                 :       11996 :         return aggstate;
    4116                 :        5998 : }
    4117                 :             : 
    4118                 :             : /*
    4119                 :             :  * Build the state needed to calculate a state value for an aggregate.
    4120                 :             :  *
    4121                 :             :  * This initializes all the fields in 'pertrans'. 'aggref' is the aggregate
    4122                 :             :  * to initialize the state for. 'transfn_oid', 'aggtranstype', and the rest
    4123                 :             :  * of the arguments could be calculated from 'aggref', but the caller has
    4124                 :             :  * calculated them already, so might as well pass them.
    4125                 :             :  *
    4126                 :             :  * 'transfn_oid' may be either the Oid of the aggtransfn or the aggcombinefn.
    4127                 :             :  */
    4128                 :             : static void
    4129                 :        6946 : build_pertrans_for_aggref(AggStatePerTrans pertrans,
    4130                 :             :                                                   AggState *aggstate, EState *estate,
    4131                 :             :                                                   Aggref *aggref,
    4132                 :             :                                                   Oid transfn_oid, Oid aggtranstype,
    4133                 :             :                                                   Oid aggserialfn, Oid aggdeserialfn,
    4134                 :             :                                                   Datum initValue, bool initValueIsNull,
    4135                 :             :                                                   Oid *inputTypes, int numArguments)
    4136                 :             : {
    4137         [ +  + ]:        6946 :         int                     numGroupingSets = Max(aggstate->maxsets, 1);
    4138                 :        6946 :         Expr       *transfnexpr;
    4139                 :        6946 :         int                     numTransArgs;
    4140                 :        6946 :         Expr       *serialfnexpr = NULL;
    4141                 :        6946 :         Expr       *deserialfnexpr = NULL;
    4142                 :        6946 :         ListCell   *lc;
    4143                 :        6946 :         int                     numInputs;
    4144                 :        6946 :         int                     numDirectArgs;
    4145                 :        6946 :         List       *sortlist;
    4146                 :        6946 :         int                     numSortCols;
    4147                 :        6946 :         int                     numDistinctCols;
    4148                 :        6946 :         int                     i;
    4149                 :             : 
    4150                 :             :         /* Begin filling in the pertrans data */
    4151                 :        6946 :         pertrans->aggref = aggref;
    4152                 :        6946 :         pertrans->aggshared = false;
    4153                 :        6946 :         pertrans->aggCollation = aggref->inputcollid;
    4154                 :        6946 :         pertrans->transfn_oid = transfn_oid;
    4155                 :        6946 :         pertrans->serialfn_oid = aggserialfn;
    4156                 :        6946 :         pertrans->deserialfn_oid = aggdeserialfn;
    4157                 :        6946 :         pertrans->initValue = initValue;
    4158                 :        6946 :         pertrans->initValueIsNull = initValueIsNull;
    4159                 :             : 
    4160                 :             :         /* Count the "direct" arguments, if any */
    4161                 :        6946 :         numDirectArgs = list_length(aggref->aggdirectargs);
    4162                 :             : 
    4163                 :             :         /* Count the number of aggregated input columns */
    4164                 :        6946 :         pertrans->numInputs = numInputs = list_length(aggref->args);
    4165                 :             : 
    4166                 :        6946 :         pertrans->aggtranstype = aggtranstype;
    4167                 :             : 
    4168                 :             :         /* account for the current transition state */
    4169                 :        6946 :         numTransArgs = pertrans->numTransInputs + 1;
    4170                 :             : 
    4171                 :             :         /*
    4172                 :             :          * Set up infrastructure for calling the transfn.  Note that invtransfn is
    4173                 :             :          * not needed here.
    4174                 :             :          */
    4175                 :       13892 :         build_aggregate_transfn_expr(inputTypes,
    4176                 :        6946 :                                                                  numArguments,
    4177                 :        6946 :                                                                  numDirectArgs,
    4178                 :        6946 :                                                                  aggref->aggvariadic,
    4179                 :        6946 :                                                                  aggtranstype,
    4180                 :        6946 :                                                                  aggref->inputcollid,
    4181                 :        6946 :                                                                  transfn_oid,
    4182                 :             :                                                                  InvalidOid,
    4183                 :             :                                                                  &transfnexpr,
    4184                 :             :                                                                  NULL);
    4185                 :             : 
    4186                 :        6946 :         fmgr_info(transfn_oid, &pertrans->transfn);
    4187                 :        6946 :         fmgr_info_set_expr((Node *) transfnexpr, &pertrans->transfn);
    4188                 :             : 
    4189                 :        6946 :         pertrans->transfn_fcinfo =
    4190                 :        6946 :                 (FunctionCallInfo) palloc(SizeForFunctionCallInfo(numTransArgs));
    4191                 :        6946 :         InitFunctionCallInfoData(*pertrans->transfn_fcinfo,
    4192                 :             :                                                          &pertrans->transfn,
    4193                 :             :                                                          numTransArgs,
    4194                 :             :                                                          pertrans->aggCollation,
    4195                 :             :                                                          (Node *) aggstate, NULL);
    4196                 :             : 
    4197                 :             :         /* get info about the state value's datatype */
    4198                 :       13892 :         get_typlenbyval(aggtranstype,
    4199                 :        6946 :                                         &pertrans->transtypeLen,
    4200                 :        6946 :                                         &pertrans->transtypeByVal);
    4201                 :             : 
    4202         [ +  + ]:        6946 :         if (OidIsValid(aggserialfn))
    4203                 :             :         {
    4204                 :          56 :                 build_aggregate_serialfn_expr(aggserialfn,
    4205                 :             :                                                                           &serialfnexpr);
    4206                 :          56 :                 fmgr_info(aggserialfn, &pertrans->serialfn);
    4207                 :          56 :                 fmgr_info_set_expr((Node *) serialfnexpr, &pertrans->serialfn);
    4208                 :             : 
    4209                 :          56 :                 pertrans->serialfn_fcinfo =
    4210                 :          56 :                         (FunctionCallInfo) palloc(SizeForFunctionCallInfo(1));
    4211                 :          56 :                 InitFunctionCallInfoData(*pertrans->serialfn_fcinfo,
    4212                 :             :                                                                  &pertrans->serialfn,
    4213                 :             :                                                                  1,
    4214                 :             :                                                                  InvalidOid,
    4215                 :             :                                                                  (Node *) aggstate, NULL);
    4216                 :          56 :         }
    4217                 :             : 
    4218         [ +  + ]:        6946 :         if (OidIsValid(aggdeserialfn))
    4219                 :             :         {
    4220                 :          20 :                 build_aggregate_deserialfn_expr(aggdeserialfn,
    4221                 :             :                                                                                 &deserialfnexpr);
    4222                 :          20 :                 fmgr_info(aggdeserialfn, &pertrans->deserialfn);
    4223                 :          20 :                 fmgr_info_set_expr((Node *) deserialfnexpr, &pertrans->deserialfn);
    4224                 :             : 
    4225                 :          20 :                 pertrans->deserialfn_fcinfo =
    4226                 :          20 :                         (FunctionCallInfo) palloc(SizeForFunctionCallInfo(2));
    4227                 :          20 :                 InitFunctionCallInfoData(*pertrans->deserialfn_fcinfo,
    4228                 :             :                                                                  &pertrans->deserialfn,
    4229                 :             :                                                                  2,
    4230                 :             :                                                                  InvalidOid,
    4231                 :             :                                                                  (Node *) aggstate, NULL);
    4232                 :          20 :         }
    4233                 :             : 
    4234                 :             :         /*
    4235                 :             :          * If we're doing either DISTINCT or ORDER BY for a plain agg, then we
    4236                 :             :          * have a list of SortGroupClause nodes; fish out the data in them and
    4237                 :             :          * stick them into arrays.  We ignore ORDER BY for an ordered-set agg,
    4238                 :             :          * however; the agg's transfn and finalfn are responsible for that.
    4239                 :             :          *
    4240                 :             :          * When the planner has set the aggpresorted flag, the input to the
    4241                 :             :          * aggregate is already correctly sorted.  For ORDER BY aggregates we can
    4242                 :             :          * simply treat these as normal aggregates.  For presorted DISTINCT
    4243                 :             :          * aggregates an extra step must be added to remove duplicate consecutive
    4244                 :             :          * inputs.
    4245                 :             :          *
    4246                 :             :          * Note that by construction, if there is a DISTINCT clause then the ORDER
    4247                 :             :          * BY clause is a prefix of it (see transformDistinctClause).
    4248                 :             :          */
    4249         [ +  + ]:        6946 :         if (AGGKIND_IS_ORDERED_SET(aggref->aggkind))
    4250                 :             :         {
    4251                 :          41 :                 sortlist = NIL;
    4252                 :          41 :                 numSortCols = numDistinctCols = 0;
    4253                 :          41 :                 pertrans->aggsortrequired = false;
    4254                 :          41 :         }
    4255   [ +  +  +  + ]:        6905 :         else if (aggref->aggpresorted && aggref->aggdistinct == NIL)
    4256                 :             :         {
    4257                 :         162 :                 sortlist = NIL;
    4258                 :         162 :                 numSortCols = numDistinctCols = 0;
    4259                 :         162 :                 pertrans->aggsortrequired = false;
    4260                 :         162 :         }
    4261         [ +  + ]:        6743 :         else if (aggref->aggdistinct)
    4262                 :             :         {
    4263                 :          95 :                 sortlist = aggref->aggdistinct;
    4264                 :          95 :                 numSortCols = numDistinctCols = list_length(sortlist);
    4265         [ +  - ]:          95 :                 Assert(numSortCols >= list_length(aggref->aggorder));
    4266                 :          95 :                 pertrans->aggsortrequired = !aggref->aggpresorted;
    4267                 :          95 :         }
    4268                 :             :         else
    4269                 :             :         {
    4270                 :        6648 :                 sortlist = aggref->aggorder;
    4271                 :        6648 :                 numSortCols = list_length(sortlist);
    4272                 :        6648 :                 numDistinctCols = 0;
    4273                 :        6648 :                 pertrans->aggsortrequired = (numSortCols > 0);
    4274                 :             :         }
    4275                 :             : 
    4276                 :        6946 :         pertrans->numSortCols = numSortCols;
    4277                 :        6946 :         pertrans->numDistinctCols = numDistinctCols;
    4278                 :             : 
    4279                 :             :         /*
    4280                 :             :          * If we have either sorting or filtering to do, create a tupledesc and
    4281                 :             :          * slot corresponding to the aggregated inputs (including sort
    4282                 :             :          * expressions) of the agg.
    4283                 :             :          */
    4284   [ +  +  +  + ]:        6946 :         if (numSortCols > 0 || aggref->aggfilter)
    4285                 :             :         {
    4286                 :         154 :                 pertrans->sortdesc = ExecTypeFromTL(aggref->args);
    4287                 :         154 :                 pertrans->sortslot =
    4288                 :         154 :                         ExecInitExtraTupleSlot(estate, pertrans->sortdesc,
    4289                 :             :                                                                    &TTSOpsMinimalTuple);
    4290                 :         154 :         }
    4291                 :             : 
    4292         [ +  + ]:        6946 :         if (numSortCols > 0)
    4293                 :             :         {
    4294                 :             :                 /*
    4295                 :             :                  * We don't implement DISTINCT or ORDER BY aggs in the HASHED case
    4296                 :             :                  * (yet)
    4297                 :             :                  */
    4298         [ +  - ]:         118 :                 Assert(aggstate->aggstrategy != AGG_HASHED && aggstate->aggstrategy != AGG_MIXED);
    4299                 :             : 
    4300                 :             :                 /* ORDER BY aggregates are not supported with partial aggregation */
    4301         [ +  - ]:         118 :                 Assert(!DO_AGGSPLIT_COMBINE(aggstate->aggsplit));
    4302                 :             : 
    4303                 :             :                 /* If we have only one input, we need its len/byval info. */
    4304         [ +  + ]:         118 :                 if (numInputs == 1)
    4305                 :             :                 {
    4306                 :         186 :                         get_typlenbyval(inputTypes[numDirectArgs],
    4307                 :          93 :                                                         &pertrans->inputtypeLen,
    4308                 :          93 :                                                         &pertrans->inputtypeByVal);
    4309                 :          93 :                 }
    4310         [ +  + ]:          25 :                 else if (numDistinctCols > 0)
    4311                 :             :                 {
    4312                 :             :                         /* we will need an extra slot to store prior values */
    4313                 :          18 :                         pertrans->uniqslot =
    4314                 :          18 :                                 ExecInitExtraTupleSlot(estate, pertrans->sortdesc,
    4315                 :             :                                                                            &TTSOpsMinimalTuple);
    4316                 :          18 :                 }
    4317                 :             : 
    4318                 :             :                 /* Extract the sort information for use later */
    4319                 :         118 :                 pertrans->sortColIdx =
    4320                 :         118 :                         (AttrNumber *) palloc(numSortCols * sizeof(AttrNumber));
    4321                 :         118 :                 pertrans->sortOperators =
    4322                 :         118 :                         (Oid *) palloc(numSortCols * sizeof(Oid));
    4323                 :         118 :                 pertrans->sortCollations =
    4324                 :         118 :                         (Oid *) palloc(numSortCols * sizeof(Oid));
    4325                 :         118 :                 pertrans->sortNullsFirst =
    4326                 :         118 :                         (bool *) palloc(numSortCols * sizeof(bool));
    4327                 :             : 
    4328                 :         118 :                 i = 0;
    4329   [ +  -  +  +  :         269 :                 foreach(lc, sortlist)
                   +  + ]
    4330                 :             :                 {
    4331                 :         151 :                         SortGroupClause *sortcl = (SortGroupClause *) lfirst(lc);
    4332                 :         151 :                         TargetEntry *tle = get_sortgroupclause_tle(sortcl, aggref->args);
    4333                 :             : 
    4334                 :             :                         /* the parser should have made sure of this */
    4335         [ +  - ]:         151 :                         Assert(OidIsValid(sortcl->sortop));
    4336                 :             : 
    4337                 :         151 :                         pertrans->sortColIdx[i] = tle->resno;
    4338                 :         151 :                         pertrans->sortOperators[i] = sortcl->sortop;
    4339                 :         151 :                         pertrans->sortCollations[i] = exprCollation((Node *) tle->expr);
    4340                 :         151 :                         pertrans->sortNullsFirst[i] = sortcl->nulls_first;
    4341                 :         151 :                         i++;
    4342                 :         151 :                 }
    4343         [ +  - ]:         118 :                 Assert(i == numSortCols);
    4344                 :         118 :         }
    4345                 :             : 
    4346         [ +  + ]:        6946 :         if (aggref->aggdistinct)
    4347                 :             :         {
    4348                 :          95 :                 Oid                *ops;
    4349                 :             : 
    4350         [ +  - ]:          95 :                 Assert(numArguments > 0);
    4351         [ +  - ]:          95 :                 Assert(list_length(aggref->aggdistinct) == numDistinctCols);
    4352                 :             : 
    4353                 :          95 :                 ops = palloc(numDistinctCols * sizeof(Oid));
    4354                 :             : 
    4355                 :          95 :                 i = 0;
    4356   [ +  -  +  +  :         220 :                 foreach(lc, aggref->aggdistinct)
                   +  + ]
    4357                 :         125 :                         ops[i++] = ((SortGroupClause *) lfirst(lc))->eqop;
    4358                 :             : 
    4359                 :             :                 /* lookup / build the necessary comparators */
    4360         [ +  + ]:          95 :                 if (numDistinctCols == 1)
    4361                 :          77 :                         fmgr_info(get_opcode(ops[0]), &pertrans->equalfnOne);
    4362                 :             :                 else
    4363                 :          18 :                         pertrans->equalfnMulti =
    4364                 :          36 :                                 execTuplesMatchPrepare(pertrans->sortdesc,
    4365                 :          18 :                                                                            numDistinctCols,
    4366                 :          18 :                                                                            pertrans->sortColIdx,
    4367                 :          18 :                                                                            ops,
    4368                 :          18 :                                                                            pertrans->sortCollations,
    4369                 :          18 :                                                                            &aggstate->ss.ps);
    4370                 :          95 :                 pfree(ops);
    4371                 :          95 :         }
    4372                 :             : 
    4373                 :        6946 :         pertrans->sortstates = palloc0_array(Tuplesortstate *, numGroupingSets);
    4374                 :        6946 : }
    4375                 :             : 
    4376                 :             : 
    4377                 :             : static Datum
    4378                 :        2855 : GetAggInitVal(Datum textInitVal, Oid transtype)
    4379                 :             : {
    4380                 :        2855 :         Oid                     typinput,
    4381                 :             :                                 typioparam;
    4382                 :        2855 :         char       *strInitVal;
    4383                 :        2855 :         Datum           initVal;
    4384                 :             : 
    4385                 :        2855 :         getTypeInputInfo(transtype, &typinput, &typioparam);
    4386                 :        2855 :         strInitVal = TextDatumGetCString(textInitVal);
    4387                 :        5710 :         initVal = OidInputFunctionCall(typinput, strInitVal,
    4388                 :        2855 :                                                                    typioparam, -1);
    4389                 :        2855 :         pfree(strInitVal);
    4390                 :        5710 :         return initVal;
    4391                 :        2855 : }
    4392                 :             : 
    4393                 :             : void
    4394                 :        5978 : ExecEndAgg(AggState *node)
    4395                 :             : {
    4396                 :        5978 :         PlanState  *outerPlan;
    4397                 :        5978 :         int                     transno;
    4398         [ +  + ]:        5978 :         int                     numGroupingSets = Max(node->maxsets, 1);
    4399                 :        5978 :         int                     setno;
    4400                 :             : 
    4401                 :             :         /*
    4402                 :             :          * When ending a parallel worker, copy the statistics gathered by the
    4403                 :             :          * worker back into shared memory so that it can be picked up by the main
    4404                 :             :          * process to report in EXPLAIN ANALYZE.
    4405                 :             :          */
    4406   [ +  +  +  + ]:        5978 :         if (node->shared_info && IsParallelWorker())
    4407                 :             :         {
    4408                 :          28 :                 AggregateInstrumentation *si;
    4409                 :             : 
    4410         [ +  - ]:          28 :                 Assert(ParallelWorkerNumber <= node->shared_info->num_workers);
    4411                 :          28 :                 si = &node->shared_info->sinstrument[ParallelWorkerNumber];
    4412                 :          28 :                 si->hash_batches_used = node->hash_batches_used;
    4413                 :          28 :                 si->hash_disk_used = node->hash_disk_used;
    4414                 :          28 :                 si->hash_mem_peak = node->hash_mem_peak;
    4415                 :          28 :         }
    4416                 :             : 
    4417                 :             :         /* Make sure we have closed any open tuplesorts */
    4418                 :             : 
    4419         [ +  + ]:        5978 :         if (node->sort_in)
    4420                 :          30 :                 tuplesort_end(node->sort_in);
    4421         [ +  + ]:        5978 :         if (node->sort_out)
    4422                 :          11 :                 tuplesort_end(node->sort_out);
    4423                 :             : 
    4424                 :        5978 :         hashagg_reset_spill_state(node);
    4425                 :             : 
    4426                 :             :         /* Release hash tables too */
    4427         [ +  + ]:        5978 :         if (node->hash_metacxt != NULL)
    4428                 :             :         {
    4429                 :         949 :                 MemoryContextDelete(node->hash_metacxt);
    4430                 :         949 :                 node->hash_metacxt = NULL;
    4431                 :         949 :         }
    4432         [ +  + ]:        5978 :         if (node->hash_tuplescxt != NULL)
    4433                 :             :         {
    4434                 :         949 :                 MemoryContextDelete(node->hash_tuplescxt);
    4435                 :         949 :                 node->hash_tuplescxt = NULL;
    4436                 :         949 :         }
    4437                 :             : 
    4438         [ +  + ]:       12905 :         for (transno = 0; transno < node->numtrans; transno++)
    4439                 :             :         {
    4440                 :        6927 :                 AggStatePerTrans pertrans = &node->pertrans[transno];
    4441                 :             : 
    4442         [ +  + ]:       14027 :                 for (setno = 0; setno < numGroupingSets; setno++)
    4443                 :             :                 {
    4444         [ +  - ]:        7100 :                         if (pertrans->sortstates[setno])
    4445                 :           0 :                                 tuplesort_end(pertrans->sortstates[setno]);
    4446                 :        7100 :                 }
    4447                 :        6927 :         }
    4448                 :             : 
    4449                 :             :         /* And ensure any agg shutdown callbacks have been called */
    4450         [ +  + ]:       12098 :         for (setno = 0; setno < numGroupingSets; setno++)
    4451                 :        6120 :                 ReScanExprContext(node->aggcontexts[setno]);
    4452         [ +  + ]:        5978 :         if (node->hashcontext)
    4453                 :         949 :                 ReScanExprContext(node->hashcontext);
    4454                 :             : 
    4455                 :        5978 :         outerPlan = outerPlanState(node);
    4456                 :        5978 :         ExecEndNode(outerPlan);
    4457                 :        5978 : }
    4458                 :             : 
    4459                 :             : void
    4460                 :        1088 : ExecReScanAgg(AggState *node)
    4461                 :             : {
    4462                 :        1088 :         ExprContext *econtext = node->ss.ps.ps_ExprContext;
    4463                 :        1088 :         PlanState  *outerPlan = outerPlanState(node);
    4464                 :        1088 :         Agg                *aggnode = (Agg *) node->ss.ps.plan;
    4465                 :        1088 :         int                     transno;
    4466         [ +  + ]:        1088 :         int                     numGroupingSets = Max(node->maxsets, 1);
    4467                 :        1088 :         int                     setno;
    4468                 :             : 
    4469                 :        1088 :         node->agg_done = false;
    4470                 :             : 
    4471         [ +  + ]:        1088 :         if (node->aggstrategy == AGG_HASHED)
    4472                 :             :         {
    4473                 :             :                 /*
    4474                 :             :                  * In the hashed case, if we haven't yet built the hash table then we
    4475                 :             :                  * can just return; nothing done yet, so nothing to undo. If subnode's
    4476                 :             :                  * chgParam is not NULL then it will be re-scanned by ExecProcNode,
    4477                 :             :                  * else no reason to re-scan it at all.
    4478                 :             :                  */
    4479         [ +  + ]:         293 :                 if (!node->table_filled)
    4480                 :           8 :                         return;
    4481                 :             : 
    4482                 :             :                 /*
    4483                 :             :                  * If we do have the hash table, and it never spilled, and the subplan
    4484                 :             :                  * does not have any parameter changes, and none of our own parameter
    4485                 :             :                  * changes affect input expressions of the aggregated functions, then
    4486                 :             :                  * we can just rescan the existing hash table; no need to build it
    4487                 :             :                  * again.
    4488                 :             :                  */
    4489   [ +  +  +  -  :         285 :                 if (outerPlan->chgParam == NULL && !node->hash_ever_spilled &&
                   +  + ]
    4490                 :         149 :                         !bms_overlap(node->ss.ps.chgParam, aggnode->aggParams))
    4491                 :             :                 {
    4492                 :         145 :                         ResetTupleHashIterator(node->perhash[0].hashtable,
    4493                 :             :                                                                    &node->perhash[0].hashiter);
    4494                 :         145 :                         select_current_set(node, 0, true);
    4495                 :         145 :                         return;
    4496                 :             :                 }
    4497                 :         140 :         }
    4498                 :             : 
    4499                 :             :         /* Make sure we have closed any open tuplesorts */
    4500         [ +  + ]:        1750 :         for (transno = 0; transno < node->numtrans; transno++)
    4501                 :             :         {
    4502         [ +  + ]:        1636 :                 for (setno = 0; setno < numGroupingSets; setno++)
    4503                 :             :                 {
    4504                 :         821 :                         AggStatePerTrans pertrans = &node->pertrans[transno];
    4505                 :             : 
    4506         [ +  - ]:         821 :                         if (pertrans->sortstates[setno])
    4507                 :             :                         {
    4508                 :           0 :                                 tuplesort_end(pertrans->sortstates[setno]);
    4509                 :           0 :                                 pertrans->sortstates[setno] = NULL;
    4510                 :           0 :                         }
    4511                 :         821 :                 }
    4512                 :         815 :         }
    4513                 :             : 
    4514                 :             :         /*
    4515                 :             :          * We don't need to ReScanExprContext the output tuple context here;
    4516                 :             :          * ExecReScan already did it. But we do need to reset our per-grouping-set
    4517                 :             :          * contexts, which may have transvalues stored in them. (We use rescan
    4518                 :             :          * rather than just reset because transfns may have registered callbacks
    4519                 :             :          * that need to be run now.) For the AGG_HASHED case, see below.
    4520                 :             :          */
    4521                 :             : 
    4522         [ +  + ]:        1876 :         for (setno = 0; setno < numGroupingSets; setno++)
    4523                 :             :         {
    4524                 :         941 :                 ReScanExprContext(node->aggcontexts[setno]);
    4525                 :         941 :         }
    4526                 :             : 
    4527                 :             :         /* Release first tuple of group, if we have made a copy */
    4528         [ +  - ]:         935 :         if (node->grp_firstTuple != NULL)
    4529                 :             :         {
    4530                 :           0 :                 heap_freetuple(node->grp_firstTuple);
    4531                 :           0 :                 node->grp_firstTuple = NULL;
    4532                 :           0 :         }
    4533                 :         935 :         ExecClearTuple(node->ss.ss_ScanTupleSlot);
    4534                 :             : 
    4535                 :             :         /* Forget current agg values */
    4536   [ +  -  +  -  :        1750 :         MemSet(econtext->ecxt_aggvalues, 0, sizeof(Datum) * node->numaggs);
          +  -  -  +  +  
                      + ]
    4537   [ +  -  +  +  :         935 :         MemSet(econtext->ecxt_aggnulls, 0, sizeof(bool) * node->numaggs);
          +  -  -  +  -  
                      + ]
    4538                 :             : 
    4539                 :             :         /*
    4540                 :             :          * With AGG_HASHED/MIXED, the hash table is allocated in a sub-context of
    4541                 :             :          * the hashcontext. This used to be an issue, but now, resetting a context
    4542                 :             :          * automatically deletes sub-contexts too.
    4543                 :             :          */
    4544   [ +  +  +  + ]:         935 :         if (node->aggstrategy == AGG_HASHED || node->aggstrategy == AGG_MIXED)
    4545                 :             :         {
    4546                 :         145 :                 hashagg_reset_spill_state(node);
    4547                 :             : 
    4548                 :         145 :                 node->hash_ever_spilled = false;
    4549                 :         145 :                 node->hash_spill_mode = false;
    4550                 :         145 :                 node->hash_ngroups_current = 0;
    4551                 :             : 
    4552                 :         145 :                 ReScanExprContext(node->hashcontext);
    4553                 :             :                 /* Rebuild empty hash table(s) */
    4554                 :         145 :                 build_hash_tables(node);
    4555                 :         145 :                 node->table_filled = false;
    4556                 :             :                 /* iterator will be reset when the table is filled */
    4557                 :             : 
    4558                 :         145 :                 hashagg_recompile_expressions(node, false, false);
    4559                 :         145 :         }
    4560                 :             : 
    4561         [ +  + ]:         935 :         if (node->aggstrategy != AGG_HASHED)
    4562                 :             :         {
    4563                 :             :                 /*
    4564                 :             :                  * Reset the per-group state (in particular, mark transvalues null)
    4565                 :             :                  */
    4566         [ +  + ]:        1596 :                 for (setno = 0; setno < numGroupingSets; setno++)
    4567                 :             :                 {
    4568   [ +  -  +  -  :        2427 :                         MemSet(node->pergroups[setno], 0,
          +  -  -  +  +  
                      + ]
    4569                 :             :                                    sizeof(AggStatePerGroupData) * node->numaggs);
    4570                 :         801 :                 }
    4571                 :             : 
    4572                 :             :                 /* reset to phase 1 */
    4573                 :         795 :                 initialize_phase(node, 1);
    4574                 :             : 
    4575                 :         795 :                 node->input_done = false;
    4576                 :         795 :                 node->projected_set = -1;
    4577                 :         795 :         }
    4578                 :             : 
    4579         [ +  + ]:         935 :         if (outerPlan->chgParam == NULL)
    4580                 :          31 :                 ExecReScan(outerPlan);
    4581         [ -  + ]:        1088 : }
    4582                 :             : 
    4583                 :             : 
    4584                 :             : /***********************************************************************
    4585                 :             :  * API exposed to aggregate functions
    4586                 :             :  ***********************************************************************/
    4587                 :             : 
    4588                 :             : 
    4589                 :             : /*
    4590                 :             :  * AggCheckCallContext - test if a SQL function is being called as an aggregate
    4591                 :             :  *
    4592                 :             :  * The transition and/or final functions of an aggregate may want to verify
    4593                 :             :  * that they are being called as aggregates, rather than as plain SQL
    4594                 :             :  * functions.  They should use this function to do so.  The return value
    4595                 :             :  * is nonzero if being called as an aggregate, or zero if not.  (Specific
    4596                 :             :  * nonzero values are AGG_CONTEXT_AGGREGATE or AGG_CONTEXT_WINDOW, but more
    4597                 :             :  * values could conceivably appear in future.)
    4598                 :             :  *
    4599                 :             :  * If aggcontext isn't NULL, the function also stores at *aggcontext the
    4600                 :             :  * identity of the memory context that aggregate transition values are being
    4601                 :             :  * stored in.  Note that the same aggregate call site (flinfo) may be called
    4602                 :             :  * interleaved on different transition values in different contexts, so it's
    4603                 :             :  * not kosher to cache aggcontext under fn_extra.  It is, however, kosher to
    4604                 :             :  * cache it in the transvalue itself (for internal-type transvalues).
    4605                 :             :  */
    4606                 :             : int
    4607                 :      702415 : AggCheckCallContext(FunctionCallInfo fcinfo, MemoryContext *aggcontext)
    4608                 :             : {
    4609   [ +  +  +  + ]:      702415 :         if (fcinfo->context && IsA(fcinfo->context, AggState))
    4610                 :             :         {
    4611         [ +  + ]:      700497 :                 if (aggcontext)
    4612                 :             :                 {
    4613                 :      256473 :                         AggState   *aggstate = ((AggState *) fcinfo->context);
    4614                 :      256473 :                         ExprContext *cxt = aggstate->curaggcontext;
    4615                 :             : 
    4616                 :      256473 :                         *aggcontext = cxt->ecxt_per_tuple_memory;
    4617                 :      256473 :                 }
    4618                 :      700497 :                 return AGG_CONTEXT_AGGREGATE;
    4619                 :             :         }
    4620   [ +  +  -  + ]:        1918 :         if (fcinfo->context && IsA(fcinfo->context, WindowAggState))
    4621                 :             :         {
    4622         [ +  + ]:        1630 :                 if (aggcontext)
    4623                 :         125 :                         *aggcontext = ((WindowAggState *) fcinfo->context)->curaggcontext;
    4624                 :        1630 :                 return AGG_CONTEXT_WINDOW;
    4625                 :             :         }
    4626                 :             : 
    4627                 :             :         /* this is just to prevent "uninitialized variable" warnings */
    4628         [ +  + ]:         288 :         if (aggcontext)
    4629                 :         280 :                 *aggcontext = NULL;
    4630                 :         288 :         return 0;
    4631                 :      702415 : }
    4632                 :             : 
    4633                 :             : /*
    4634                 :             :  * AggGetAggref - allow an aggregate support function to get its Aggref
    4635                 :             :  *
    4636                 :             :  * If the function is being called as an aggregate support function,
    4637                 :             :  * return the Aggref node for the aggregate call.  Otherwise, return NULL.
    4638                 :             :  *
    4639                 :             :  * Aggregates sharing the same inputs and transition functions can get
    4640                 :             :  * merged into a single transition calculation.  If the transition function
    4641                 :             :  * calls AggGetAggref, it will get some one of the Aggrefs for which it is
    4642                 :             :  * executing.  It must therefore not pay attention to the Aggref fields that
    4643                 :             :  * relate to the final function, as those are indeterminate.  But if a final
    4644                 :             :  * function calls AggGetAggref, it will get a precise result.
    4645                 :             :  *
    4646                 :             :  * Note that if an aggregate is being used as a window function, this will
    4647                 :             :  * return NULL.  We could provide a similar function to return the relevant
    4648                 :             :  * WindowFunc node in such cases, but it's not needed yet.
    4649                 :             :  */
    4650                 :             : Aggref *
    4651                 :          40 : AggGetAggref(FunctionCallInfo fcinfo)
    4652                 :             : {
    4653   [ +  -  -  + ]:          40 :         if (fcinfo->context && IsA(fcinfo->context, AggState))
    4654                 :             :         {
    4655                 :          40 :                 AggState   *aggstate = (AggState *) fcinfo->context;
    4656                 :          40 :                 AggStatePerAgg curperagg;
    4657                 :          40 :                 AggStatePerTrans curpertrans;
    4658                 :             : 
    4659                 :             :                 /* check curperagg (valid when in a final function) */
    4660                 :          40 :                 curperagg = aggstate->curperagg;
    4661                 :             : 
    4662         [ -  + ]:          40 :                 if (curperagg)
    4663                 :           0 :                         return curperagg->aggref;
    4664                 :             : 
    4665                 :             :                 /* check curpertrans (valid when in a transition function) */
    4666                 :          40 :                 curpertrans = aggstate->curpertrans;
    4667                 :             : 
    4668         [ +  - ]:          40 :                 if (curpertrans)
    4669                 :          40 :                         return curpertrans->aggref;
    4670      [ -  +  - ]:          40 :         }
    4671                 :           0 :         return NULL;
    4672                 :          40 : }
    4673                 :             : 
    4674                 :             : /*
    4675                 :             :  * AggGetTempMemoryContext - fetch short-term memory context for aggregates
    4676                 :             :  *
    4677                 :             :  * This is useful in agg final functions; the context returned is one that
    4678                 :             :  * the final function can safely reset as desired.  This isn't useful for
    4679                 :             :  * transition functions, since the context returned MAY (we don't promise)
    4680                 :             :  * be the same as the context those are called in.
    4681                 :             :  *
    4682                 :             :  * As above, this is currently not useful for aggs called as window functions.
    4683                 :             :  */
    4684                 :             : MemoryContext
    4685                 :           0 : AggGetTempMemoryContext(FunctionCallInfo fcinfo)
    4686                 :             : {
    4687   [ #  #  #  # ]:           0 :         if (fcinfo->context && IsA(fcinfo->context, AggState))
    4688                 :             :         {
    4689                 :           0 :                 AggState   *aggstate = (AggState *) fcinfo->context;
    4690                 :             : 
    4691                 :           0 :                 return aggstate->tmpcontext->ecxt_per_tuple_memory;
    4692                 :           0 :         }
    4693                 :           0 :         return NULL;
    4694                 :           0 : }
    4695                 :             : 
    4696                 :             : /*
    4697                 :             :  * AggStateIsShared - find out whether transition state is shared
    4698                 :             :  *
    4699                 :             :  * If the function is being called as an aggregate support function,
    4700                 :             :  * return true if the aggregate's transition state is shared across
    4701                 :             :  * multiple aggregates, false if it is not.
    4702                 :             :  *
    4703                 :             :  * Returns true if not called as an aggregate support function.
    4704                 :             :  * This is intended as a conservative answer, ie "no you'd better not
    4705                 :             :  * scribble on your input".  In particular, will return true if the
    4706                 :             :  * aggregate is being used as a window function, which is a scenario
    4707                 :             :  * in which changing the transition state is a bad idea.  We might
    4708                 :             :  * want to refine the behavior for the window case in future.
    4709                 :             :  */
    4710                 :             : bool
    4711                 :          40 : AggStateIsShared(FunctionCallInfo fcinfo)
    4712                 :             : {
    4713   [ +  -  -  + ]:          40 :         if (fcinfo->context && IsA(fcinfo->context, AggState))
    4714                 :             :         {
    4715                 :          40 :                 AggState   *aggstate = (AggState *) fcinfo->context;
    4716                 :          40 :                 AggStatePerAgg curperagg;
    4717                 :          40 :                 AggStatePerTrans curpertrans;
    4718                 :             : 
    4719                 :             :                 /* check curperagg (valid when in a final function) */
    4720                 :          40 :                 curperagg = aggstate->curperagg;
    4721                 :             : 
    4722         [ -  + ]:          40 :                 if (curperagg)
    4723                 :           0 :                         return aggstate->pertrans[curperagg->transno].aggshared;
    4724                 :             : 
    4725                 :             :                 /* check curpertrans (valid when in a transition function) */
    4726                 :          40 :                 curpertrans = aggstate->curpertrans;
    4727                 :             : 
    4728         [ +  - ]:          40 :                 if (curpertrans)
    4729                 :          40 :                         return curpertrans->aggshared;
    4730      [ -  +  - ]:          40 :         }
    4731                 :           0 :         return true;
    4732                 :          40 : }
    4733                 :             : 
    4734                 :             : /*
    4735                 :             :  * AggRegisterCallback - register a cleanup callback for an aggregate
    4736                 :             :  *
    4737                 :             :  * This is useful for aggs to register shutdown callbacks, which will ensure
    4738                 :             :  * that non-memory resources are freed.  The callback will occur just before
    4739                 :             :  * the associated aggcontext (as returned by AggCheckCallContext) is reset,
    4740                 :             :  * either between groups or as a result of rescanning the query.  The callback
    4741                 :             :  * will NOT be called on error paths.  The typical use-case is for freeing of
    4742                 :             :  * tuplestores or tuplesorts maintained in aggcontext, or pins held by slots
    4743                 :             :  * created by the agg functions.  (The callback will not be called until after
    4744                 :             :  * the result of the finalfn is no longer needed, so it's safe for the finalfn
    4745                 :             :  * to return data that will be freed by the callback.)
    4746                 :             :  *
    4747                 :             :  * As above, this is currently not useful for aggs called as window functions.
    4748                 :             :  */
    4749                 :             : void
    4750                 :         103 : AggRegisterCallback(FunctionCallInfo fcinfo,
    4751                 :             :                                         ExprContextCallbackFunction func,
    4752                 :             :                                         Datum arg)
    4753                 :             : {
    4754         [ +  - ]:         103 :         if (fcinfo->context && IsA(fcinfo->context, AggState))
    4755                 :             :         {
    4756                 :         103 :                 AggState   *aggstate = (AggState *) fcinfo->context;
    4757                 :         103 :                 ExprContext *cxt = aggstate->curaggcontext;
    4758                 :             : 
    4759                 :         103 :                 RegisterExprContextCallback(cxt, func, arg);
    4760                 :             : 
    4761                 :             :                 return;
    4762                 :         103 :         }
    4763   [ #  #  #  # ]:           0 :         elog(ERROR, "aggregate function cannot register a callback in this context");
    4764                 :         103 : }
    4765                 :             : 
    4766                 :             : 
    4767                 :             : /* ----------------------------------------------------------------
    4768                 :             :  *                                              Parallel Query Support
    4769                 :             :  * ----------------------------------------------------------------
    4770                 :             :  */
    4771                 :             : 
    4772                 :             :  /* ----------------------------------------------------------------
    4773                 :             :   *             ExecAggEstimate
    4774                 :             :   *
    4775                 :             :   *             Estimate space required to propagate aggregate statistics.
    4776                 :             :   * ----------------------------------------------------------------
    4777                 :             :   */
    4778                 :             : void
    4779                 :          95 : ExecAggEstimate(AggState *node, ParallelContext *pcxt)
    4780                 :             : {
    4781                 :          95 :         Size            size;
    4782                 :             : 
    4783                 :             :         /* don't need this if not instrumenting or no workers */
    4784   [ +  +  -  + ]:          95 :         if (!node->ss.ps.instrument || pcxt->nworkers == 0)
    4785                 :          78 :                 return;
    4786                 :             : 
    4787                 :          17 :         size = mul_size(pcxt->nworkers, sizeof(AggregateInstrumentation));
    4788                 :          17 :         size = add_size(size, offsetof(SharedAggInfo, sinstrument));
    4789                 :          17 :         shm_toc_estimate_chunk(&pcxt->estimator, size);
    4790                 :          17 :         shm_toc_estimate_keys(&pcxt->estimator, 1);
    4791         [ -  + ]:          95 : }
    4792                 :             : 
    4793                 :             : /* ----------------------------------------------------------------
    4794                 :             :  *              ExecAggInitializeDSM
    4795                 :             :  *
    4796                 :             :  *              Initialize DSM space for aggregate statistics.
    4797                 :             :  * ----------------------------------------------------------------
    4798                 :             :  */
    4799                 :             : void
    4800                 :          95 : ExecAggInitializeDSM(AggState *node, ParallelContext *pcxt)
    4801                 :             : {
    4802                 :          95 :         Size            size;
    4803                 :             : 
    4804                 :             :         /* don't need this if not instrumenting or no workers */
    4805   [ +  +  -  + ]:          95 :         if (!node->ss.ps.instrument || pcxt->nworkers == 0)
    4806                 :          78 :                 return;
    4807                 :             : 
    4808                 :          17 :         size = offsetof(SharedAggInfo, sinstrument)
    4809                 :          17 :                 + pcxt->nworkers * sizeof(AggregateInstrumentation);
    4810                 :          17 :         node->shared_info = shm_toc_allocate(pcxt->toc, size);
    4811                 :             :         /* ensure any unfilled slots will contain zeroes */
    4812                 :          17 :         memset(node->shared_info, 0, size);
    4813                 :          17 :         node->shared_info->num_workers = pcxt->nworkers;
    4814                 :          34 :         shm_toc_insert(pcxt->toc, node->ss.ps.plan->plan_node_id,
    4815                 :          17 :                                    node->shared_info);
    4816         [ -  + ]:          95 : }
    4817                 :             : 
    4818                 :             : /* ----------------------------------------------------------------
    4819                 :             :  *              ExecAggInitializeWorker
    4820                 :             :  *
    4821                 :             :  *              Attach worker to DSM space for aggregate statistics.
    4822                 :             :  * ----------------------------------------------------------------
    4823                 :             :  */
    4824                 :             : void
    4825                 :         271 : ExecAggInitializeWorker(AggState *node, ParallelWorkerContext *pwcxt)
    4826                 :             : {
    4827                 :         271 :         node->shared_info =
    4828                 :         271 :                 shm_toc_lookup(pwcxt->toc, node->ss.ps.plan->plan_node_id, true);
    4829                 :         271 : }
    4830                 :             : 
    4831                 :             : /* ----------------------------------------------------------------
    4832                 :             :  *              ExecAggRetrieveInstrumentation
    4833                 :             :  *
    4834                 :             :  *              Transfer aggregate statistics from DSM to private memory.
    4835                 :             :  * ----------------------------------------------------------------
    4836                 :             :  */
    4837                 :             : void
    4838                 :          17 : ExecAggRetrieveInstrumentation(AggState *node)
    4839                 :             : {
    4840                 :          17 :         Size            size;
    4841                 :          17 :         SharedAggInfo *si;
    4842                 :             : 
    4843         [ +  - ]:          17 :         if (node->shared_info == NULL)
    4844                 :           0 :                 return;
    4845                 :             : 
    4846                 :          17 :         size = offsetof(SharedAggInfo, sinstrument)
    4847                 :          17 :                 + node->shared_info->num_workers * sizeof(AggregateInstrumentation);
    4848                 :          17 :         si = palloc(size);
    4849                 :          17 :         memcpy(si, node->shared_info, size);
    4850                 :          17 :         node->shared_info = si;
    4851         [ -  + ]:          17 : }
        

Generated by: LCOV version 2.3.2-1