LCOV - code coverage report
Current view: top level - src/bin/pg_dump - pg_backup_archiver.c (source / functions) Hit Total Coverage
Test: PostgreSQL 19devel Lines: 1622 2000 81.1 %
Date: 2025-08-25 18:18:17 Functions: 91 96 94.8 %
Legend: Lines: hit not hit

          Line data    Source code
       1             : /*-------------------------------------------------------------------------
       2             :  *
       3             :  * pg_backup_archiver.c
       4             :  *
       5             :  *  Private implementation of the archiver routines.
       6             :  *
       7             :  *  See the headers to pg_restore for more details.
       8             :  *
       9             :  * Copyright (c) 2000, Philip Warner
      10             :  *  Rights are granted to use this software in any way so long
      11             :  *  as this notice is not removed.
      12             :  *
      13             :  *  The author is not responsible for loss or damages that may
      14             :  *  result from its use.
      15             :  *
      16             :  *
      17             :  * IDENTIFICATION
      18             :  *      src/bin/pg_dump/pg_backup_archiver.c
      19             :  *
      20             :  *-------------------------------------------------------------------------
      21             :  */
      22             : #include "postgres_fe.h"
      23             : 
      24             : #include <ctype.h>
      25             : #include <fcntl.h>
      26             : #include <unistd.h>
      27             : #include <sys/stat.h>
      28             : #include <sys/wait.h>
      29             : #ifdef WIN32
      30             : #include <io.h>
      31             : #endif
      32             : 
      33             : #include "catalog/pg_class_d.h"
      34             : #include "catalog/pg_largeobject_metadata_d.h"
      35             : #include "catalog/pg_shdepend_d.h"
      36             : #include "common/string.h"
      37             : #include "compress_io.h"
      38             : #include "dumputils.h"
      39             : #include "fe_utils/string_utils.h"
      40             : #include "lib/binaryheap.h"
      41             : #include "lib/stringinfo.h"
      42             : #include "libpq/libpq-fs.h"
      43             : #include "parallel.h"
      44             : #include "pg_backup_archiver.h"
      45             : #include "pg_backup_db.h"
      46             : #include "pg_backup_utils.h"
      47             : 
      48             : #define TEXT_DUMP_HEADER "--\n-- PostgreSQL database dump\n--\n\n"
      49             : #define TEXT_DUMPALL_HEADER "--\n-- PostgreSQL database cluster dump\n--\n\n"
      50             : 
      51             : #define TOC_PREFIX_NONE     ""
      52             : #define TOC_PREFIX_DATA     "Data for "
      53             : #define TOC_PREFIX_STATS    "Statistics for "
      54             : 
      55             : static ArchiveHandle *_allocAH(const char *FileSpec, const ArchiveFormat fmt,
      56             :                                const pg_compress_specification compression_spec,
      57             :                                bool dosync, ArchiveMode mode,
      58             :                                SetupWorkerPtrType setupWorkerPtr,
      59             :                                DataDirSyncMethod sync_method);
      60             : static void _getObjectDescription(PQExpBuffer buf, const TocEntry *te);
      61             : static void _printTocEntry(ArchiveHandle *AH, TocEntry *te, const char *pfx);
      62             : static void _doSetFixedOutputState(ArchiveHandle *AH);
      63             : static void _doSetSessionAuth(ArchiveHandle *AH, const char *user);
      64             : static void _reconnectToDB(ArchiveHandle *AH, const char *dbname);
      65             : static void _becomeUser(ArchiveHandle *AH, const char *user);
      66             : static void _becomeOwner(ArchiveHandle *AH, TocEntry *te);
      67             : static void _selectOutputSchema(ArchiveHandle *AH, const char *schemaName);
      68             : static void _selectTablespace(ArchiveHandle *AH, const char *tablespace);
      69             : static void _selectTableAccessMethod(ArchiveHandle *AH, const char *tableam);
      70             : static void _printTableAccessMethodNoStorage(ArchiveHandle *AH,
      71             :                                              TocEntry *te);
      72             : static void processEncodingEntry(ArchiveHandle *AH, TocEntry *te);
      73             : static void processStdStringsEntry(ArchiveHandle *AH, TocEntry *te);
      74             : static void processSearchPathEntry(ArchiveHandle *AH, TocEntry *te);
      75             : static int  _tocEntryRequired(TocEntry *te, teSection curSection, ArchiveHandle *AH);
      76             : static RestorePass _tocEntryRestorePass(TocEntry *te);
      77             : static bool _tocEntryIsACL(TocEntry *te);
      78             : static void _disableTriggersIfNecessary(ArchiveHandle *AH, TocEntry *te);
      79             : static void _enableTriggersIfNecessary(ArchiveHandle *AH, TocEntry *te);
      80             : static bool is_load_via_partition_root(TocEntry *te);
      81             : static void buildTocEntryArrays(ArchiveHandle *AH);
      82             : static void _moveBefore(TocEntry *pos, TocEntry *te);
      83             : static int  _discoverArchiveFormat(ArchiveHandle *AH);
      84             : 
      85             : static int  RestoringToDB(ArchiveHandle *AH);
      86             : static void dump_lo_buf(ArchiveHandle *AH);
      87             : static void dumpTimestamp(ArchiveHandle *AH, const char *msg, time_t tim);
      88             : static void SetOutput(ArchiveHandle *AH, const char *filename,
      89             :                       const pg_compress_specification compression_spec);
      90             : static CompressFileHandle *SaveOutput(ArchiveHandle *AH);
      91             : static void RestoreOutput(ArchiveHandle *AH, CompressFileHandle *savedOutput);
      92             : 
      93             : static int  restore_toc_entry(ArchiveHandle *AH, TocEntry *te, bool is_parallel);
      94             : static void restore_toc_entries_prefork(ArchiveHandle *AH,
      95             :                                         TocEntry *pending_list);
      96             : static void restore_toc_entries_parallel(ArchiveHandle *AH,
      97             :                                          ParallelState *pstate,
      98             :                                          TocEntry *pending_list);
      99             : static void restore_toc_entries_postfork(ArchiveHandle *AH,
     100             :                                          TocEntry *pending_list);
     101             : static void pending_list_header_init(TocEntry *l);
     102             : static void pending_list_append(TocEntry *l, TocEntry *te);
     103             : static void pending_list_remove(TocEntry *te);
     104             : static int  TocEntrySizeCompareQsort(const void *p1, const void *p2);
     105             : static int  TocEntrySizeCompareBinaryheap(void *p1, void *p2, void *arg);
     106             : static void move_to_ready_heap(TocEntry *pending_list,
     107             :                                binaryheap *ready_heap,
     108             :                                RestorePass pass);
     109             : static TocEntry *pop_next_work_item(binaryheap *ready_heap,
     110             :                                     ParallelState *pstate);
     111             : static void mark_dump_job_done(ArchiveHandle *AH,
     112             :                                TocEntry *te,
     113             :                                int status,
     114             :                                void *callback_data);
     115             : static void mark_restore_job_done(ArchiveHandle *AH,
     116             :                                   TocEntry *te,
     117             :                                   int status,
     118             :                                   void *callback_data);
     119             : static void fix_dependencies(ArchiveHandle *AH);
     120             : static bool has_lock_conflicts(TocEntry *te1, TocEntry *te2);
     121             : static void repoint_table_dependencies(ArchiveHandle *AH);
     122             : static void identify_locking_dependencies(ArchiveHandle *AH, TocEntry *te);
     123             : static void reduce_dependencies(ArchiveHandle *AH, TocEntry *te,
     124             :                                 binaryheap *ready_heap);
     125             : static void mark_create_done(ArchiveHandle *AH, TocEntry *te);
     126             : static void inhibit_data_for_failed_table(ArchiveHandle *AH, TocEntry *te);
     127             : 
     128             : static void StrictNamesCheck(RestoreOptions *ropt);
     129             : 
     130             : 
     131             : /*
     132             :  * Allocate a new DumpOptions block containing all default values.
     133             :  */
     134             : DumpOptions *
     135         116 : NewDumpOptions(void)
     136             : {
     137         116 :     DumpOptions *opts = (DumpOptions *) pg_malloc(sizeof(DumpOptions));
     138             : 
     139         116 :     InitDumpOptions(opts);
     140         116 :     return opts;
     141             : }
     142             : 
     143             : /*
     144             :  * Initialize a DumpOptions struct to all default values
     145             :  */
     146             : void
     147         570 : InitDumpOptions(DumpOptions *opts)
     148             : {
     149         570 :     memset(opts, 0, sizeof(DumpOptions));
     150             :     /* set any fields that shouldn't default to zeroes */
     151         570 :     opts->include_everything = true;
     152         570 :     opts->cparams.promptPassword = TRI_DEFAULT;
     153         570 :     opts->dumpSections = DUMP_UNSECTIONED;
     154         570 :     opts->dumpSchema = true;
     155         570 :     opts->dumpData = true;
     156         570 :     opts->dumpStatistics = false;
     157         570 : }
     158             : 
     159             : /*
     160             :  * Create a freshly allocated DumpOptions with options equivalent to those
     161             :  * found in the given RestoreOptions.
     162             :  */
     163             : DumpOptions *
     164         116 : dumpOptionsFromRestoreOptions(RestoreOptions *ropt)
     165             : {
     166         116 :     DumpOptions *dopt = NewDumpOptions();
     167             : 
     168             :     /* this is the inverse of what's at the end of pg_dump.c's main() */
     169         116 :     dopt->cparams.dbname = ropt->cparams.dbname ? pg_strdup(ropt->cparams.dbname) : NULL;
     170         116 :     dopt->cparams.pgport = ropt->cparams.pgport ? pg_strdup(ropt->cparams.pgport) : NULL;
     171         116 :     dopt->cparams.pghost = ropt->cparams.pghost ? pg_strdup(ropt->cparams.pghost) : NULL;
     172         116 :     dopt->cparams.username = ropt->cparams.username ? pg_strdup(ropt->cparams.username) : NULL;
     173         116 :     dopt->cparams.promptPassword = ropt->cparams.promptPassword;
     174         116 :     dopt->outputClean = ropt->dropSchema;
     175         116 :     dopt->dumpData = ropt->dumpData;
     176         116 :     dopt->dumpSchema = ropt->dumpSchema;
     177         116 :     dopt->dumpSections = ropt->dumpSections;
     178         116 :     dopt->dumpStatistics = ropt->dumpStatistics;
     179         116 :     dopt->if_exists = ropt->if_exists;
     180         116 :     dopt->column_inserts = ropt->column_inserts;
     181         116 :     dopt->aclsSkip = ropt->aclsSkip;
     182         116 :     dopt->outputSuperuser = ropt->superuser;
     183         116 :     dopt->outputCreateDB = ropt->createDB;
     184         116 :     dopt->outputNoOwner = ropt->noOwner;
     185         116 :     dopt->outputNoTableAm = ropt->noTableAm;
     186         116 :     dopt->outputNoTablespaces = ropt->noTablespace;
     187         116 :     dopt->disable_triggers = ropt->disable_triggers;
     188         116 :     dopt->use_setsessauth = ropt->use_setsessauth;
     189         116 :     dopt->disable_dollar_quoting = ropt->disable_dollar_quoting;
     190         116 :     dopt->dump_inserts = ropt->dump_inserts;
     191         116 :     dopt->no_comments = ropt->no_comments;
     192         116 :     dopt->no_policies = ropt->no_policies;
     193         116 :     dopt->no_publications = ropt->no_publications;
     194         116 :     dopt->no_security_labels = ropt->no_security_labels;
     195         116 :     dopt->no_subscriptions = ropt->no_subscriptions;
     196         116 :     dopt->lockWaitTimeout = ropt->lockWaitTimeout;
     197         116 :     dopt->include_everything = ropt->include_everything;
     198         116 :     dopt->enable_row_security = ropt->enable_row_security;
     199         116 :     dopt->sequence_data = ropt->sequence_data;
     200         116 :     dopt->restrict_key = ropt->restrict_key ? pg_strdup(ropt->restrict_key) : NULL;
     201             : 
     202         116 :     return dopt;
     203             : }
     204             : 
     205             : 
     206             : /*
     207             :  *  Wrapper functions.
     208             :  *
     209             :  *  The objective is to make writing new formats and dumpers as simple
     210             :  *  as possible, if necessary at the expense of extra function calls etc.
     211             :  *
     212             :  */
     213             : 
     214             : /*
     215             :  * The dump worker setup needs lots of knowledge of the internals of pg_dump,
     216             :  * so it's defined in pg_dump.c and passed into OpenArchive. The restore worker
     217             :  * setup doesn't need to know anything much, so it's defined here.
     218             :  */
     219             : static void
     220          20 : setupRestoreWorker(Archive *AHX)
     221             : {
     222          20 :     ArchiveHandle *AH = (ArchiveHandle *) AHX;
     223             : 
     224          20 :     AH->ReopenPtr(AH);
     225          20 : }
     226             : 
     227             : 
     228             : /* Create a new archive */
     229             : /* Public */
     230             : Archive *
     231         404 : CreateArchive(const char *FileSpec, const ArchiveFormat fmt,
     232             :               const pg_compress_specification compression_spec,
     233             :               bool dosync, ArchiveMode mode,
     234             :               SetupWorkerPtrType setupDumpWorker,
     235             :               DataDirSyncMethod sync_method)
     236             : 
     237             : {
     238         404 :     ArchiveHandle *AH = _allocAH(FileSpec, fmt, compression_spec,
     239             :                                  dosync, mode, setupDumpWorker, sync_method);
     240             : 
     241         402 :     return (Archive *) AH;
     242             : }
     243             : 
     244             : /* Open an existing archive */
     245             : /* Public */
     246             : Archive *
     247         112 : OpenArchive(const char *FileSpec, const ArchiveFormat fmt)
     248             : {
     249             :     ArchiveHandle *AH;
     250         112 :     pg_compress_specification compression_spec = {0};
     251             : 
     252         112 :     compression_spec.algorithm = PG_COMPRESSION_NONE;
     253         112 :     AH = _allocAH(FileSpec, fmt, compression_spec, true,
     254             :                   archModeRead, setupRestoreWorker,
     255             :                   DATA_DIR_SYNC_METHOD_FSYNC);
     256             : 
     257         112 :     return (Archive *) AH;
     258             : }
     259             : 
     260             : /* Public */
     261             : void
     262         474 : CloseArchive(Archive *AHX)
     263             : {
     264         474 :     ArchiveHandle *AH = (ArchiveHandle *) AHX;
     265             : 
     266         474 :     AH->ClosePtr(AH);
     267             : 
     268             :     /* Close the output */
     269         474 :     errno = 0;
     270         474 :     if (!EndCompressFileHandle(AH->OF))
     271           0 :         pg_fatal("could not close output file: %m");
     272         474 : }
     273             : 
     274             : /* Public */
     275             : void
     276         886 : SetArchiveOptions(Archive *AH, DumpOptions *dopt, RestoreOptions *ropt)
     277             : {
     278             :     /* Caller can omit dump options, in which case we synthesize them */
     279         886 :     if (dopt == NULL && ropt != NULL)
     280         116 :         dopt = dumpOptionsFromRestoreOptions(ropt);
     281             : 
     282             :     /* Save options for later access */
     283         886 :     AH->dopt = dopt;
     284         886 :     AH->ropt = ropt;
     285         886 : }
     286             : 
     287             : /* Public */
     288             : void
     289         468 : ProcessArchiveRestoreOptions(Archive *AHX)
     290             : {
     291         468 :     ArchiveHandle *AH = (ArchiveHandle *) AHX;
     292         468 :     RestoreOptions *ropt = AH->public.ropt;
     293             :     TocEntry   *te;
     294             :     teSection   curSection;
     295             : 
     296             :     /* Decide which TOC entries will be dumped/restored, and mark them */
     297         468 :     curSection = SECTION_PRE_DATA;
     298       99536 :     for (te = AH->toc->next; te != AH->toc; te = te->next)
     299             :     {
     300             :         /*
     301             :          * When writing an archive, we also take this opportunity to check
     302             :          * that we have generated the entries in a sane order that respects
     303             :          * the section divisions.  When reading, don't complain, since buggy
     304             :          * old versions of pg_dump might generate out-of-order archives.
     305             :          */
     306       99068 :         if (AH->mode != archModeRead)
     307             :         {
     308       84596 :             switch (te->section)
     309             :             {
     310       17076 :                 case SECTION_NONE:
     311             :                     /* ok to be anywhere */
     312       17076 :                     break;
     313       39064 :                 case SECTION_PRE_DATA:
     314       39064 :                     if (curSection != SECTION_PRE_DATA)
     315           0 :                         pg_log_warning("archive items not in correct section order");
     316       39064 :                     break;
     317       14458 :                 case SECTION_DATA:
     318       14458 :                     if (curSection == SECTION_POST_DATA)
     319           0 :                         pg_log_warning("archive items not in correct section order");
     320       14458 :                     break;
     321       13998 :                 case SECTION_POST_DATA:
     322             :                     /* ok no matter which section we were in */
     323       13998 :                     break;
     324           0 :                 default:
     325           0 :                     pg_fatal("unexpected section code %d",
     326             :                              (int) te->section);
     327             :                     break;
     328             :             }
     329             :         }
     330             : 
     331       99068 :         if (te->section != SECTION_NONE)
     332       80402 :             curSection = te->section;
     333             : 
     334       99068 :         te->reqs = _tocEntryRequired(te, curSection, AH);
     335             :     }
     336             : 
     337             :     /* Enforce strict names checking */
     338         468 :     if (ropt->strict_names)
     339           0 :         StrictNamesCheck(ropt);
     340         468 : }
     341             : 
     342             : /* Public */
     343             : void
     344         366 : RestoreArchive(Archive *AHX)
     345             : {
     346         366 :     ArchiveHandle *AH = (ArchiveHandle *) AHX;
     347         366 :     RestoreOptions *ropt = AH->public.ropt;
     348             :     bool        parallel_mode;
     349             :     TocEntry   *te;
     350             :     CompressFileHandle *sav;
     351             : 
     352         366 :     AH->stage = STAGE_INITIALIZING;
     353             : 
     354             :     /*
     355             :      * If we're going to do parallel restore, there are some restrictions.
     356             :      */
     357         366 :     parallel_mode = (AH->public.numWorkers > 1 && ropt->useDB);
     358         366 :     if (parallel_mode)
     359             :     {
     360             :         /* We haven't got round to making this work for all archive formats */
     361           8 :         if (AH->ClonePtr == NULL || AH->ReopenPtr == NULL)
     362           0 :             pg_fatal("parallel restore is not supported with this archive file format");
     363             : 
     364             :         /* Doesn't work if the archive represents dependencies as OIDs */
     365           8 :         if (AH->version < K_VERS_1_8)
     366           0 :             pg_fatal("parallel restore is not supported with archives made by pre-8.0 pg_dump");
     367             : 
     368             :         /*
     369             :          * It's also not gonna work if we can't reopen the input file, so
     370             :          * let's try that immediately.
     371             :          */
     372           8 :         AH->ReopenPtr(AH);
     373             :     }
     374             : 
     375             :     /*
     376             :      * Make sure we won't need (de)compression we haven't got
     377             :      */
     378         366 :     if (AH->PrintTocDataPtr != NULL)
     379             :     {
     380       57822 :         for (te = AH->toc->next; te != AH->toc; te = te->next)
     381             :         {
     382       57710 :             if (te->hadDumper && (te->reqs & REQ_DATA) != 0)
     383             :             {
     384         254 :                 char       *errmsg = supports_compression(AH->compression_spec);
     385             : 
     386         254 :                 if (errmsg)
     387           0 :                     pg_fatal("cannot restore from compressed archive (%s)",
     388             :                              errmsg);
     389             :                 else
     390         254 :                     break;
     391             :             }
     392             :         }
     393             :     }
     394             : 
     395             :     /*
     396             :      * Prepare index arrays, so we can assume we have them throughout restore.
     397             :      * It's possible we already did this, though.
     398             :      */
     399         366 :     if (AH->tocsByDumpId == NULL)
     400         362 :         buildTocEntryArrays(AH);
     401             : 
     402             :     /*
     403             :      * If we're using a DB connection, then connect it.
     404             :      */
     405         366 :     if (ropt->useDB)
     406             :     {
     407          64 :         pg_log_info("connecting to database for restore");
     408          64 :         if (AH->version < K_VERS_1_3)
     409           0 :             pg_fatal("direct database connections are not supported in pre-1.3 archives");
     410             : 
     411             :         /*
     412             :          * We don't want to guess at whether the dump will successfully
     413             :          * restore; allow the attempt regardless of the version of the restore
     414             :          * target.
     415             :          */
     416          64 :         AHX->minRemoteVersion = 0;
     417          64 :         AHX->maxRemoteVersion = 9999999;
     418             : 
     419          64 :         ConnectDatabaseAhx(AHX, &ropt->cparams, false);
     420             : 
     421             :         /*
     422             :          * If we're talking to the DB directly, don't send comments since they
     423             :          * obscure SQL when displaying errors
     424             :          */
     425          64 :         AH->noTocComments = 1;
     426             :     }
     427             : 
     428             :     /*
     429             :      * Work out if we have an implied schema-less restore. This can happen if
     430             :      * the dump excluded the schema or the user has used a toc list to exclude
     431             :      * all of the schema data. All we do is look for schema entries - if none
     432             :      * are found then we unset the dumpSchema flag.
     433             :      *
     434             :      * We could scan for wanted TABLE entries, but that is not the same as
     435             :      * data-only. At this stage, it seems unnecessary (6-Mar-2001).
     436             :      */
     437         366 :     if (ropt->dumpSchema)
     438             :     {
     439         348 :         bool        no_schema_found = true;
     440             : 
     441        2906 :         for (te = AH->toc->next; te != AH->toc; te = te->next)
     442             :         {
     443        2862 :             if ((te->reqs & REQ_SCHEMA) != 0)
     444             :             {
     445         304 :                 no_schema_found = false;
     446         304 :                 break;
     447             :             }
     448             :         }
     449         348 :         if (no_schema_found)
     450             :         {
     451          44 :             ropt->dumpSchema = false;
     452          44 :             pg_log_info("implied no-schema restore");
     453             :         }
     454             :     }
     455             : 
     456             :     /*
     457             :      * Setup the output file if necessary.
     458             :      */
     459         366 :     sav = SaveOutput(AH);
     460         366 :     if (ropt->filename || ropt->compression_spec.algorithm != PG_COMPRESSION_NONE)
     461         278 :         SetOutput(AH, ropt->filename, ropt->compression_spec);
     462             : 
     463         366 :     ahprintf(AH, "--\n-- PostgreSQL database dump\n--\n\n");
     464             : 
     465             :     /*
     466             :      * If generating plain-text output, enter restricted mode to block any
     467             :      * unexpected psql meta-commands.  A malicious source might try to inject
     468             :      * a variety of things via bogus responses to queries.  While we cannot
     469             :      * prevent such sources from affecting the destination at restore time, we
     470             :      * can block psql meta-commands so that the client machine that runs psql
     471             :      * with the dump output remains unaffected.
     472             :      */
     473         366 :     if (ropt->restrict_key)
     474         298 :         ahprintf(AH, "\\restrict %s\n\n", ropt->restrict_key);
     475             : 
     476         366 :     if (AH->archiveRemoteVersion)
     477         366 :         ahprintf(AH, "-- Dumped from database version %s\n",
     478             :                  AH->archiveRemoteVersion);
     479         366 :     if (AH->archiveDumpVersion)
     480         366 :         ahprintf(AH, "-- Dumped by pg_dump version %s\n",
     481             :                  AH->archiveDumpVersion);
     482             : 
     483         366 :     ahprintf(AH, "\n");
     484             : 
     485         366 :     if (AH->public.verbose)
     486          78 :         dumpTimestamp(AH, "Started on", AH->createDate);
     487             : 
     488         366 :     if (ropt->single_txn)
     489             :     {
     490           0 :         if (AH->connection)
     491           0 :             StartTransaction(AHX);
     492             :         else
     493           0 :             ahprintf(AH, "BEGIN;\n\n");
     494             :     }
     495             : 
     496             :     /*
     497             :      * Establish important parameter values right away.
     498             :      */
     499         366 :     _doSetFixedOutputState(AH);
     500             : 
     501         366 :     AH->stage = STAGE_PROCESSING;
     502             : 
     503             :     /*
     504             :      * Drop the items at the start, in reverse order
     505             :      */
     506         366 :     if (ropt->dropSchema)
     507             :     {
     508        2856 :         for (te = AH->toc->prev; te != AH->toc; te = te->prev)
     509             :         {
     510        2810 :             AH->currentTE = te;
     511             : 
     512             :             /*
     513             :              * In createDB mode, issue a DROP *only* for the database as a
     514             :              * whole.  Issuing drops against anything else would be wrong,
     515             :              * because at this point we're connected to the wrong database.
     516             :              * (The DATABASE PROPERTIES entry, if any, should be treated like
     517             :              * the DATABASE entry.)
     518             :              */
     519        2810 :             if (ropt->createDB)
     520             :             {
     521        1200 :                 if (strcmp(te->desc, "DATABASE") != 0 &&
     522        1164 :                     strcmp(te->desc, "DATABASE PROPERTIES") != 0)
     523        1132 :                     continue;
     524             :             }
     525             : 
     526             :             /* Otherwise, drop anything that's selected and has a dropStmt */
     527        1678 :             if (((te->reqs & (REQ_SCHEMA | REQ_DATA)) != 0) && te->dropStmt)
     528             :             {
     529         680 :                 bool        not_allowed_in_txn = false;
     530             : 
     531         680 :                 pg_log_info("dropping %s %s", te->desc, te->tag);
     532             : 
     533             :                 /*
     534             :                  * In --transaction-size mode, we have to temporarily exit our
     535             :                  * transaction block to drop objects that can't be dropped
     536             :                  * within a transaction.
     537             :                  */
     538         680 :                 if (ropt->txn_size > 0)
     539             :                 {
     540          64 :                     if (strcmp(te->desc, "DATABASE") == 0 ||
     541          32 :                         strcmp(te->desc, "DATABASE PROPERTIES") == 0)
     542             :                     {
     543          64 :                         not_allowed_in_txn = true;
     544          64 :                         if (AH->connection)
     545          64 :                             CommitTransaction(AHX);
     546             :                         else
     547           0 :                             ahprintf(AH, "COMMIT;\n");
     548             :                     }
     549             :                 }
     550             : 
     551             :                 /* Select owner and schema as necessary */
     552         680 :                 _becomeOwner(AH, te);
     553         680 :                 _selectOutputSchema(AH, te->namespace);
     554             : 
     555             :                 /*
     556             :                  * Now emit the DROP command, if the object has one.  Note we
     557             :                  * don't necessarily emit it verbatim; at this point we add an
     558             :                  * appropriate IF EXISTS clause, if the user requested it.
     559             :                  */
     560         680 :                 if (strcmp(te->desc, "BLOB METADATA") == 0)
     561             :                 {
     562             :                     /* We must generate the per-blob commands */
     563           8 :                     if (ropt->if_exists)
     564           4 :                         IssueCommandPerBlob(AH, te,
     565             :                                             "SELECT pg_catalog.lo_unlink(oid) "
     566             :                                             "FROM pg_catalog.pg_largeobject_metadata "
     567             :                                             "WHERE oid = '", "'");
     568             :                     else
     569           4 :                         IssueCommandPerBlob(AH, te,
     570             :                                             "SELECT pg_catalog.lo_unlink('",
     571             :                                             "')");
     572             :                 }
     573         672 :                 else if (*te->dropStmt != '\0')
     574             :                 {
     575         624 :                     if (!ropt->if_exists ||
     576         286 :                         strncmp(te->dropStmt, "--", 2) == 0)
     577             :                     {
     578             :                         /*
     579             :                          * Without --if-exists, or if it's just a comment (as
     580             :                          * happens for the public schema), print the dropStmt
     581             :                          * as-is.
     582             :                          */
     583         340 :                         ahprintf(AH, "%s", te->dropStmt);
     584             :                     }
     585             :                     else
     586             :                     {
     587             :                         /*
     588             :                          * Inject an appropriate spelling of "if exists".  For
     589             :                          * old-style large objects, we have a routine that
     590             :                          * knows how to do it, without depending on
     591             :                          * te->dropStmt; use that.  For other objects we need
     592             :                          * to parse the command.
     593             :                          */
     594         284 :                         if (strcmp(te->desc, "BLOB") == 0)
     595             :                         {
     596           0 :                             DropLOIfExists(AH, te->catalogId.oid);
     597             :                         }
     598             :                         else
     599             :                         {
     600         284 :                             char       *dropStmt = pg_strdup(te->dropStmt);
     601         284 :                             char       *dropStmtOrig = dropStmt;
     602         284 :                             PQExpBuffer ftStmt = createPQExpBuffer();
     603             : 
     604             :                             /*
     605             :                              * Need to inject IF EXISTS clause after ALTER
     606             :                              * TABLE part in ALTER TABLE .. DROP statement
     607             :                              */
     608         284 :                             if (strncmp(dropStmt, "ALTER TABLE", 11) == 0)
     609             :                             {
     610          38 :                                 appendPQExpBufferStr(ftStmt,
     611             :                                                      "ALTER TABLE IF EXISTS");
     612          38 :                                 dropStmt = dropStmt + 11;
     613             :                             }
     614             : 
     615             :                             /*
     616             :                              * ALTER TABLE..ALTER COLUMN..DROP DEFAULT does
     617             :                              * not support the IF EXISTS clause, and therefore
     618             :                              * we simply emit the original command for DEFAULT
     619             :                              * objects (modulo the adjustment made above).
     620             :                              *
     621             :                              * Likewise, don't mess with DATABASE PROPERTIES.
     622             :                              *
     623             :                              * If we used CREATE OR REPLACE VIEW as a means of
     624             :                              * quasi-dropping an ON SELECT rule, that should
     625             :                              * be emitted unchanged as well.
     626             :                              *
     627             :                              * For other object types, we need to extract the
     628             :                              * first part of the DROP which includes the
     629             :                              * object type.  Most of the time this matches
     630             :                              * te->desc, so search for that; however for the
     631             :                              * different kinds of CONSTRAINTs, we know to
     632             :                              * search for hardcoded "DROP CONSTRAINT" instead.
     633             :                              */
     634         284 :                             if (strcmp(te->desc, "DEFAULT") == 0 ||
     635         278 :                                 strcmp(te->desc, "DATABASE PROPERTIES") == 0 ||
     636         278 :                                 strncmp(dropStmt, "CREATE OR REPLACE VIEW", 22) == 0)
     637           6 :                                 appendPQExpBufferStr(ftStmt, dropStmt);
     638             :                             else
     639             :                             {
     640             :                                 char        buffer[40];
     641             :                                 char       *mark;
     642             : 
     643         278 :                                 if (strcmp(te->desc, "CONSTRAINT") == 0 ||
     644         250 :                                     strcmp(te->desc, "CHECK CONSTRAINT") == 0 ||
     645         250 :                                     strcmp(te->desc, "FK CONSTRAINT") == 0)
     646          32 :                                     strcpy(buffer, "DROP CONSTRAINT");
     647             :                                 else
     648         246 :                                     snprintf(buffer, sizeof(buffer), "DROP %s",
     649             :                                              te->desc);
     650             : 
     651         278 :                                 mark = strstr(dropStmt, buffer);
     652             : 
     653         278 :                                 if (mark)
     654             :                                 {
     655         278 :                                     *mark = '\0';
     656         278 :                                     appendPQExpBuffer(ftStmt, "%s%s IF EXISTS%s",
     657             :                                                       dropStmt, buffer,
     658         278 :                                                       mark + strlen(buffer));
     659             :                                 }
     660             :                                 else
     661             :                                 {
     662             :                                     /* complain and emit unmodified command */
     663           0 :                                     pg_log_warning("could not find where to insert IF EXISTS in statement \"%s\"",
     664             :                                                    dropStmtOrig);
     665           0 :                                     appendPQExpBufferStr(ftStmt, dropStmt);
     666             :                                 }
     667             :                             }
     668             : 
     669         284 :                             ahprintf(AH, "%s", ftStmt->data);
     670             : 
     671         284 :                             destroyPQExpBuffer(ftStmt);
     672         284 :                             pg_free(dropStmtOrig);
     673             :                         }
     674             :                     }
     675             :                 }
     676             : 
     677             :                 /*
     678             :                  * In --transaction-size mode, re-establish the transaction
     679             :                  * block if needed; otherwise, commit after every N drops.
     680             :                  */
     681         680 :                 if (ropt->txn_size > 0)
     682             :                 {
     683          64 :                     if (not_allowed_in_txn)
     684             :                     {
     685          64 :                         if (AH->connection)
     686          64 :                             StartTransaction(AHX);
     687             :                         else
     688           0 :                             ahprintf(AH, "BEGIN;\n");
     689          64 :                         AH->txnCount = 0;
     690             :                     }
     691           0 :                     else if (++AH->txnCount >= ropt->txn_size)
     692             :                     {
     693           0 :                         if (AH->connection)
     694             :                         {
     695           0 :                             CommitTransaction(AHX);
     696           0 :                             StartTransaction(AHX);
     697             :                         }
     698             :                         else
     699           0 :                             ahprintf(AH, "COMMIT;\nBEGIN;\n");
     700           0 :                         AH->txnCount = 0;
     701             :                     }
     702             :                 }
     703             :             }
     704             :         }
     705             : 
     706             :         /*
     707             :          * _selectOutputSchema may have set currSchema to reflect the effect
     708             :          * of a "SET search_path" command it emitted.  However, by now we may
     709             :          * have dropped that schema; or it might not have existed in the first
     710             :          * place.  In either case the effective value of search_path will not
     711             :          * be what we think.  Forcibly reset currSchema so that we will
     712             :          * re-establish the search_path setting when needed (after creating
     713             :          * the schema).
     714             :          *
     715             :          * If we treated users as pg_dump'able objects then we'd need to reset
     716             :          * currUser here too.
     717             :          */
     718          46 :         free(AH->currSchema);
     719          46 :         AH->currSchema = NULL;
     720             :     }
     721             : 
     722         366 :     if (parallel_mode)
     723             :     {
     724             :         /*
     725             :          * In parallel mode, turn control over to the parallel-restore logic.
     726             :          */
     727             :         ParallelState *pstate;
     728             :         TocEntry    pending_list;
     729             : 
     730             :         /* The archive format module may need some setup for this */
     731           8 :         if (AH->PrepParallelRestorePtr)
     732           8 :             AH->PrepParallelRestorePtr(AH);
     733             : 
     734           8 :         pending_list_header_init(&pending_list);
     735             : 
     736             :         /* This runs PRE_DATA items and then disconnects from the database */
     737           8 :         restore_toc_entries_prefork(AH, &pending_list);
     738             :         Assert(AH->connection == NULL);
     739             : 
     740             :         /* ParallelBackupStart() will actually fork the processes */
     741           8 :         pstate = ParallelBackupStart(AH);
     742           8 :         restore_toc_entries_parallel(AH, pstate, &pending_list);
     743           8 :         ParallelBackupEnd(AH, pstate);
     744             : 
     745             :         /* reconnect the leader and see if we missed something */
     746           8 :         restore_toc_entries_postfork(AH, &pending_list);
     747             :         Assert(AH->connection != NULL);
     748             :     }
     749             :     else
     750             :     {
     751             :         /*
     752             :          * In serial mode, process everything in three phases: normal items,
     753             :          * then ACLs, then post-ACL items.  We might be able to skip one or
     754             :          * both extra phases in some cases, eg data-only restores.
     755             :          */
     756         358 :         bool        haveACL = false;
     757         358 :         bool        havePostACL = false;
     758             : 
     759       85628 :         for (te = AH->toc->next; te != AH->toc; te = te->next)
     760             :         {
     761       85272 :             if ((te->reqs & (REQ_SCHEMA | REQ_DATA | REQ_STATS)) == 0)
     762        2980 :                 continue;       /* ignore if not to be dumped at all */
     763             : 
     764       82292 :             switch (_tocEntryRestorePass(te))
     765             :             {
     766       75090 :                 case RESTORE_PASS_MAIN:
     767       75090 :                     (void) restore_toc_entry(AH, te, false);
     768       75088 :                     break;
     769        4036 :                 case RESTORE_PASS_ACL:
     770        4036 :                     haveACL = true;
     771        4036 :                     break;
     772        3166 :                 case RESTORE_PASS_POST_ACL:
     773        3166 :                     havePostACL = true;
     774        3166 :                     break;
     775             :             }
     776             :         }
     777             : 
     778         356 :         if (haveACL)
     779             :         {
     780       82692 :             for (te = AH->toc->next; te != AH->toc; te = te->next)
     781             :             {
     782      162948 :                 if ((te->reqs & (REQ_SCHEMA | REQ_DATA | REQ_STATS)) != 0 &&
     783       80412 :                     _tocEntryRestorePass(te) == RESTORE_PASS_ACL)
     784        4036 :                     (void) restore_toc_entry(AH, te, false);
     785             :             }
     786             :         }
     787             : 
     788         356 :         if (havePostACL)
     789             :         {
     790       54208 :             for (te = AH->toc->next; te != AH->toc; te = te->next)
     791             :             {
     792      107348 :                 if ((te->reqs & (REQ_SCHEMA | REQ_DATA | REQ_STATS)) != 0 &&
     793       53234 :                     _tocEntryRestorePass(te) == RESTORE_PASS_POST_ACL)
     794        3166 :                     (void) restore_toc_entry(AH, te, false);
     795             :             }
     796             :         }
     797             :     }
     798             : 
     799             :     /*
     800             :      * Close out any persistent transaction we may have.  While these two
     801             :      * cases are started in different places, we can end both cases here.
     802             :      */
     803         364 :     if (ropt->single_txn || ropt->txn_size > 0)
     804             :     {
     805          56 :         if (AH->connection)
     806          56 :             CommitTransaction(AHX);
     807             :         else
     808           0 :             ahprintf(AH, "COMMIT;\n\n");
     809             :     }
     810             : 
     811         364 :     if (AH->public.verbose)
     812          78 :         dumpTimestamp(AH, "Completed on", time(NULL));
     813             : 
     814         364 :     ahprintf(AH, "--\n-- PostgreSQL database dump complete\n--\n\n");
     815             : 
     816             :     /*
     817             :      * If generating plain-text output, exit restricted mode at the very end
     818             :      * of the script. This is not pro forma; in particular, pg_dumpall
     819             :      * requires this when transitioning from one database to another.
     820             :      */
     821         364 :     if (ropt->restrict_key)
     822         296 :         ahprintf(AH, "\\unrestrict %s\n\n", ropt->restrict_key);
     823             : 
     824             :     /*
     825             :      * Clean up & we're done.
     826             :      */
     827         364 :     AH->stage = STAGE_FINALIZING;
     828             : 
     829         364 :     if (ropt->filename || ropt->compression_spec.algorithm != PG_COMPRESSION_NONE)
     830         278 :         RestoreOutput(AH, sav);
     831             : 
     832         364 :     if (ropt->useDB)
     833          64 :         DisconnectDatabase(&AH->public);
     834         364 : }
     835             : 
     836             : /*
     837             :  * Restore a single TOC item.  Used in both parallel and non-parallel restore;
     838             :  * is_parallel is true if we are in a worker child process.
     839             :  *
     840             :  * Returns 0 normally, but WORKER_CREATE_DONE or WORKER_INHIBIT_DATA if
     841             :  * the parallel parent has to make the corresponding status update.
     842             :  */
     843             : static int
     844       82484 : restore_toc_entry(ArchiveHandle *AH, TocEntry *te, bool is_parallel)
     845             : {
     846       82484 :     RestoreOptions *ropt = AH->public.ropt;
     847       82484 :     int         status = WORKER_OK;
     848             :     int         reqs;
     849             :     bool        defnDumped;
     850             : 
     851       82484 :     AH->currentTE = te;
     852             : 
     853             :     /* Dump any relevant dump warnings to stderr */
     854       82484 :     if (!ropt->suppressDumpWarnings && strcmp(te->desc, "WARNING") == 0)
     855             :     {
     856           0 :         if (ropt->dumpSchema && te->defn != NULL && strlen(te->defn) != 0)
     857           0 :             pg_log_warning("warning from original dump file: %s", te->defn);
     858           0 :         else if (te->copyStmt != NULL && strlen(te->copyStmt) != 0)
     859           0 :             pg_log_warning("warning from original dump file: %s", te->copyStmt);
     860             :     }
     861             : 
     862             :     /* Work out what, if anything, we want from this entry */
     863       82484 :     reqs = te->reqs;
     864             : 
     865       82484 :     defnDumped = false;
     866             : 
     867             :     /*
     868             :      * If it has a schema component that we want, then process that
     869             :      */
     870       82484 :     if ((reqs & REQ_SCHEMA) != 0)
     871             :     {
     872       65564 :         bool        object_is_db = false;
     873             : 
     874             :         /*
     875             :          * In --transaction-size mode, must exit our transaction block to
     876             :          * create a database or set its properties.
     877             :          */
     878       65564 :         if (strcmp(te->desc, "DATABASE") == 0 ||
     879       65444 :             strcmp(te->desc, "DATABASE PROPERTIES") == 0)
     880             :         {
     881         184 :             object_is_db = true;
     882         184 :             if (ropt->txn_size > 0)
     883             :             {
     884         112 :                 if (AH->connection)
     885         112 :                     CommitTransaction(&AH->public);
     886             :                 else
     887           0 :                     ahprintf(AH, "COMMIT;\n\n");
     888             :             }
     889             :         }
     890             : 
     891             :         /* Show namespace in log message if available */
     892       65564 :         if (te->namespace)
     893       62764 :             pg_log_info("creating %s \"%s.%s\"",
     894             :                         te->desc, te->namespace, te->tag);
     895             :         else
     896        2800 :             pg_log_info("creating %s \"%s\"",
     897             :                         te->desc, te->tag);
     898             : 
     899       65564 :         _printTocEntry(AH, te, TOC_PREFIX_NONE);
     900       65564 :         defnDumped = true;
     901             : 
     902       65564 :         if (strcmp(te->desc, "TABLE") == 0)
     903             :         {
     904       10840 :             if (AH->lastErrorTE == te)
     905             :             {
     906             :                 /*
     907             :                  * We failed to create the table. If
     908             :                  * --no-data-for-failed-tables was given, mark the
     909             :                  * corresponding TABLE DATA to be ignored.
     910             :                  *
     911             :                  * In the parallel case this must be done in the parent, so we
     912             :                  * just set the return value.
     913             :                  */
     914           0 :                 if (ropt->noDataForFailedTables)
     915             :                 {
     916           0 :                     if (is_parallel)
     917           0 :                         status = WORKER_INHIBIT_DATA;
     918             :                     else
     919           0 :                         inhibit_data_for_failed_table(AH, te);
     920             :                 }
     921             :             }
     922             :             else
     923             :             {
     924             :                 /*
     925             :                  * We created the table successfully.  Mark the corresponding
     926             :                  * TABLE DATA for possible truncation.
     927             :                  *
     928             :                  * In the parallel case this must be done in the parent, so we
     929             :                  * just set the return value.
     930             :                  */
     931       10840 :                 if (is_parallel)
     932           0 :                     status = WORKER_CREATE_DONE;
     933             :                 else
     934       10840 :                     mark_create_done(AH, te);
     935             :             }
     936             :         }
     937             : 
     938             :         /*
     939             :          * If we created a DB, connect to it.  Also, if we changed DB
     940             :          * properties, reconnect to ensure that relevant GUC settings are
     941             :          * applied to our session.  (That also restarts the transaction block
     942             :          * in --transaction-size mode.)
     943             :          */
     944       65564 :         if (object_is_db)
     945             :         {
     946         184 :             pg_log_info("connecting to new database \"%s\"", te->tag);
     947         184 :             _reconnectToDB(AH, te->tag);
     948             :         }
     949             :     }
     950             : 
     951             :     /*
     952             :      * If it has a data component that we want, then process that
     953             :      */
     954       82484 :     if ((reqs & REQ_DATA) != 0)
     955             :     {
     956             :         /*
     957             :          * hadDumper will be set if there is genuine data component for this
     958             :          * node. Otherwise, we need to check the defn field for statements
     959             :          * that need to be executed in data-only restores.
     960             :          */
     961        9890 :         if (te->hadDumper)
     962             :         {
     963             :             /*
     964             :              * If we can output the data, then restore it.
     965             :              */
     966        8790 :             if (AH->PrintTocDataPtr != NULL)
     967             :             {
     968        8790 :                 _printTocEntry(AH, te, TOC_PREFIX_DATA);
     969             : 
     970        8790 :                 if (strcmp(te->desc, "BLOBS") == 0 ||
     971        8642 :                     strcmp(te->desc, "BLOB COMMENTS") == 0)
     972             :                 {
     973         148 :                     pg_log_info("processing %s", te->desc);
     974             : 
     975         148 :                     _selectOutputSchema(AH, "pg_catalog");
     976             : 
     977             :                     /* Send BLOB COMMENTS data to ExecuteSimpleCommands() */
     978         148 :                     if (strcmp(te->desc, "BLOB COMMENTS") == 0)
     979           0 :                         AH->outputKind = OUTPUT_OTHERDATA;
     980             : 
     981         148 :                     AH->PrintTocDataPtr(AH, te);
     982             : 
     983         148 :                     AH->outputKind = OUTPUT_SQLCMDS;
     984             :                 }
     985             :                 else
     986             :                 {
     987             :                     bool        use_truncate;
     988             : 
     989        8642 :                     _disableTriggersIfNecessary(AH, te);
     990             : 
     991             :                     /* Select owner and schema as necessary */
     992        8642 :                     _becomeOwner(AH, te);
     993        8642 :                     _selectOutputSchema(AH, te->namespace);
     994             : 
     995        8642 :                     pg_log_info("processing data for table \"%s.%s\"",
     996             :                                 te->namespace, te->tag);
     997             : 
     998             :                     /*
     999             :                      * In parallel restore, if we created the table earlier in
    1000             :                      * this run (so that we know it is empty) and we are not
    1001             :                      * restoring a load-via-partition-root data item then we
    1002             :                      * wrap the COPY in a transaction and precede it with a
    1003             :                      * TRUNCATE.  If wal_level is set to minimal this prevents
    1004             :                      * WAL-logging the COPY.  This obtains a speedup similar
    1005             :                      * to that from using single_txn mode in non-parallel
    1006             :                      * restores.
    1007             :                      *
    1008             :                      * We mustn't do this for load-via-partition-root cases
    1009             :                      * because some data might get moved across partition
    1010             :                      * boundaries, risking deadlock and/or loss of previously
    1011             :                      * loaded data.  (We assume that all partitions of a
    1012             :                      * partitioned table will be treated the same way.)
    1013             :                      */
    1014        8674 :                     use_truncate = is_parallel && te->created &&
    1015          32 :                         !is_load_via_partition_root(te);
    1016             : 
    1017        8642 :                     if (use_truncate)
    1018             :                     {
    1019             :                         /*
    1020             :                          * Parallel restore is always talking directly to a
    1021             :                          * server, so no need to see if we should issue BEGIN.
    1022             :                          */
    1023          20 :                         StartTransaction(&AH->public);
    1024             : 
    1025             :                         /*
    1026             :                          * Issue TRUNCATE with ONLY so that child tables are
    1027             :                          * not wiped.
    1028             :                          */
    1029          20 :                         ahprintf(AH, "TRUNCATE TABLE ONLY %s;\n\n",
    1030          20 :                                  fmtQualifiedId(te->namespace, te->tag));
    1031             :                     }
    1032             : 
    1033             :                     /*
    1034             :                      * If we have a copy statement, use it.
    1035             :                      */
    1036        8642 :                     if (te->copyStmt && strlen(te->copyStmt) > 0)
    1037             :                     {
    1038        8472 :                         ahprintf(AH, "%s", te->copyStmt);
    1039        8472 :                         AH->outputKind = OUTPUT_COPYDATA;
    1040             :                     }
    1041             :                     else
    1042         170 :                         AH->outputKind = OUTPUT_OTHERDATA;
    1043             : 
    1044        8642 :                     AH->PrintTocDataPtr(AH, te);
    1045             : 
    1046             :                     /*
    1047             :                      * Terminate COPY if needed.
    1048             :                      */
    1049       17110 :                     if (AH->outputKind == OUTPUT_COPYDATA &&
    1050        8470 :                         RestoringToDB(AH))
    1051         130 :                         EndDBCopyMode(&AH->public, te->tag);
    1052        8640 :                     AH->outputKind = OUTPUT_SQLCMDS;
    1053             : 
    1054             :                     /* close out the transaction started above */
    1055        8640 :                     if (use_truncate)
    1056          20 :                         CommitTransaction(&AH->public);
    1057             : 
    1058        8640 :                     _enableTriggersIfNecessary(AH, te);
    1059             :                 }
    1060             :             }
    1061             :         }
    1062        1100 :         else if (!defnDumped)
    1063             :         {
    1064             :             /* If we haven't already dumped the defn part, do so now */
    1065        1100 :             pg_log_info("executing %s %s", te->desc, te->tag);
    1066        1100 :             _printTocEntry(AH, te, TOC_PREFIX_NONE);
    1067             :         }
    1068             :     }
    1069             : 
    1070             :     /*
    1071             :      * If it has a statistics component that we want, then process that
    1072             :      */
    1073       82482 :     if ((reqs & REQ_STATS) != 0)
    1074        7000 :         _printTocEntry(AH, te, TOC_PREFIX_STATS);
    1075             : 
    1076             :     /*
    1077             :      * If we emitted anything for this TOC entry, that counts as one action
    1078             :      * against the transaction-size limit.  Commit if it's time to.
    1079             :      */
    1080       82482 :     if ((reqs & (REQ_SCHEMA | REQ_DATA | REQ_STATS)) != 0 && ropt->txn_size > 0)
    1081             :     {
    1082        6726 :         if (++AH->txnCount >= ropt->txn_size)
    1083             :         {
    1084          20 :             if (AH->connection)
    1085             :             {
    1086          20 :                 CommitTransaction(&AH->public);
    1087          20 :                 StartTransaction(&AH->public);
    1088             :             }
    1089             :             else
    1090           0 :                 ahprintf(AH, "COMMIT;\nBEGIN;\n\n");
    1091          20 :             AH->txnCount = 0;
    1092             :         }
    1093             :     }
    1094             : 
    1095       82482 :     if (AH->public.n_errors > 0 && status == WORKER_OK)
    1096           0 :         status = WORKER_IGNORED_ERRORS;
    1097             : 
    1098       82482 :     return status;
    1099             : }
    1100             : 
    1101             : /*
    1102             :  * Allocate a new RestoreOptions block.
    1103             :  * This is mainly so we can initialize it, but also for future expansion,
    1104             :  */
    1105             : RestoreOptions *
    1106         548 : NewRestoreOptions(void)
    1107             : {
    1108             :     RestoreOptions *opts;
    1109             : 
    1110         548 :     opts = (RestoreOptions *) pg_malloc0(sizeof(RestoreOptions));
    1111             : 
    1112             :     /* set any fields that shouldn't default to zeroes */
    1113         548 :     opts->format = archUnknown;
    1114         548 :     opts->cparams.promptPassword = TRI_DEFAULT;
    1115         548 :     opts->dumpSections = DUMP_UNSECTIONED;
    1116         548 :     opts->compression_spec.algorithm = PG_COMPRESSION_NONE;
    1117         548 :     opts->compression_spec.level = 0;
    1118         548 :     opts->dumpSchema = true;
    1119         548 :     opts->dumpData = true;
    1120         548 :     opts->dumpStatistics = true;
    1121             : 
    1122         548 :     return opts;
    1123             : }
    1124             : 
    1125             : static void
    1126        8642 : _disableTriggersIfNecessary(ArchiveHandle *AH, TocEntry *te)
    1127             : {
    1128        8642 :     RestoreOptions *ropt = AH->public.ropt;
    1129             : 
    1130             :     /* This hack is only needed in a data-only restore */
    1131        8642 :     if (ropt->dumpSchema || !ropt->disable_triggers)
    1132        8566 :         return;
    1133             : 
    1134          76 :     pg_log_info("disabling triggers for %s", te->tag);
    1135             : 
    1136             :     /*
    1137             :      * Become superuser if possible, since they are the only ones who can
    1138             :      * disable constraint triggers.  If -S was not given, assume the initial
    1139             :      * user identity is a superuser.  (XXX would it be better to become the
    1140             :      * table owner?)
    1141             :      */
    1142          76 :     _becomeUser(AH, ropt->superuser);
    1143             : 
    1144             :     /*
    1145             :      * Disable them.
    1146             :      */
    1147          76 :     ahprintf(AH, "ALTER TABLE %s DISABLE TRIGGER ALL;\n\n",
    1148          76 :              fmtQualifiedId(te->namespace, te->tag));
    1149             : }
    1150             : 
    1151             : static void
    1152        8640 : _enableTriggersIfNecessary(ArchiveHandle *AH, TocEntry *te)
    1153             : {
    1154        8640 :     RestoreOptions *ropt = AH->public.ropt;
    1155             : 
    1156             :     /* This hack is only needed in a data-only restore */
    1157        8640 :     if (ropt->dumpSchema || !ropt->disable_triggers)
    1158        8564 :         return;
    1159             : 
    1160          76 :     pg_log_info("enabling triggers for %s", te->tag);
    1161             : 
    1162             :     /*
    1163             :      * Become superuser if possible, since they are the only ones who can
    1164             :      * disable constraint triggers.  If -S was not given, assume the initial
    1165             :      * user identity is a superuser.  (XXX would it be better to become the
    1166             :      * table owner?)
    1167             :      */
    1168          76 :     _becomeUser(AH, ropt->superuser);
    1169             : 
    1170             :     /*
    1171             :      * Enable them.
    1172             :      */
    1173          76 :     ahprintf(AH, "ALTER TABLE %s ENABLE TRIGGER ALL;\n\n",
    1174          76 :              fmtQualifiedId(te->namespace, te->tag));
    1175             : }
    1176             : 
    1177             : /*
    1178             :  * Detect whether a TABLE DATA TOC item is performing "load via partition
    1179             :  * root", that is the target table is an ancestor partition rather than the
    1180             :  * table the TOC item is nominally for.
    1181             :  *
    1182             :  * In newer archive files this can be detected by checking for a special
    1183             :  * comment placed in te->defn.  In older files we have to fall back to seeing
    1184             :  * if the COPY statement targets the named table or some other one.  This
    1185             :  * will not work for data dumped as INSERT commands, so we could give a false
    1186             :  * negative in that case; fortunately, that's a rarely-used option.
    1187             :  */
    1188             : static bool
    1189          32 : is_load_via_partition_root(TocEntry *te)
    1190             : {
    1191          32 :     if (te->defn &&
    1192          12 :         strncmp(te->defn, "-- load via partition root ", 27) == 0)
    1193          12 :         return true;
    1194          20 :     if (te->copyStmt && *te->copyStmt)
    1195             :     {
    1196          12 :         PQExpBuffer copyStmt = createPQExpBuffer();
    1197             :         bool        result;
    1198             : 
    1199             :         /*
    1200             :          * Build the initial part of the COPY as it would appear if the
    1201             :          * nominal target table is the actual target.  If we see anything
    1202             :          * else, it must be a load-via-partition-root case.
    1203             :          */
    1204          12 :         appendPQExpBuffer(copyStmt, "COPY %s ",
    1205          12 :                           fmtQualifiedId(te->namespace, te->tag));
    1206          12 :         result = strncmp(te->copyStmt, copyStmt->data, copyStmt->len) != 0;
    1207          12 :         destroyPQExpBuffer(copyStmt);
    1208          12 :         return result;
    1209             :     }
    1210             :     /* Assume it's not load-via-partition-root */
    1211           8 :     return false;
    1212             : }
    1213             : 
    1214             : /*
    1215             :  * This is a routine that is part of the dumper interface, hence the 'Archive*' parameter.
    1216             :  */
    1217             : 
    1218             : /* Public */
    1219             : void
    1220     3667258 : WriteData(Archive *AHX, const void *data, size_t dLen)
    1221             : {
    1222     3667258 :     ArchiveHandle *AH = (ArchiveHandle *) AHX;
    1223             : 
    1224     3667258 :     if (!AH->currToc)
    1225           0 :         pg_fatal("internal error -- WriteData cannot be called outside the context of a DataDumper routine");
    1226             : 
    1227     3667258 :     AH->WriteDataPtr(AH, data, dLen);
    1228     3667258 : }
    1229             : 
    1230             : /*
    1231             :  * Create a new TOC entry. The TOC was designed as a TOC, but is now the
    1232             :  * repository for all metadata. But the name has stuck.
    1233             :  *
    1234             :  * The new entry is added to the Archive's TOC list.  Most callers can ignore
    1235             :  * the result value because nothing else need be done, but a few want to
    1236             :  * manipulate the TOC entry further.
    1237             :  */
    1238             : 
    1239             : /* Public */
    1240             : TocEntry *
    1241       84596 : ArchiveEntry(Archive *AHX, CatalogId catalogId, DumpId dumpId,
    1242             :              ArchiveOpts *opts)
    1243             : {
    1244       84596 :     ArchiveHandle *AH = (ArchiveHandle *) AHX;
    1245             :     TocEntry   *newToc;
    1246             : 
    1247       84596 :     newToc = (TocEntry *) pg_malloc0(sizeof(TocEntry));
    1248             : 
    1249       84596 :     AH->tocCount++;
    1250       84596 :     if (dumpId > AH->maxDumpId)
    1251       26786 :         AH->maxDumpId = dumpId;
    1252             : 
    1253       84596 :     newToc->prev = AH->toc->prev;
    1254       84596 :     newToc->next = AH->toc;
    1255       84596 :     AH->toc->prev->next = newToc;
    1256       84596 :     AH->toc->prev = newToc;
    1257             : 
    1258       84596 :     newToc->catalogId = catalogId;
    1259       84596 :     newToc->dumpId = dumpId;
    1260       84596 :     newToc->section = opts->section;
    1261             : 
    1262       84596 :     newToc->tag = pg_strdup(opts->tag);
    1263       84596 :     newToc->namespace = opts->namespace ? pg_strdup(opts->namespace) : NULL;
    1264       84596 :     newToc->tablespace = opts->tablespace ? pg_strdup(opts->tablespace) : NULL;
    1265       84596 :     newToc->tableam = opts->tableam ? pg_strdup(opts->tableam) : NULL;
    1266       84596 :     newToc->relkind = opts->relkind;
    1267       84596 :     newToc->owner = opts->owner ? pg_strdup(opts->owner) : NULL;
    1268       84596 :     newToc->desc = pg_strdup(opts->description);
    1269       84596 :     newToc->defn = opts->createStmt ? pg_strdup(opts->createStmt) : NULL;
    1270       84596 :     newToc->dropStmt = opts->dropStmt ? pg_strdup(opts->dropStmt) : NULL;
    1271       84596 :     newToc->copyStmt = opts->copyStmt ? pg_strdup(opts->copyStmt) : NULL;
    1272             : 
    1273       84596 :     if (opts->nDeps > 0)
    1274             :     {
    1275       34990 :         newToc->dependencies = (DumpId *) pg_malloc(opts->nDeps * sizeof(DumpId));
    1276       34990 :         memcpy(newToc->dependencies, opts->deps, opts->nDeps * sizeof(DumpId));
    1277       34990 :         newToc->nDeps = opts->nDeps;
    1278             :     }
    1279             :     else
    1280             :     {
    1281       49606 :         newToc->dependencies = NULL;
    1282       49606 :         newToc->nDeps = 0;
    1283             :     }
    1284             : 
    1285       84596 :     newToc->dataDumper = opts->dumpFn;
    1286       84596 :     newToc->dataDumperArg = opts->dumpArg;
    1287       84596 :     newToc->hadDumper = opts->dumpFn ? true : false;
    1288             : 
    1289       84596 :     newToc->defnDumper = opts->defnFn;
    1290       84596 :     newToc->defnDumperArg = opts->defnArg;
    1291             : 
    1292       84596 :     newToc->formatData = NULL;
    1293       84596 :     newToc->dataLength = 0;
    1294             : 
    1295       84596 :     if (AH->ArchiveEntryPtr != NULL)
    1296       14414 :         AH->ArchiveEntryPtr(AH, newToc);
    1297             : 
    1298       84596 :     return newToc;
    1299             : }
    1300             : 
    1301             : /* Public */
    1302             : void
    1303           8 : PrintTOCSummary(Archive *AHX)
    1304             : {
    1305           8 :     ArchiveHandle *AH = (ArchiveHandle *) AHX;
    1306           8 :     RestoreOptions *ropt = AH->public.ropt;
    1307             :     TocEntry   *te;
    1308           8 :     pg_compress_specification out_compression_spec = {0};
    1309             :     teSection   curSection;
    1310             :     CompressFileHandle *sav;
    1311             :     const char *fmtName;
    1312             :     char        stamp_str[64];
    1313             : 
    1314             :     /* TOC is always uncompressed */
    1315           8 :     out_compression_spec.algorithm = PG_COMPRESSION_NONE;
    1316             : 
    1317           8 :     sav = SaveOutput(AH);
    1318           8 :     if (ropt->filename)
    1319           0 :         SetOutput(AH, ropt->filename, out_compression_spec);
    1320             : 
    1321           8 :     if (strftime(stamp_str, sizeof(stamp_str), PGDUMP_STRFTIME_FMT,
    1322           8 :                  localtime(&AH->createDate)) == 0)
    1323           0 :         strcpy(stamp_str, "[unknown]");
    1324             : 
    1325           8 :     ahprintf(AH, ";\n; Archive created at %s\n", stamp_str);
    1326          16 :     ahprintf(AH, ";     dbname: %s\n;     TOC Entries: %d\n;     Compression: %s\n",
    1327           8 :              sanitize_line(AH->archdbname, false),
    1328             :              AH->tocCount,
    1329             :              get_compress_algorithm_name(AH->compression_spec.algorithm));
    1330             : 
    1331           8 :     switch (AH->format)
    1332             :     {
    1333           6 :         case archCustom:
    1334           6 :             fmtName = "CUSTOM";
    1335           6 :             break;
    1336           2 :         case archDirectory:
    1337           2 :             fmtName = "DIRECTORY";
    1338           2 :             break;
    1339           0 :         case archTar:
    1340           0 :             fmtName = "TAR";
    1341           0 :             break;
    1342           0 :         default:
    1343           0 :             fmtName = "UNKNOWN";
    1344             :     }
    1345             : 
    1346           8 :     ahprintf(AH, ";     Dump Version: %d.%d-%d\n",
    1347           8 :              ARCHIVE_MAJOR(AH->version), ARCHIVE_MINOR(AH->version), ARCHIVE_REV(AH->version));
    1348           8 :     ahprintf(AH, ";     Format: %s\n", fmtName);
    1349           8 :     ahprintf(AH, ";     Integer: %d bytes\n", (int) AH->intSize);
    1350           8 :     ahprintf(AH, ";     Offset: %d bytes\n", (int) AH->offSize);
    1351           8 :     if (AH->archiveRemoteVersion)
    1352           8 :         ahprintf(AH, ";     Dumped from database version: %s\n",
    1353             :                  AH->archiveRemoteVersion);
    1354           8 :     if (AH->archiveDumpVersion)
    1355           8 :         ahprintf(AH, ";     Dumped by pg_dump version: %s\n",
    1356             :                  AH->archiveDumpVersion);
    1357             : 
    1358           8 :     ahprintf(AH, ";\n;\n; Selected TOC Entries:\n;\n");
    1359             : 
    1360           8 :     curSection = SECTION_PRE_DATA;
    1361        3080 :     for (te = AH->toc->next; te != AH->toc; te = te->next)
    1362             :     {
    1363             :         /* This bit must match ProcessArchiveRestoreOptions' marking logic */
    1364        3072 :         if (te->section != SECTION_NONE)
    1365        2472 :             curSection = te->section;
    1366        3072 :         te->reqs = _tocEntryRequired(te, curSection, AH);
    1367             :         /* Now, should we print it? */
    1368        3072 :         if (ropt->verbose ||
    1369        3072 :             (te->reqs & (REQ_SCHEMA | REQ_DATA | REQ_STATS)) != 0)
    1370             :         {
    1371             :             char       *sanitized_name;
    1372             :             char       *sanitized_schema;
    1373             :             char       *sanitized_owner;
    1374             : 
    1375             :             /*
    1376             :              */
    1377        3032 :             sanitized_name = sanitize_line(te->tag, false);
    1378        3032 :             sanitized_schema = sanitize_line(te->namespace, true);
    1379        3032 :             sanitized_owner = sanitize_line(te->owner, false);
    1380             : 
    1381        3032 :             ahprintf(AH, "%d; %u %u %s %s %s %s\n", te->dumpId,
    1382             :                      te->catalogId.tableoid, te->catalogId.oid,
    1383             :                      te->desc, sanitized_schema, sanitized_name,
    1384             :                      sanitized_owner);
    1385             : 
    1386        3032 :             free(sanitized_name);
    1387        3032 :             free(sanitized_schema);
    1388        3032 :             free(sanitized_owner);
    1389             :         }
    1390        3072 :         if (ropt->verbose && te->nDeps > 0)
    1391             :         {
    1392             :             int         i;
    1393             : 
    1394           0 :             ahprintf(AH, ";\tdepends on:");
    1395           0 :             for (i = 0; i < te->nDeps; i++)
    1396           0 :                 ahprintf(AH, " %d", te->dependencies[i]);
    1397           0 :             ahprintf(AH, "\n");
    1398             :         }
    1399             :     }
    1400             : 
    1401             :     /* Enforce strict names checking */
    1402           8 :     if (ropt->strict_names)
    1403           0 :         StrictNamesCheck(ropt);
    1404             : 
    1405           8 :     if (ropt->filename)
    1406           0 :         RestoreOutput(AH, sav);
    1407           8 : }
    1408             : 
    1409             : /***********
    1410             :  * Large Object Archival
    1411             :  ***********/
    1412             : 
    1413             : /* Called by a dumper to signal start of a LO */
    1414             : int
    1415         160 : StartLO(Archive *AHX, Oid oid)
    1416             : {
    1417         160 :     ArchiveHandle *AH = (ArchiveHandle *) AHX;
    1418             : 
    1419         160 :     if (!AH->StartLOPtr)
    1420           0 :         pg_fatal("large-object output not supported in chosen format");
    1421             : 
    1422         160 :     AH->StartLOPtr(AH, AH->currToc, oid);
    1423             : 
    1424         160 :     return 1;
    1425             : }
    1426             : 
    1427             : /* Called by a dumper to signal end of a LO */
    1428             : int
    1429         160 : EndLO(Archive *AHX, Oid oid)
    1430             : {
    1431         160 :     ArchiveHandle *AH = (ArchiveHandle *) AHX;
    1432             : 
    1433         160 :     if (AH->EndLOPtr)
    1434         160 :         AH->EndLOPtr(AH, AH->currToc, oid);
    1435             : 
    1436         160 :     return 1;
    1437             : }
    1438             : 
    1439             : /**********
    1440             :  * Large Object Restoration
    1441             :  **********/
    1442             : 
    1443             : /*
    1444             :  * Called by a format handler before a group of LOs is restored
    1445             :  */
    1446             : void
    1447          32 : StartRestoreLOs(ArchiveHandle *AH)
    1448             : {
    1449          32 :     RestoreOptions *ropt = AH->public.ropt;
    1450             : 
    1451             :     /*
    1452             :      * LOs must be restored within a transaction block, since we need the LO
    1453             :      * handle to stay open while we write it.  Establish a transaction unless
    1454             :      * there's one being used globally.
    1455             :      */
    1456          32 :     if (!(ropt->single_txn || ropt->txn_size > 0))
    1457             :     {
    1458          32 :         if (AH->connection)
    1459           0 :             StartTransaction(&AH->public);
    1460             :         else
    1461          32 :             ahprintf(AH, "BEGIN;\n\n");
    1462             :     }
    1463             : 
    1464          32 :     AH->loCount = 0;
    1465          32 : }
    1466             : 
    1467             : /*
    1468             :  * Called by a format handler after a group of LOs is restored
    1469             :  */
    1470             : void
    1471          32 : EndRestoreLOs(ArchiveHandle *AH)
    1472             : {
    1473          32 :     RestoreOptions *ropt = AH->public.ropt;
    1474             : 
    1475          32 :     if (!(ropt->single_txn || ropt->txn_size > 0))
    1476             :     {
    1477          32 :         if (AH->connection)
    1478           0 :             CommitTransaction(&AH->public);
    1479             :         else
    1480          32 :             ahprintf(AH, "COMMIT;\n\n");
    1481             :     }
    1482             : 
    1483          32 :     pg_log_info(ngettext("restored %d large object",
    1484             :                          "restored %d large objects",
    1485             :                          AH->loCount),
    1486             :                 AH->loCount);
    1487          32 : }
    1488             : 
    1489             : 
    1490             : /*
    1491             :  * Called by a format handler to initiate restoration of a LO
    1492             :  */
    1493             : void
    1494          32 : StartRestoreLO(ArchiveHandle *AH, Oid oid, bool drop)
    1495             : {
    1496          32 :     bool        old_lo_style = (AH->version < K_VERS_1_12);
    1497             :     Oid         loOid;
    1498             : 
    1499          32 :     AH->loCount++;
    1500             : 
    1501             :     /* Initialize the LO Buffer */
    1502          32 :     if (AH->lo_buf == NULL)
    1503             :     {
    1504             :         /* First time through (in this process) so allocate the buffer */
    1505          16 :         AH->lo_buf_size = LOBBUFSIZE;
    1506          16 :         AH->lo_buf = pg_malloc(LOBBUFSIZE);
    1507             :     }
    1508          32 :     AH->lo_buf_used = 0;
    1509             : 
    1510          32 :     pg_log_info("restoring large object with OID %u", oid);
    1511             : 
    1512             :     /* With an old archive we must do drop and create logic here */
    1513          32 :     if (old_lo_style && drop)
    1514           0 :         DropLOIfExists(AH, oid);
    1515             : 
    1516          32 :     if (AH->connection)
    1517             :     {
    1518           0 :         if (old_lo_style)
    1519             :         {
    1520           0 :             loOid = lo_create(AH->connection, oid);
    1521           0 :             if (loOid == 0 || loOid != oid)
    1522           0 :                 pg_fatal("could not create large object %u: %s",
    1523             :                          oid, PQerrorMessage(AH->connection));
    1524             :         }
    1525           0 :         AH->loFd = lo_open(AH->connection, oid, INV_WRITE);
    1526           0 :         if (AH->loFd == -1)
    1527           0 :             pg_fatal("could not open large object %u: %s",
    1528             :                      oid, PQerrorMessage(AH->connection));
    1529             :     }
    1530             :     else
    1531             :     {
    1532          32 :         if (old_lo_style)
    1533           0 :             ahprintf(AH, "SELECT pg_catalog.lo_open(pg_catalog.lo_create('%u'), %d);\n",
    1534             :                      oid, INV_WRITE);
    1535             :         else
    1536          32 :             ahprintf(AH, "SELECT pg_catalog.lo_open('%u', %d);\n",
    1537             :                      oid, INV_WRITE);
    1538             :     }
    1539             : 
    1540          32 :     AH->writingLO = true;
    1541          32 : }
    1542             : 
    1543             : void
    1544          32 : EndRestoreLO(ArchiveHandle *AH, Oid oid)
    1545             : {
    1546          32 :     if (AH->lo_buf_used > 0)
    1547             :     {
    1548             :         /* Write remaining bytes from the LO buffer */
    1549          16 :         dump_lo_buf(AH);
    1550             :     }
    1551             : 
    1552          32 :     AH->writingLO = false;
    1553             : 
    1554          32 :     if (AH->connection)
    1555             :     {
    1556           0 :         lo_close(AH->connection, AH->loFd);
    1557           0 :         AH->loFd = -1;
    1558             :     }
    1559             :     else
    1560             :     {
    1561          32 :         ahprintf(AH, "SELECT pg_catalog.lo_close(0);\n\n");
    1562             :     }
    1563          32 : }
    1564             : 
    1565             : /***********
    1566             :  * Sorting and Reordering
    1567             :  ***********/
    1568             : 
    1569             : void
    1570           0 : SortTocFromFile(Archive *AHX)
    1571             : {
    1572           0 :     ArchiveHandle *AH = (ArchiveHandle *) AHX;
    1573           0 :     RestoreOptions *ropt = AH->public.ropt;
    1574             :     FILE       *fh;
    1575             :     StringInfoData linebuf;
    1576             : 
    1577             :     /* Allocate space for the 'wanted' array, and init it */
    1578           0 :     ropt->idWanted = (bool *) pg_malloc0(sizeof(bool) * AH->maxDumpId);
    1579             : 
    1580             :     /* Setup the file */
    1581           0 :     fh = fopen(ropt->tocFile, PG_BINARY_R);
    1582           0 :     if (!fh)
    1583           0 :         pg_fatal("could not open TOC file \"%s\": %m", ropt->tocFile);
    1584             : 
    1585           0 :     initStringInfo(&linebuf);
    1586             : 
    1587           0 :     while (pg_get_line_buf(fh, &linebuf))
    1588             :     {
    1589             :         char       *cmnt;
    1590             :         char       *endptr;
    1591             :         DumpId      id;
    1592             :         TocEntry   *te;
    1593             : 
    1594             :         /* Truncate line at comment, if any */
    1595           0 :         cmnt = strchr(linebuf.data, ';');
    1596           0 :         if (cmnt != NULL)
    1597             :         {
    1598           0 :             cmnt[0] = '\0';
    1599           0 :             linebuf.len = cmnt - linebuf.data;
    1600             :         }
    1601             : 
    1602             :         /* Ignore if all blank */
    1603           0 :         if (strspn(linebuf.data, " \t\r\n") == linebuf.len)
    1604           0 :             continue;
    1605             : 
    1606             :         /* Get an ID, check it's valid and not already seen */
    1607           0 :         id = strtol(linebuf.data, &endptr, 10);
    1608           0 :         if (endptr == linebuf.data || id <= 0 || id > AH->maxDumpId ||
    1609           0 :             ropt->idWanted[id - 1])
    1610             :         {
    1611           0 :             pg_log_warning("line ignored: %s", linebuf.data);
    1612           0 :             continue;
    1613             :         }
    1614             : 
    1615             :         /* Find TOC entry */
    1616           0 :         te = getTocEntryByDumpId(AH, id);
    1617           0 :         if (!te)
    1618           0 :             pg_fatal("could not find entry for ID %d",
    1619             :                      id);
    1620             : 
    1621             :         /* Mark it wanted */
    1622           0 :         ropt->idWanted[id - 1] = true;
    1623             : 
    1624             :         /*
    1625             :          * Move each item to the end of the list as it is selected, so that
    1626             :          * they are placed in the desired order.  Any unwanted items will end
    1627             :          * up at the front of the list, which may seem unintuitive but it's
    1628             :          * what we need.  In an ordinary serial restore that makes no
    1629             :          * difference, but in a parallel restore we need to mark unrestored
    1630             :          * items' dependencies as satisfied before we start examining
    1631             :          * restorable items.  Otherwise they could have surprising
    1632             :          * side-effects on the order in which restorable items actually get
    1633             :          * restored.
    1634             :          */
    1635           0 :         _moveBefore(AH->toc, te);
    1636             :     }
    1637             : 
    1638           0 :     pg_free(linebuf.data);
    1639             : 
    1640           0 :     if (fclose(fh) != 0)
    1641           0 :         pg_fatal("could not close TOC file: %m");
    1642           0 : }
    1643             : 
    1644             : /**********************
    1645             :  * Convenience functions that look like standard IO functions
    1646             :  * for writing data when in dump mode.
    1647             :  **********************/
    1648             : 
    1649             : /* Public */
    1650             : void
    1651       46076 : archputs(const char *s, Archive *AH)
    1652             : {
    1653       46076 :     WriteData(AH, s, strlen(s));
    1654       46076 : }
    1655             : 
    1656             : /* Public */
    1657             : int
    1658        8432 : archprintf(Archive *AH, const char *fmt,...)
    1659             : {
    1660        8432 :     int         save_errno = errno;
    1661             :     char       *p;
    1662        8432 :     size_t      len = 128;      /* initial assumption about buffer size */
    1663             :     size_t      cnt;
    1664             : 
    1665             :     for (;;)
    1666           0 :     {
    1667             :         va_list     args;
    1668             : 
    1669             :         /* Allocate work buffer. */
    1670        8432 :         p = (char *) pg_malloc(len);
    1671             : 
    1672             :         /* Try to format the data. */
    1673        8432 :         errno = save_errno;
    1674        8432 :         va_start(args, fmt);
    1675        8432 :         cnt = pvsnprintf(p, len, fmt, args);
    1676        8432 :         va_end(args);
    1677             : 
    1678        8432 :         if (cnt < len)
    1679        8432 :             break;              /* success */
    1680             : 
    1681             :         /* Release buffer and loop around to try again with larger len. */
    1682           0 :         free(p);
    1683           0 :         len = cnt;
    1684             :     }
    1685             : 
    1686        8432 :     WriteData(AH, p, cnt);
    1687        8432 :     free(p);
    1688        8432 :     return (int) cnt;
    1689             : }
    1690             : 
    1691             : 
    1692             : /*******************************
    1693             :  * Stuff below here should be 'private' to the archiver routines
    1694             :  *******************************/
    1695             : 
    1696             : static void
    1697         278 : SetOutput(ArchiveHandle *AH, const char *filename,
    1698             :           const pg_compress_specification compression_spec)
    1699             : {
    1700             :     CompressFileHandle *CFH;
    1701             :     const char *mode;
    1702         278 :     int         fn = -1;
    1703             : 
    1704         278 :     if (filename)
    1705             :     {
    1706         278 :         if (strcmp(filename, "-") == 0)
    1707           0 :             fn = fileno(stdout);
    1708             :     }
    1709           0 :     else if (AH->FH)
    1710           0 :         fn = fileno(AH->FH);
    1711           0 :     else if (AH->fSpec)
    1712             :     {
    1713           0 :         filename = AH->fSpec;
    1714             :     }
    1715             :     else
    1716           0 :         fn = fileno(stdout);
    1717             : 
    1718         278 :     if (AH->mode == archModeAppend)
    1719          86 :         mode = PG_BINARY_A;
    1720             :     else
    1721         192 :         mode = PG_BINARY_W;
    1722             : 
    1723         278 :     CFH = InitCompressFileHandle(compression_spec);
    1724             : 
    1725         278 :     if (!CFH->open_func(filename, fn, mode, CFH))
    1726             :     {
    1727           0 :         if (filename)
    1728           0 :             pg_fatal("could not open output file \"%s\": %m", filename);
    1729             :         else
    1730           0 :             pg_fatal("could not open output file: %m");
    1731             :     }
    1732             : 
    1733         278 :     AH->OF = CFH;
    1734         278 : }
    1735             : 
    1736             : static CompressFileHandle *
    1737         374 : SaveOutput(ArchiveHandle *AH)
    1738             : {
    1739         374 :     return (CompressFileHandle *) AH->OF;
    1740             : }
    1741             : 
    1742             : static void
    1743         278 : RestoreOutput(ArchiveHandle *AH, CompressFileHandle *savedOutput)
    1744             : {
    1745         278 :     errno = 0;
    1746         278 :     if (!EndCompressFileHandle(AH->OF))
    1747           0 :         pg_fatal("could not close output file: %m");
    1748             : 
    1749         278 :     AH->OF = savedOutput;
    1750         278 : }
    1751             : 
    1752             : 
    1753             : 
    1754             : /*
    1755             :  *  Print formatted text to the output file (usually stdout).
    1756             :  */
    1757             : int
    1758      443436 : ahprintf(ArchiveHandle *AH, const char *fmt,...)
    1759             : {
    1760      443436 :     int         save_errno = errno;
    1761             :     char       *p;
    1762      443436 :     size_t      len = 128;      /* initial assumption about buffer size */
    1763             :     size_t      cnt;
    1764             : 
    1765             :     for (;;)
    1766       28052 :     {
    1767             :         va_list     args;
    1768             : 
    1769             :         /* Allocate work buffer. */
    1770      471488 :         p = (char *) pg_malloc(len);
    1771             : 
    1772             :         /* Try to format the data. */
    1773      471488 :         errno = save_errno;
    1774      471488 :         va_start(args, fmt);
    1775      471488 :         cnt = pvsnprintf(p, len, fmt, args);
    1776      471488 :         va_end(args);
    1777             : 
    1778      471488 :         if (cnt < len)
    1779      443436 :             break;              /* success */
    1780             : 
    1781             :         /* Release buffer and loop around to try again with larger len. */
    1782       28052 :         free(p);
    1783       28052 :         len = cnt;
    1784             :     }
    1785             : 
    1786      443436 :     ahwrite(p, 1, cnt, AH);
    1787      443436 :     free(p);
    1788      443436 :     return (int) cnt;
    1789             : }
    1790             : 
    1791             : /*
    1792             :  * Single place for logic which says 'We are restoring to a direct DB connection'.
    1793             :  */
    1794             : static int
    1795     4065792 : RestoringToDB(ArchiveHandle *AH)
    1796             : {
    1797     4065792 :     RestoreOptions *ropt = AH->public.ropt;
    1798             : 
    1799     4065792 :     return (ropt && ropt->useDB && AH->connection);
    1800             : }
    1801             : 
    1802             : /*
    1803             :  * Dump the current contents of the LO data buffer while writing a LO
    1804             :  */
    1805             : static void
    1806          16 : dump_lo_buf(ArchiveHandle *AH)
    1807             : {
    1808          16 :     if (AH->connection)
    1809             :     {
    1810             :         int         res;
    1811             : 
    1812           0 :         res = lo_write(AH->connection, AH->loFd, AH->lo_buf, AH->lo_buf_used);
    1813           0 :         pg_log_debug(ngettext("wrote %zu byte of large object data (result = %d)",
    1814             :                               "wrote %zu bytes of large object data (result = %d)",
    1815             :                               AH->lo_buf_used),
    1816             :                      AH->lo_buf_used, res);
    1817             :         /* We assume there are no short writes, only errors */
    1818           0 :         if (res != AH->lo_buf_used)
    1819           0 :             warn_or_exit_horribly(AH, "could not write to large object: %s",
    1820           0 :                                   PQerrorMessage(AH->connection));
    1821             :     }
    1822             :     else
    1823             :     {
    1824          16 :         PQExpBuffer buf = createPQExpBuffer();
    1825             : 
    1826          16 :         appendByteaLiteralAHX(buf,
    1827             :                               (const unsigned char *) AH->lo_buf,
    1828             :                               AH->lo_buf_used,
    1829             :                               AH);
    1830             : 
    1831             :         /* Hack: turn off writingLO so ahwrite doesn't recurse to here */
    1832          16 :         AH->writingLO = false;
    1833          16 :         ahprintf(AH, "SELECT pg_catalog.lowrite(0, %s);\n", buf->data);
    1834          16 :         AH->writingLO = true;
    1835             : 
    1836          16 :         destroyPQExpBuffer(buf);
    1837             :     }
    1838          16 :     AH->lo_buf_used = 0;
    1839          16 : }
    1840             : 
    1841             : 
    1842             : /*
    1843             :  *  Write buffer to the output file (usually stdout). This is used for
    1844             :  *  outputting 'restore' scripts etc. It is even possible for an archive
    1845             :  *  format to create a custom output routine to 'fake' a restore if it
    1846             :  *  wants to generate a script (see TAR output).
    1847             :  */
    1848             : void
    1849     4060608 : ahwrite(const void *ptr, size_t size, size_t nmemb, ArchiveHandle *AH)
    1850             : {
    1851     4060608 :     int         bytes_written = 0;
    1852             : 
    1853     4060608 :     if (AH->writingLO)
    1854             :     {
    1855          26 :         size_t      remaining = size * nmemb;
    1856             : 
    1857          26 :         while (AH->lo_buf_used + remaining > AH->lo_buf_size)
    1858             :         {
    1859           0 :             size_t      avail = AH->lo_buf_size - AH->lo_buf_used;
    1860             : 
    1861           0 :             memcpy((char *) AH->lo_buf + AH->lo_buf_used, ptr, avail);
    1862           0 :             ptr = (const char *) ptr + avail;
    1863           0 :             remaining -= avail;
    1864           0 :             AH->lo_buf_used += avail;
    1865           0 :             dump_lo_buf(AH);
    1866             :         }
    1867             : 
    1868          26 :         memcpy((char *) AH->lo_buf + AH->lo_buf_used, ptr, remaining);
    1869          26 :         AH->lo_buf_used += remaining;
    1870             : 
    1871          26 :         bytes_written = size * nmemb;
    1872             :     }
    1873     4060582 :     else if (AH->CustomOutPtr)
    1874        4618 :         bytes_written = AH->CustomOutPtr(AH, ptr, size * nmemb);
    1875             : 
    1876             :     /*
    1877             :      * If we're doing a restore, and it's direct to DB, and we're connected
    1878             :      * then send it to the DB.
    1879             :      */
    1880     4055964 :     else if (RestoringToDB(AH))
    1881       12756 :         bytes_written = ExecuteSqlCommandBuf(&AH->public, (const char *) ptr, size * nmemb);
    1882             :     else
    1883             :     {
    1884     4043208 :         CompressFileHandle *CFH = (CompressFileHandle *) AH->OF;
    1885             : 
    1886     4043208 :         if (CFH->write_func(ptr, size * nmemb, CFH))
    1887     4043208 :             bytes_written = size * nmemb;
    1888             :     }
    1889             : 
    1890     4060608 :     if (bytes_written != size * nmemb)
    1891           0 :         WRITE_ERROR_EXIT;
    1892     4060608 : }
    1893             : 
    1894             : /* on some error, we may decide to go on... */
    1895             : void
    1896           0 : warn_or_exit_horribly(ArchiveHandle *AH, const char *fmt,...)
    1897             : {
    1898             :     va_list     ap;
    1899             : 
    1900           0 :     switch (AH->stage)
    1901             :     {
    1902             : 
    1903           0 :         case STAGE_NONE:
    1904             :             /* Do nothing special */
    1905           0 :             break;
    1906             : 
    1907           0 :         case STAGE_INITIALIZING:
    1908           0 :             if (AH->stage != AH->lastErrorStage)
    1909           0 :                 pg_log_info("while INITIALIZING:");
    1910           0 :             break;
    1911             : 
    1912           0 :         case STAGE_PROCESSING:
    1913           0 :             if (AH->stage != AH->lastErrorStage)
    1914           0 :                 pg_log_info("while PROCESSING TOC:");
    1915           0 :             break;
    1916             : 
    1917           0 :         case STAGE_FINALIZING:
    1918           0 :             if (AH->stage != AH->lastErrorStage)
    1919           0 :                 pg_log_info("while FINALIZING:");
    1920           0 :             break;
    1921             :     }
    1922           0 :     if (AH->currentTE != NULL && AH->currentTE != AH->lastErrorTE)
    1923             :     {
    1924           0 :         pg_log_info("from TOC entry %d; %u %u %s %s %s",
    1925             :                     AH->currentTE->dumpId,
    1926             :                     AH->currentTE->catalogId.tableoid,
    1927             :                     AH->currentTE->catalogId.oid,
    1928             :                     AH->currentTE->desc ? AH->currentTE->desc : "(no desc)",
    1929             :                     AH->currentTE->tag ? AH->currentTE->tag : "(no tag)",
    1930             :                     AH->currentTE->owner ? AH->currentTE->owner : "(no owner)");
    1931             :     }
    1932           0 :     AH->lastErrorStage = AH->stage;
    1933           0 :     AH->lastErrorTE = AH->currentTE;
    1934             : 
    1935           0 :     va_start(ap, fmt);
    1936           0 :     pg_log_generic_v(PG_LOG_ERROR, PG_LOG_PRIMARY, fmt, ap);
    1937           0 :     va_end(ap);
    1938             : 
    1939           0 :     if (AH->public.exit_on_error)
    1940           0 :         exit_nicely(1);
    1941             :     else
    1942           0 :         AH->public.n_errors++;
    1943           0 : }
    1944             : 
    1945             : #ifdef NOT_USED
    1946             : 
    1947             : static void
    1948             : _moveAfter(ArchiveHandle *AH, TocEntry *pos, TocEntry *te)
    1949             : {
    1950             :     /* Unlink te from list */
    1951             :     te->prev->next = te->next;
    1952             :     te->next->prev = te->prev;
    1953             : 
    1954             :     /* and insert it after "pos" */
    1955             :     te->prev = pos;
    1956             :     te->next = pos->next;
    1957             :     pos->next->prev = te;
    1958             :     pos->next = te;
    1959             : }
    1960             : #endif
    1961             : 
    1962             : static void
    1963           0 : _moveBefore(TocEntry *pos, TocEntry *te)
    1964             : {
    1965             :     /* Unlink te from list */
    1966           0 :     te->prev->next = te->next;
    1967           0 :     te->next->prev = te->prev;
    1968             : 
    1969             :     /* and insert it before "pos" */
    1970           0 :     te->prev = pos->prev;
    1971           0 :     te->next = pos;
    1972           0 :     pos->prev->next = te;
    1973           0 :     pos->prev = te;
    1974           0 : }
    1975             : 
    1976             : /*
    1977             :  * Build index arrays for the TOC list
    1978             :  *
    1979             :  * This should be invoked only after we have created or read in all the TOC
    1980             :  * items.
    1981             :  *
    1982             :  * The arrays are indexed by dump ID (so entry zero is unused).  Note that the
    1983             :  * array entries run only up to maxDumpId.  We might see dependency dump IDs
    1984             :  * beyond that (if the dump was partial); so always check the array bound
    1985             :  * before trying to touch an array entry.
    1986             :  */
    1987             : static void
    1988         436 : buildTocEntryArrays(ArchiveHandle *AH)
    1989             : {
    1990         436 :     DumpId      maxDumpId = AH->maxDumpId;
    1991             :     TocEntry   *te;
    1992             : 
    1993         436 :     AH->tocsByDumpId = (TocEntry **) pg_malloc0((maxDumpId + 1) * sizeof(TocEntry *));
    1994         436 :     AH->tableDataId = (DumpId *) pg_malloc0((maxDumpId + 1) * sizeof(DumpId));
    1995             : 
    1996       99170 :     for (te = AH->toc->next; te != AH->toc; te = te->next)
    1997             :     {
    1998             :         /* this check is purely paranoia, maxDumpId should be correct */
    1999       98734 :         if (te->dumpId <= 0 || te->dumpId > maxDumpId)
    2000           0 :             pg_fatal("bad dumpId");
    2001             : 
    2002             :         /* tocsByDumpId indexes all TOCs by their dump ID */
    2003       98734 :         AH->tocsByDumpId[te->dumpId] = te;
    2004             : 
    2005             :         /*
    2006             :          * tableDataId provides the TABLE DATA item's dump ID for each TABLE
    2007             :          * TOC entry that has a DATA item.  We compute this by reversing the
    2008             :          * TABLE DATA item's dependency, knowing that a TABLE DATA item has
    2009             :          * just one dependency and it is the TABLE item.
    2010             :          */
    2011       98734 :         if (strcmp(te->desc, "TABLE DATA") == 0 && te->nDeps > 0)
    2012             :         {
    2013        9544 :             DumpId      tableId = te->dependencies[0];
    2014             : 
    2015             :             /*
    2016             :              * The TABLE item might not have been in the archive, if this was
    2017             :              * a data-only dump; but its dump ID should be less than its data
    2018             :              * item's dump ID, so there should be a place for it in the array.
    2019             :              */
    2020        9544 :             if (tableId <= 0 || tableId > maxDumpId)
    2021           0 :                 pg_fatal("bad table dumpId for TABLE DATA item");
    2022             : 
    2023        9544 :             AH->tableDataId[tableId] = te->dumpId;
    2024             :         }
    2025             :     }
    2026         436 : }
    2027             : 
    2028             : TocEntry *
    2029       22494 : getTocEntryByDumpId(ArchiveHandle *AH, DumpId id)
    2030             : {
    2031             :     /* build index arrays if we didn't already */
    2032       22494 :     if (AH->tocsByDumpId == NULL)
    2033          74 :         buildTocEntryArrays(AH);
    2034             : 
    2035       22494 :     if (id > 0 && id <= AH->maxDumpId)
    2036       22494 :         return AH->tocsByDumpId[id];
    2037             : 
    2038           0 :     return NULL;
    2039             : }
    2040             : 
    2041             : int
    2042       22118 : TocIDRequired(ArchiveHandle *AH, DumpId id)
    2043             : {
    2044       22118 :     TocEntry   *te = getTocEntryByDumpId(AH, id);
    2045             : 
    2046       22118 :     if (!te)
    2047       10242 :         return 0;
    2048             : 
    2049       11876 :     return te->reqs;
    2050             : }
    2051             : 
    2052             : size_t
    2053       12588 : WriteOffset(ArchiveHandle *AH, pgoff_t o, int wasSet)
    2054             : {
    2055             :     int         off;
    2056             : 
    2057             :     /* Save the flag */
    2058       12588 :     AH->WriteBytePtr(AH, wasSet);
    2059             : 
    2060             :     /* Write out pgoff_t smallest byte first, prevents endian mismatch */
    2061      113292 :     for (off = 0; off < sizeof(pgoff_t); off++)
    2062             :     {
    2063      100704 :         AH->WriteBytePtr(AH, o & 0xFF);
    2064      100704 :         o >>= 8;
    2065             :     }
    2066       12588 :     return sizeof(pgoff_t) + 1;
    2067             : }
    2068             : 
    2069             : int
    2070       12504 : ReadOffset(ArchiveHandle *AH, pgoff_t * o)
    2071             : {
    2072             :     int         i;
    2073             :     int         off;
    2074             :     int         offsetFlg;
    2075             : 
    2076             :     /* Initialize to zero */
    2077       12504 :     *o = 0;
    2078             : 
    2079             :     /* Check for old version */
    2080       12504 :     if (AH->version < K_VERS_1_7)
    2081             :     {
    2082             :         /* Prior versions wrote offsets using WriteInt */
    2083           0 :         i = ReadInt(AH);
    2084             :         /* -1 means not set */
    2085           0 :         if (i < 0)
    2086           0 :             return K_OFFSET_POS_NOT_SET;
    2087           0 :         else if (i == 0)
    2088           0 :             return K_OFFSET_NO_DATA;
    2089             : 
    2090             :         /* Cast to pgoff_t because it was written as an int. */
    2091           0 :         *o = (pgoff_t) i;
    2092           0 :         return K_OFFSET_POS_SET;
    2093             :     }
    2094             : 
    2095             :     /*
    2096             :      * Read the flag indicating the state of the data pointer. Check if valid
    2097             :      * and die if not.
    2098             :      *
    2099             :      * This used to be handled by a negative or zero pointer, now we use an
    2100             :      * extra byte specifically for the state.
    2101             :      */
    2102       12504 :     offsetFlg = AH->ReadBytePtr(AH) & 0xFF;
    2103             : 
    2104       12504 :     switch (offsetFlg)
    2105             :     {
    2106       12504 :         case K_OFFSET_POS_NOT_SET:
    2107             :         case K_OFFSET_NO_DATA:
    2108             :         case K_OFFSET_POS_SET:
    2109             : 
    2110       12504 :             break;
    2111             : 
    2112           0 :         default:
    2113           0 :             pg_fatal("unexpected data offset flag %d", offsetFlg);
    2114             :     }
    2115             : 
    2116             :     /*
    2117             :      * Read the bytes
    2118             :      */
    2119      112536 :     for (off = 0; off < AH->offSize; off++)
    2120             :     {
    2121      100032 :         if (off < sizeof(pgoff_t))
    2122      100032 :             *o |= ((pgoff_t) (AH->ReadBytePtr(AH))) << (off * 8);
    2123             :         else
    2124             :         {
    2125           0 :             if (AH->ReadBytePtr(AH) != 0)
    2126           0 :                 pg_fatal("file offset in dump file is too large");
    2127             :         }
    2128             :     }
    2129             : 
    2130       12504 :     return offsetFlg;
    2131             : }
    2132             : 
    2133             : size_t
    2134      319770 : WriteInt(ArchiveHandle *AH, int i)
    2135             : {
    2136             :     int         b;
    2137             : 
    2138             :     /*
    2139             :      * This is a bit yucky, but I don't want to make the binary format very
    2140             :      * dependent on representation, and not knowing much about it, I write out
    2141             :      * a sign byte. If you change this, don't forget to change the file
    2142             :      * version #, and modify ReadInt to read the new format AS WELL AS the old
    2143             :      * formats.
    2144             :      */
    2145             : 
    2146             :     /* SIGN byte */
    2147      319770 :     if (i < 0)
    2148             :     {
    2149       76278 :         AH->WriteBytePtr(AH, 1);
    2150       76278 :         i = -i;
    2151             :     }
    2152             :     else
    2153      243492 :         AH->WriteBytePtr(AH, 0);
    2154             : 
    2155     1598850 :     for (b = 0; b < AH->intSize; b++)
    2156             :     {
    2157     1279080 :         AH->WriteBytePtr(AH, i & 0xFF);
    2158     1279080 :         i >>= 8;
    2159             :     }
    2160             : 
    2161      319770 :     return AH->intSize + 1;
    2162             : }
    2163             : 
    2164             : int
    2165      334048 : ReadInt(ArchiveHandle *AH)
    2166             : {
    2167      334048 :     int         res = 0;
    2168             :     int         bv,
    2169             :                 b;
    2170      334048 :     int         sign = 0;       /* Default positive */
    2171      334048 :     int         bitShift = 0;
    2172             : 
    2173      334048 :     if (AH->version > K_VERS_1_0)
    2174             :         /* Read a sign byte */
    2175      334048 :         sign = AH->ReadBytePtr(AH);
    2176             : 
    2177     1670240 :     for (b = 0; b < AH->intSize; b++)
    2178             :     {
    2179     1336192 :         bv = AH->ReadBytePtr(AH) & 0xFF;
    2180     1336192 :         if (bv != 0)
    2181      316854 :             res = res + (bv << bitShift);
    2182     1336192 :         bitShift += 8;
    2183             :     }
    2184             : 
    2185      334048 :     if (sign)
    2186       79300 :         res = -res;
    2187             : 
    2188      334048 :     return res;
    2189             : }
    2190             : 
    2191             : size_t
    2192      250180 : WriteStr(ArchiveHandle *AH, const char *c)
    2193             : {
    2194             :     size_t      res;
    2195             : 
    2196      250180 :     if (c)
    2197             :     {
    2198      173902 :         int         len = strlen(c);
    2199             : 
    2200      173902 :         res = WriteInt(AH, len);
    2201      173902 :         AH->WriteBufPtr(AH, c, len);
    2202      173902 :         res += len;
    2203             :     }
    2204             :     else
    2205       76278 :         res = WriteInt(AH, -1);
    2206             : 
    2207      250180 :     return res;
    2208             : }
    2209             : 
    2210             : char *
    2211      261752 : ReadStr(ArchiveHandle *AH)
    2212             : {
    2213             :     char       *buf;
    2214             :     int         l;
    2215             : 
    2216      261752 :     l = ReadInt(AH);
    2217      261752 :     if (l < 0)
    2218       79300 :         buf = NULL;
    2219             :     else
    2220             :     {
    2221      182452 :         buf = (char *) pg_malloc(l + 1);
    2222      182452 :         AH->ReadBufPtr(AH, buf, l);
    2223             : 
    2224      182452 :         buf[l] = '\0';
    2225             :     }
    2226             : 
    2227      261752 :     return buf;
    2228             : }
    2229             : 
    2230             : static bool
    2231          22 : _fileExistsInDirectory(const char *dir, const char *filename)
    2232             : {
    2233             :     struct stat st;
    2234             :     char        buf[MAXPGPATH];
    2235             : 
    2236          22 :     if (snprintf(buf, MAXPGPATH, "%s/%s", dir, filename) >= MAXPGPATH)
    2237           0 :         pg_fatal("directory name too long: \"%s\"", dir);
    2238             : 
    2239          22 :     return (stat(buf, &st) == 0 && S_ISREG(st.st_mode));
    2240             : }
    2241             : 
    2242             : static int
    2243          92 : _discoverArchiveFormat(ArchiveHandle *AH)
    2244             : {
    2245             :     FILE       *fh;
    2246             :     char        sig[6];         /* More than enough */
    2247             :     size_t      cnt;
    2248          92 :     int         wantClose = 0;
    2249             : 
    2250          92 :     pg_log_debug("attempting to ascertain archive format");
    2251             : 
    2252          92 :     free(AH->lookahead);
    2253             : 
    2254          92 :     AH->readHeader = 0;
    2255          92 :     AH->lookaheadSize = 512;
    2256          92 :     AH->lookahead = pg_malloc0(512);
    2257          92 :     AH->lookaheadLen = 0;
    2258          92 :     AH->lookaheadPos = 0;
    2259             : 
    2260          92 :     if (AH->fSpec)
    2261             :     {
    2262             :         struct stat st;
    2263             : 
    2264          92 :         wantClose = 1;
    2265             : 
    2266             :         /*
    2267             :          * Check if the specified archive is a directory. If so, check if
    2268             :          * there's a "toc.dat" (or "toc.dat.{gz,lz4,zst}") file in it.
    2269             :          */
    2270          92 :         if (stat(AH->fSpec, &st) == 0 && S_ISDIR(st.st_mode))
    2271             :         {
    2272          22 :             AH->format = archDirectory;
    2273          22 :             if (_fileExistsInDirectory(AH->fSpec, "toc.dat"))
    2274          22 :                 return AH->format;
    2275             : #ifdef HAVE_LIBZ
    2276           0 :             if (_fileExistsInDirectory(AH->fSpec, "toc.dat.gz"))
    2277           0 :                 return AH->format;
    2278             : #endif
    2279             : #ifdef USE_LZ4
    2280           0 :             if (_fileExistsInDirectory(AH->fSpec, "toc.dat.lz4"))
    2281           0 :                 return AH->format;
    2282             : #endif
    2283             : #ifdef USE_ZSTD
    2284             :             if (_fileExistsInDirectory(AH->fSpec, "toc.dat.zst"))
    2285             :                 return AH->format;
    2286             : #endif
    2287           0 :             pg_fatal("directory \"%s\" does not appear to be a valid archive (\"toc.dat\" does not exist)",
    2288             :                      AH->fSpec);
    2289             :             fh = NULL;          /* keep compiler quiet */
    2290             :         }
    2291             :         else
    2292             :         {
    2293          70 :             fh = fopen(AH->fSpec, PG_BINARY_R);
    2294          70 :             if (!fh)
    2295           0 :                 pg_fatal("could not open input file \"%s\": %m", AH->fSpec);
    2296             :         }
    2297             :     }
    2298             :     else
    2299             :     {
    2300           0 :         fh = stdin;
    2301           0 :         if (!fh)
    2302           0 :             pg_fatal("could not open input file: %m");
    2303             :     }
    2304             : 
    2305          70 :     if ((cnt = fread(sig, 1, 5, fh)) != 5)
    2306             :     {
    2307           0 :         if (ferror(fh))
    2308           0 :             pg_fatal("could not read input file: %m");
    2309             :         else
    2310           0 :             pg_fatal("input file is too short (read %lu, expected 5)",
    2311             :                      (unsigned long) cnt);
    2312             :     }
    2313             : 
    2314             :     /* Save it, just in case we need it later */
    2315          70 :     memcpy(&AH->lookahead[0], sig, 5);
    2316          70 :     AH->lookaheadLen = 5;
    2317             : 
    2318          70 :     if (strncmp(sig, "PGDMP", 5) == 0)
    2319             :     {
    2320             :         /* It's custom format, stop here */
    2321          68 :         AH->format = archCustom;
    2322          68 :         AH->readHeader = 1;
    2323             :     }
    2324             :     else
    2325             :     {
    2326             :         /*
    2327             :          * *Maybe* we have a tar archive format file or a text dump ... So,
    2328             :          * read first 512 byte header...
    2329             :          */
    2330           2 :         cnt = fread(&AH->lookahead[AH->lookaheadLen], 1, 512 - AH->lookaheadLen, fh);
    2331             :         /* read failure is checked below */
    2332           2 :         AH->lookaheadLen += cnt;
    2333             : 
    2334           2 :         if (AH->lookaheadLen >= strlen(TEXT_DUMPALL_HEADER) &&
    2335           2 :             (strncmp(AH->lookahead, TEXT_DUMP_HEADER, strlen(TEXT_DUMP_HEADER)) == 0 ||
    2336           2 :              strncmp(AH->lookahead, TEXT_DUMPALL_HEADER, strlen(TEXT_DUMPALL_HEADER)) == 0))
    2337             :         {
    2338             :             /*
    2339             :              * looks like it's probably a text format dump. so suggest they
    2340             :              * try psql
    2341             :              */
    2342           0 :             pg_fatal("input file appears to be a text format dump. Please use psql.");
    2343             :         }
    2344             : 
    2345           2 :         if (AH->lookaheadLen != 512)
    2346             :         {
    2347           0 :             if (feof(fh))
    2348           0 :                 pg_fatal("input file does not appear to be a valid archive (too short?)");
    2349             :             else
    2350           0 :                 READ_ERROR_EXIT(fh);
    2351             :         }
    2352             : 
    2353           2 :         if (!isValidTarHeader(AH->lookahead))
    2354           0 :             pg_fatal("input file does not appear to be a valid archive");
    2355             : 
    2356           2 :         AH->format = archTar;
    2357             :     }
    2358             : 
    2359             :     /* Close the file if we opened it */
    2360          70 :     if (wantClose)
    2361             :     {
    2362          70 :         if (fclose(fh) != 0)
    2363           0 :             pg_fatal("could not close input file: %m");
    2364             :         /* Forget lookahead, since we'll re-read header after re-opening */
    2365          70 :         AH->readHeader = 0;
    2366          70 :         AH->lookaheadLen = 0;
    2367             :     }
    2368             : 
    2369          70 :     return AH->format;
    2370             : }
    2371             : 
    2372             : 
    2373             : /*
    2374             :  * Allocate an archive handle
    2375             :  */
    2376             : static ArchiveHandle *
    2377         516 : _allocAH(const char *FileSpec, const ArchiveFormat fmt,
    2378             :          const pg_compress_specification compression_spec,
    2379             :          bool dosync, ArchiveMode mode,
    2380             :          SetupWorkerPtrType setupWorkerPtr, DataDirSyncMethod sync_method)
    2381             : {
    2382             :     ArchiveHandle *AH;
    2383             :     CompressFileHandle *CFH;
    2384         516 :     pg_compress_specification out_compress_spec = {0};
    2385             : 
    2386         516 :     pg_log_debug("allocating AH for %s, format %d",
    2387             :                  FileSpec ? FileSpec : "(stdio)", fmt);
    2388             : 
    2389         516 :     AH = (ArchiveHandle *) pg_malloc0(sizeof(ArchiveHandle));
    2390             : 
    2391         516 :     AH->version = K_VERS_SELF;
    2392             : 
    2393             :     /* initialize for backwards compatible string processing */
    2394         516 :     AH->public.encoding = 0; /* PG_SQL_ASCII */
    2395         516 :     AH->public.std_strings = false;
    2396             : 
    2397             :     /* sql error handling */
    2398         516 :     AH->public.exit_on_error = true;
    2399         516 :     AH->public.n_errors = 0;
    2400             : 
    2401         516 :     AH->archiveDumpVersion = PG_VERSION;
    2402             : 
    2403         516 :     AH->createDate = time(NULL);
    2404             : 
    2405         516 :     AH->intSize = sizeof(int);
    2406         516 :     AH->offSize = sizeof(pgoff_t);
    2407         516 :     if (FileSpec)
    2408             :     {
    2409         464 :         AH->fSpec = pg_strdup(FileSpec);
    2410             : 
    2411             :         /*
    2412             :          * Not used; maybe later....
    2413             :          *
    2414             :          * AH->workDir = pg_strdup(FileSpec); for(i=strlen(FileSpec) ; i > 0 ;
    2415             :          * i--) if (AH->workDir[i-1] == '/')
    2416             :          */
    2417             :     }
    2418             :     else
    2419          52 :         AH->fSpec = NULL;
    2420             : 
    2421         516 :     AH->currUser = NULL;     /* unknown */
    2422         516 :     AH->currSchema = NULL;       /* ditto */
    2423         516 :     AH->currTablespace = NULL;   /* ditto */
    2424         516 :     AH->currTableAm = NULL;      /* ditto */
    2425             : 
    2426         516 :     AH->toc = (TocEntry *) pg_malloc0(sizeof(TocEntry));
    2427             : 
    2428         516 :     AH->toc->next = AH->toc;
    2429         516 :     AH->toc->prev = AH->toc;
    2430             : 
    2431         516 :     AH->mode = mode;
    2432         516 :     AH->compression_spec = compression_spec;
    2433         516 :     AH->dosync = dosync;
    2434         516 :     AH->sync_method = sync_method;
    2435             : 
    2436         516 :     memset(&(AH->sqlparse), 0, sizeof(AH->sqlparse));
    2437             : 
    2438             :     /* Open stdout with no compression for AH output handle */
    2439         516 :     out_compress_spec.algorithm = PG_COMPRESSION_NONE;
    2440         516 :     CFH = InitCompressFileHandle(out_compress_spec);
    2441         516 :     if (!CFH->open_func(NULL, fileno(stdout), PG_BINARY_A, CFH))
    2442           0 :         pg_fatal("could not open stdout for appending: %m");
    2443         516 :     AH->OF = CFH;
    2444             : 
    2445             :     /*
    2446             :      * On Windows, we need to use binary mode to read/write non-text files,
    2447             :      * which include all archive formats as well as compressed plain text.
    2448             :      * Force stdin/stdout into binary mode if that is what we are using.
    2449             :      */
    2450             : #ifdef WIN32
    2451             :     if ((fmt != archNull || compression_spec.algorithm != PG_COMPRESSION_NONE) &&
    2452             :         (AH->fSpec == NULL || strcmp(AH->fSpec, "") == 0))
    2453             :     {
    2454             :         if (mode == archModeWrite)
    2455             :             _setmode(fileno(stdout), O_BINARY);
    2456             :         else
    2457             :             _setmode(fileno(stdin), O_BINARY);
    2458             :     }
    2459             : #endif
    2460             : 
    2461         516 :     AH->SetupWorkerPtr = setupWorkerPtr;
    2462             : 
    2463         516 :     if (fmt == archUnknown)
    2464          92 :         AH->format = _discoverArchiveFormat(AH);
    2465             :     else
    2466         424 :         AH->format = fmt;
    2467             : 
    2468         516 :     switch (AH->format)
    2469             :     {
    2470         166 :         case archCustom:
    2471         166 :             InitArchiveFmt_Custom(AH);
    2472         166 :             break;
    2473             : 
    2474         296 :         case archNull:
    2475         296 :             InitArchiveFmt_Null(AH);
    2476         296 :             break;
    2477             : 
    2478          44 :         case archDirectory:
    2479          44 :             InitArchiveFmt_Directory(AH);
    2480          44 :             break;
    2481             : 
    2482          10 :         case archTar:
    2483          10 :             InitArchiveFmt_Tar(AH);
    2484           8 :             break;
    2485             : 
    2486           0 :         default:
    2487           0 :             pg_fatal("unrecognized file format \"%d\"", AH->format);
    2488             :     }
    2489             : 
    2490         514 :     return AH;
    2491             : }
    2492             : 
    2493             : /*
    2494             :  * Write out all data (tables & LOs)
    2495             :  */
    2496             : void
    2497         106 : WriteDataChunks(ArchiveHandle *AH, ParallelState *pstate)
    2498             : {
    2499             :     TocEntry   *te;
    2500             : 
    2501         106 :     if (pstate && pstate->numWorkers > 1)
    2502          16 :     {
    2503             :         /*
    2504             :          * In parallel mode, this code runs in the leader process.  We
    2505             :          * construct an array of candidate TEs, then sort it into decreasing
    2506             :          * size order, then dispatch each TE to a data-transfer worker.  By
    2507             :          * dumping larger tables first, we avoid getting into a situation
    2508             :          * where we're down to one job and it's big, losing parallelism.
    2509             :          */
    2510             :         TocEntry  **tes;
    2511             :         int         ntes;
    2512             : 
    2513          16 :         tes = (TocEntry **) pg_malloc(AH->tocCount * sizeof(TocEntry *));
    2514          16 :         ntes = 0;
    2515        2656 :         for (te = AH->toc->next; te != AH->toc; te = te->next)
    2516             :         {
    2517             :             /* Consider only TEs with dataDumper functions ... */
    2518        2640 :             if (!te->dataDumper)
    2519        2356 :                 continue;
    2520             :             /* ... and ignore ones not enabled for dump */
    2521         284 :             if ((te->reqs & REQ_DATA) == 0)
    2522           0 :                 continue;
    2523             : 
    2524         284 :             tes[ntes++] = te;
    2525             :         }
    2526             : 
    2527          16 :         if (ntes > 1)
    2528          14 :             qsort(tes, ntes, sizeof(TocEntry *), TocEntrySizeCompareQsort);
    2529             : 
    2530         300 :         for (int i = 0; i < ntes; i++)
    2531         284 :             DispatchJobForTocEntry(AH, pstate, tes[i], ACT_DUMP,
    2532             :                                    mark_dump_job_done, NULL);
    2533             : 
    2534          16 :         pg_free(tes);
    2535             : 
    2536             :         /* Now wait for workers to finish. */
    2537          16 :         WaitForWorkers(AH, pstate, WFW_ALL_IDLE);
    2538             :     }
    2539             :     else
    2540             :     {
    2541             :         /* Non-parallel mode: just dump all candidate TEs sequentially. */
    2542       11864 :         for (te = AH->toc->next; te != AH->toc; te = te->next)
    2543             :         {
    2544             :             /* Must have same filter conditions as above */
    2545       11774 :             if (!te->dataDumper)
    2546       11186 :                 continue;
    2547         588 :             if ((te->reqs & REQ_DATA) == 0)
    2548           6 :                 continue;
    2549             : 
    2550         582 :             WriteDataChunksForTocEntry(AH, te);
    2551             :         }
    2552             :     }
    2553         106 : }
    2554             : 
    2555             : 
    2556             : /*
    2557             :  * Callback function that's invoked in the leader process after a step has
    2558             :  * been parallel dumped.
    2559             :  *
    2560             :  * We don't need to do anything except check for worker failure.
    2561             :  */
    2562             : static void
    2563         284 : mark_dump_job_done(ArchiveHandle *AH,
    2564             :                    TocEntry *te,
    2565             :                    int status,
    2566             :                    void *callback_data)
    2567             : {
    2568         284 :     pg_log_info("finished item %d %s %s",
    2569             :                 te->dumpId, te->desc, te->tag);
    2570             : 
    2571         284 :     if (status != 0)
    2572           0 :         pg_fatal("worker process failed: exit code %d",
    2573             :                  status);
    2574         284 : }
    2575             : 
    2576             : 
    2577             : void
    2578         866 : WriteDataChunksForTocEntry(ArchiveHandle *AH, TocEntry *te)
    2579             : {
    2580             :     StartDataPtrType startPtr;
    2581             :     EndDataPtrType endPtr;
    2582             : 
    2583         866 :     AH->currToc = te;
    2584             : 
    2585         866 :     if (strcmp(te->desc, "BLOBS") == 0)
    2586             :     {
    2587          32 :         startPtr = AH->StartLOsPtr;
    2588          32 :         endPtr = AH->EndLOsPtr;
    2589             :     }
    2590             :     else
    2591             :     {
    2592         834 :         startPtr = AH->StartDataPtr;
    2593         834 :         endPtr = AH->EndDataPtr;
    2594             :     }
    2595             : 
    2596         866 :     if (startPtr != NULL)
    2597         866 :         (*startPtr) (AH, te);
    2598             : 
    2599             :     /*
    2600             :      * The user-provided DataDumper routine needs to call AH->WriteData
    2601             :      */
    2602         866 :     te->dataDumper((Archive *) AH, te->dataDumperArg);
    2603             : 
    2604         866 :     if (endPtr != NULL)
    2605         866 :         (*endPtr) (AH, te);
    2606             : 
    2607         866 :     AH->currToc = NULL;
    2608         866 : }
    2609             : 
    2610             : void
    2611         118 : WriteToc(ArchiveHandle *AH)
    2612             : {
    2613             :     TocEntry   *te;
    2614             :     char        workbuf[32];
    2615             :     int         tocCount;
    2616             :     int         i;
    2617             : 
    2618             :     /* count entries that will actually be dumped */
    2619         118 :     tocCount = 0;
    2620       16972 :     for (te = AH->toc->next; te != AH->toc; te = te->next)
    2621             :     {
    2622       16854 :         if ((te->reqs & (REQ_SCHEMA | REQ_DATA | REQ_STATS | REQ_SPECIAL)) != 0)
    2623       16848 :             tocCount++;
    2624             :     }
    2625             : 
    2626             :     /* printf("%d TOC Entries to save\n", tocCount); */
    2627             : 
    2628         118 :     WriteInt(AH, tocCount);
    2629             : 
    2630       16972 :     for (te = AH->toc->next; te != AH->toc; te = te->next)
    2631             :     {
    2632       16854 :         if ((te->reqs & (REQ_SCHEMA | REQ_DATA | REQ_STATS | REQ_SPECIAL)) == 0)
    2633           6 :             continue;
    2634             : 
    2635       16848 :         WriteInt(AH, te->dumpId);
    2636       16848 :         WriteInt(AH, te->dataDumper ? 1 : 0);
    2637             : 
    2638             :         /* OID is recorded as a string for historical reasons */
    2639       16848 :         sprintf(workbuf, "%u", te->catalogId.tableoid);
    2640       16848 :         WriteStr(AH, workbuf);
    2641       16848 :         sprintf(workbuf, "%u", te->catalogId.oid);
    2642       16848 :         WriteStr(AH, workbuf);
    2643             : 
    2644       16848 :         WriteStr(AH, te->tag);
    2645       16848 :         WriteStr(AH, te->desc);
    2646       16848 :         WriteInt(AH, te->section);
    2647             : 
    2648       16848 :         if (te->defnLen)
    2649             :         {
    2650             :             /*
    2651             :              * defnLen should only be set for custom format's second call to
    2652             :              * WriteToc(), which rewrites the TOC in place to update data
    2653             :              * offsets.  Instead of calling the defnDumper a second time
    2654             :              * (which could involve re-executing queries), just skip writing
    2655             :              * the entry.  While regenerating the definition should
    2656             :              * theoretically produce the same result as before, it's expensive
    2657             :              * and feels risky.
    2658             :              *
    2659             :              * The custom format only calls WriteToc() a second time if
    2660             :              * fseeko() is usable (see _CloseArchive() in pg_backup_custom.c),
    2661             :              * so we can safely use it without checking.  For other formats,
    2662             :              * we fail because one of our assumptions must no longer hold
    2663             :              * true.
    2664             :              *
    2665             :              * XXX This is a layering violation, but the alternative is an
    2666             :              * awkward and complicated callback infrastructure for this
    2667             :              * special case.  This might be worth revisiting in the future.
    2668             :              */
    2669         432 :             if (AH->format != archCustom)
    2670           0 :                 pg_fatal("unexpected TOC entry in WriteToc(): %d %s %s",
    2671             :                          te->dumpId, te->desc, te->tag);
    2672             : 
    2673         432 :             if (fseeko(AH->FH, te->defnLen, SEEK_CUR) != 0)
    2674           0 :                 pg_fatal("error during file seek: %m");
    2675             :         }
    2676       16416 :         else if (te->defnDumper)
    2677             :         {
    2678        3400 :             char       *defn = te->defnDumper((Archive *) AH, te->defnDumperArg, te);
    2679             : 
    2680        3400 :             te->defnLen = WriteStr(AH, defn);
    2681        3400 :             pg_free(defn);
    2682             :         }
    2683             :         else
    2684       13016 :             WriteStr(AH, te->defn);
    2685             : 
    2686       16848 :         WriteStr(AH, te->dropStmt);
    2687       16848 :         WriteStr(AH, te->copyStmt);
    2688       16848 :         WriteStr(AH, te->namespace);
    2689       16848 :         WriteStr(AH, te->tablespace);
    2690       16848 :         WriteStr(AH, te->tableam);
    2691       16848 :         WriteInt(AH, te->relkind);
    2692       16848 :         WriteStr(AH, te->owner);
    2693       16848 :         WriteStr(AH, "false");
    2694             : 
    2695             :         /* Dump list of dependencies */
    2696       43858 :         for (i = 0; i < te->nDeps; i++)
    2697             :         {
    2698       27010 :             sprintf(workbuf, "%d", te->dependencies[i]);
    2699       27010 :             WriteStr(AH, workbuf);
    2700             :         }
    2701       16848 :         WriteStr(AH, NULL);     /* Terminate List */
    2702             : 
    2703       16848 :         if (AH->WriteExtraTocPtr)
    2704       16848 :             AH->WriteExtraTocPtr(AH, te);
    2705             :     }
    2706         118 : }
    2707             : 
    2708             : void
    2709         112 : ReadToc(ArchiveHandle *AH)
    2710             : {
    2711             :     int         i;
    2712             :     char       *tmp;
    2713             :     DumpId     *deps;
    2714             :     int         depIdx;
    2715             :     int         depSize;
    2716             :     TocEntry   *te;
    2717             :     bool        is_supported;
    2718             : 
    2719         112 :     AH->tocCount = ReadInt(AH);
    2720         112 :     AH->maxDumpId = 0;
    2721             : 
    2722       17656 :     for (i = 0; i < AH->tocCount; i++)
    2723             :     {
    2724       17544 :         te = (TocEntry *) pg_malloc0(sizeof(TocEntry));
    2725       17544 :         te->dumpId = ReadInt(AH);
    2726             : 
    2727       17544 :         if (te->dumpId > AH->maxDumpId)
    2728        7036 :             AH->maxDumpId = te->dumpId;
    2729             : 
    2730             :         /* Sanity check */
    2731       17544 :         if (te->dumpId <= 0)
    2732           0 :             pg_fatal("entry ID %d out of range -- perhaps a corrupt TOC",
    2733             :                      te->dumpId);
    2734             : 
    2735       17544 :         te->hadDumper = ReadInt(AH);
    2736             : 
    2737       17544 :         if (AH->version >= K_VERS_1_8)
    2738             :         {
    2739       17544 :             tmp = ReadStr(AH);
    2740       17544 :             sscanf(tmp, "%u", &te->catalogId.tableoid);
    2741       17544 :             free(tmp);
    2742             :         }
    2743             :         else
    2744           0 :             te->catalogId.tableoid = InvalidOid;
    2745       17544 :         tmp = ReadStr(AH);
    2746       17544 :         sscanf(tmp, "%u", &te->catalogId.oid);
    2747       17544 :         free(tmp);
    2748             : 
    2749       17544 :         te->tag = ReadStr(AH);
    2750       17544 :         te->desc = ReadStr(AH);
    2751             : 
    2752       17544 :         if (AH->version >= K_VERS_1_11)
    2753             :         {
    2754       17544 :             te->section = ReadInt(AH);
    2755             :         }
    2756             :         else
    2757             :         {
    2758             :             /*
    2759             :              * Rules for pre-8.4 archives wherein pg_dump hasn't classified
    2760             :              * the entries into sections.  This list need not cover entry
    2761             :              * types added later than 8.4.
    2762             :              */
    2763           0 :             if (strcmp(te->desc, "COMMENT") == 0 ||
    2764           0 :                 strcmp(te->desc, "ACL") == 0 ||
    2765           0 :                 strcmp(te->desc, "ACL LANGUAGE") == 0)
    2766           0 :                 te->section = SECTION_NONE;
    2767           0 :             else if (strcmp(te->desc, "TABLE DATA") == 0 ||
    2768           0 :                      strcmp(te->desc, "BLOBS") == 0 ||
    2769           0 :                      strcmp(te->desc, "BLOB COMMENTS") == 0)
    2770           0 :                 te->section = SECTION_DATA;
    2771           0 :             else if (strcmp(te->desc, "CONSTRAINT") == 0 ||
    2772           0 :                      strcmp(te->desc, "CHECK CONSTRAINT") == 0 ||
    2773           0 :                      strcmp(te->desc, "FK CONSTRAINT") == 0 ||
    2774           0 :                      strcmp(te->desc, "INDEX") == 0 ||
    2775           0 :                      strcmp(te->desc, "RULE") == 0 ||
    2776           0 :                      strcmp(te->desc, "TRIGGER") == 0)
    2777           0 :                 te->section = SECTION_POST_DATA;
    2778             :             else
    2779           0 :                 te->section = SECTION_PRE_DATA;
    2780             :         }
    2781             : 
    2782       17544 :         te->defn = ReadStr(AH);
    2783       17544 :         te->dropStmt = ReadStr(AH);
    2784             : 
    2785       17544 :         if (AH->version >= K_VERS_1_3)
    2786       17544 :             te->copyStmt = ReadStr(AH);
    2787             : 
    2788       17544 :         if (AH->version >= K_VERS_1_6)
    2789       17544 :             te->namespace = ReadStr(AH);
    2790             : 
    2791       17544 :         if (AH->version >= K_VERS_1_10)
    2792       17544 :             te->tablespace = ReadStr(AH);
    2793             : 
    2794       17544 :         if (AH->version >= K_VERS_1_14)
    2795       17544 :             te->tableam = ReadStr(AH);
    2796             : 
    2797       17544 :         if (AH->version >= K_VERS_1_16)
    2798       17544 :             te->relkind = ReadInt(AH);
    2799             : 
    2800       17544 :         te->owner = ReadStr(AH);
    2801       17544 :         is_supported = true;
    2802       17544 :         if (AH->version < K_VERS_1_9)
    2803           0 :             is_supported = false;
    2804             :         else
    2805             :         {
    2806       17544 :             tmp = ReadStr(AH);
    2807             : 
    2808       17544 :             if (strcmp(tmp, "true") == 0)
    2809           0 :                 is_supported = false;
    2810             : 
    2811       17544 :             free(tmp);
    2812             :         }
    2813             : 
    2814       17544 :         if (!is_supported)
    2815           0 :             pg_log_warning("restoring tables WITH OIDS is not supported anymore");
    2816             : 
    2817             :         /* Read TOC entry dependencies */
    2818       17544 :         if (AH->version >= K_VERS_1_5)
    2819             :         {
    2820       17544 :             depSize = 100;
    2821       17544 :             deps = (DumpId *) pg_malloc(sizeof(DumpId) * depSize);
    2822       17544 :             depIdx = 0;
    2823             :             for (;;)
    2824             :             {
    2825       45848 :                 tmp = ReadStr(AH);
    2826       45848 :                 if (!tmp)
    2827       17544 :                     break;      /* end of list */
    2828       28304 :                 if (depIdx >= depSize)
    2829             :                 {
    2830           0 :                     depSize *= 2;
    2831           0 :                     deps = (DumpId *) pg_realloc(deps, sizeof(DumpId) * depSize);
    2832             :                 }
    2833       28304 :                 sscanf(tmp, "%d", &deps[depIdx]);
    2834       28304 :                 free(tmp);
    2835       28304 :                 depIdx++;
    2836             :             }
    2837             : 
    2838       17544 :             if (depIdx > 0)      /* We have a non-null entry */
    2839             :             {
    2840       14818 :                 deps = (DumpId *) pg_realloc(deps, sizeof(DumpId) * depIdx);
    2841       14818 :                 te->dependencies = deps;
    2842       14818 :                 te->nDeps = depIdx;
    2843             :             }
    2844             :             else
    2845             :             {
    2846        2726 :                 free(deps);
    2847        2726 :                 te->dependencies = NULL;
    2848        2726 :                 te->nDeps = 0;
    2849             :             }
    2850             :         }
    2851             :         else
    2852             :         {
    2853           0 :             te->dependencies = NULL;
    2854           0 :             te->nDeps = 0;
    2855             :         }
    2856       17544 :         te->dataLength = 0;
    2857             : 
    2858       17544 :         if (AH->ReadExtraTocPtr)
    2859       17544 :             AH->ReadExtraTocPtr(AH, te);
    2860             : 
    2861       17544 :         pg_log_debug("read TOC entry %d (ID %d) for %s %s",
    2862             :                      i, te->dumpId, te->desc, te->tag);
    2863             : 
    2864             :         /* link completed entry into TOC circular list */
    2865       17544 :         te->prev = AH->toc->prev;
    2866       17544 :         AH->toc->prev->next = te;
    2867       17544 :         AH->toc->prev = te;
    2868       17544 :         te->next = AH->toc;
    2869             : 
    2870             :         /* special processing immediately upon read for some items */
    2871       17544 :         if (strcmp(te->desc, "ENCODING") == 0)
    2872         112 :             processEncodingEntry(AH, te);
    2873       17432 :         else if (strcmp(te->desc, "STDSTRINGS") == 0)
    2874         112 :             processStdStringsEntry(AH, te);
    2875       17320 :         else if (strcmp(te->desc, "SEARCHPATH") == 0)
    2876         112 :             processSearchPathEntry(AH, te);
    2877             :     }
    2878         112 : }
    2879             : 
    2880             : static void
    2881         112 : processEncodingEntry(ArchiveHandle *AH, TocEntry *te)
    2882             : {
    2883             :     /* te->defn should have the form SET client_encoding = 'foo'; */
    2884         112 :     char       *defn = pg_strdup(te->defn);
    2885             :     char       *ptr1;
    2886         112 :     char       *ptr2 = NULL;
    2887             :     int         encoding;
    2888             : 
    2889         112 :     ptr1 = strchr(defn, '\'');
    2890         112 :     if (ptr1)
    2891         112 :         ptr2 = strchr(++ptr1, '\'');
    2892         112 :     if (ptr2)
    2893             :     {
    2894         112 :         *ptr2 = '\0';
    2895         112 :         encoding = pg_char_to_encoding(ptr1);
    2896         112 :         if (encoding < 0)
    2897           0 :             pg_fatal("unrecognized encoding \"%s\"",
    2898             :                      ptr1);
    2899         112 :         AH->public.encoding = encoding;
    2900         112 :         setFmtEncoding(encoding);
    2901             :     }
    2902             :     else
    2903           0 :         pg_fatal("invalid ENCODING item: %s",
    2904             :                  te->defn);
    2905             : 
    2906         112 :     free(defn);
    2907         112 : }
    2908             : 
    2909             : static void
    2910         112 : processStdStringsEntry(ArchiveHandle *AH, TocEntry *te)
    2911             : {
    2912             :     /* te->defn should have the form SET standard_conforming_strings = 'x'; */
    2913             :     char       *ptr1;
    2914             : 
    2915         112 :     ptr1 = strchr(te->defn, '\'');
    2916         112 :     if (ptr1 && strncmp(ptr1, "'on'", 4) == 0)
    2917         112 :         AH->public.std_strings = true;
    2918           0 :     else if (ptr1 && strncmp(ptr1, "'off'", 5) == 0)
    2919           0 :         AH->public.std_strings = false;
    2920             :     else
    2921           0 :         pg_fatal("invalid STDSTRINGS item: %s",
    2922             :                  te->defn);
    2923         112 : }
    2924             : 
    2925             : static void
    2926         112 : processSearchPathEntry(ArchiveHandle *AH, TocEntry *te)
    2927             : {
    2928             :     /*
    2929             :      * te->defn should contain a command to set search_path.  We just copy it
    2930             :      * verbatim for use later.
    2931             :      */
    2932         112 :     AH->public.searchpath = pg_strdup(te->defn);
    2933         112 : }
    2934             : 
    2935             : static void
    2936           0 : StrictNamesCheck(RestoreOptions *ropt)
    2937             : {
    2938             :     const char *missing_name;
    2939             : 
    2940             :     Assert(ropt->strict_names);
    2941             : 
    2942           0 :     if (ropt->schemaNames.head != NULL)
    2943             :     {
    2944           0 :         missing_name = simple_string_list_not_touched(&ropt->schemaNames);
    2945           0 :         if (missing_name != NULL)
    2946           0 :             pg_fatal("schema \"%s\" not found", missing_name);
    2947             :     }
    2948             : 
    2949           0 :     if (ropt->tableNames.head != NULL)
    2950             :     {
    2951           0 :         missing_name = simple_string_list_not_touched(&ropt->tableNames);
    2952           0 :         if (missing_name != NULL)
    2953           0 :             pg_fatal("table \"%s\" not found", missing_name);
    2954             :     }
    2955             : 
    2956           0 :     if (ropt->indexNames.head != NULL)
    2957             :     {
    2958           0 :         missing_name = simple_string_list_not_touched(&ropt->indexNames);
    2959           0 :         if (missing_name != NULL)
    2960           0 :             pg_fatal("index \"%s\" not found", missing_name);
    2961             :     }
    2962             : 
    2963           0 :     if (ropt->functionNames.head != NULL)
    2964             :     {
    2965           0 :         missing_name = simple_string_list_not_touched(&ropt->functionNames);
    2966           0 :         if (missing_name != NULL)
    2967           0 :             pg_fatal("function \"%s\" not found", missing_name);
    2968             :     }
    2969             : 
    2970           0 :     if (ropt->triggerNames.head != NULL)
    2971             :     {
    2972           0 :         missing_name = simple_string_list_not_touched(&ropt->triggerNames);
    2973           0 :         if (missing_name != NULL)
    2974           0 :             pg_fatal("trigger \"%s\" not found", missing_name);
    2975             :     }
    2976           0 : }
    2977             : 
    2978             : /*
    2979             :  * Determine whether we want to restore this TOC entry.
    2980             :  *
    2981             :  * Returns 0 if entry should be skipped, or some combination of the
    2982             :  * REQ_SCHEMA, REQ_DATA, and REQ_STATS bits if we want to restore schema, data
    2983             :  * and/or statistics portions of this TOC entry, or REQ_SPECIAL if it's a
    2984             :  * special entry.
    2985             :  */
    2986             : static int
    2987      102140 : _tocEntryRequired(TocEntry *te, teSection curSection, ArchiveHandle *AH)
    2988             : {
    2989      102140 :     int         res = REQ_SCHEMA | REQ_DATA;
    2990      102140 :     RestoreOptions *ropt = AH->public.ropt;
    2991             : 
    2992             :     /*
    2993             :      * For binary upgrade mode, dump pg_largeobject_metadata and the
    2994             :      * associated pg_shdepend rows. This is faster to restore than the
    2995             :      * equivalent set of large object commands.  We can only do this for
    2996             :      * upgrades from v12 and newer; in older versions, pg_largeobject_metadata
    2997             :      * was created WITH OIDS, so the OID column is hidden and won't be dumped.
    2998             :      */
    2999      102140 :     if (ropt->binary_upgrade && AH->public.remoteVersion >= 120000 &&
    3000        7812 :         strcmp(te->desc, "TABLE DATA") == 0 &&
    3001         146 :         (te->catalogId.oid == LargeObjectMetadataRelationId ||
    3002          74 :          te->catalogId.oid == SharedDependRelationId))
    3003         144 :         return REQ_DATA;
    3004             : 
    3005             :     /* These items are treated specially */
    3006      101996 :     if (strcmp(te->desc, "ENCODING") == 0 ||
    3007      101520 :         strcmp(te->desc, "STDSTRINGS") == 0 ||
    3008      101044 :         strcmp(te->desc, "SEARCHPATH") == 0)
    3009        1428 :         return REQ_SPECIAL;
    3010             : 
    3011      100568 :     if (strcmp(te->desc, "STATISTICS DATA") == 0)
    3012             :     {
    3013       11120 :         if (!ropt->dumpStatistics)
    3014           0 :             return 0;
    3015             : 
    3016       11120 :         res = REQ_STATS;
    3017             :     }
    3018             : 
    3019             :     /*
    3020             :      * DATABASE and DATABASE PROPERTIES also have a special rule: they are
    3021             :      * restored in createDB mode, and not restored otherwise, independently of
    3022             :      * all else.
    3023             :      */
    3024      100568 :     if (strcmp(te->desc, "DATABASE") == 0 ||
    3025      100292 :         strcmp(te->desc, "DATABASE PROPERTIES") == 0)
    3026             :     {
    3027         412 :         if (ropt->createDB)
    3028         356 :             return REQ_SCHEMA;
    3029             :         else
    3030          56 :             return 0;
    3031             :     }
    3032             : 
    3033             :     /*
    3034             :      * Process exclusions that affect certain classes of TOC entries.
    3035             :      */
    3036             : 
    3037             :     /* If it's an ACL, maybe ignore it */
    3038      100156 :     if (ropt->aclsSkip && _tocEntryIsACL(te))
    3039           0 :         return 0;
    3040             : 
    3041             :     /* If it's a comment, maybe ignore it */
    3042      100156 :     if (ropt->no_comments && strcmp(te->desc, "COMMENT") == 0)
    3043           0 :         return 0;
    3044             : 
    3045             :     /* If it's a policy, maybe ignore it */
    3046      100156 :     if (ropt->no_policies &&
    3047         744 :         (strcmp(te->desc, "POLICY") == 0 ||
    3048         744 :          strcmp(te->desc, "ROW SECURITY") == 0))
    3049           0 :         return 0;
    3050             : 
    3051             :     /*
    3052             :      * If it's a publication or a table part of a publication, maybe ignore
    3053             :      * it.
    3054             :      */
    3055      100156 :     if (ropt->no_publications &&
    3056           0 :         (strcmp(te->desc, "PUBLICATION") == 0 ||
    3057           0 :          strcmp(te->desc, "PUBLICATION TABLE") == 0 ||
    3058           0 :          strcmp(te->desc, "PUBLICATION TABLES IN SCHEMA") == 0))
    3059           0 :         return 0;
    3060             : 
    3061             :     /* If it's a security label, maybe ignore it */
    3062      100156 :     if (ropt->no_security_labels && strcmp(te->desc, "SECURITY LABEL") == 0)
    3063           0 :         return 0;
    3064             : 
    3065             :     /* If it's a subscription, maybe ignore it */
    3066      100156 :     if (ropt->no_subscriptions && strcmp(te->desc, "SUBSCRIPTION") == 0)
    3067           0 :         return 0;
    3068             : 
    3069             :     /* Ignore it if section is not to be dumped/restored */
    3070      100156 :     switch (curSection)
    3071             :     {
    3072       62680 :         case SECTION_PRE_DATA:
    3073       62680 :             if (!(ropt->dumpSections & DUMP_PRE_DATA))
    3074         760 :                 return 0;
    3075       61920 :             break;
    3076       18634 :         case SECTION_DATA:
    3077       18634 :             if (!(ropt->dumpSections & DUMP_DATA))
    3078         376 :                 return 0;
    3079       18258 :             break;
    3080       18842 :         case SECTION_POST_DATA:
    3081       18842 :             if (!(ropt->dumpSections & DUMP_POST_DATA))
    3082         444 :                 return 0;
    3083       18398 :             break;
    3084           0 :         default:
    3085             :             /* shouldn't get here, really, but ignore it */
    3086           0 :             return 0;
    3087             :     }
    3088             : 
    3089             :     /* Ignore it if rejected by idWanted[] (cf. SortTocFromFile) */
    3090       98576 :     if (ropt->idWanted && !ropt->idWanted[te->dumpId - 1])
    3091           0 :         return 0;
    3092             : 
    3093             :     /*
    3094             :      * Check options for selective dump/restore.
    3095             :      */
    3096       98576 :     if (strcmp(te->desc, "ACL") == 0 ||
    3097       93504 :         strcmp(te->desc, "COMMENT") == 0 ||
    3098       79634 :         strcmp(te->desc, "STATISTICS DATA") == 0 ||
    3099       68802 :         strcmp(te->desc, "SECURITY LABEL") == 0)
    3100             :     {
    3101             :         /* Database properties react to createDB, not selectivity options. */
    3102       29774 :         if (strncmp(te->tag, "DATABASE ", 9) == 0)
    3103             :         {
    3104         184 :             if (!ropt->createDB)
    3105          38 :                 return 0;
    3106             :         }
    3107       29590 :         else if (ropt->schemaNames.head != NULL ||
    3108       29590 :                  ropt->schemaExcludeNames.head != NULL ||
    3109       29590 :                  ropt->selTypes)
    3110             :         {
    3111             :             /*
    3112             :              * In a selective dump/restore, we want to restore these dependent
    3113             :              * TOC entry types only if their parent object is being restored.
    3114             :              * Without selectivity options, we let through everything in the
    3115             :              * archive.  Note there may be such entries with no parent, eg
    3116             :              * non-default ACLs for built-in objects.  Also, we make
    3117             :              * per-column ACLs additionally depend on the table's ACL if any
    3118             :              * to ensure correct restore order, so those dependencies should
    3119             :              * be ignored in this check.
    3120             :              *
    3121             :              * This code depends on the parent having been marked already,
    3122             :              * which should be the case; if it isn't, perhaps due to
    3123             :              * SortTocFromFile rearrangement, skipping the dependent entry
    3124             :              * seems prudent anyway.
    3125             :              *
    3126             :              * Ideally we'd handle, eg, table CHECK constraints this way too.
    3127             :              * But it's hard to tell which of their dependencies is the one to
    3128             :              * consult.
    3129             :              */
    3130           0 :             bool        dumpthis = false;
    3131             : 
    3132           0 :             for (int i = 0; i < te->nDeps; i++)
    3133             :             {
    3134           0 :                 TocEntry   *pte = getTocEntryByDumpId(AH, te->dependencies[i]);
    3135             : 
    3136           0 :                 if (!pte)
    3137           0 :                     continue;   /* probably shouldn't happen */
    3138           0 :                 if (strcmp(pte->desc, "ACL") == 0)
    3139           0 :                     continue;   /* ignore dependency on another ACL */
    3140           0 :                 if (pte->reqs == 0)
    3141           0 :                     continue;   /* this object isn't marked, so ignore it */
    3142             :                 /* Found a parent to be dumped, so we want to dump this too */
    3143           0 :                 dumpthis = true;
    3144           0 :                 break;
    3145             :             }
    3146           0 :             if (!dumpthis)
    3147           0 :                 return 0;
    3148             :         }
    3149             :     }
    3150             :     else
    3151             :     {
    3152             :         /* Apply selective-restore rules for standalone TOC entries. */
    3153       68802 :         if (ropt->schemaNames.head != NULL)
    3154             :         {
    3155             :             /* If no namespace is specified, it means all. */
    3156          40 :             if (!te->namespace)
    3157           4 :                 return 0;
    3158          36 :             if (!simple_string_list_member(&ropt->schemaNames, te->namespace))
    3159          28 :                 return 0;
    3160             :         }
    3161             : 
    3162       68770 :         if (ropt->schemaExcludeNames.head != NULL &&
    3163          76 :             te->namespace &&
    3164          36 :             simple_string_list_member(&ropt->schemaExcludeNames, te->namespace))
    3165           8 :             return 0;
    3166             : 
    3167       68762 :         if (ropt->selTypes)
    3168             :         {
    3169         156 :             if (strcmp(te->desc, "TABLE") == 0 ||
    3170         116 :                 strcmp(te->desc, "TABLE DATA") == 0 ||
    3171          76 :                 strcmp(te->desc, "VIEW") == 0 ||
    3172          76 :                 strcmp(te->desc, "FOREIGN TABLE") == 0 ||
    3173          76 :                 strcmp(te->desc, "MATERIALIZED VIEW") == 0 ||
    3174          76 :                 strcmp(te->desc, "MATERIALIZED VIEW DATA") == 0 ||
    3175          76 :                 strcmp(te->desc, "SEQUENCE") == 0 ||
    3176          70 :                 strcmp(te->desc, "SEQUENCE SET") == 0)
    3177             :             {
    3178          92 :                 if (!ropt->selTable)
    3179          60 :                     return 0;
    3180          32 :                 if (ropt->tableNames.head != NULL &&
    3181          32 :                     !simple_string_list_member(&ropt->tableNames, te->tag))
    3182          28 :                     return 0;
    3183             :             }
    3184          64 :             else if (strcmp(te->desc, "INDEX") == 0)
    3185             :             {
    3186          12 :                 if (!ropt->selIndex)
    3187           8 :                     return 0;
    3188           4 :                 if (ropt->indexNames.head != NULL &&
    3189           4 :                     !simple_string_list_member(&ropt->indexNames, te->tag))
    3190           2 :                     return 0;
    3191             :             }
    3192          52 :             else if (strcmp(te->desc, "FUNCTION") == 0 ||
    3193          28 :                      strcmp(te->desc, "AGGREGATE") == 0 ||
    3194          28 :                      strcmp(te->desc, "PROCEDURE") == 0)
    3195             :             {
    3196          24 :                 if (!ropt->selFunction)
    3197           8 :                     return 0;
    3198          16 :                 if (ropt->functionNames.head != NULL &&
    3199          16 :                     !simple_string_list_member(&ropt->functionNames, te->tag))
    3200          12 :                     return 0;
    3201             :             }
    3202          28 :             else if (strcmp(te->desc, "TRIGGER") == 0)
    3203             :             {
    3204          12 :                 if (!ropt->selTrigger)
    3205           8 :                     return 0;
    3206           4 :                 if (ropt->triggerNames.head != NULL &&
    3207           4 :                     !simple_string_list_member(&ropt->triggerNames, te->tag))
    3208           2 :                     return 0;
    3209             :             }
    3210             :             else
    3211          16 :                 return 0;
    3212             :         }
    3213             :     }
    3214             : 
    3215             : 
    3216             :     /*
    3217             :      * Determine whether the TOC entry contains schema and/or data components,
    3218             :      * and mask off inapplicable REQ bits.  If it had a dataDumper, assume
    3219             :      * it's both schema and data.  Otherwise it's probably schema-only, but
    3220             :      * there are exceptions.
    3221             :      */
    3222       98354 :     if (!te->hadDumper)
    3223             :     {
    3224             :         /*
    3225             :          * Special Case: If 'SEQUENCE SET' or anything to do with LOs, then it
    3226             :          * is considered a data entry.  We don't need to check for BLOBS or
    3227             :          * old-style BLOB COMMENTS entries, because they will have hadDumper =
    3228             :          * true ... but we do need to check new-style BLOB ACLs, comments,
    3229             :          * etc.
    3230             :          */
    3231       88598 :         if (strcmp(te->desc, "SEQUENCE SET") == 0 ||
    3232       87610 :             strcmp(te->desc, "BLOB") == 0 ||
    3233       87610 :             strcmp(te->desc, "BLOB METADATA") == 0 ||
    3234       87418 :             (strcmp(te->desc, "ACL") == 0 &&
    3235        5072 :              strncmp(te->tag, "LARGE OBJECT", 12) == 0) ||
    3236       87328 :             (strcmp(te->desc, "COMMENT") == 0 &&
    3237       13832 :              strncmp(te->tag, "LARGE OBJECT", 12) == 0) ||
    3238       87208 :             (strcmp(te->desc, "SECURITY LABEL") == 0 &&
    3239           0 :              strncmp(te->tag, "LARGE OBJECT", 12) == 0))
    3240        1390 :             res = res & REQ_DATA;
    3241             :         else
    3242       87208 :             res = res & ~REQ_DATA;
    3243             :     }
    3244             : 
    3245             :     /*
    3246             :      * If there's no definition command, there's no schema component.  Treat
    3247             :      * "load via partition root" comments as not schema.
    3248             :      */
    3249       98354 :     if (!te->defn || !te->defn[0] ||
    3250       81942 :         strncmp(te->defn, "-- load via partition root ", 27) == 0)
    3251       16620 :         res = res & ~REQ_SCHEMA;
    3252             : 
    3253             :     /*
    3254             :      * Special case: <Init> type with <Max OID> tag; this is obsolete and we
    3255             :      * always ignore it.
    3256             :      */
    3257       98354 :     if ((strcmp(te->desc, "<Init>") == 0) && (strcmp(te->tag, "Max OID") == 0))
    3258           0 :         return 0;
    3259             : 
    3260             :     /* Mask it if we don't want data */
    3261       98354 :     if (!ropt->dumpData)
    3262             :     {
    3263             :         /*
    3264             :          * The sequence_data option overrides dumpData for SEQUENCE SET.
    3265             :          *
    3266             :          * In binary-upgrade mode, even with dumpData unset, we do not mask
    3267             :          * out large objects.  (Only large object definitions, comments and
    3268             :          * other metadata should be generated in binary-upgrade mode, not the
    3269             :          * actual data, but that need not concern us here.)
    3270             :          */
    3271        8132 :         if (!(ropt->sequence_data && strcmp(te->desc, "SEQUENCE SET") == 0) &&
    3272        8002 :             !(ropt->binary_upgrade &&
    3273        7182 :               (strcmp(te->desc, "BLOB") == 0 ||
    3274        7182 :                strcmp(te->desc, "BLOB METADATA") == 0 ||
    3275        7182 :                (strcmp(te->desc, "ACL") == 0 &&
    3276         176 :                 strncmp(te->tag, "LARGE OBJECT", 12) == 0) ||
    3277        7182 :                (strcmp(te->desc, "COMMENT") == 0 &&
    3278         190 :                 strncmp(te->tag, "LARGE OBJECT", 12) == 0) ||
    3279        7176 :                (strcmp(te->desc, "SECURITY LABEL") == 0 &&
    3280           0 :                 strncmp(te->tag, "LARGE OBJECT", 12) == 0))))
    3281        7996 :             res = res & (REQ_SCHEMA | REQ_STATS);
    3282             :     }
    3283             : 
    3284             :     /* Mask it if we don't want schema */
    3285       98354 :     if (!ropt->dumpSchema)
    3286         886 :         res = res & (REQ_DATA | REQ_STATS);
    3287             : 
    3288       98354 :     return res;
    3289             : }
    3290             : 
    3291             : /*
    3292             :  * Identify which pass we should restore this TOC entry in.
    3293             :  *
    3294             :  * See notes with the RestorePass typedef in pg_backup_archiver.h.
    3295             :  */
    3296             : static RestorePass
    3297      216318 : _tocEntryRestorePass(TocEntry *te)
    3298             : {
    3299             :     /* "ACL LANGUAGE" was a crock emitted only in PG 7.4 */
    3300      216318 :     if (strcmp(te->desc, "ACL") == 0 ||
    3301      205468 :         strcmp(te->desc, "ACL LANGUAGE") == 0 ||
    3302      205468 :         strcmp(te->desc, "DEFAULT ACL") == 0)
    3303       11690 :         return RESTORE_PASS_ACL;
    3304      204628 :     if (strcmp(te->desc, "EVENT TRIGGER") == 0 ||
    3305      204402 :         strcmp(te->desc, "MATERIALIZED VIEW DATA") == 0)
    3306        1938 :         return RESTORE_PASS_POST_ACL;
    3307             : 
    3308             :     /*
    3309             :      * Comments need to be emitted in the same pass as their parent objects.
    3310             :      * ACLs haven't got comments, and neither do matview data objects, but
    3311             :      * event triggers do.  (Fortunately, event triggers haven't got ACLs, or
    3312             :      * we'd need yet another weird special case.)
    3313             :      */
    3314      202690 :     if (strcmp(te->desc, "COMMENT") == 0 &&
    3315       27784 :         strncmp(te->tag, "EVENT TRIGGER ", 14) == 0)
    3316           0 :         return RESTORE_PASS_POST_ACL;
    3317             : 
    3318             :     /*
    3319             :      * If statistics data is dependent on materialized view data, it must be
    3320             :      * deferred to RESTORE_PASS_POST_ACL.  Those entries are already marked as
    3321             :      * SECTION_POST_DATA, and some other stats entries (e.g., index stats)
    3322             :      * will also be marked as SECTION_POST_DATA.  Additionally, our lookahead
    3323             :      * code in fetchAttributeStats() assumes that we dump all statistics data
    3324             :      * entries in TOC order.  To ensure this assumption holds, we move all
    3325             :      * statistics data entries in SECTION_POST_DATA to RESTORE_PASS_POST_ACL.
    3326             :      */
    3327      202690 :     if (strcmp(te->desc, "STATISTICS DATA") == 0 &&
    3328       20406 :         te->section == SECTION_POST_DATA)
    3329        7404 :         return RESTORE_PASS_POST_ACL;
    3330             : 
    3331             :     /* All else can be handled in the main pass. */
    3332      195286 :     return RESTORE_PASS_MAIN;
    3333             : }
    3334             : 
    3335             : /*
    3336             :  * Identify TOC entries that are ACLs.
    3337             :  *
    3338             :  * Note: it seems worth duplicating some code here to avoid a hard-wired
    3339             :  * assumption that these are exactly the same entries that we restore during
    3340             :  * the RESTORE_PASS_ACL phase.
    3341             :  */
    3342             : static bool
    3343       83122 : _tocEntryIsACL(TocEntry *te)
    3344             : {
    3345             :     /* "ACL LANGUAGE" was a crock emitted only in PG 7.4 */
    3346       83122 :     if (strcmp(te->desc, "ACL") == 0 ||
    3347       79366 :         strcmp(te->desc, "ACL LANGUAGE") == 0 ||
    3348       79366 :         strcmp(te->desc, "DEFAULT ACL") == 0)
    3349        4036 :         return true;
    3350       79086 :     return false;
    3351             : }
    3352             : 
    3353             : /*
    3354             :  * Issue SET commands for parameters that we want to have set the same way
    3355             :  * at all times during execution of a restore script.
    3356             :  */
    3357             : static void
    3358         578 : _doSetFixedOutputState(ArchiveHandle *AH)
    3359             : {
    3360         578 :     RestoreOptions *ropt = AH->public.ropt;
    3361             : 
    3362             :     /*
    3363             :      * Disable timeouts to allow for slow commands, idle parallel workers, etc
    3364             :      */
    3365         578 :     ahprintf(AH, "SET statement_timeout = 0;\n");
    3366         578 :     ahprintf(AH, "SET lock_timeout = 0;\n");
    3367         578 :     ahprintf(AH, "SET idle_in_transaction_session_timeout = 0;\n");
    3368         578 :     ahprintf(AH, "SET transaction_timeout = 0;\n");
    3369             : 
    3370             :     /* Select the correct character set encoding */
    3371         578 :     ahprintf(AH, "SET client_encoding = '%s';\n",
    3372             :              pg_encoding_to_char(AH->public.encoding));
    3373             : 
    3374             :     /* Select the correct string literal syntax */
    3375         578 :     ahprintf(AH, "SET standard_conforming_strings = %s;\n",
    3376         578 :              AH->public.std_strings ? "on" : "off");
    3377             : 
    3378             :     /* Select the role to be used during restore */
    3379         578 :     if (ropt && ropt->use_role)
    3380           0 :         ahprintf(AH, "SET ROLE %s;\n", fmtId(ropt->use_role));
    3381             : 
    3382             :     /* Select the dump-time search_path */
    3383         578 :     if (AH->public.searchpath)
    3384         578 :         ahprintf(AH, "%s", AH->public.searchpath);
    3385             : 
    3386             :     /* Make sure function checking is disabled */
    3387         578 :     ahprintf(AH, "SET check_function_bodies = false;\n");
    3388             : 
    3389             :     /* Ensure that all valid XML data will be accepted */
    3390         578 :     ahprintf(AH, "SET xmloption = content;\n");
    3391             : 
    3392             :     /* Avoid annoying notices etc */
    3393         578 :     ahprintf(AH, "SET client_min_messages = warning;\n");
    3394         578 :     if (!AH->public.std_strings)
    3395           0 :         ahprintf(AH, "SET escape_string_warning = off;\n");
    3396             : 
    3397             :     /* Adjust row-security state */
    3398         578 :     if (ropt && ropt->enable_row_security)
    3399           0 :         ahprintf(AH, "SET row_security = on;\n");
    3400             :     else
    3401         578 :         ahprintf(AH, "SET row_security = off;\n");
    3402             : 
    3403             :     /*
    3404             :      * In --transaction-size mode, we should always be in a transaction when
    3405             :      * we begin to restore objects.
    3406             :      */
    3407         578 :     if (ropt && ropt->txn_size > 0)
    3408             :     {
    3409         168 :         if (AH->connection)
    3410         168 :             StartTransaction(&AH->public);
    3411             :         else
    3412           0 :             ahprintf(AH, "\nBEGIN;\n");
    3413         168 :         AH->txnCount = 0;
    3414             :     }
    3415             : 
    3416         578 :     ahprintf(AH, "\n");
    3417         578 : }
    3418             : 
    3419             : /*
    3420             :  * Issue a SET SESSION AUTHORIZATION command.  Caller is responsible
    3421             :  * for updating state if appropriate.  If user is NULL or an empty string,
    3422             :  * the specification DEFAULT will be used.
    3423             :  */
    3424             : static void
    3425           2 : _doSetSessionAuth(ArchiveHandle *AH, const char *user)
    3426             : {
    3427           2 :     PQExpBuffer cmd = createPQExpBuffer();
    3428             : 
    3429           2 :     appendPQExpBufferStr(cmd, "SET SESSION AUTHORIZATION ");
    3430             : 
    3431             :     /*
    3432             :      * SQL requires a string literal here.  Might as well be correct.
    3433             :      */
    3434           2 :     if (user && *user)
    3435           2 :         appendStringLiteralAHX(cmd, user, AH);
    3436             :     else
    3437           0 :         appendPQExpBufferStr(cmd, "DEFAULT");
    3438           2 :     appendPQExpBufferChar(cmd, ';');
    3439             : 
    3440           2 :     if (RestoringToDB(AH))
    3441             :     {
    3442             :         PGresult   *res;
    3443             : 
    3444           0 :         res = PQexec(AH->connection, cmd->data);
    3445             : 
    3446           0 :         if (!res || PQresultStatus(res) != PGRES_COMMAND_OK)
    3447             :             /* NOT warn_or_exit_horribly... use -O instead to skip this. */
    3448           0 :             pg_fatal("could not set session user to \"%s\": %s",
    3449             :                      user, PQerrorMessage(AH->connection));
    3450             : 
    3451           0 :         PQclear(res);
    3452             :     }
    3453             :     else
    3454           2 :         ahprintf(AH, "%s\n\n", cmd->data);
    3455             : 
    3456           2 :     destroyPQExpBuffer(cmd);
    3457           2 : }
    3458             : 
    3459             : 
    3460             : /*
    3461             :  * Issue the commands to connect to the specified database.
    3462             :  *
    3463             :  * If we're currently restoring right into a database, this will
    3464             :  * actually establish a connection. Otherwise it puts a \connect into
    3465             :  * the script output.
    3466             :  */
    3467             : static void
    3468         184 : _reconnectToDB(ArchiveHandle *AH, const char *dbname)
    3469             : {
    3470         184 :     if (RestoringToDB(AH))
    3471         114 :         ReconnectToServer(AH, dbname);
    3472             :     else
    3473             :     {
    3474             :         PQExpBufferData connectbuf;
    3475          70 :         RestoreOptions *ropt = AH->public.ropt;
    3476             : 
    3477             :         /*
    3478             :          * We must temporarily exit restricted mode for \connect, etc.
    3479             :          * Anything added between this line and the following \restrict must
    3480             :          * be careful to avoid any possible meta-command injection vectors.
    3481             :          */
    3482          70 :         ahprintf(AH, "\\unrestrict %s\n", ropt->restrict_key);
    3483             : 
    3484          70 :         initPQExpBuffer(&connectbuf);
    3485          70 :         appendPsqlMetaConnect(&connectbuf, dbname);
    3486          70 :         ahprintf(AH, "%s", connectbuf.data);
    3487          70 :         termPQExpBuffer(&connectbuf);
    3488             : 
    3489          70 :         ahprintf(AH, "\\restrict %s\n\n", ropt->restrict_key);
    3490             :     }
    3491             : 
    3492             :     /*
    3493             :      * NOTE: currUser keeps track of what the imaginary session user in our
    3494             :      * script is.  It's now effectively reset to the original userID.
    3495             :      */
    3496         184 :     free(AH->currUser);
    3497         184 :     AH->currUser = NULL;
    3498             : 
    3499             :     /* don't assume we still know the output schema, tablespace, etc either */
    3500         184 :     free(AH->currSchema);
    3501         184 :     AH->currSchema = NULL;
    3502             : 
    3503         184 :     free(AH->currTableAm);
    3504         184 :     AH->currTableAm = NULL;
    3505             : 
    3506         184 :     free(AH->currTablespace);
    3507         184 :     AH->currTablespace = NULL;
    3508             : 
    3509             :     /* re-establish fixed state */
    3510         184 :     _doSetFixedOutputState(AH);
    3511         184 : }
    3512             : 
    3513             : /*
    3514             :  * Become the specified user, and update state to avoid redundant commands
    3515             :  *
    3516             :  * NULL or empty argument is taken to mean restoring the session default
    3517             :  */
    3518             : static void
    3519         152 : _becomeUser(ArchiveHandle *AH, const char *user)
    3520             : {
    3521         152 :     if (!user)
    3522           0 :         user = "";                /* avoid null pointers */
    3523             : 
    3524         152 :     if (AH->currUser && strcmp(AH->currUser, user) == 0)
    3525         150 :         return;                 /* no need to do anything */
    3526             : 
    3527           2 :     _doSetSessionAuth(AH, user);
    3528             : 
    3529             :     /*
    3530             :      * NOTE: currUser keeps track of what the imaginary session user in our
    3531             :      * script is
    3532             :      */
    3533           2 :     free(AH->currUser);
    3534           2 :     AH->currUser = pg_strdup(user);
    3535             : }
    3536             : 
    3537             : /*
    3538             :  * Become the owner of the given TOC entry object.  If
    3539             :  * changes in ownership are not allowed, this doesn't do anything.
    3540             :  */
    3541             : static void
    3542       91776 : _becomeOwner(ArchiveHandle *AH, TocEntry *te)
    3543             : {
    3544       91776 :     RestoreOptions *ropt = AH->public.ropt;
    3545             : 
    3546       91776 :     if (ropt && (ropt->noOwner || !ropt->use_setsessauth))
    3547       91776 :         return;
    3548             : 
    3549           0 :     _becomeUser(AH, te->owner);
    3550             : }
    3551             : 
    3552             : 
    3553             : /*
    3554             :  * Issue the commands to select the specified schema as the current schema
    3555             :  * in the target database.
    3556             :  */
    3557             : static void
    3558       91924 : _selectOutputSchema(ArchiveHandle *AH, const char *schemaName)
    3559             : {
    3560             :     PQExpBuffer qry;
    3561             : 
    3562             :     /*
    3563             :      * If there was a SEARCHPATH TOC entry, we're supposed to just stay with
    3564             :      * that search_path rather than switching to entry-specific paths.
    3565             :      * Otherwise, it's an old archive that will not restore correctly unless
    3566             :      * we set the search_path as it's expecting.
    3567             :      */
    3568       91924 :     if (AH->public.searchpath)
    3569       91924 :         return;
    3570             : 
    3571           0 :     if (!schemaName || *schemaName == '\0' ||
    3572           0 :         (AH->currSchema && strcmp(AH->currSchema, schemaName) == 0))
    3573           0 :         return;                 /* no need to do anything */
    3574             : 
    3575           0 :     qry = createPQExpBuffer();
    3576             : 
    3577           0 :     appendPQExpBuffer(qry, "SET search_path = %s",
    3578             :                       fmtId(schemaName));
    3579           0 :     if (strcmp(schemaName, "pg_catalog") != 0)
    3580           0 :         appendPQExpBufferStr(qry, ", pg_catalog");
    3581             : 
    3582           0 :     if (RestoringToDB(AH))
    3583             :     {
    3584             :         PGresult   *res;
    3585             : 
    3586           0 :         res = PQexec(AH->connection, qry->data);
    3587             : 
    3588           0 :         if (!res || PQresultStatus(res) != PGRES_COMMAND_OK)
    3589           0 :             warn_or_exit_horribly(AH,
    3590             :                                   "could not set \"search_path\" to \"%s\": %s",
    3591           0 :                                   schemaName, PQerrorMessage(AH->connection));
    3592             : 
    3593           0 :         PQclear(res);
    3594             :     }
    3595             :     else
    3596           0 :         ahprintf(AH, "%s;\n\n", qry->data);
    3597             : 
    3598           0 :     free(AH->currSchema);
    3599           0 :     AH->currSchema = pg_strdup(schemaName);
    3600             : 
    3601           0 :     destroyPQExpBuffer(qry);
    3602             : }
    3603             : 
    3604             : /*
    3605             :  * Issue the commands to select the specified tablespace as the current one
    3606             :  * in the target database.
    3607             :  */
    3608             : static void
    3609       82454 : _selectTablespace(ArchiveHandle *AH, const char *tablespace)
    3610             : {
    3611       82454 :     RestoreOptions *ropt = AH->public.ropt;
    3612             :     PQExpBuffer qry;
    3613             :     const char *want,
    3614             :                *have;
    3615             : 
    3616             :     /* do nothing in --no-tablespaces mode */
    3617       82454 :     if (ropt->noTablespace)
    3618           0 :         return;
    3619             : 
    3620       82454 :     have = AH->currTablespace;
    3621       82454 :     want = tablespace;
    3622             : 
    3623             :     /* no need to do anything for non-tablespace object */
    3624       82454 :     if (!want)
    3625       65866 :         return;
    3626             : 
    3627       16588 :     if (have && strcmp(want, have) == 0)
    3628       16132 :         return;                 /* no need to do anything */
    3629             : 
    3630         456 :     qry = createPQExpBuffer();
    3631             : 
    3632         456 :     if (strcmp(want, "") == 0)
    3633             :     {
    3634             :         /* We want the tablespace to be the database's default */
    3635         340 :         appendPQExpBufferStr(qry, "SET default_tablespace = ''");
    3636             :     }
    3637             :     else
    3638             :     {
    3639             :         /* We want an explicit tablespace */
    3640         116 :         appendPQExpBuffer(qry, "SET default_tablespace = %s", fmtId(want));
    3641             :     }
    3642             : 
    3643         456 :     if (RestoringToDB(AH))
    3644             :     {
    3645             :         PGresult   *res;
    3646             : 
    3647          58 :         res = PQexec(AH->connection, qry->data);
    3648             : 
    3649          58 :         if (!res || PQresultStatus(res) != PGRES_COMMAND_OK)
    3650           0 :             warn_or_exit_horribly(AH,
    3651             :                                   "could not set \"default_tablespace\" to %s: %s",
    3652           0 :                                   fmtId(want), PQerrorMessage(AH->connection));
    3653             : 
    3654          58 :         PQclear(res);
    3655             :     }
    3656             :     else
    3657         398 :         ahprintf(AH, "%s;\n\n", qry->data);
    3658             : 
    3659         456 :     free(AH->currTablespace);
    3660         456 :     AH->currTablespace = pg_strdup(want);
    3661             : 
    3662         456 :     destroyPQExpBuffer(qry);
    3663             : }
    3664             : 
    3665             : /*
    3666             :  * Set the proper default_table_access_method value for the table.
    3667             :  */
    3668             : static void
    3669       81306 : _selectTableAccessMethod(ArchiveHandle *AH, const char *tableam)
    3670             : {
    3671       81306 :     RestoreOptions *ropt = AH->public.ropt;
    3672             :     PQExpBuffer cmd;
    3673             :     const char *want,
    3674             :                *have;
    3675             : 
    3676             :     /* do nothing in --no-table-access-method mode */
    3677       81306 :     if (ropt->noTableAm)
    3678         750 :         return;
    3679             : 
    3680       80556 :     have = AH->currTableAm;
    3681       80556 :     want = tableam;
    3682             : 
    3683       80556 :     if (!want)
    3684       70200 :         return;
    3685             : 
    3686       10356 :     if (have && strcmp(want, have) == 0)
    3687        9706 :         return;
    3688             : 
    3689         650 :     cmd = createPQExpBuffer();
    3690         650 :     appendPQExpBuffer(cmd, "SET default_table_access_method = %s;", fmtId(want));
    3691             : 
    3692         650 :     if (RestoringToDB(AH))
    3693             :     {
    3694             :         PGresult   *res;
    3695             : 
    3696          46 :         res = PQexec(AH->connection, cmd->data);
    3697             : 
    3698          46 :         if (!res || PQresultStatus(res) != PGRES_COMMAND_OK)
    3699           0 :             warn_or_exit_horribly(AH,
    3700             :                                   "could not set \"default_table_access_method\": %s",
    3701           0 :                                   PQerrorMessage(AH->connection));
    3702             : 
    3703          46 :         PQclear(res);
    3704             :     }
    3705             :     else
    3706         604 :         ahprintf(AH, "%s\n\n", cmd->data);
    3707             : 
    3708         650 :     destroyPQExpBuffer(cmd);
    3709             : 
    3710         650 :     free(AH->currTableAm);
    3711         650 :     AH->currTableAm = pg_strdup(want);
    3712             : }
    3713             : 
    3714             : /*
    3715             :  * Set the proper default table access method for a table without storage.
    3716             :  * Currently, this is required only for partitioned tables with a table AM.
    3717             :  */
    3718             : static void
    3719        1148 : _printTableAccessMethodNoStorage(ArchiveHandle *AH, TocEntry *te)
    3720             : {
    3721        1148 :     RestoreOptions *ropt = AH->public.ropt;
    3722        1148 :     const char *tableam = te->tableam;
    3723             :     PQExpBuffer cmd;
    3724             : 
    3725             :     /* do nothing in --no-table-access-method mode */
    3726        1148 :     if (ropt->noTableAm)
    3727           8 :         return;
    3728             : 
    3729        1140 :     if (!tableam)
    3730        1074 :         return;
    3731             : 
    3732             :     Assert(te->relkind == RELKIND_PARTITIONED_TABLE);
    3733             : 
    3734          66 :     cmd = createPQExpBuffer();
    3735             : 
    3736          66 :     appendPQExpBufferStr(cmd, "ALTER TABLE ");
    3737          66 :     appendPQExpBuffer(cmd, "%s ", fmtQualifiedId(te->namespace, te->tag));
    3738          66 :     appendPQExpBuffer(cmd, "SET ACCESS METHOD %s;",
    3739             :                       fmtId(tableam));
    3740             : 
    3741          66 :     if (RestoringToDB(AH))
    3742             :     {
    3743             :         PGresult   *res;
    3744             : 
    3745           0 :         res = PQexec(AH->connection, cmd->data);
    3746             : 
    3747           0 :         if (!res || PQresultStatus(res) != PGRES_COMMAND_OK)
    3748           0 :             warn_or_exit_horribly(AH,
    3749             :                                   "could not alter table access method: %s",
    3750           0 :                                   PQerrorMessage(AH->connection));
    3751           0 :         PQclear(res);
    3752             :     }
    3753             :     else
    3754          66 :         ahprintf(AH, "%s\n\n", cmd->data);
    3755             : 
    3756          66 :     destroyPQExpBuffer(cmd);
    3757             : }
    3758             : 
    3759             : /*
    3760             :  * Extract an object description for a TOC entry, and append it to buf.
    3761             :  *
    3762             :  * This is used for ALTER ... OWNER TO.
    3763             :  *
    3764             :  * If the object type has no owner, do nothing.
    3765             :  */
    3766             : static void
    3767       41212 : _getObjectDescription(PQExpBuffer buf, const TocEntry *te)
    3768             : {
    3769       41212 :     const char *type = te->desc;
    3770             : 
    3771             :     /* objects that don't require special decoration */
    3772       41212 :     if (strcmp(type, "COLLATION") == 0 ||
    3773       36158 :         strcmp(type, "CONVERSION") == 0 ||
    3774       35324 :         strcmp(type, "DOMAIN") == 0 ||
    3775       35018 :         strcmp(type, "FOREIGN TABLE") == 0 ||
    3776       34948 :         strcmp(type, "MATERIALIZED VIEW") == 0 ||
    3777       34208 :         strcmp(type, "SEQUENCE") == 0 ||
    3778       33740 :         strcmp(type, "STATISTICS") == 0 ||
    3779       33504 :         strcmp(type, "TABLE") == 0 ||
    3780       22752 :         strcmp(type, "TEXT SEARCH DICTIONARY") == 0 ||
    3781       22416 :         strcmp(type, "TEXT SEARCH CONFIGURATION") == 0 ||
    3782       22130 :         strcmp(type, "TYPE") == 0 ||
    3783       20862 :         strcmp(type, "VIEW") == 0 ||
    3784             :     /* non-schema-specified objects */
    3785       19800 :         strcmp(type, "DATABASE") == 0 ||
    3786       19680 :         strcmp(type, "PROCEDURAL LANGUAGE") == 0 ||
    3787       19616 :         strcmp(type, "SCHEMA") == 0 ||
    3788       19240 :         strcmp(type, "EVENT TRIGGER") == 0 ||
    3789       19166 :         strcmp(type, "FOREIGN DATA WRAPPER") == 0 ||
    3790       19076 :         strcmp(type, "SERVER") == 0 ||
    3791       18982 :         strcmp(type, "PUBLICATION") == 0 ||
    3792       18610 :         strcmp(type, "SUBSCRIPTION") == 0)
    3793             :     {
    3794       22798 :         appendPQExpBuffer(buf, "%s ", type);
    3795       22798 :         if (te->namespace && *te->namespace)
    3796       21412 :             appendPQExpBuffer(buf, "%s.", fmtId(te->namespace));
    3797       22798 :         appendPQExpBufferStr(buf, fmtId(te->tag));
    3798             :     }
    3799             :     /* LOs just have a name, but it's numeric so must not use fmtId */
    3800       18414 :     else if (strcmp(type, "BLOB") == 0)
    3801             :     {
    3802           0 :         appendPQExpBuffer(buf, "LARGE OBJECT %s", te->tag);
    3803             :     }
    3804             : 
    3805             :     /*
    3806             :      * These object types require additional decoration.  Fortunately, the
    3807             :      * information needed is exactly what's in the DROP command.
    3808             :      */
    3809       18414 :     else if (strcmp(type, "AGGREGATE") == 0 ||
    3810       17876 :              strcmp(type, "FUNCTION") == 0 ||
    3811       14732 :              strcmp(type, "OPERATOR") == 0 ||
    3812        9762 :              strcmp(type, "OPERATOR CLASS") == 0 ||
    3813        8472 :              strcmp(type, "OPERATOR FAMILY") == 0 ||
    3814        7394 :              strcmp(type, "PROCEDURE") == 0)
    3815             :     {
    3816             :         /* Chop "DROP " off the front and make a modifiable copy */
    3817       11206 :         char       *first = pg_strdup(te->dropStmt + 5);
    3818             :         char       *last;
    3819             : 
    3820             :         /* point to last character in string */
    3821       11206 :         last = first + strlen(first) - 1;
    3822             : 
    3823             :         /* Strip off any ';' or '\n' at the end */
    3824       33618 :         while (last >= first && (*last == '\n' || *last == ';'))
    3825       22412 :             last--;
    3826       11206 :         *(last + 1) = '\0';
    3827             : 
    3828       11206 :         appendPQExpBufferStr(buf, first);
    3829             : 
    3830       11206 :         free(first);
    3831       11206 :         return;
    3832             :     }
    3833             :     /* these object types don't have separate owners */
    3834        7208 :     else if (strcmp(type, "CAST") == 0 ||
    3835        7208 :              strcmp(type, "CHECK CONSTRAINT") == 0 ||
    3836        7108 :              strcmp(type, "CONSTRAINT") == 0 ||
    3837        4118 :              strcmp(type, "DATABASE PROPERTIES") == 0 ||
    3838        4102 :              strcmp(type, "DEFAULT") == 0 ||
    3839        3764 :              strcmp(type, "FK CONSTRAINT") == 0 ||
    3840        3442 :              strcmp(type, "INDEX") == 0 ||
    3841        1732 :              strcmp(type, "RULE") == 0 ||
    3842        1310 :              strcmp(type, "TRIGGER") == 0 ||
    3843         538 :              strcmp(type, "ROW SECURITY") == 0 ||
    3844         538 :              strcmp(type, "POLICY") == 0 ||
    3845          64 :              strcmp(type, "USER MAPPING") == 0)
    3846             :     {
    3847             :         /* do nothing */
    3848             :     }
    3849             :     else
    3850           0 :         pg_fatal("don't know how to set owner for object type \"%s\"", type);
    3851             : }
    3852             : 
    3853             : /*
    3854             :  * Emit the SQL commands to create the object represented by a TOC entry
    3855             :  *
    3856             :  * This now also includes issuing an ALTER OWNER command to restore the
    3857             :  * object's ownership, if wanted.  But note that the object's permissions
    3858             :  * will remain at default, until the matching ACL TOC entry is restored.
    3859             :  */
    3860             : static void
    3861       82454 : _printTocEntry(ArchiveHandle *AH, TocEntry *te, const char *pfx)
    3862             : {
    3863       82454 :     RestoreOptions *ropt = AH->public.ropt;
    3864             : 
    3865             :     /*
    3866             :      * Select owner, schema, tablespace and default AM as necessary. The
    3867             :      * default access method for partitioned tables is handled after
    3868             :      * generating the object definition, as it requires an ALTER command
    3869             :      * rather than SET.
    3870             :      */
    3871       82454 :     _becomeOwner(AH, te);
    3872       82454 :     _selectOutputSchema(AH, te->namespace);
    3873       82454 :     _selectTablespace(AH, te->tablespace);
    3874       82454 :     if (te->relkind != RELKIND_PARTITIONED_TABLE)
    3875       81306 :         _selectTableAccessMethod(AH, te->tableam);
    3876             : 
    3877             :     /* Emit header comment for item */
    3878       82454 :     if (!AH->noTocComments)
    3879             :     {
    3880             :         char       *sanitized_name;
    3881             :         char       *sanitized_schema;
    3882             :         char       *sanitized_owner;
    3883             : 
    3884       75566 :         ahprintf(AH, "--\n");
    3885       75566 :         if (AH->public.verbose)
    3886             :         {
    3887        2290 :             ahprintf(AH, "-- TOC entry %d (class %u OID %u)\n",
    3888             :                      te->dumpId, te->catalogId.tableoid, te->catalogId.oid);
    3889        2290 :             if (te->nDeps > 0)
    3890             :             {
    3891             :                 int         i;
    3892             : 
    3893        1522 :                 ahprintf(AH, "-- Dependencies:");
    3894        4164 :                 for (i = 0; i < te->nDeps; i++)
    3895        2642 :                     ahprintf(AH, " %d", te->dependencies[i]);
    3896        1522 :                 ahprintf(AH, "\n");
    3897             :             }
    3898             :         }
    3899             : 
    3900       75566 :         sanitized_name = sanitize_line(te->tag, false);
    3901       75566 :         sanitized_schema = sanitize_line(te->namespace, true);
    3902       75566 :         sanitized_owner = sanitize_line(ropt->noOwner ? NULL : te->owner, true);
    3903             : 
    3904       75566 :         ahprintf(AH, "-- %sName: %s; Type: %s; Schema: %s; Owner: %s",
    3905             :                  pfx, sanitized_name, te->desc, sanitized_schema,
    3906             :                  sanitized_owner);
    3907             : 
    3908       75566 :         free(sanitized_name);
    3909       75566 :         free(sanitized_schema);
    3910       75566 :         free(sanitized_owner);
    3911             : 
    3912       75566 :         if (te->tablespace && strlen(te->tablespace) > 0 && !ropt->noTablespace)
    3913             :         {
    3914             :             char       *sanitized_tablespace;
    3915             : 
    3916         204 :             sanitized_tablespace = sanitize_line(te->tablespace, false);
    3917         204 :             ahprintf(AH, "; Tablespace: %s", sanitized_tablespace);
    3918         204 :             free(sanitized_tablespace);
    3919             :         }
    3920       75566 :         ahprintf(AH, "\n");
    3921             : 
    3922       75566 :         if (AH->PrintExtraTocPtr != NULL)
    3923        7808 :             AH->PrintExtraTocPtr(AH, te);
    3924       75566 :         ahprintf(AH, "--\n\n");
    3925             :     }
    3926             : 
    3927             :     /*
    3928             :      * Actually print the definition.  Normally we can just print the defn
    3929             :      * string if any, but we have four special cases:
    3930             :      *
    3931             :      * 1. A crude hack for suppressing AUTHORIZATION clause that old pg_dump
    3932             :      * versions put into CREATE SCHEMA.  Don't mutate the variant for schema
    3933             :      * "public" that is a comment.  We have to do this when --no-owner mode is
    3934             :      * selected.  This is ugly, but I see no other good way ...
    3935             :      *
    3936             :      * 2. BLOB METADATA entries need special processing since their defn
    3937             :      * strings are just lists of OIDs, not complete SQL commands.
    3938             :      *
    3939             :      * 3. ACL LARGE OBJECTS entries need special processing because they
    3940             :      * contain only one copy of the ACL GRANT/REVOKE commands, which we must
    3941             :      * apply to each large object listed in the associated BLOB METADATA.
    3942             :      *
    3943             :      * 4. Entries with a defnDumper need to call it to generate the
    3944             :      * definition.  This is primarily intended to provide a way to save memory
    3945             :      * for objects that would otherwise need a lot of it (e.g., statistics
    3946             :      * data).
    3947             :      */
    3948       82454 :     if (ropt->noOwner &&
    3949         790 :         strcmp(te->desc, "SCHEMA") == 0 && strncmp(te->defn, "--", 2) != 0)
    3950             :     {
    3951           4 :         ahprintf(AH, "CREATE SCHEMA %s;\n\n\n", fmtId(te->tag));
    3952             :     }
    3953       82450 :     else if (strcmp(te->desc, "BLOB METADATA") == 0)
    3954             :     {
    3955         148 :         IssueCommandPerBlob(AH, te, "SELECT pg_catalog.lo_create('", "')");
    3956             :     }
    3957       82302 :     else if (strcmp(te->desc, "ACL") == 0 &&
    3958        3756 :              strncmp(te->tag, "LARGE OBJECTS", 13) == 0)
    3959             :     {
    3960           0 :         IssueACLPerBlob(AH, te);
    3961             :     }
    3962       82302 :     else if (te->defnLen && AH->format != archTar)
    3963             :     {
    3964             :         /*
    3965             :          * If defnLen is set, the defnDumper has already been called for this
    3966             :          * TOC entry.  We don't normally expect a defnDumper to be called for
    3967             :          * a TOC entry a second time in _printTocEntry(), but there's an
    3968             :          * exception.  The tar format first calls WriteToc(), which scans the
    3969             :          * entire TOC, and then it later calls RestoreArchive() to generate
    3970             :          * restore.sql, which scans the TOC again.  There doesn't appear to be
    3971             :          * a good way to prevent a second defnDumper call in this case without
    3972             :          * storing the definition in memory, which defeats the purpose.  This
    3973             :          * second defnDumper invocation should generate the same output as the
    3974             :          * first, but even if it doesn't, the worst-case scenario is that
    3975             :          * restore.sql might have different statistics data than the archive.
    3976             :          *
    3977             :          * In all other cases, encountering a TOC entry a second time in
    3978             :          * _printTocEntry() is unexpected, so we fail because one of our
    3979             :          * assumptions must no longer hold true.
    3980             :          *
    3981             :          * XXX This is a layering violation, but the alternative is an awkward
    3982             :          * and complicated callback infrastructure for this special case. This
    3983             :          * might be worth revisiting in the future.
    3984             :          */
    3985           0 :         pg_fatal("unexpected TOC entry in _printTocEntry(): %d %s %s",
    3986             :                  te->dumpId, te->desc, te->tag);
    3987             :     }
    3988       82302 :     else if (te->defnDumper)
    3989             :     {
    3990        3608 :         char       *defn = te->defnDumper((Archive *) AH, te->defnDumperArg, te);
    3991             : 
    3992        3608 :         te->defnLen = ahprintf(AH, "%s\n\n", defn);
    3993        3608 :         pg_free(defn);
    3994             :     }
    3995       78694 :     else if (te->defn && strlen(te->defn) > 0)
    3996             :     {
    3997       70056 :         ahprintf(AH, "%s\n\n", te->defn);
    3998             : 
    3999             :         /*
    4000             :          * If the defn string contains multiple SQL commands, txn_size mode
    4001             :          * should count it as N actions not one.  But rather than build a full
    4002             :          * SQL parser, approximate this by counting semicolons.  One case
    4003             :          * where that tends to be badly fooled is function definitions, so
    4004             :          * ignore them.  (restore_toc_entry will count one action anyway.)
    4005             :          */
    4006       70056 :         if (ropt->txn_size > 0 &&
    4007        6614 :             strcmp(te->desc, "FUNCTION") != 0 &&
    4008        6086 :             strcmp(te->desc, "PROCEDURE") != 0)
    4009             :         {
    4010        6062 :             const char *p = te->defn;
    4011        6062 :             int         nsemis = 0;
    4012             : 
    4013       27068 :             while ((p = strchr(p, ';')) != NULL)
    4014             :             {
    4015       21006 :                 nsemis++;
    4016       21006 :                 p++;
    4017             :             }
    4018        6062 :             if (nsemis > 1)
    4019        2954 :                 AH->txnCount += nsemis - 1;
    4020             :         }
    4021             :     }
    4022             : 
    4023             :     /*
    4024             :      * If we aren't using SET SESSION AUTH to determine ownership, we must
    4025             :      * instead issue an ALTER OWNER command.  Schema "public" is special; when
    4026             :      * a dump emits a comment in lieu of creating it, we use ALTER OWNER even
    4027             :      * when using SET SESSION for all other objects.  We assume that anything
    4028             :      * without a DROP command is not a separately ownable object.
    4029             :      */
    4030       82454 :     if (!ropt->noOwner &&
    4031       81664 :         (!ropt->use_setsessauth ||
    4032           0 :          (strcmp(te->desc, "SCHEMA") == 0 &&
    4033           0 :           strncmp(te->defn, "--", 2) == 0)) &&
    4034       81664 :         te->owner && strlen(te->owner) > 0 &&
    4035       74012 :         te->dropStmt && strlen(te->dropStmt) > 0)
    4036             :     {
    4037       41356 :         if (strcmp(te->desc, "BLOB METADATA") == 0)
    4038             :         {
    4039             :             /* BLOB METADATA needs special code to handle multiple LOs */
    4040         144 :             char       *cmdEnd = psprintf(" OWNER TO %s", fmtId(te->owner));
    4041             : 
    4042         144 :             IssueCommandPerBlob(AH, te, "ALTER LARGE OBJECT ", cmdEnd);
    4043         144 :             pg_free(cmdEnd);
    4044             :         }
    4045             :         else
    4046             :         {
    4047             :             /* For all other cases, we can use _getObjectDescription */
    4048             :             PQExpBufferData temp;
    4049             : 
    4050       41212 :             initPQExpBuffer(&temp);
    4051       41212 :             _getObjectDescription(&temp, te);
    4052             : 
    4053             :             /*
    4054             :              * If _getObjectDescription() didn't fill the buffer, then there
    4055             :              * is no owner.
    4056             :              */
    4057       41212 :             if (temp.data[0])
    4058       34004 :                 ahprintf(AH, "ALTER %s OWNER TO %s;\n\n",
    4059       34004 :                          temp.data, fmtId(te->owner));
    4060       41212 :             termPQExpBuffer(&temp);
    4061             :         }
    4062             :     }
    4063             : 
    4064             :     /*
    4065             :      * Select a partitioned table's default AM, once the table definition has
    4066             :      * been generated.
    4067             :      */
    4068       82454 :     if (te->relkind == RELKIND_PARTITIONED_TABLE)
    4069        1148 :         _printTableAccessMethodNoStorage(AH, te);
    4070             : 
    4071             :     /*
    4072             :      * If it's an ACL entry, it might contain SET SESSION AUTHORIZATION
    4073             :      * commands, so we can no longer assume we know the current auth setting.
    4074             :      */
    4075       82454 :     if (_tocEntryIsACL(te))
    4076             :     {
    4077        4036 :         free(AH->currUser);
    4078        4036 :         AH->currUser = NULL;
    4079             :     }
    4080       82454 : }
    4081             : 
    4082             : /*
    4083             :  * Write the file header for a custom-format archive
    4084             :  */
    4085             : void
    4086         106 : WriteHead(ArchiveHandle *AH)
    4087             : {
    4088             :     struct tm   crtm;
    4089             : 
    4090         106 :     AH->WriteBufPtr(AH, "PGDMP", 5);   /* Magic code */
    4091         106 :     AH->WriteBytePtr(AH, ARCHIVE_MAJOR(AH->version));
    4092         106 :     AH->WriteBytePtr(AH, ARCHIVE_MINOR(AH->version));
    4093         106 :     AH->WriteBytePtr(AH, ARCHIVE_REV(AH->version));
    4094         106 :     AH->WriteBytePtr(AH, AH->intSize);
    4095         106 :     AH->WriteBytePtr(AH, AH->offSize);
    4096         106 :     AH->WriteBytePtr(AH, AH->format);
    4097         106 :     AH->WriteBytePtr(AH, AH->compression_spec.algorithm);
    4098         106 :     crtm = *localtime(&AH->createDate);
    4099         106 :     WriteInt(AH, crtm.tm_sec);
    4100         106 :     WriteInt(AH, crtm.tm_min);
    4101         106 :     WriteInt(AH, crtm.tm_hour);
    4102         106 :     WriteInt(AH, crtm.tm_mday);
    4103         106 :     WriteInt(AH, crtm.tm_mon);
    4104         106 :     WriteInt(AH, crtm.tm_year);
    4105         106 :     WriteInt(AH, crtm.tm_isdst);
    4106         106 :     WriteStr(AH, PQdb(AH->connection));
    4107         106 :     WriteStr(AH, AH->public.remoteVersionStr);
    4108         106 :     WriteStr(AH, PG_VERSION);
    4109         106 : }
    4110             : 
    4111             : void
    4112         112 : ReadHead(ArchiveHandle *AH)
    4113             : {
    4114             :     char       *errmsg;
    4115             :     char        vmaj,
    4116             :                 vmin,
    4117             :                 vrev;
    4118             :     int         fmt;
    4119             : 
    4120             :     /*
    4121             :      * If we haven't already read the header, do so.
    4122             :      *
    4123             :      * NB: this code must agree with _discoverArchiveFormat().  Maybe find a
    4124             :      * way to unify the cases?
    4125             :      */
    4126         112 :     if (!AH->readHeader)
    4127             :     {
    4128             :         char        tmpMag[7];
    4129             : 
    4130         112 :         AH->ReadBufPtr(AH, tmpMag, 5);
    4131             : 
    4132         112 :         if (strncmp(tmpMag, "PGDMP", 5) != 0)
    4133           0 :             pg_fatal("did not find magic string in file header");
    4134             :     }
    4135             : 
    4136         112 :     vmaj = AH->ReadBytePtr(AH);
    4137         112 :     vmin = AH->ReadBytePtr(AH);
    4138             : 
    4139         112 :     if (vmaj > 1 || (vmaj == 1 && vmin > 0))  /* Version > 1.0 */
    4140         112 :         vrev = AH->ReadBytePtr(AH);
    4141             :     else
    4142           0 :         vrev = 0;
    4143             : 
    4144         112 :     AH->version = MAKE_ARCHIVE_VERSION(vmaj, vmin, vrev);
    4145             : 
    4146         112 :     if (AH->version < K_VERS_1_0 || AH->version > K_VERS_MAX)
    4147           0 :         pg_fatal("unsupported version (%d.%d) in file header",
    4148             :                  vmaj, vmin);
    4149             : 
    4150         112 :     AH->intSize = AH->ReadBytePtr(AH);
    4151         112 :     if (AH->intSize > 32)
    4152           0 :         pg_fatal("sanity check on integer size (%lu) failed",
    4153             :                  (unsigned long) AH->intSize);
    4154             : 
    4155         112 :     if (AH->intSize > sizeof(int))
    4156           0 :         pg_log_warning("archive was made on a machine with larger integers, some operations might fail");
    4157             : 
    4158         112 :     if (AH->version >= K_VERS_1_7)
    4159         112 :         AH->offSize = AH->ReadBytePtr(AH);
    4160             :     else
    4161           0 :         AH->offSize = AH->intSize;
    4162             : 
    4163         112 :     fmt = AH->ReadBytePtr(AH);
    4164             : 
    4165         112 :     if (AH->format != fmt)
    4166           0 :         pg_fatal("expected format (%d) differs from format found in file (%d)",
    4167             :                  AH->format, fmt);
    4168             : 
    4169         112 :     if (AH->version >= K_VERS_1_15)
    4170         112 :         AH->compression_spec.algorithm = AH->ReadBytePtr(AH);
    4171           0 :     else if (AH->version >= K_VERS_1_2)
    4172             :     {
    4173             :         /* Guess the compression method based on the level */
    4174           0 :         if (AH->version < K_VERS_1_4)
    4175           0 :             AH->compression_spec.level = AH->ReadBytePtr(AH);
    4176             :         else
    4177           0 :             AH->compression_spec.level = ReadInt(AH);
    4178             : 
    4179           0 :         if (AH->compression_spec.level != 0)
    4180           0 :             AH->compression_spec.algorithm = PG_COMPRESSION_GZIP;
    4181             :     }
    4182             :     else
    4183           0 :         AH->compression_spec.algorithm = PG_COMPRESSION_GZIP;
    4184             : 
    4185         112 :     errmsg = supports_compression(AH->compression_spec);
    4186         112 :     if (errmsg)
    4187             :     {
    4188           0 :         pg_log_warning("archive is compressed, but this installation does not support compression (%s) -- no data will be available",
    4189             :                        errmsg);
    4190           0 :         pg_free(errmsg);
    4191             :     }
    4192             : 
    4193         112 :     if (AH->version >= K_VERS_1_4)
    4194             :     {
    4195             :         struct tm   crtm;
    4196             : 
    4197         112 :         crtm.tm_sec = ReadInt(AH);
    4198         112 :         crtm.tm_min = ReadInt(AH);
    4199         112 :         crtm.tm_hour = ReadInt(AH);
    4200         112 :         crtm.tm_mday = ReadInt(AH);
    4201         112 :         crtm.tm_mon = ReadInt(AH);
    4202         112 :         crtm.tm_year = ReadInt(AH);
    4203         112 :         crtm.tm_isdst = ReadInt(AH);
    4204             : 
    4205             :         /*
    4206             :          * Newer versions of glibc have mktime() report failure if tm_isdst is
    4207             :          * inconsistent with the prevailing timezone, e.g. tm_isdst = 1 when
    4208             :          * TZ=UTC.  This is problematic when restoring an archive under a
    4209             :          * different timezone setting.  If we get a failure, try again with
    4210             :          * tm_isdst set to -1 ("don't know").
    4211             :          *
    4212             :          * XXX with or without this hack, we reconstruct createDate
    4213             :          * incorrectly when the prevailing timezone is different from
    4214             :          * pg_dump's.  Next time we bump the archive version, we should flush
    4215             :          * this representation and store a plain seconds-since-the-Epoch
    4216             :          * timestamp instead.
    4217             :          */
    4218         112 :         AH->createDate = mktime(&crtm);
    4219         112 :         if (AH->createDate == (time_t) -1)
    4220             :         {
    4221           0 :             crtm.tm_isdst = -1;
    4222           0 :             AH->createDate = mktime(&crtm);
    4223           0 :             if (AH->createDate == (time_t) -1)
    4224           0 :                 pg_log_warning("invalid creation date in header");
    4225             :         }
    4226             :     }
    4227             : 
    4228         112 :     if (AH->version >= K_VERS_1_4)
    4229             :     {
    4230         112 :         AH->archdbname = ReadStr(AH);
    4231             :     }
    4232             : 
    4233         112 :     if (AH->version >= K_VERS_1_10)
    4234             :     {
    4235         112 :         AH->archiveRemoteVersion = ReadStr(AH);
    4236         112 :         AH->archiveDumpVersion = ReadStr(AH);
    4237             :     }
    4238         112 : }
    4239             : 
    4240             : 
    4241             : /*
    4242             :  * checkSeek
    4243             :  *    check to see if ftell/fseek can be performed.
    4244             :  */
    4245             : bool
    4246         176 : checkSeek(FILE *fp)
    4247             : {
    4248             :     pgoff_t     tpos;
    4249             : 
    4250             :     /* Check that ftello works on this file */
    4251         176 :     tpos = ftello(fp);
    4252         176 :     if (tpos < 0)
    4253           2 :         return false;
    4254             : 
    4255             :     /*
    4256             :      * Check that fseeko(SEEK_SET) works, too.  NB: we used to try to test
    4257             :      * this with fseeko(fp, 0, SEEK_CUR).  But some platforms treat that as a
    4258             :      * successful no-op even on files that are otherwise unseekable.
    4259             :      */
    4260         174 :     if (fseeko(fp, tpos, SEEK_SET) != 0)
    4261           0 :         return false;
    4262             : 
    4263         174 :     return true;
    4264             : }
    4265             : 
    4266             : 
    4267             : /*
    4268             :  * dumpTimestamp
    4269             :  */
    4270             : static void
    4271         156 : dumpTimestamp(ArchiveHandle *AH, const char *msg, time_t tim)
    4272             : {
    4273             :     char        buf[64];
    4274             : 
    4275         156 :     if (strftime(buf, sizeof(buf), PGDUMP_STRFTIME_FMT, localtime(&tim)) != 0)
    4276         156 :         ahprintf(AH, "-- %s %s\n\n", msg, buf);
    4277         156 : }
    4278             : 
    4279             : /*
    4280             :  * Main engine for parallel restore.
    4281             :  *
    4282             :  * Parallel restore is done in three phases.  In this first phase,
    4283             :  * we'll process all SECTION_PRE_DATA TOC entries that are allowed to be
    4284             :  * processed in the RESTORE_PASS_MAIN pass.  (In practice, that's all
    4285             :  * PRE_DATA items other than ACLs.)  Entries we can't process now are
    4286             :  * added to the pending_list for later phases to deal with.
    4287             :  */
    4288             : static void
    4289           8 : restore_toc_entries_prefork(ArchiveHandle *AH, TocEntry *pending_list)
    4290             : {
    4291             :     bool        skipped_some;
    4292             :     TocEntry   *next_work_item;
    4293             : 
    4294           8 :     pg_log_debug("entering restore_toc_entries_prefork");
    4295             : 
    4296             :     /* Adjust dependency information */
    4297           8 :     fix_dependencies(AH);
    4298             : 
    4299             :     /*
    4300             :      * Do all the early stuff in a single connection in the parent. There's no
    4301             :      * great point in running it in parallel, in fact it will actually run
    4302             :      * faster in a single connection because we avoid all the connection and
    4303             :      * setup overhead.  Also, pre-9.2 pg_dump versions were not very good
    4304             :      * about showing all the dependencies of SECTION_PRE_DATA items, so we do
    4305             :      * not risk trying to process them out-of-order.
    4306             :      *
    4307             :      * Stuff that we can't do immediately gets added to the pending_list.
    4308             :      * Note: we don't yet filter out entries that aren't going to be restored.
    4309             :      * They might participate in dependency chains connecting entries that
    4310             :      * should be restored, so we treat them as live until we actually process
    4311             :      * them.
    4312             :      *
    4313             :      * Note: as of 9.2, it should be guaranteed that all PRE_DATA items appear
    4314             :      * before DATA items, and all DATA items before POST_DATA items.  That is
    4315             :      * not certain to be true in older archives, though, and in any case use
    4316             :      * of a list file would destroy that ordering (cf. SortTocFromFile).  So
    4317             :      * this loop cannot assume that it holds.
    4318             :      */
    4319           8 :     AH->restorePass = RESTORE_PASS_MAIN;
    4320           8 :     skipped_some = false;
    4321         200 :     for (next_work_item = AH->toc->next; next_work_item != AH->toc; next_work_item = next_work_item->next)
    4322             :     {
    4323         192 :         bool        do_now = true;
    4324             : 
    4325         192 :         if (next_work_item->section != SECTION_PRE_DATA)
    4326             :         {
    4327             :             /* DATA and POST_DATA items are just ignored for now */
    4328          92 :             if (next_work_item->section == SECTION_DATA ||
    4329          60 :                 next_work_item->section == SECTION_POST_DATA)
    4330             :             {
    4331          92 :                 do_now = false;
    4332          92 :                 skipped_some = true;
    4333             :             }
    4334             :             else
    4335             :             {
    4336             :                 /*
    4337             :                  * SECTION_NONE items, such as comments, can be processed now
    4338             :                  * if we are still in the PRE_DATA part of the archive.  Once
    4339             :                  * we've skipped any items, we have to consider whether the
    4340             :                  * comment's dependencies are satisfied, so skip it for now.
    4341             :                  */
    4342           0 :                 if (skipped_some)
    4343           0 :                     do_now = false;
    4344             :             }
    4345             :         }
    4346             : 
    4347             :         /*
    4348             :          * Also skip items that need to be forced into later passes.  We need
    4349             :          * not set skipped_some in this case, since by assumption no main-pass
    4350             :          * items could depend on these.
    4351             :          */
    4352         192 :         if (_tocEntryRestorePass(next_work_item) != RESTORE_PASS_MAIN)
    4353           0 :             do_now = false;
    4354             : 
    4355         192 :         if (do_now)
    4356             :         {
    4357             :             /* OK, restore the item and update its dependencies */
    4358         100 :             pg_log_info("processing item %d %s %s",
    4359             :                         next_work_item->dumpId,
    4360             :                         next_work_item->desc, next_work_item->tag);
    4361             : 
    4362         100 :             (void) restore_toc_entry(AH, next_work_item, false);
    4363             : 
    4364             :             /* Reduce dependencies, but don't move anything to ready_heap */
    4365         100 :             reduce_dependencies(AH, next_work_item, NULL);
    4366             :         }
    4367             :         else
    4368             :         {
    4369             :             /* Nope, so add it to pending_list */
    4370          92 :             pending_list_append(pending_list, next_work_item);
    4371             :         }
    4372             :     }
    4373             : 
    4374             :     /*
    4375             :      * In --transaction-size mode, we must commit the open transaction before
    4376             :      * dropping the database connection.  This also ensures that child workers
    4377             :      * can see the objects we've created so far.
    4378             :      */
    4379           8 :     if (AH->public.ropt->txn_size > 0)
    4380           0 :         CommitTransaction(&AH->public);
    4381             : 
    4382             :     /*
    4383             :      * Now close parent connection in prep for parallel steps.  We do this
    4384             :      * mainly to ensure that we don't exceed the specified number of parallel
    4385             :      * connections.
    4386             :      */
    4387           8 :     DisconnectDatabase(&AH->public);
    4388             : 
    4389             :     /* blow away any transient state from the old connection */
    4390           8 :     free(AH->currUser);
    4391           8 :     AH->currUser = NULL;
    4392           8 :     free(AH->currSchema);
    4393           8 :     AH->currSchema = NULL;
    4394           8 :     free(AH->currTablespace);
    4395           8 :     AH->currTablespace = NULL;
    4396           8 :     free(AH->currTableAm);
    4397           8 :     AH->currTableAm = NULL;
    4398           8 : }
    4399             : 
    4400             : /*
    4401             :  * Main engine for parallel restore.
    4402             :  *
    4403             :  * Parallel restore is done in three phases.  In this second phase,
    4404             :  * we process entries by dispatching them to parallel worker children
    4405             :  * (processes on Unix, threads on Windows), each of which connects
    4406             :  * separately to the database.  Inter-entry dependencies are respected,
    4407             :  * and so is the RestorePass multi-pass structure.  When we can no longer
    4408             :  * make any entries ready to process, we exit.  Normally, there will be
    4409             :  * nothing left to do; but if there is, the third phase will mop up.
    4410             :  */
    4411             : static void
    4412           8 : restore_toc_entries_parallel(ArchiveHandle *AH, ParallelState *pstate,
    4413             :                              TocEntry *pending_list)
    4414             : {
    4415             :     binaryheap *ready_heap;
    4416             :     TocEntry   *next_work_item;
    4417             : 
    4418           8 :     pg_log_debug("entering restore_toc_entries_parallel");
    4419             : 
    4420             :     /* Set up ready_heap with enough room for all known TocEntrys */
    4421           8 :     ready_heap = binaryheap_allocate(AH->tocCount,
    4422             :                                      TocEntrySizeCompareBinaryheap,
    4423             :                                      NULL);
    4424             : 
    4425             :     /*
    4426             :      * The pending_list contains all items that we need to restore.  Move all
    4427             :      * items that are available to process immediately into the ready_heap.
    4428             :      * After this setup, the pending list is everything that needs to be done
    4429             :      * but is blocked by one or more dependencies, while the ready heap
    4430             :      * contains items that have no remaining dependencies and are OK to
    4431             :      * process in the current restore pass.
    4432             :      */
    4433           8 :     AH->restorePass = RESTORE_PASS_MAIN;
    4434           8 :     move_to_ready_heap(pending_list, ready_heap, AH->restorePass);
    4435             : 
    4436             :     /*
    4437             :      * main parent loop
    4438             :      *
    4439             :      * Keep going until there is no worker still running AND there is no work
    4440             :      * left to be done.  Note invariant: at top of loop, there should always
    4441             :      * be at least one worker available to dispatch a job to.
    4442             :      */
    4443           8 :     pg_log_info("entering main parallel loop");
    4444             : 
    4445             :     for (;;)
    4446             :     {
    4447             :         /* Look for an item ready to be dispatched to a worker */
    4448         140 :         next_work_item = pop_next_work_item(ready_heap, pstate);
    4449         140 :         if (next_work_item != NULL)
    4450             :         {
    4451             :             /* If not to be restored, don't waste time launching a worker */
    4452          92 :             if ((next_work_item->reqs & (REQ_SCHEMA | REQ_DATA | REQ_STATS)) == 0)
    4453             :             {
    4454           0 :                 pg_log_info("skipping item %d %s %s",
    4455             :                             next_work_item->dumpId,
    4456             :                             next_work_item->desc, next_work_item->tag);
    4457             :                 /* Update its dependencies as though we'd completed it */
    4458           0 :                 reduce_dependencies(AH, next_work_item, ready_heap);
    4459             :                 /* Loop around to see if anything else can be dispatched */
    4460           0 :                 continue;
    4461             :             }
    4462             : 
    4463          92 :             pg_log_info("launching item %d %s %s",
    4464             :                         next_work_item->dumpId,
    4465             :                         next_work_item->desc, next_work_item->tag);
    4466             : 
    4467             :             /* Dispatch to some worker */
    4468          92 :             DispatchJobForTocEntry(AH, pstate, next_work_item, ACT_RESTORE,
    4469             :                                    mark_restore_job_done, ready_heap);
    4470             :         }
    4471          48 :         else if (IsEveryWorkerIdle(pstate))
    4472             :         {
    4473             :             /*
    4474             :              * Nothing is ready and no worker is running, so we're done with
    4475             :              * the current pass or maybe with the whole process.
    4476             :              */
    4477          24 :             if (AH->restorePass == RESTORE_PASS_LAST)
    4478           8 :                 break;          /* No more parallel processing is possible */
    4479             : 
    4480             :             /* Advance to next restore pass */
    4481          16 :             AH->restorePass++;
    4482             :             /* That probably allows some stuff to be made ready */
    4483          16 :             move_to_ready_heap(pending_list, ready_heap, AH->restorePass);
    4484             :             /* Loop around to see if anything's now ready */
    4485          16 :             continue;
    4486             :         }
    4487             :         else
    4488             :         {
    4489             :             /*
    4490             :              * We have nothing ready, but at least one child is working, so
    4491             :              * wait for some subjob to finish.
    4492             :              */
    4493             :         }
    4494             : 
    4495             :         /*
    4496             :          * Before dispatching another job, check to see if anything has
    4497             :          * finished.  We should check every time through the loop so as to
    4498             :          * reduce dependencies as soon as possible.  If we were unable to
    4499             :          * dispatch any job this time through, wait until some worker finishes
    4500             :          * (and, hopefully, unblocks some pending item).  If we did dispatch
    4501             :          * something, continue as soon as there's at least one idle worker.
    4502             :          * Note that in either case, there's guaranteed to be at least one
    4503             :          * idle worker when we return to the top of the loop.  This ensures we
    4504             :          * won't block inside DispatchJobForTocEntry, which would be
    4505             :          * undesirable: we'd rather postpone dispatching until we see what's
    4506             :          * been unblocked by finished jobs.
    4507             :          */
    4508         116 :         WaitForWorkers(AH, pstate,
    4509             :                        next_work_item ? WFW_ONE_IDLE : WFW_GOT_STATUS);
    4510             :     }
    4511             : 
    4512             :     /* There should now be nothing in ready_heap. */
    4513             :     Assert(binaryheap_empty(ready_heap));
    4514             : 
    4515           8 :     binaryheap_free(ready_heap);
    4516             : 
    4517           8 :     pg_log_info("finished main parallel loop");
    4518           8 : }
    4519             : 
    4520             : /*
    4521             :  * Main engine for parallel restore.
    4522             :  *
    4523             :  * Parallel restore is done in three phases.  In this third phase,
    4524             :  * we mop up any remaining TOC entries by processing them serially.
    4525             :  * This phase normally should have nothing to do, but if we've somehow
    4526             :  * gotten stuck due to circular dependencies or some such, this provides
    4527             :  * at least some chance of completing the restore successfully.
    4528             :  */
    4529             : static void
    4530           8 : restore_toc_entries_postfork(ArchiveHandle *AH, TocEntry *pending_list)
    4531             : {
    4532           8 :     RestoreOptions *ropt = AH->public.ropt;
    4533             :     TocEntry   *te;
    4534             : 
    4535           8 :     pg_log_debug("entering restore_toc_entries_postfork");
    4536             : 
    4537             :     /*
    4538             :      * Now reconnect the single parent connection.
    4539             :      */
    4540           8 :     ConnectDatabaseAhx((Archive *) AH, &ropt->cparams, true);
    4541             : 
    4542             :     /* re-establish fixed state */
    4543           8 :     _doSetFixedOutputState(AH);
    4544             : 
    4545             :     /*
    4546             :      * Make sure there is no work left due to, say, circular dependencies, or
    4547             :      * some other pathological condition.  If so, do it in the single parent
    4548             :      * connection.  We don't sweat about RestorePass ordering; it's likely we
    4549             :      * already violated that.
    4550             :      */
    4551           8 :     for (te = pending_list->pending_next; te != pending_list; te = te->pending_next)
    4552             :     {
    4553           0 :         pg_log_info("processing missed item %d %s %s",
    4554             :                     te->dumpId, te->desc, te->tag);
    4555           0 :         (void) restore_toc_entry(AH, te, false);
    4556             :     }
    4557           8 : }
    4558             : 
    4559             : /*
    4560             :  * Check if te1 has an exclusive lock requirement for an item that te2 also
    4561             :  * requires, whether or not te2's requirement is for an exclusive lock.
    4562             :  */
    4563             : static bool
    4564         314 : has_lock_conflicts(TocEntry *te1, TocEntry *te2)
    4565             : {
    4566             :     int         j,
    4567             :                 k;
    4568             : 
    4569         774 :     for (j = 0; j < te1->nLockDeps; j++)
    4570             :     {
    4571        1960 :         for (k = 0; k < te2->nDeps; k++)
    4572             :         {
    4573        1500 :             if (te1->lockDeps[j] == te2->dependencies[k])
    4574           6 :                 return true;
    4575             :         }
    4576             :     }
    4577         308 :     return false;
    4578             : }
    4579             : 
    4580             : 
    4581             : /*
    4582             :  * Initialize the header of the pending-items list.
    4583             :  *
    4584             :  * This is a circular list with a dummy TocEntry as header, just like the
    4585             :  * main TOC list; but we use separate list links so that an entry can be in
    4586             :  * the main TOC list as well as in the pending list.
    4587             :  */
    4588             : static void
    4589           8 : pending_list_header_init(TocEntry *l)
    4590             : {
    4591           8 :     l->pending_prev = l->pending_next = l;
    4592           8 : }
    4593             : 
    4594             : /* Append te to the end of the pending-list headed by l */
    4595             : static void
    4596          92 : pending_list_append(TocEntry *l, TocEntry *te)
    4597             : {
    4598          92 :     te->pending_prev = l->pending_prev;
    4599          92 :     l->pending_prev->pending_next = te;
    4600          92 :     l->pending_prev = te;
    4601          92 :     te->pending_next = l;
    4602          92 : }
    4603             : 
    4604             : /* Remove te from the pending-list */
    4605             : static void
    4606          92 : pending_list_remove(TocEntry *te)
    4607             : {
    4608          92 :     te->pending_prev->pending_next = te->pending_next;
    4609          92 :     te->pending_next->pending_prev = te->pending_prev;
    4610          92 :     te->pending_prev = NULL;
    4611          92 :     te->pending_next = NULL;
    4612          92 : }
    4613             : 
    4614             : 
    4615             : /* qsort comparator for sorting TocEntries by dataLength */
    4616             : static int
    4617        1730 : TocEntrySizeCompareQsort(const void *p1, const void *p2)
    4618             : {
    4619        1730 :     const TocEntry *te1 = *(const TocEntry *const *) p1;
    4620        1730 :     const TocEntry *te2 = *(const TocEntry *const *) p2;
    4621             : 
    4622             :     /* Sort by decreasing dataLength */
    4623        1730 :     if (te1->dataLength > te2->dataLength)
    4624          88 :         return -1;
    4625        1642 :     if (te1->dataLength < te2->dataLength)
    4626         200 :         return 1;
    4627             : 
    4628             :     /* For equal dataLengths, sort by dumpId, just to be stable */
    4629        1442 :     if (te1->dumpId < te2->dumpId)
    4630         506 :         return -1;
    4631         936 :     if (te1->dumpId > te2->dumpId)
    4632         908 :         return 1;
    4633             : 
    4634          28 :     return 0;
    4635             : }
    4636             : 
    4637             : /* binaryheap comparator for sorting TocEntries by dataLength */
    4638             : static int
    4639         268 : TocEntrySizeCompareBinaryheap(void *p1, void *p2, void *arg)
    4640             : {
    4641             :     /* return opposite of qsort comparator for max-heap */
    4642         268 :     return -TocEntrySizeCompareQsort(&p1, &p2);
    4643             : }
    4644             : 
    4645             : 
    4646             : /*
    4647             :  * Move all immediately-ready items from pending_list to ready_heap.
    4648             :  *
    4649             :  * Items are considered ready if they have no remaining dependencies and
    4650             :  * they belong in the current restore pass.  (See also reduce_dependencies,
    4651             :  * which applies the same logic one-at-a-time.)
    4652             :  */
    4653             : static void
    4654          24 : move_to_ready_heap(TocEntry *pending_list,
    4655             :                    binaryheap *ready_heap,
    4656             :                    RestorePass pass)
    4657             : {
    4658             :     TocEntry   *te;
    4659             :     TocEntry   *next_te;
    4660             : 
    4661         116 :     for (te = pending_list->pending_next; te != pending_list; te = next_te)
    4662             :     {
    4663             :         /* must save list link before possibly removing te from list */
    4664          92 :         next_te = te->pending_next;
    4665             : 
    4666         132 :         if (te->depCount == 0 &&
    4667          40 :             _tocEntryRestorePass(te) == pass)
    4668             :         {
    4669             :             /* Remove it from pending_list ... */
    4670          40 :             pending_list_remove(te);
    4671             :             /* ... and add to ready_heap */
    4672          40 :             binaryheap_add(ready_heap, te);
    4673             :         }
    4674             :     }
    4675          24 : }
    4676             : 
    4677             : /*
    4678             :  * Find the next work item (if any) that is capable of being run now,
    4679             :  * and remove it from the ready_heap.
    4680             :  *
    4681             :  * Returns the item, or NULL if nothing is runnable.
    4682             :  *
    4683             :  * To qualify, the item must have no remaining dependencies
    4684             :  * and no requirements for locks that are incompatible with
    4685             :  * items currently running.  Items in the ready_heap are known to have
    4686             :  * no remaining dependencies, but we have to check for lock conflicts.
    4687             :  */
    4688             : static TocEntry *
    4689         140 : pop_next_work_item(binaryheap *ready_heap,
    4690             :                    ParallelState *pstate)
    4691             : {
    4692             :     /*
    4693             :      * Search the ready_heap until we find a suitable item.  Note that we do a
    4694             :      * sequential scan through the heap nodes, so even though we will first
    4695             :      * try to choose the highest-priority item, we might end up picking
    4696             :      * something with a much lower priority.  However, we expect that we will
    4697             :      * typically be able to pick one of the first few items, which should
    4698             :      * usually have a relatively high priority.
    4699             :      */
    4700         146 :     for (int i = 0; i < binaryheap_size(ready_heap); i++)
    4701             :     {
    4702          98 :         TocEntry   *te = (TocEntry *) binaryheap_get_node(ready_heap, i);
    4703          98 :         bool        conflicts = false;
    4704             : 
    4705             :         /*
    4706             :          * Check to see if the item would need exclusive lock on something
    4707             :          * that a currently running item also needs lock on, or vice versa. If
    4708             :          * so, we don't want to schedule them together.
    4709             :          */
    4710         380 :         for (int k = 0; k < pstate->numWorkers; k++)
    4711             :         {
    4712         288 :             TocEntry   *running_te = pstate->te[k];
    4713             : 
    4714         288 :             if (running_te == NULL)
    4715         128 :                 continue;
    4716         314 :             if (has_lock_conflicts(te, running_te) ||
    4717         154 :                 has_lock_conflicts(running_te, te))
    4718             :             {
    4719           6 :                 conflicts = true;
    4720           6 :                 break;
    4721             :             }
    4722             :         }
    4723             : 
    4724          98 :         if (conflicts)
    4725           6 :             continue;
    4726             : 
    4727             :         /* passed all tests, so this item can run */
    4728          92 :         binaryheap_remove_node(ready_heap, i);
    4729          92 :         return te;
    4730             :     }
    4731             : 
    4732          48 :     pg_log_debug("no item ready");
    4733          48 :     return NULL;
    4734             : }
    4735             : 
    4736             : 
    4737             : /*
    4738             :  * Restore a single TOC item in parallel with others
    4739             :  *
    4740             :  * this is run in the worker, i.e. in a thread (Windows) or a separate process
    4741             :  * (everything else). A worker process executes several such work items during
    4742             :  * a parallel backup or restore. Once we terminate here and report back that
    4743             :  * our work is finished, the leader process will assign us a new work item.
    4744             :  */
    4745             : int
    4746          92 : parallel_restore(ArchiveHandle *AH, TocEntry *te)
    4747             : {
    4748             :     int         status;
    4749             : 
    4750             :     Assert(AH->connection != NULL);
    4751             : 
    4752             :     /* Count only errors associated with this TOC entry */
    4753          92 :     AH->public.n_errors = 0;
    4754             : 
    4755             :     /* Restore the TOC item */
    4756          92 :     status = restore_toc_entry(AH, te, true);
    4757             : 
    4758          92 :     return status;
    4759             : }
    4760             : 
    4761             : 
    4762             : /*
    4763             :  * Callback function that's invoked in the leader process after a step has
    4764             :  * been parallel restored.
    4765             :  *
    4766             :  * Update status and reduce the dependency count of any dependent items.
    4767             :  */
    4768             : static void
    4769          92 : mark_restore_job_done(ArchiveHandle *AH,
    4770             :                       TocEntry *te,
    4771             :                       int status,
    4772             :                       void *callback_data)
    4773             : {
    4774          92 :     binaryheap *ready_heap = (binaryheap *) callback_data;
    4775             : 
    4776          92 :     pg_log_info("finished item %d %s %s",
    4777             :                 te->dumpId, te->desc, te->tag);
    4778             : 
    4779          92 :     if (status == WORKER_CREATE_DONE)
    4780           0 :         mark_create_done(AH, te);
    4781          92 :     else if (status == WORKER_INHIBIT_DATA)
    4782             :     {
    4783           0 :         inhibit_data_for_failed_table(AH, te);
    4784           0 :         AH->public.n_errors++;
    4785             :     }
    4786          92 :     else if (status == WORKER_IGNORED_ERRORS)
    4787           0 :         AH->public.n_errors++;
    4788          92 :     else if (status != 0)
    4789           0 :         pg_fatal("worker process failed: exit code %d",
    4790             :                  status);
    4791             : 
    4792          92 :     reduce_dependencies(AH, te, ready_heap);
    4793          92 : }
    4794             : 
    4795             : 
    4796             : /*
    4797             :  * Process the dependency information into a form useful for parallel restore.
    4798             :  *
    4799             :  * This function takes care of fixing up some missing or badly designed
    4800             :  * dependencies, and then prepares subsidiary data structures that will be
    4801             :  * used in the main parallel-restore logic, including:
    4802             :  * 1. We build the revDeps[] arrays of incoming dependency dumpIds.
    4803             :  * 2. We set up depCount fields that are the number of as-yet-unprocessed
    4804             :  * dependencies for each TOC entry.
    4805             :  *
    4806             :  * We also identify locking dependencies so that we can avoid trying to
    4807             :  * schedule conflicting items at the same time.
    4808             :  */
    4809             : static void
    4810           8 : fix_dependencies(ArchiveHandle *AH)
    4811             : {
    4812             :     TocEntry   *te;
    4813             :     int         i;
    4814             : 
    4815             :     /*
    4816             :      * Initialize the depCount/revDeps/nRevDeps fields, and make sure the TOC
    4817             :      * items are marked as not being in any parallel-processing list.
    4818             :      */
    4819         200 :     for (te = AH->toc->next; te != AH->toc; te = te->next)
    4820             :     {
    4821         192 :         te->depCount = te->nDeps;
    4822         192 :         te->revDeps = NULL;
    4823         192 :         te->nRevDeps = 0;
    4824         192 :         te->pending_prev = NULL;
    4825         192 :         te->pending_next = NULL;
    4826             :     }
    4827             : 
    4828             :     /*
    4829             :      * POST_DATA items that are shown as depending on a table need to be
    4830             :      * re-pointed to depend on that table's data, instead.  This ensures they
    4831             :      * won't get scheduled until the data has been loaded.
    4832             :      */
    4833           8 :     repoint_table_dependencies(AH);
    4834             : 
    4835             :     /*
    4836             :      * Pre-8.4 versions of pg_dump neglected to set up a dependency from BLOB
    4837             :      * COMMENTS to BLOBS.  Cope.  (We assume there's only one BLOBS and only
    4838             :      * one BLOB COMMENTS in such files.)
    4839             :      */
    4840           8 :     if (AH->version < K_VERS_1_11)
    4841             :     {
    4842           0 :         for (te = AH->toc->next; te != AH->toc; te = te->next)
    4843             :         {
    4844           0 :             if (strcmp(te->desc, "BLOB COMMENTS") == 0 && te->nDeps == 0)
    4845             :             {
    4846             :                 TocEntry   *te2;
    4847             : 
    4848           0 :                 for (te2 = AH->toc->next; te2 != AH->toc; te2 = te2->next)
    4849             :                 {
    4850           0 :                     if (strcmp(te2->desc, "BLOBS") == 0)
    4851             :                     {
    4852           0 :                         te->dependencies = (DumpId *) pg_malloc(sizeof(DumpId));
    4853           0 :                         te->dependencies[0] = te2->dumpId;
    4854           0 :                         te->nDeps++;
    4855           0 :                         te->depCount++;
    4856           0 :                         break;
    4857             :                     }
    4858             :                 }
    4859           0 :                 break;
    4860             :             }
    4861             :         }
    4862             :     }
    4863             : 
    4864             :     /*
    4865             :      * At this point we start to build the revDeps reverse-dependency arrays,
    4866             :      * so all changes of dependencies must be complete.
    4867             :      */
    4868             : 
    4869             :     /*
    4870             :      * Count the incoming dependencies for each item.  Also, it is possible
    4871             :      * that the dependencies list items that are not in the archive at all
    4872             :      * (that should not happen in 9.2 and later, but is highly likely in older
    4873             :      * archives).  Subtract such items from the depCounts.
    4874             :      */
    4875         200 :     for (te = AH->toc->next; te != AH->toc; te = te->next)
    4876             :     {
    4877         576 :         for (i = 0; i < te->nDeps; i++)
    4878             :         {
    4879         384 :             DumpId      depid = te->dependencies[i];
    4880             : 
    4881         384 :             if (depid <= AH->maxDumpId && AH->tocsByDumpId[depid] != NULL)
    4882         384 :                 AH->tocsByDumpId[depid]->nRevDeps++;
    4883             :             else
    4884           0 :                 te->depCount--;
    4885             :         }
    4886             :     }
    4887             : 
    4888             :     /*
    4889             :      * Allocate space for revDeps[] arrays, and reset nRevDeps so we can use
    4890             :      * it as a counter below.
    4891             :      */
    4892         200 :     for (te = AH->toc->next; te != AH->toc; te = te->next)
    4893             :     {
    4894         192 :         if (te->nRevDeps > 0)
    4895         104 :             te->revDeps = (DumpId *) pg_malloc(te->nRevDeps * sizeof(DumpId));
    4896         192 :         te->nRevDeps = 0;
    4897             :     }
    4898             : 
    4899             :     /*
    4900             :      * Build the revDeps[] arrays of incoming-dependency dumpIds.  This had
    4901             :      * better agree with the loops above.
    4902             :      */
    4903         200 :     for (te = AH->toc->next; te != AH->toc; te = te->next)
    4904             :     {
    4905         576 :         for (i = 0; i < te->nDeps; i++)
    4906             :         {
    4907         384 :             DumpId      depid = te->dependencies[i];
    4908             : 
    4909         384 :             if (depid <= AH->maxDumpId && AH->tocsByDumpId[depid] != NULL)
    4910             :             {
    4911         384 :                 TocEntry   *otherte = AH->tocsByDumpId[depid];
    4912             : 
    4913         384 :                 otherte->revDeps[otherte->nRevDeps++] = te->dumpId;
    4914             :             }
    4915             :         }
    4916             :     }
    4917             : 
    4918             :     /*
    4919             :      * Lastly, work out the locking dependencies.
    4920             :      */
    4921         200 :     for (te = AH->toc->next; te != AH->toc; te = te->next)
    4922             :     {
    4923         192 :         te->lockDeps = NULL;
    4924         192 :         te->nLockDeps = 0;
    4925         192 :         identify_locking_dependencies(AH, te);
    4926             :     }
    4927           8 : }
    4928             : 
    4929             : /*
    4930             :  * Change dependencies on table items to depend on table data items instead,
    4931             :  * but only in POST_DATA items.
    4932             :  *
    4933             :  * Also, for any item having such dependency(s), set its dataLength to the
    4934             :  * largest dataLength of the table data items it depends on.  This ensures
    4935             :  * that parallel restore will prioritize larger jobs (index builds, FK
    4936             :  * constraint checks, etc) over smaller ones, avoiding situations where we
    4937             :  * end a restore with only one active job working on a large table.
    4938             :  */
    4939             : static void
    4940           8 : repoint_table_dependencies(ArchiveHandle *AH)
    4941             : {
    4942             :     TocEntry   *te;
    4943             :     int         i;
    4944             :     DumpId      olddep;
    4945             : 
    4946         200 :     for (te = AH->toc->next; te != AH->toc; te = te->next)
    4947             :     {
    4948         192 :         if (te->section != SECTION_POST_DATA)
    4949         132 :             continue;
    4950         320 :         for (i = 0; i < te->nDeps; i++)
    4951             :         {
    4952         260 :             olddep = te->dependencies[i];
    4953         260 :             if (olddep <= AH->maxDumpId &&
    4954         260 :                 AH->tableDataId[olddep] != 0)
    4955             :             {
    4956         124 :                 DumpId      tabledataid = AH->tableDataId[olddep];
    4957         124 :                 TocEntry   *tabledatate = AH->tocsByDumpId[tabledataid];
    4958             : 
    4959         124 :                 te->dependencies[i] = tabledataid;
    4960         124 :                 te->dataLength = Max(te->dataLength, tabledatate->dataLength);
    4961         124 :                 pg_log_debug("transferring dependency %d -> %d to %d",
    4962             :                              te->dumpId, olddep, tabledataid);
    4963             :             }
    4964             :         }
    4965             :     }
    4966           8 : }
    4967             : 
    4968             : /*
    4969             :  * Identify which objects we'll need exclusive lock on in order to restore
    4970             :  * the given TOC entry (*other* than the one identified by the TOC entry
    4971             :  * itself).  Record their dump IDs in the entry's lockDeps[] array.
    4972             :  */
    4973             : static void
    4974         192 : identify_locking_dependencies(ArchiveHandle *AH, TocEntry *te)
    4975             : {
    4976             :     DumpId     *lockids;
    4977             :     int         nlockids;
    4978             :     int         i;
    4979             : 
    4980             :     /*
    4981             :      * We only care about this for POST_DATA items.  PRE_DATA items are not
    4982             :      * run in parallel, and DATA items are all independent by assumption.
    4983             :      */
    4984         192 :     if (te->section != SECTION_POST_DATA)
    4985         132 :         return;
    4986             : 
    4987             :     /* Quick exit if no dependencies at all */
    4988          60 :     if (te->nDeps == 0)
    4989           0 :         return;
    4990             : 
    4991             :     /*
    4992             :      * Most POST_DATA items are ALTER TABLEs or some moral equivalent of that,
    4993             :      * and hence require exclusive lock.  However, we know that CREATE INDEX
    4994             :      * does not.  (Maybe someday index-creating CONSTRAINTs will fall in that
    4995             :      * category too ... but today is not that day.)
    4996             :      */
    4997          60 :     if (strcmp(te->desc, "INDEX") == 0)
    4998           0 :         return;
    4999             : 
    5000             :     /*
    5001             :      * We assume the entry requires exclusive lock on each TABLE or TABLE DATA
    5002             :      * item listed among its dependencies.  Originally all of these would have
    5003             :      * been TABLE items, but repoint_table_dependencies would have repointed
    5004             :      * them to the TABLE DATA items if those are present (which they might not
    5005             :      * be, eg in a schema-only dump).  Note that all of the entries we are
    5006             :      * processing here are POST_DATA; otherwise there might be a significant
    5007             :      * difference between a dependency on a table and a dependency on its
    5008             :      * data, so that closer analysis would be needed here.
    5009             :      */
    5010          60 :     lockids = (DumpId *) pg_malloc(te->nDeps * sizeof(DumpId));
    5011          60 :     nlockids = 0;
    5012         320 :     for (i = 0; i < te->nDeps; i++)
    5013             :     {
    5014         260 :         DumpId      depid = te->dependencies[i];
    5015             : 
    5016         260 :         if (depid <= AH->maxDumpId && AH->tocsByDumpId[depid] != NULL &&
    5017         260 :             ((strcmp(AH->tocsByDumpId[depid]->desc, "TABLE DATA") == 0) ||
    5018         136 :              strcmp(AH->tocsByDumpId[depid]->desc, "TABLE") == 0))
    5019         164 :             lockids[nlockids++] = depid;
    5020             :     }
    5021             : 
    5022          60 :     if (nlockids == 0)
    5023             :     {
    5024           0 :         free(lockids);
    5025           0 :         return;
    5026             :     }
    5027             : 
    5028          60 :     te->lockDeps = pg_realloc(lockids, nlockids * sizeof(DumpId));
    5029          60 :     te->nLockDeps = nlockids;
    5030             : }
    5031             : 
    5032             : /*
    5033             :  * Remove the specified TOC entry from the depCounts of items that depend on
    5034             :  * it, thereby possibly making them ready-to-run.  Any pending item that
    5035             :  * becomes ready should be moved to the ready_heap, if that's provided.
    5036             :  */
    5037             : static void
    5038         192 : reduce_dependencies(ArchiveHandle *AH, TocEntry *te,
    5039             :                     binaryheap *ready_heap)
    5040             : {
    5041             :     int         i;
    5042             : 
    5043         192 :     pg_log_debug("reducing dependencies for %d", te->dumpId);
    5044             : 
    5045         576 :     for (i = 0; i < te->nRevDeps; i++)
    5046             :     {
    5047         384 :         TocEntry   *otherte = AH->tocsByDumpId[te->revDeps[i]];
    5048             : 
    5049             :         Assert(otherte->depCount > 0);
    5050         384 :         otherte->depCount--;
    5051             : 
    5052             :         /*
    5053             :          * It's ready if it has no remaining dependencies, and it belongs in
    5054             :          * the current restore pass, and it is currently a member of the
    5055             :          * pending list (that check is needed to prevent double restore in
    5056             :          * some cases where a list-file forces out-of-order restoring).
    5057             :          * However, if ready_heap == NULL then caller doesn't want any list
    5058             :          * memberships changed.
    5059             :          */
    5060         384 :         if (otherte->depCount == 0 &&
    5061         148 :             _tocEntryRestorePass(otherte) == AH->restorePass &&
    5062         148 :             otherte->pending_prev != NULL &&
    5063             :             ready_heap != NULL)
    5064             :         {
    5065             :             /* Remove it from pending list ... */
    5066          52 :             pending_list_remove(otherte);
    5067             :             /* ... and add to ready_heap */
    5068          52 :             binaryheap_add(ready_heap, otherte);
    5069             :         }
    5070             :     }
    5071         192 : }
    5072             : 
    5073             : /*
    5074             :  * Set the created flag on the DATA member corresponding to the given
    5075             :  * TABLE member
    5076             :  */
    5077             : static void
    5078       10840 : mark_create_done(ArchiveHandle *AH, TocEntry *te)
    5079             : {
    5080       10840 :     if (AH->tableDataId[te->dumpId] != 0)
    5081             :     {
    5082        8178 :         TocEntry   *ted = AH->tocsByDumpId[AH->tableDataId[te->dumpId]];
    5083             : 
    5084        8178 :         ted->created = true;
    5085             :     }
    5086       10840 : }
    5087             : 
    5088             : /*
    5089             :  * Mark the DATA member corresponding to the given TABLE member
    5090             :  * as not wanted
    5091             :  */
    5092             : static void
    5093           0 : inhibit_data_for_failed_table(ArchiveHandle *AH, TocEntry *te)
    5094             : {
    5095           0 :     pg_log_info("table \"%s\" could not be created, will not restore its data",
    5096             :                 te->tag);
    5097             : 
    5098           0 :     if (AH->tableDataId[te->dumpId] != 0)
    5099             :     {
    5100           0 :         TocEntry   *ted = AH->tocsByDumpId[AH->tableDataId[te->dumpId]];
    5101             : 
    5102           0 :         ted->reqs = 0;
    5103             :     }
    5104           0 : }
    5105             : 
    5106             : /*
    5107             :  * Clone and de-clone routines used in parallel restoration.
    5108             :  *
    5109             :  * Enough of the structure is cloned to ensure that there is no
    5110             :  * conflict between different threads each with their own clone.
    5111             :  */
    5112             : ArchiveHandle *
    5113          52 : CloneArchive(ArchiveHandle *AH)
    5114             : {
    5115             :     ArchiveHandle *clone;
    5116             : 
    5117             :     /* Make a "flat" copy */
    5118          52 :     clone = (ArchiveHandle *) pg_malloc(sizeof(ArchiveHandle));
    5119          52 :     memcpy(clone, AH, sizeof(ArchiveHandle));
    5120             : 
    5121             :     /* Likewise flat-copy the RestoreOptions, so we can alter them locally */
    5122          52 :     clone->public.ropt = (RestoreOptions *) pg_malloc(sizeof(RestoreOptions));
    5123          52 :     memcpy(clone->public.ropt, AH->public.ropt, sizeof(RestoreOptions));
    5124             : 
    5125             :     /* Handle format-independent fields */
    5126          52 :     memset(&(clone->sqlparse), 0, sizeof(clone->sqlparse));
    5127             : 
    5128             :     /* The clone will have its own connection, so disregard connection state */
    5129          52 :     clone->connection = NULL;
    5130          52 :     clone->connCancel = NULL;
    5131          52 :     clone->currUser = NULL;
    5132          52 :     clone->currSchema = NULL;
    5133          52 :     clone->currTableAm = NULL;
    5134          52 :     clone->currTablespace = NULL;
    5135             : 
    5136             :     /* savedPassword must be local in case we change it while connecting */
    5137          52 :     if (clone->savedPassword)
    5138           0 :         clone->savedPassword = pg_strdup(clone->savedPassword);
    5139             : 
    5140             :     /* clone has its own error count, too */
    5141          52 :     clone->public.n_errors = 0;
    5142             : 
    5143             :     /* clones should not share lo_buf */
    5144          52 :     clone->lo_buf = NULL;
    5145             : 
    5146             :     /*
    5147             :      * Clone connections disregard --transaction-size; they must commit after
    5148             :      * each command so that the results are immediately visible to other
    5149             :      * workers.
    5150             :      */
    5151          52 :     clone->public.ropt->txn_size = 0;
    5152             : 
    5153             :     /*
    5154             :      * Connect our new clone object to the database, using the same connection
    5155             :      * parameters used for the original connection.
    5156             :      */
    5157          52 :     ConnectDatabaseAhx((Archive *) clone, &clone->public.ropt->cparams, true);
    5158             : 
    5159             :     /* re-establish fixed state */
    5160          52 :     if (AH->mode == archModeRead)
    5161          20 :         _doSetFixedOutputState(clone);
    5162             :     /* in write case, setupDumpWorker will fix up connection state */
    5163             : 
    5164             :     /* Let the format-specific code have a chance too */
    5165          52 :     clone->ClonePtr(clone);
    5166             : 
    5167             :     Assert(clone->connection != NULL);
    5168          52 :     return clone;
    5169             : }
    5170             : 
    5171             : /*
    5172             :  * Release clone-local storage.
    5173             :  *
    5174             :  * Note: we assume any clone-local connection was already closed.
    5175             :  */
    5176             : void
    5177          52 : DeCloneArchive(ArchiveHandle *AH)
    5178             : {
    5179             :     /* Should not have an open database connection */
    5180             :     Assert(AH->connection == NULL);
    5181             : 
    5182             :     /* Clear format-specific state */
    5183          52 :     AH->DeClonePtr(AH);
    5184             : 
    5185             :     /* Clear state allocated by CloneArchive */
    5186          52 :     if (AH->sqlparse.curCmd)
    5187           6 :         destroyPQExpBuffer(AH->sqlparse.curCmd);
    5188             : 
    5189             :     /* Clear any connection-local state */
    5190          52 :     free(AH->currUser);
    5191          52 :     free(AH->currSchema);
    5192          52 :     free(AH->currTablespace);
    5193          52 :     free(AH->currTableAm);
    5194          52 :     free(AH->savedPassword);
    5195             : 
    5196          52 :     free(AH);
    5197          52 : }

Generated by: LCOV version 1.16