</programlisting>
      is compared to the total number of tuples inserted, updated, or deleted
      since the last <command>ANALYZE</command>.
 -    For partitioned tables, inserts, updates and deletes on partitions
 -    are counted towards this threshold; however, DDL
 -    operations such as <literal>ATTACH</literal>, <literal>DETACH</literal>
 -    and <literal>DROP</literal> are not, so running a manual
 -    <command>ANALYZE</command> is recommended if the partition added or
 -    removed contains a statistically significant volume of data.
     </para>
  
     <para>
             <para>
      Whenever you have significantly altered the distribution of data
      within a table, running <link linkend="sql-analyze"><command>ANALYZE</command></link> is strongly recommended. This
 -    includes bulk loading large amounts of data into the table as well as
 -    attaching, detaching or dropping partitions.  Running
 +    includes bulk loading large amounts of data into the table.  Running
      <command>ANALYZE</command> (or <command>VACUUM ANALYZE</command>)
      ensures that the planner has up-to-date statistics about the
      table.  With no statistics or obsolete statistics, the planner might
            </para>
  
    <para>
 -   If the table being analyzed is partitioned, <command>ANALYZE</command>
 -   will gather statistics by sampling blocks randomly from its partitions;
 -   in addition, it will recurse into each partition and update its statistics.
 -   (However, in multi-level partitioning scenarios, each leaf partition
 -   will only be analyzed once.)
 -   By contrast, if the table being analyzed has inheritance children,
 -   <command>ANALYZE</command> will gather statistics for it twice:
 -   once on the rows of the parent table only, and a second time on the
 -   rows of the parent table with all of its children.  This second set of
 -   statistics is needed when planning queries that traverse the entire
 -   inheritance tree.  The child tables themselves are not individually
 -   analyzed in this case.
 +    If the table being analyzed has one or more children,
 +    <command>ANALYZE</command> will gather statistics twice: once on the
 +    rows of the parent table only, and a second time on the rows of the
 +    parent table with all of its children.  This second set of statistics
 +    is needed when planning queries that traverse the entire inheritance
 +    tree.  The autovacuum daemon, however, will only consider inserts or
 +    updates on the parent table itself when deciding whether to trigger an
 +    automatic analyze for that table.  If that table is rarely inserted into
 +    or updated, the inheritance statistics will not be up to date unless you
 +    run <command>ANALYZE</command> manually.
    </para>
  
    <para>
 -   The autovacuum daemon counts inserts, updates and deletes in the
 -   partitions to determine if auto-analyze is needed.  However, adding
 -   or removing partitions does not affect autovacuum daemon decisions,
 -   so triggering a manual <command>ANALYZE</command> is recommended
 -   when this occurs.
 -  </para>
 -
 -  <para>
 -   Tuples changed in inheritance children do not count towards analyze
 -   on the parent table.  If the parent table is empty or rarely modified,
 -   it may never be processed by autovacuum.  It's necessary to
 -   periodically run a manual <command>ANALYZE</command> to keep the
 -   statistics of the table hierarchy up to date.
 -  </para>
 -
 -  <para>
 -    If any of the child tables or partitions are foreign tables whose foreign data wrappers
 +    If any of the child tables are foreign tables whose foreign data wrappers
      do not support <command>ANALYZE</command>, those child tables are ignored while
      gathering inheritance statistics.
    </para>
              If a table parameter value is set and the
      equivalent <literal>toast.</literal> parameter is not, the TOAST table
      will use the table's parameter value.
 -    Except where noted, these parameters are not supported on partitioned
 -    tables; however, you can specify them on individual leaf partitions.
 +    Specifying these parameters for partitioned tables is not supported,
 +    but you may specify them for individual leaf partitions.
     </para>
  
     <variablelist>
        If true, the autovacuum daemon will perform automatic <command>VACUUM</command>
       and/or <command>ANALYZE</command> operations on this table following the rules
       discussed in <xref linkend="autovacuum"/>.
 -     This parameter can be set for partitioned tables to prevent autovacuum
 -     from running <command>ANALYZE</command> on them.
       If false, this table will not be autovacuumed, except to prevent
       transaction ID wraparound. See <xref linkend="vacuum-for-wraparound"/> for
       more about wraparound prevention.
        <para>
        Per-table value for <xref linkend="guc-autovacuum-analyze-threshold"/>
        parameter.
 -      This parameter can be set for partitioned tables.
       </para>
      </listitem>
     </varlistentry>
        <para>
        Per-table value for <xref linkend="guc-autovacuum-analyze-scale-factor"/>
        parameter.
 -      This parameter can be set for partitioned tables.
       </para>
      </listitem>
     </varlistentry>
          
    <para>
     Once restored, it is wise to run <command>ANALYZE</command> on each
 -   restored table so the optimizer has useful statistics.
 -   If the table is a partition or an inheritance child, it may also be useful
 -   to analyze the parent to update statistics for the table hierarchy.
 -   See <xref linkend="vacuum-for-statistics"/> and
 +   restored table so the optimizer has useful statistics; see
 +   <xref linkend="vacuum-for-statistics"/> and
     <xref linkend="autovacuum"/> for more information.
    </para>
  
                 {
             "autovacuum_enabled",
             "Enables autovacuum in this relation",
 -           RELOPT_KIND_HEAP | RELOPT_KIND_TOAST | RELOPT_KIND_PARTITIONED,
 +           RELOPT_KIND_HEAP | RELOPT_KIND_TOAST,
             ShareUpdateExclusiveLock
         },
         true
          {
             "autovacuum_analyze_threshold",
             "Minimum number of tuple inserts, updates or deletes prior to analyze",
 -           RELOPT_KIND_HEAP | RELOPT_KIND_PARTITIONED,
 +           RELOPT_KIND_HEAP,
             ShareUpdateExclusiveLock
         },
         -1, 0, INT_MAX
          {
             "autovacuum_analyze_scale_factor",
             "Number of tuple inserts, updates or deletes prior to analyze as a fraction of reltuples",
 -           RELOPT_KIND_HEAP | RELOPT_KIND_PARTITIONED,
 +           RELOPT_KIND_HEAP,
             ShareUpdateExclusiveLock
         },
         -1, 0.0, 100.0
   partitioned_table_reloptions(Datum reloptions, bool validate)
  {
     /*
 -    * autovacuum_enabled, autovacuum_analyze_threshold and
 -    * autovacuum_analyze_scale_factor are supported for partitioned tables.
 +    * There are no options for partitioned tables yet, but this is able to do
 +    * some validation.
      */
 -
 -   return default_reloptions(reloptions, validate, RELOPT_KIND_PARTITIONED);
 +   return (bytea *) build_reloptions(reloptions, validate,
 +                                     RELOPT_KIND_PARTITIONED,
 +                                     0, NULL, 0);
  }
  
  /*
                                          PROGRESS_ANALYZE_PHASE_FINALIZE_ANALYZE);
  
     /*
 -    * Update pages/tuples stats in pg_class ... but not if we're doing
 -    * inherited stats.
 +    * Update pages/tuples stats in pg_class, and report ANALYZE to the stats
 +    * collector ... but not if we're doing inherited stats.
      *
      * We assume that VACUUM hasn't set pg_class.reltuples already, even
      * during a VACUUM ANALYZE.  Although VACUUM often updates pg_class,
                                  InvalidMultiXactId,
                                 in_outer_xact);
         }
 -   }
 -   else if (onerel->rd_rel->relkind == RELKIND_PARTITIONED_TABLE)
 -   {
 +
         /*
 -        * Partitioned tables don't have storage, so we don't set any fields
 -        * in their pg_class entries except for reltuples, which is necessary
 -        * for auto-analyze to work properly, and relhasindex.
 +        * Now report ANALYZE to the stats collector.
 +        *
 +        * We deliberately don't report to the stats collector when doing
 +        * inherited stats, because the stats collector only tracks per-table
 +        * stats.
 +        *
 +        * Reset the changes_since_analyze counter only if we analyzed all
 +        * columns; otherwise, there is still work for auto-analyze to do.
          */
 -       vac_update_relstats(onerel, -1, totalrows,
 -                           0, hasindex, InvalidTransactionId,
 -                           InvalidMultiXactId,
 -                           in_outer_xact);
 -   }
 -
 -   /*
 -    * Now report ANALYZE to the stats collector.  For regular tables, we do
 -    * it only if not doing inherited stats.  For partitioned tables, we only
 -    * do it for inherited stats. (We're never called for not-inherited stats
 -    * on partitioned tables anyway.)
 -    *
 -    * Reset the changes_since_analyze counter only if we analyzed all
 -    * columns; otherwise, there is still work for auto-analyze to do.
 -    */
 -   if (!inh || onerel->rd_rel->relkind == RELKIND_PARTITIONED_TABLE)
         pgstat_report_analyze(onerel, totalrows, totaldeadrows,
                               (va_cols == NIL));
 -
 -   /*
 -    * If this is a manual analyze of all columns of a permanent leaf
 -    * partition, and not doing inherited stats, also let the collector know
 -    * about the ancestor tables of this partition.  Autovacuum does the
 -    * equivalent of this at the start of its run, so there's no reason to do
 -    * it there.
 -    */
 -   if (!inh && !IsAutoVacuumWorkerProcess() &&
 -       (va_cols == NIL) &&
 -       onerel->rd_rel->relispartition &&
 -       onerel->rd_rel->relkind == RELKIND_RELATION &&
 -       onerel->rd_rel->relpersistence == RELPERSISTENCE_PERMANENT)
 -   {
 -       pgstat_report_anl_ancestors(RelationGetRelid(onerel));
     }
  
     /*
          static void truncate_check_rel(Oid relid, Form_pg_class reltuple);
  static void truncate_check_perms(Oid relid, Form_pg_class reltuple);
  static void truncate_check_activity(Relation rel);
 -static void truncate_update_partedrel_stats(List *parted_rels);
  static void RangeVarCallbackForTruncate(const RangeVar *relation,
                                         Oid relId, Oid oldRelId, void *arg);
  static List *MergeAttributes(List *schema, List *supers, char relpersistence,
   {
     List       *rels;
     List       *seq_relids = NIL;
 -   List       *parted_rels = NIL;
     HTAB       *ft_htab = NULL;
     EState     *estate;
     ResultRelInfo *resultRelInfos;
      {
         Relation    rel = (Relation) lfirst(cell);
  
 -       /*
 -        * Save OID of partitioned tables for later; nothing else to do for
 -        * them here.
 -        */
 +       /* Skip partitioned tables as there is nothing to do */
         if (rel->rd_rel->relkind == RELKIND_PARTITIONED_TABLE)
 -       {
 -           parted_rels = lappend_oid(parted_rels, RelationGetRelid(rel));
             continue;
 -       }
  
         /*
          * Build the lists of foreign tables belonging to each foreign server
          ResetSequence(seq_relid);
     }
  
 -   /* Reset partitioned tables' pg_class.reltuples */
 -   truncate_update_partedrel_stats(parted_rels);
 -
     /*
      * Write a WAL record to allow this set of actions to be logically
      * decoded.
      CheckTableNotInUse(rel, "TRUNCATE");
  }
  
 -/*
 - * Update pg_class.reltuples for all the given partitioned tables to 0.
 - */
 -static void
 -truncate_update_partedrel_stats(List *parted_rels)
 -{
 -   Relation    pg_class;
 -   ListCell   *lc;
 -
 -   pg_class = table_open(RelationRelationId, RowExclusiveLock);
 -
 -   foreach(lc, parted_rels)
 -   {
 -       Oid         relid = lfirst_oid(lc);
 -       HeapTuple   tuple;
 -       Form_pg_class rd_rel;
 -
 -       tuple = SearchSysCacheCopy1(RELOID, ObjectIdGetDatum(relid));
 -       if (!HeapTupleIsValid(tuple))
 -           elog(ERROR, "could not find tuple for relation %u", relid);
 -       rd_rel = (Form_pg_class) GETSTRUCT(tuple);
 -       if (rd_rel->reltuples != (float4) 0)
 -       {
 -           rd_rel->reltuples = (float4) 0;
 -
 -           heap_inplace_update(pg_class, tuple);
 -       }
 -
 -       heap_freetuple(tuple);
 -   }
 -
 -   table_close(pg_class, RowExclusiveLock);
 -}
 -
  /*
   * storage_name
   *   returns the name corresponding to a typstorage/attstorage enum value
          #include "catalog/dependency.h"
  #include "catalog/namespace.h"
  #include "catalog/pg_database.h"
 -#include "catalog/pg_inherits.h"
  #include "commands/dbcommands.h"
  #include "commands/vacuum.h"
  #include "lib/ilist.h"
      int         effective_multixact_freeze_max_age;
     bool        did_vacuum = false;
     bool        found_concurrent_worker = false;
 -   bool        updated = false;
     int         i;
  
     /*
      /*
      * Scan pg_class to determine which tables to vacuum.
      *
 -    * We do this in three passes: First we let pgstat collector know about
 -    * the partitioned table ancestors of all partitions that have recently
 -    * acquired rows for analyze.  This informs the second pass about the
 -    * total number of tuple count in partitioning hierarchies.
 -    *
 -    * On the second pass, we collect the list of plain relations,
 -    * materialized views and partitioned tables.  On the third one we collect
 -    * TOAST tables.
 -    *
 -    * The reason for doing the third pass is that during it we want to use
 -    * the main relation's pg_class.reloptions entry if the TOAST table does
 -    * not have any, and we cannot obtain it unless we know beforehand what's
 -    * the main table OID.
 +    * We do this in two passes: on the first one we collect the list of plain
 +    * relations and materialized views, and on the second one we collect
 +    * TOAST tables. The reason for doing the second pass is that during it we
 +    * want to use the main relation's pg_class.reloptions entry if the TOAST
 +    * table does not have any, and we cannot obtain it unless we know
 +    * beforehand what's the main table OID.
      *
      * We need to check TOAST tables separately because in cases with short,
      * wide tables there might be proportionally much more activity in the
      relScan = table_beginscan_catalog(classRel, 0, NULL);
  
     /*
 -    * First pass: before collecting the list of tables to vacuum, let stat
 -    * collector know about partitioned-table ancestors of each partition.
 -    */
 -   while ((tuple = heap_getnext(relScan, ForwardScanDirection)) != NULL)
 -   {
 -       Form_pg_class classForm = (Form_pg_class) GETSTRUCT(tuple);
 -       Oid         relid = classForm->oid;
 -       PgStat_StatTabEntry *tabentry;
 -
 -       /* Only consider permanent leaf partitions */
 -       if (!classForm->relispartition ||
 -           classForm->relkind == RELKIND_PARTITIONED_TABLE ||
 -           classForm->relpersistence == RELPERSISTENCE_TEMP)
 -           continue;
 -
 -       /*
 -        * No need to do this for partitions that haven't acquired any rows.
 -        */
 -       tabentry = pgstat_fetch_stat_tabentry(relid);
 -       if (tabentry &&
 -           tabentry->changes_since_analyze -
 -           tabentry->changes_since_analyze_reported > 0)
 -       {
 -           pgstat_report_anl_ancestors(relid);
 -           updated = true;
 -       }
 -   }
 -
 -   /* Acquire fresh stats for the next passes, if needed */
 -   if (updated)
 -   {
 -       autovac_refresh_stats();
 -       dbentry = pgstat_fetch_stat_dbentry(MyDatabaseId);
 -       shared = pgstat_fetch_stat_dbentry(InvalidOid);
 -   }
 -
 -   /*
 -    * On the second pass, we collect main tables to vacuum, and also the main
 +    * On the first pass, we collect main tables to vacuum, and also the main
      * table relid to TOAST relid mapping.
      */
     while ((tuple = heap_getnext(relScan, ForwardScanDirection)) != NULL)
          bool        wraparound;
  
         if (classForm->relkind != RELKIND_RELATION &&
 -           classForm->relkind != RELKIND_MATVIEW &&
 -           classForm->relkind != RELKIND_PARTITIONED_TABLE)
 +           classForm->relkind != RELKIND_MATVIEW)
             continue;
  
         relid = classForm->oid;
   
     table_endscan(relScan);
  
 -   /* third pass: check TOAST tables */
 +   /* second pass: check TOAST tables */
     ScanKeyInit(&key,
                 Anum_pg_class_relkind,
                 BTEqualStrategyNumber, F_CHAREQ,
   
     Assert(((Form_pg_class) GETSTRUCT(tup))->relkind == RELKIND_RELATION ||
            ((Form_pg_class) GETSTRUCT(tup))->relkind == RELKIND_MATVIEW ||
 -          ((Form_pg_class) GETSTRUCT(tup))->relkind == RELKIND_PARTITIONED_TABLE ||
            ((Form_pg_class) GETSTRUCT(tup))->relkind == RELKIND_TOASTVALUE);
  
     relopts = extractRelOptions(tup, pg_class_desc, NULL);
          #include "access/transam.h"
  #include "access/twophase_rmgr.h"
  #include "access/xact.h"
 -#include "catalog/partition.h"
  #include "catalog/pg_database.h"
  #include "catalog/pg_proc.h"
  #include "common/ip.h"
   static void pgstat_recv_autovac(PgStat_MsgAutovacStart *msg, int len);
  static void pgstat_recv_vacuum(PgStat_MsgVacuum *msg, int len);
  static void pgstat_recv_analyze(PgStat_MsgAnalyze *msg, int len);
 -static void pgstat_recv_anl_ancestors(PgStat_MsgAnlAncestors *msg, int len);
  static void pgstat_recv_archiver(PgStat_MsgArchiver *msg, int len);
  static void pgstat_recv_bgwriter(PgStat_MsgBgWriter *msg, int len);
  static void pgstat_recv_checkpointer(PgStat_MsgCheckpointer *msg, int len);
    *
   * Caller must provide new live- and dead-tuples estimates, as well as a
   * flag indicating whether to reset the changes_since_analyze counter.
 - * Exceptional support only changes_since_analyze for partitioned tables,
 - * though they don't have any data.  This counter will tell us whether
 - * partitioned tables need autoanalyze or not.
   * --------
   */
  void
       * be double-counted after commit.  (This approach also ensures that the
      * collector ends up with the right numbers if we abort instead of
      * committing.)
 -    *
 -    * For partitioned tables, we don't report live and dead tuples, because
 -    * such tables don't have any data.
      */
     if (rel->pgstat_info != NULL)
     {
         PgStat_TableXactStatus *trans;
  
 -       if (rel->rd_rel->relkind == RELKIND_PARTITIONED_TABLE)
 -           /* If this rel is partitioned, skip modifying */
 -           livetuples = deadtuples = 0;
 -       else
 +       for (trans = rel->pgstat_info->trans; trans; trans = trans->upper)
         {
 -           for (trans = rel->pgstat_info->trans; trans; trans = trans->upper)
 -           {
 -               livetuples -= trans->tuples_inserted - trans->tuples_deleted;
 -               deadtuples -= trans->tuples_updated + trans->tuples_deleted;
 -           }
 -           /* count stuff inserted by already-aborted subxacts, too */
 -           deadtuples -= rel->pgstat_info->t_counts.t_delta_dead_tuples;
 -           /* Since ANALYZE's counts are estimates, we could have underflowed */
 -           livetuples = Max(livetuples, 0);
 -           deadtuples = Max(deadtuples, 0);
 +           livetuples -= trans->tuples_inserted - trans->tuples_deleted;
 +           deadtuples -= trans->tuples_updated + trans->tuples_deleted;
         }
 -
 +       /* count stuff inserted by already-aborted subxacts, too */
 +       deadtuples -= rel->pgstat_info->t_counts.t_delta_dead_tuples;
 +       /* Since ANALYZE's counts are estimates, we could have underflowed */
 +       livetuples = Max(livetuples, 0);
 +       deadtuples = Max(deadtuples, 0);
     }
  
     pgstat_setheader(&msg.m_hdr, PGSTAT_MTYPE_ANALYZE);
      msg.m_live_tuples = livetuples;
     msg.m_dead_tuples = deadtuples;
     pgstat_send(&msg, sizeof(msg));
 -
 -}
 -
 -/*
 - * pgstat_report_anl_ancestors
 - *
 - * Send list of partitioned table ancestors of the given partition to the
 - * collector.  The collector is in charge of propagating the analyze tuple
 - * counts from the partition to its ancestors.  This is necessary so that
 - * other processes can decide whether to analyze the partitioned tables.
 - */
 -void
 -pgstat_report_anl_ancestors(Oid relid)
 -{
 -   PgStat_MsgAnlAncestors msg;
 -   List       *ancestors;
 -   ListCell   *lc;
 -
 -   pgstat_setheader(&msg.m_hdr, PGSTAT_MTYPE_ANL_ANCESTORS);
 -   msg.m_databaseid = MyDatabaseId;
 -   msg.m_tableoid = relid;
 -   msg.m_nancestors = 0;
 -
 -   ancestors = get_partition_ancestors(relid);
 -   foreach(lc, ancestors)
 -   {
 -       Oid         ancestor = lfirst_oid(lc);
 -
 -       msg.m_ancestors[msg.m_nancestors] = ancestor;
 -       if (++msg.m_nancestors >= PGSTAT_NUM_ANCESTORENTRIES)
 -       {
 -           pgstat_send(&msg, offsetof(PgStat_MsgAnlAncestors, m_ancestors[0]) +
 -                       msg.m_nancestors * sizeof(Oid));
 -           msg.m_nancestors = 0;
 -       }
 -   }
 -
 -   if (msg.m_nancestors > 0)
 -       pgstat_send(&msg, offsetof(PgStat_MsgAnlAncestors, m_ancestors[0]) +
 -                   msg.m_nancestors * sizeof(Oid));
 -
 -   list_free(ancestors);
  }
  
  /* --------
      char        relkind = rel->rd_rel->relkind;
  
     /* We only count stats for things that have storage */
 -   if (!RELKIND_HAS_STORAGE(relkind) &&
 -       relkind != RELKIND_PARTITIONED_TABLE)
 +   if (!RELKIND_HAS_STORAGE(relkind))
     {
         rel->pgstat_info = NULL;
         return;
                      pgstat_recv_analyze(&msg.msg_analyze, len);
                     break;
  
 -               case PGSTAT_MTYPE_ANL_ANCESTORS:
 -                   pgstat_recv_anl_ancestors(&msg.msg_anl_ancestors, len);
 -                   break;
 -
                 case PGSTAT_MTYPE_ARCHIVER:
                     pgstat_recv_archiver(&msg.msg_archiver, len);
                     break;
          result->n_live_tuples = 0;
         result->n_dead_tuples = 0;
         result->changes_since_analyze = 0;
 -       result->changes_since_analyze_reported = 0;
         result->inserts_since_vacuum = 0;
         result->blocks_fetched = 0;
         result->blocks_hit = 0;
              tabentry->n_live_tuples = tabmsg->t_counts.t_delta_live_tuples;
             tabentry->n_dead_tuples = tabmsg->t_counts.t_delta_dead_tuples;
             tabentry->changes_since_analyze = tabmsg->t_counts.t_changed_tuples;
 -           tabentry->changes_since_analyze_reported = 0;
             tabentry->inserts_since_vacuum = tabmsg->t_counts.t_tuples_inserted;
             tabentry->blocks_fetched = tabmsg->t_counts.t_blocks_fetched;
             tabentry->blocks_hit = tabmsg->t_counts.t_blocks_hit;
       * have no good way to estimate how many of those there were.
      */
     if (msg->m_resetcounter)
 -   {
         tabentry->changes_since_analyze = 0;
 -       tabentry->changes_since_analyze_reported = 0;
 -   }
  
     if (msg->m_autovacuum)
     {
      }
  }
  
 -static void
 -pgstat_recv_anl_ancestors(PgStat_MsgAnlAncestors *msg, int len)
 -{
 -   PgStat_StatDBEntry *dbentry;
 -   PgStat_StatTabEntry *tabentry;
 -
 -   dbentry = pgstat_get_db_entry(msg->m_databaseid, true);
 -
 -   tabentry = pgstat_get_tab_entry(dbentry, msg->m_tableoid, true);
 -
 -   for (int i = 0; i < msg->m_nancestors; i++)
 -   {
 -       Oid         ancestor_relid = msg->m_ancestors[i];
 -       PgStat_StatTabEntry *ancestor;
 -
 -       ancestor = pgstat_get_tab_entry(dbentry, ancestor_relid, true);
 -       ancestor->changes_since_analyze +=
 -           tabentry->changes_since_analyze - tabentry->changes_since_analyze_reported;
 -   }
 -
 -   tabentry->changes_since_analyze_reported = tabentry->changes_since_analyze;
 -
 -}
  
  /* ----------
   * pgstat_recv_archiver() -
             PGSTAT_MTYPE_AUTOVAC_START,
     PGSTAT_MTYPE_VACUUM,
     PGSTAT_MTYPE_ANALYZE,
 -   PGSTAT_MTYPE_ANL_ANCESTORS,
     PGSTAT_MTYPE_ARCHIVER,
     PGSTAT_MTYPE_BGWRITER,
     PGSTAT_MTYPE_CHECKPOINTER,
    *
   * tuples_inserted/updated/deleted/hot_updated count attempted actions,
   * regardless of whether the transaction committed.  delta_live_tuples,
 - * delta_dead_tuples, changed_tuples are set depending on commit or abort.
 + * delta_dead_tuples, and changed_tuples are set depending on commit or abort.
   * Note that delta_live_tuples and delta_dead_tuples can be negative!
   * ----------
   */
      PgStat_Counter m_dead_tuples;
  } PgStat_MsgAnalyze;
  
 -/* ----------
 - * PgStat_MsgAnlAncestors      Sent by the backend or autovacuum daemon
 - *                             to inform partitioned tables that are
 - *                             ancestors of a partition, to propagate
 - *                             analyze counters
 - * ----------
 - */
 -#define PGSTAT_NUM_ANCESTORENTRIES    \
 -   ((PGSTAT_MSG_PAYLOAD - sizeof(Oid) - sizeof(Oid) - sizeof(int)) \
 -    / sizeof(Oid))
 -
 -typedef struct PgStat_MsgAnlAncestors
 -{
 -   PgStat_MsgHdr m_hdr;
 -   Oid         m_databaseid;
 -   Oid         m_tableoid;
 -   int         m_nancestors;
 -   Oid         m_ancestors[PGSTAT_NUM_ANCESTORENTRIES];
 -} PgStat_MsgAnlAncestors;
  
  /* ----------
   * PgStat_MsgArchiver          Sent by the archiver to update statistics.
      PgStat_MsgAutovacStart msg_autovacuum_start;
     PgStat_MsgVacuum msg_vacuum;
     PgStat_MsgAnalyze msg_analyze;
 -   PgStat_MsgAnlAncestors msg_anl_ancestors;
     PgStat_MsgArchiver msg_archiver;
     PgStat_MsgBgWriter msg_bgwriter;
     PgStat_MsgCheckpointer msg_checkpointer;
    * ------------------------------------------------------------
   */
  
 -#define PGSTAT_FILE_FORMAT_ID  0x01A5BCA3
 +#define PGSTAT_FILE_FORMAT_ID  0x01A5BCA4
  
  /* ----------
   * PgStat_StatDBEntry          The collector's data per database
      PgStat_Counter n_live_tuples;
     PgStat_Counter n_dead_tuples;
     PgStat_Counter changes_since_analyze;
 -   PgStat_Counter changes_since_analyze_reported;
     PgStat_Counter inserts_since_vacuum;
  
     PgStat_Counter blocks_fetched;
   extern void pgstat_report_analyze(Relation rel,
                                   PgStat_Counter livetuples, PgStat_Counter deadtuples,
                                   bool resetcounter);
 -extern void pgstat_report_anl_ancestors(Oid relid);
  
  extern void pgstat_report_recovery_conflict(int reason);
  extern void pgstat_report_deadlock(void);