ereport(ERROR,
                (errcode(ERRCODE_PROGRAM_LIMIT_EXCEEDED),
            errmsg("index row size %zu exceeds maximum %zu for index \"%s\"",
-                  itemsz, BrinMaxItemSize, RelationGetRelationName(idxrel))));
+                itemsz, BrinMaxItemSize, RelationGetRelationName(idxrel))));
        return InvalidOffsetNumber;     /* keep compiler quiet */
    }
 
 
            continue;           /* got it */
        ereport(INFO,
                (errcode(ERRCODE_INVALID_OBJECT_DEFINITION),
-         errmsg("operator class \"%s\" of access method %s is missing support function %d",
-                opclassname, "brin", i)));
+                errmsg("operator class \"%s\" of access method %s is missing support function %d",
+                       opclassname, "brin", i)));
        result = false;
    }
 
 
            continue;           /* don't need both, see check below loop */
        ereport(INFO,
                (errcode(ERRCODE_INVALID_OBJECT_DEFINITION),
-          errmsg("operator class \"%s\" of access method %s is missing support function %d",
-                 opclassname, "gin", i)));
+                errmsg("operator class \"%s\" of access method %s is missing support function %d",
+                       opclassname, "gin", i)));
        result = false;
    }
    if (!opclassgroup ||
 
            continue;           /* optional methods */
        ereport(INFO,
                (errcode(ERRCODE_INVALID_OBJECT_DEFINITION),
-         errmsg("operator class \"%s\" of access method %s is missing support function %d",
-                opclassname, "gist", i)));
+                errmsg("operator class \"%s\" of access method %s is missing support function %d",
+                       opclassname, "gist", i)));
        result = false;
    }
 
 
                (errmsg("index \"%s\" was reindexed",
                        get_rel_name(indexId)),
                 errdetail_internal("%s",
-                          pg_rusage_show(&ru0))));
+                                   pg_rusage_show(&ru0))));
 
    /* Close rels, but keep locks */
    index_close(iRel, NoLock);
 
                 * tuple such that the partition constraint is no longer
                 * satisfied, so we need to check in that case.
                 */
-               bool    check_partition_constr =
-                                   (resultRelInfo->ri_PartitionCheck != NIL);
+               bool        check_partition_constr =
+               (resultRelInfo->ri_PartitionCheck != NIL);
 
                if (saved_resultRelInfo != NULL &&
                    !(resultRelInfo->ri_TrigDesc &&
 
                        RelationGetRelationName(onerel),
                        old_rel_pages, new_rel_pages),
                 errdetail_internal("%s",
-                          pg_rusage_show(&ru0))));
+                                   pg_rusage_show(&ru0))));
        old_rel_pages = new_rel_pages;
    } while (new_rel_pages > vacrelstats->nonempty_pages &&
             vacrelstats->lock_waiter_detected);
 
         */
        ereport(ERROR,
                (errcode(ERRCODE_INVALID_TRANSACTION_STATE),
-             errmsg("cannot change client_encoding during a parallel operation")));
+       errmsg("cannot change client_encoding during a parallel operation")));
    }
 
    /* We do not expect an error if PrepareClientEncoding succeeded */
 
 static void EvalPlanQualStart(EPQState *epqstate, EState *parentestate,
                  Plan *planTree);
 static void ExecPartitionCheck(ResultRelInfo *resultRelInfo,
-                 TupleTableSlot *slot, EState *estate);
+                  TupleTableSlot *slot, EState *estate);
 
 /*
  * Note that GetUpdatedColumns() also exists in commands/trigger.c.  There does
     * partition, if there any BR triggers defined on the table.  Although
     * tuple-routing implicitly preserves the partition constraint of the
     * target partition for a given row, the BR triggers may change the row
-    * such that the constraint is no longer satisfied, which we must fail
-    * for by checking it explicitly.
+    * such that the constraint is no longer satisfied, which we must fail for
+    * by checking it explicitly.
     *
     * If this is a partitioned table, the partition constraint (if any) of a
     * given row will be checked just before performing tuple-routing.
 
         * trigger might modify the tuple such that the partition constraint
         * is no longer satisfied, so we need to check in that case.
         */
-       bool    check_partition_constr =
-                               (resultRelInfo->ri_PartitionCheck != NIL);
+       bool        check_partition_constr =
+       (resultRelInfo->ri_PartitionCheck != NIL);
 
        /*
         * Constraints might reference the tableoid column, so initialize
 
                 * parsed.
                 */
                ereport(LOG,
-                       (errmsg("invalid SCRAM verifier for user \"%s\"", username)));
+                       (errmsg("invalid SCRAM verifier for user \"%s\"",
+                               username)));
                got_verifier = false;
            }
        }
        ereport(ERROR,
                (errcode(ERRCODE_PROTOCOL_VIOLATION),
                 errmsg("malformed SCRAM message"),
-                errdetail("Attribute expected, but found invalid character %s.",
-                          sanitize_char(attr))));
+            errdetail("Attribute expected, but found invalid character %s.",
+                      sanitize_char(attr))));
    if (attr_p)
        *attr_p = attr;
    begin++;
        ereport(ERROR,
                (errcode(ERRCODE_PROTOCOL_VIOLATION),
                 errmsg("malformed SCRAM message"),
-                errdetail("Garbage found at the end of client-final-message.")));
+           errdetail("Garbage found at the end of client-final-message.")));
 
    state->client_final_message_without_proof = palloc(proof - begin + 1);
    memcpy(state->client_final_message_without_proof, input, proof - begin);
 
                continue;
 
            attnum = logicalrep_rel_att_by_name(remoterel,
-                                               NameStr(desc->attrs[i]->attname));
+                                          NameStr(desc->attrs[i]->attname));
 
            entry->attrmap[i] = attnum;
            if (attnum >= 0)
 
  *      point it sets state to READY and stops tracking.  Again, there might
  *      be zero changes in between.
  *
- *    So the state progression is always: INIT -> DATASYNC -> SYNCWAIT -> CATCHUP ->
- *    SYNCDONE -> READY.
+ *   So the state progression is always: INIT -> DATASYNC -> SYNCWAIT -> CATCHUP ->
+ *   SYNCDONE -> READY.
  *
  *   The catalog pg_subscription_rel is used to keep information about
  *   subscribed tables and their state.  Some transient state during data
    StartTransactionCommand();
    ereport(LOG,
            (errmsg("logical replication table synchronization worker for subscription \"%s\", table \"%s\" has finished",
-                   MySubscription->name, get_rel_name(MyLogicalRepWorker->relid))));
+                   MySubscription->name,
+                   get_rel_name(MyLogicalRepWorker->relid))));
    CommitTransactionCommand();
 
    /* Find the main apply worker and signal it. */
    for (;;)
    {
        LogicalRepWorker *worker;
-       XLogRecPtr      statelsn;
+       XLogRecPtr  statelsn;
 
        CHECK_FOR_INTERRUPTS();
 
 
        /* Check if the opposite worker is still running and bail if not. */
        worker = logicalrep_worker_find(MyLogicalRepWorker->subid,
-                                       am_tablesync_worker() ? InvalidOid : relid,
+                                 am_tablesync_worker() ? InvalidOid : relid,
                                        false);
        LWLockRelease(LogicalRepWorkerLock);
        if (!worker)
        {
            /*
             * Apply has caught up to the position where the table sync has
-            * finished.  Mark the table as ready so that the apply will
-            * just continue to replicate it normally.
+            * finished.  Mark the table as ready so that the apply will just
+            * continue to replicate it normally.
             */
            if (current_lsn >= rstate->lsn)
            {
            else
 
                /*
-                * If there is no sync worker for this table yet, count running sync
-                * workers for this subscription, while we have the lock, for
-                * later.
+                * If there is no sync worker for this table yet, count
+                * running sync workers for this subscription, while we have
+                * the lock, for later.
                 */
                nsyncworkers = logicalrep_sync_worker_count(MyLogicalRepWorker->subid);
            LWLockRelease(LogicalRepWorkerLock);
 
                /*
                 * Use a standard write lock here. It might be better to
-                * disallow access to the table while it's being synchronized. But
-                * we don't want to block the main apply process from working
-                * and it has to open the relation in RowExclusiveLock when
-                * remapping remote relation id to local one.
+                * disallow access to the table while it's being synchronized.
+                * But we don't want to block the main apply process from
+                * working and it has to open the relation in RowExclusiveLock
+                * when remapping remote relation id to local one.
                 */
                rel = heap_open(MyLogicalRepWorker->relid, RowExclusiveLock);
 
                /*
                 * Create a temporary slot for the sync process. We do this
-                * inside the transaction so that we can use the snapshot made by
-                * the slot to get existing data.
+                * inside the transaction so that we can use the snapshot made
+                * by the slot to get existing data.
                 */
                res = walrcv_exec(wrconn,
                                  "BEGIN READ ONLY ISOLATION LEVEL "
                /* Wait for main apply worker to tell us to catchup. */
                wait_for_worker_state_change(SUBREL_STATE_CATCHUP);
 
-               /*
+               /*----------
                 * There are now two possible states here:
                 * a) Sync is behind the apply.  If that's the case we need to
-                *    catch up with it by consuming the logical replication
-                *    stream up to the relstate_lsn.  For that, we exit this
-                *    function and continue in ApplyWorkerMain().
+                *    catch up with it by consuming the logical replication
+                *    stream up to the relstate_lsn.  For that, we exit this
+                *    function and continue in ApplyWorkerMain().
                 * b) Sync is caught up with the apply.  So it can just set
-                *    the state to SYNCDONE and finish.
+                *    the state to SYNCDONE and finish.
+                *----------
                 */
                if (*origin_startpos >= MyLogicalRepWorker->relstate_lsn)
                {
        case SUBREL_STATE_SYNCDONE:
        case SUBREL_STATE_READY:
        case SUBREL_STATE_UNKNOWN:
-           /* Nothing to do here but finish.  (UNKNOWN means the relation was
+
+           /*
+            * Nothing to do here but finish.  (UNKNOWN means the relation was
             * removed from pg_subscription_rel before the sync worker could
-            * start.) */
+            * start.)
+            */
            finish_sync_worker();
            break;
        default:
 
    if (!newsub)
    {
        ereport(LOG,
-          (errmsg("logical replication apply worker for subscription \"%s\" will "
-                  "stop because the subscription was removed",
-                  MySubscription->name)));
+               (errmsg("logical replication apply worker for subscription \"%s\" will "
+                       "stop because the subscription was removed",
+                       MySubscription->name)));
 
        proc_exit(0);
    }
    if (!newsub->enabled)
    {
        ereport(LOG,
-          (errmsg("logical replication apply worker for subscription \"%s\" will "
-                  "stop because the subscription was disabled",
-                  MySubscription->name)));
+               (errmsg("logical replication apply worker for subscription \"%s\" will "
+                       "stop because the subscription was disabled",
+                       MySubscription->name)));
 
        proc_exit(0);
    }
    if (strcmp(newsub->conninfo, MySubscription->conninfo) != 0)
    {
        ereport(LOG,
-          (errmsg("logical replication apply worker for subscription \"%s\" will "
-                  "restart because the connection information was changed",
-                  MySubscription->name)));
+               (errmsg("logical replication apply worker for subscription \"%s\" will "
+                   "restart because the connection information was changed",
+                       MySubscription->name)));
 
        proc_exit(0);
    }
    if (strcmp(newsub->name, MySubscription->name) != 0)
    {
        ereport(LOG,
-          (errmsg("logical replication apply worker for subscription \"%s\" will "
-                  "restart because subscription was renamed",
-                  MySubscription->name)));
+               (errmsg("logical replication apply worker for subscription \"%s\" will "
+                       "restart because subscription was renamed",
+                       MySubscription->name)));
 
        proc_exit(0);
    }
    if (strcmp(newsub->slotname, MySubscription->slotname) != 0)
    {
        ereport(LOG,
-          (errmsg("logical replication apply worker for subscription \"%s\" will "
-                  "restart because the replication slot name was changed",
-                  MySubscription->name)));
+               (errmsg("logical replication apply worker for subscription \"%s\" will "
+                    "restart because the replication slot name was changed",
+                       MySubscription->name)));
 
        proc_exit(0);
    }
    if (!equal(newsub->publications, MySubscription->publications))
    {
        ereport(LOG,
-          (errmsg("logical replication apply worker for subscription \"%s\" will "
-                  "restart because subscription's publications were changed",
-                  MySubscription->name)));
+               (errmsg("logical replication apply worker for subscription \"%s\" will "
+                 "restart because subscription's publications were changed",
+                       MySubscription->name)));
 
        proc_exit(0);
    }
    if (!MySubscription->enabled)
    {
        ereport(LOG,
-       (errmsg("logical replication apply worker for subscription \"%s\" will not "
+               (errmsg("logical replication apply worker for subscription \"%s\" will not "
                "start because the subscription was disabled during startup",
-               MySubscription->name)));
+                       MySubscription->name)));
 
        proc_exit(0);
    }
    if (am_tablesync_worker())
        ereport(LOG,
                (errmsg("logical replication table synchronization worker for subscription \"%s\", table \"%s\" has started",
-                       MySubscription->name, get_rel_name(MyLogicalRepWorker->relid))));
+           MySubscription->name, get_rel_name(MyLogicalRepWorker->relid))));
    else
        ereport(LOG,
                (errmsg("logical replication apply worker for subscription \"%s\" has started",
 
        /*
         * This shouldn't happen if the subscription is enabled, but guard
-        * against DDL bugs or manual catalog changes.  (libpqwalreceiver
-        * will crash if slot is NULL.
+        * against DDL bugs or manual catalog changes.  (libpqwalreceiver will
+        * crash if slot is NULL.)
         */
        if (!myslotname)
            ereport(ERROR,
 
        /* Only normal relations can have RLS policies */
        if (rte->rtekind != RTE_RELATION ||
            (rte->relkind != RELKIND_RELATION &&
-           rte->relkind != RELKIND_PARTITIONED_TABLE))
+            rte->relkind != RELKIND_PARTITIONED_TABLE))
            continue;
 
        rel = heap_open(rte->relid, NoLock);
 
            offset != MAXALIGN(offset))
            ereport(ERROR,
                    (errcode(ERRCODE_DATA_CORRUPTED),
-                    errmsg("corrupted item pointer: offset = %u, length = %u",
-                           offset, (unsigned int) size)));
+                  errmsg("corrupted item pointer: offset = %u, length = %u",
+                         offset, (unsigned int) size)));
 
        if (nextitm < nitems && offnum == itemnos[nextitm])
        {
 
        WalSndSignals();
    else
    {
-       pqsignal(SIGHUP, PostgresSigHupHandler);        /* set flag to read config
-                                                        * file */
+       pqsignal(SIGHUP, PostgresSigHupHandler);        /* set flag to read
+                                                        * config file */
        pqsignal(SIGINT, StatementCancelHandler);       /* cancel current query */
        pqsignal(SIGTERM, die); /* cancel current query and exit */
 
 
        if (arg_type == InvalidOid)
            ereport(ERROR,
                    (errcode(ERRCODE_INVALID_PARAMETER_VALUE),
-                    errmsg("could not determine data type for argument %d", 1)));
+               errmsg("could not determine data type for argument %d", 1)));
 
        json_categorize_type(arg_type, &state->key_category,
                             &state->key_output_func);
        if (arg_type == InvalidOid)
            ereport(ERROR,
                    (errcode(ERRCODE_INVALID_PARAMETER_VALUE),
-                    errmsg("could not determine data type for argument %d", 2)));
+               errmsg("could not determine data type for argument %d", 2)));
 
        json_categorize_type(arg_type, &state->val_category,
                             &state->val_output_func);
 
        if (val_type == InvalidOid || val_type == UNKNOWNOID)
            ereport(ERROR,
                    (errcode(ERRCODE_INVALID_PARAMETER_VALUE),
-              errmsg("could not determine data type for argument %d", i + 1)));
+           errmsg("could not determine data type for argument %d", i + 1)));
 
        add_jsonb(arg, false, &result, val_type, true);
 
        if (val_type == InvalidOid || val_type == UNKNOWNOID)
            ereport(ERROR,
                    (errcode(ERRCODE_INVALID_PARAMETER_VALUE),
-              errmsg("could not determine data type for argument %d", i + 2)));
+           errmsg("could not determine data type for argument %d", i + 2)));
        add_jsonb(arg, PG_ARGISNULL(i + 1), &result, val_type, false);
    }
 
        if (val_type == InvalidOid || val_type == UNKNOWNOID)
            ereport(ERROR,
                    (errcode(ERRCODE_INVALID_PARAMETER_VALUE),
-              errmsg("could not determine data type for argument %d", i + 1)));
+           errmsg("could not determine data type for argument %d", i + 1)));
        add_jsonb(arg, PG_ARGISNULL(i), &result, val_type, false);
    }
 
 
            printfPQExpBuffer(&buf,
                              "SELECT pub.pubname\n"
                              " FROM pg_catalog.pg_publication pub,\n"
-                             "      pg_catalog.pg_get_publication_tables(pub.pubname)\n"
+                 "      pg_catalog.pg_get_publication_tables(pub.pubname)\n"
                              "WHERE relid = '%s'\n"
                              "ORDER BY 1;",
                              oid);
 
    PROCSIG_CATCHUP_INTERRUPT,  /* sinval catchup interrupt */
    PROCSIG_NOTIFY_INTERRUPT,   /* listen/notify interrupt */
    PROCSIG_PARALLEL_MESSAGE,   /* message from cooperating parallel backend */
-   PROCSIG_WALSND_INIT_STOPPING,   /* ask walsenders to prepare for shutdown  */
+   PROCSIG_WALSND_INIT_STOPPING,       /* ask walsenders to prepare for
+                                        * shutdown  */
 
    /* Recovery conflict reasons */
    PROCSIG_RECOVERY_CONFLICT_DATABASE,
 
 #define ZPBITOID    1560
 #define VARBITOID    1562
 #define NUMERICOID     1700
-#define REFCURSOROID    1790
+#define REFCURSOROID   1790
 #define REGPROCEDUREOID 2202
-#define REGOPEROID      2203
-#define REGOPERATOROID  2204
-#define REGCLASSOID     2205
-#define REGTYPEOID      2206
-#define REGROLEOID      4096
-#define REGNAMESPACEOID     4089
+#define REGOPEROID     2203
+#define REGOPERATOROID 2204
+#define REGCLASSOID        2205
+#define REGTYPEOID     2206
+#define REGROLEOID     4096
+#define REGNAMESPACEOID        4089
 #define REGTYPEARRAYOID 2211
 #define UUIDOID 2950
-#define LSNOID          3220
-#define TSVECTOROID     3614
-#define GTSVECTOROID    3642
-#define TSQUERYOID      3615
-#define REGCONFIGOID    3734
-#define REGDICTIONARYOID    3769
+#define LSNOID         3220
+#define TSVECTOROID        3614
+#define GTSVECTOROID   3642
+#define TSQUERYOID     3615
+#define REGCONFIGOID   3734
+#define REGDICTIONARYOID   3769
 #define JSONBOID 3802
-#define INT4RANGEOID        3904
+#define INT4RANGEOID       3904
 
 #endif   /* PG_TYPE_H */
 
    if (conn->sspictx)
    {
        printfPQExpBuffer(&conn->errorMessage,
-                   libpq_gettext("duplicate SSPI authentication request\n"));
+                  libpq_gettext("duplicate SSPI authentication request\n"));
        return STATUS_ERROR;
    }
 
    else
    {
        printfPQExpBuffer(&conn->errorMessage,
-                  libpq_gettext("unrecognized password encryption algorithm \"%s\"\n"),
+       libpq_gettext("unrecognized password encryption algorithm \"%s\"\n"),
                          algorithm);
        return NULL;
    }
 
                return 0;
        }
 
-       if (ret == 1)   /* connect_timeout elapsed */
+       if (ret == 1)           /* connect_timeout elapsed */
        {
-           /* If there are no more hosts, return (the error message is already set) */
+           /*
+            * If there are no more hosts, return (the error message is
+            * already set)
+            */
            if (++conn->whichhost >= conn->nconnhost)
            {
                conn->whichhost = 0;
                conn->status = CONNECTION_BAD;
                return 0;
            }
-           /* Attempt connection to the next host, starting the connect_timeout timer */
+
+           /*
+            * Attempt connection to the next host, starting the
+            * connect_timeout timer
+            */
            pqDropConnection(conn, true);
            conn->addr_cur = conn->connhost[conn->whichhost].addrlist;
            conn->status = CONNECTION_NEEDED;