Fix typos in comments
authorMichael Paquier <[email protected]>
Tue, 2 May 2023 03:23:08 +0000 (12:23 +0900)
committerMichael Paquier <[email protected]>
Tue, 2 May 2023 03:23:08 +0000 (12:23 +0900)
The changes done in this commit impact comments with no direct
user-visible changes, with fixes for incorrect function, variable or
structure names.

Author: Alexander Lakhin
Discussion: https://postgr.es/m/e8c38840-596a-83d6-bd8d-cebc51111572@gmail.com

43 files changed:
config/config.sub
contrib/amcheck/verify_nbtree.c
contrib/intarray/_int.h
src/backend/access/gist/gistxlog.c
src/backend/access/heap/heapam.c
src/backend/access/heap/heapam_handler.c
src/backend/access/heap/pruneheap.c
src/backend/access/heap/vacuumlazy.c
src/backend/access/nbtree/nbtsplitloc.c
src/backend/access/transam/slru.c
src/backend/access/transam/xlogreader.c
src/backend/commands/opclasscmds.c
src/backend/commands/subscriptioncmds.c
src/backend/commands/tablecmds.c
src/backend/executor/nodeAgg.c
src/backend/jit/llvm/llvmjit_expr.c
src/backend/optimizer/plan/planagg.c
src/backend/parser/gram.y
src/backend/partitioning/partbounds.c
src/backend/partitioning/partdesc.c
src/backend/replication/logical/reorderbuffer.c
src/backend/replication/syncrep.c
src/backend/storage/file/fd.c
src/backend/storage/ipc/latch.c
src/backend/storage/ipc/procarray.c
src/backend/storage/lmgr/spin.c
src/backend/utils/activity/backend_status.c
src/backend/utils/activity/pgstat_wal.c
src/backend/utils/adt/acl.c
src/backend/utils/adt/pg_locale.c
src/backend/utils/adt/selfuncs.c
src/backend/utils/mb/mbutils.c
src/bin/pg_rewind/rewind_source.h
src/include/access/tableam.h
src/include/access/toast_helper.h
src/include/nodes/nodeFuncs.h
src/include/nodes/queryjumble.h
src/include/pg_config_manual.h
src/interfaces/libpq/fe-protocol3.c
src/interfaces/libpq/libpq-int.h
src/pl/plperl/plperl.c
src/test/recovery/t/023_pitr_prepared_xact.pl
src/test/subscription/t/004_sync.pl

index de4259e4047972f77ffc089796b32e325636c207..3c26ae98b2fe9647035b092bd4d12bbf6f916264 100644 (file)
@@ -1721,7 +1721,7 @@ case $os in
        # Likewise for "kernel-abi"
        eabi* | gnueabi*)
                ;;
-       # VxWorks passes extra cpu info in the 4th filed.
+       # VxWorks passes extra cpu info in the 4th field.
        simlinux | simwindows | spe)
                ;;
        # Now accept the basic system types.
index eb280d4893d3729b240b94344e6ddb68be582f31..6979aff727be0dfd604183ec43f62545a6b4db90 100644 (file)
@@ -104,7 +104,7 @@ typedef struct BtreeCheckState
 
        /*
         * The rightlink and incomplete split flag of block one level down to the
-        * target page, which was visited last time via downlink from taget page.
+        * target page, which was visited last time via downlink from target page.
         * We use it to check for missing downlinks.
         */
        BlockNumber prevrightlink;
index a52ec38ba4e13d23cbdfac502a34bb2a3515ca5d..0352cbd36826b48bd6138ae42d7cd5e9f99d444a 100644 (file)
@@ -15,7 +15,7 @@
                                                                         ((GISTIntArrayOptions *) PG_GET_OPCLASS_OPTIONS())->num_ranges : \
                                                                         G_INT_NUMRANGES_DEFAULT)
 
-/* gist_int_ops opclass options */
+/* gist__int_ops opclass options */
 typedef struct
 {
        int32           vl_len_;                /* varlena header (do not touch directly!) */
@@ -80,7 +80,7 @@ typedef char *BITVECP;
 #define HASHVAL(val, siglen) (((unsigned int)(val)) % SIGLENBIT(siglen))
 #define HASH(sign, val, siglen) SETBIT((sign), HASHVAL(val, siglen))
 
-/* gist_intbig_ops opclass options */
+/* gist__intbig_ops opclass options */
 typedef struct
 {
        int32           vl_len_;                /* varlena header (do not touch directly!) */
index 9a86fb3feffde85dc901eb33f040abad0bea0ae1..a2ddfd5e694058ce10ab02ffdd81e7a3505cd558 100644 (file)
@@ -580,8 +580,8 @@ gistXLogAssignLSN(void)
        int                     dummy = 0;
 
        /*
-        * Records other than SWITCH_WAL must have content. We use an integer 0 to
-        * follow the restriction.
+        * Records other than XLOG_SWITCH must have content. We use an integer 0
+        * to follow the restriction.
         */
        XLogBeginInsert();
        XLogSetRecordFlags(XLOG_MARK_UNIMPORTANT);
index b300a4675e8903db35496ff2ff38dea007421e5d..0124f37911f823f5be3ac9f866ed7f0e429cf915 100644 (file)
@@ -1223,7 +1223,7 @@ heap_set_tidrange(TableScanDesc sscan, ItemPointer mintid,
         * Calculate the first block and the number of blocks we must scan. We
         * could be more aggressive here and perform some more validation to try
         * and further narrow the scope of blocks to scan by checking if the
-        * lowerItem has an offset above MaxOffsetNumber.  In this case, we could
+        * lowestItem has an offset above MaxOffsetNumber.  In this case, we could
         * advance startBlk by one.  Likewise, if highestItem has an offset of 0
         * we could scan one fewer blocks.  However, such an optimization does not
         * seem worth troubling over, currently.
index e2e35b71eaa03bd3c2de840db671fe7fa42ad7af..cbb35aa73d6024c8e9bc5a140492f81edf0a9cda 100644 (file)
@@ -816,7 +816,7 @@ heapam_relation_copy_for_cluster(Relation OldHeap, Relation NewHeap,
                                 * If the last pages of the scan were empty, we would go to
                                 * the next phase while heap_blks_scanned != heap_blks_total.
                                 * Instead, to ensure that heap_blks_scanned is equivalent to
-                                * total_heap_blks after the table scan phase, this parameter
+                                * heap_blks_total after the table scan phase, this parameter
                                 * is manually updated to the correct value when the table
                                 * scan finishes.
                                 */
index 3f0342351fbf1ad150b3794a1a2358769f6cc861..20df39c14972960d79750f67c52719a4ce53498d 100644 (file)
@@ -198,8 +198,7 @@ heap_page_prune_opt(Relation relation, Buffer buffer)
                /*
                 * Now that we have buffer lock, get accurate information about the
                 * page's free space, and recheck the heuristic about whether to
-                * prune. (We needn't recheck PageIsPrunable, since no one else could
-                * have pruned while we hold pin.)
+                * prune.
                 */
                if (PageIsFull(page) || PageGetHeapFreeSpace(page) < minfree)
                {
@@ -490,7 +489,7 @@ heap_page_prune(Relation relation, Buffer buffer,
  *
  * Due to its cost we also only want to call
  * TransactionIdLimitedForOldSnapshots() if necessary, i.e. we might not have
- * done so in heap_hot_prune_opt() if pd_prune_xid was old enough. But we
+ * done so in heap_page_prune_opt() if pd_prune_xid was old enough. But we
  * still want to be able to remove rows that are too new to be removed
  * according to prstate->vistest, but that can be removed based on
  * old_snapshot_threshold. So we call TransactionIdLimitedForOldSnapshots() on
index 442db3551b040e3743ad3d69d30f28dc1f2f74c3..cda8889f5ea83037b31f88067d16e64ce4d7e9ee 100644 (file)
@@ -2575,7 +2575,7 @@ lazy_vacuum_heap_page(LVRelState *vacrel, BlockNumber blkno, Buffer buffer,
        END_CRIT_SECTION();
 
        /*
-        * Now that we have removed the LD_DEAD items from the page, once again
+        * Now that we have removed the LP_DEAD items from the page, once again
         * check if the page has become all-visible.  The page is already marked
         * dirty, exclusively locked, and, if needed, a full page image has been
         * emitted.
index ecb49bb47118ff1526b41c5a67b2bd3ca0c26ed1..43b67893d94619907d3f23fe6bcf0975e204fdd0 100644 (file)
@@ -119,7 +119,7 @@ static inline IndexTuple _bt_split_firstright(FindSplitData *state,
  * righthand page (which is called firstrightoff), plus a boolean
  * indicating whether the new tuple goes on the left or right page.  You
  * can think of the returned state as a point _between_ two adjacent data
- * items (laftleft and firstright data items) on an imaginary version of
+ * items (lastleft and firstright data items) on an imaginary version of
  * origpage that already includes newitem.  The bool is necessary to
  * disambiguate the case where firstrightoff == newitemoff (i.e. it is
  * sometimes needed to determine if the firstright tuple for the split is
index 2a42f31ec2aa19bb3ad24021535037f341a0ae41..71ac70fb40c5d85bccaad8488304c46f2f5b2f4b 100644 (file)
@@ -809,7 +809,7 @@ SlruPhysicalWritePage(SlruCtl ctl, int pageno, int slotno, SlruWriteAll fdata)
        }
 
        /*
-        * During a WriteAll, we may already have the desired file open.
+        * During a SimpleLruWriteAll, we may already have the desired file open.
         */
        if (fdata)
        {
@@ -864,7 +864,7 @@ SlruPhysicalWritePage(SlruCtl ctl, int pageno, int slotno, SlruWriteAll fdata)
                        else
                        {
                                /*
-                                * In the unlikely event that we exceed MAX_FLUSH_BUFFERS,
+                                * In the unlikely event that we exceed MAX_WRITEALL_BUFFERS,
                                 * fall back to treating it as a standalone write.
                                 */
                                fdata = NULL;
@@ -1478,7 +1478,7 @@ SlruPagePrecedesTestOffset(SlruCtl ctl, int per_page, uint32 offset)
  *
  * This assumes every uint32 >= FirstNormalTransactionId is a valid key.  It
  * assumes each value occupies a contiguous, fixed-size region of SLRU bytes.
- * (MultiXactMemberCtl separates flags from XIDs.  AsyncCtl has
+ * (MultiXactMemberCtl separates flags from XIDs.  NotifyCtl has
  * variable-length entries, no keys, and no random access.  These unit tests
  * do not apply to them.)
  */
index cadea21b3760f0594aac269ee9ed86a526cfb1aa..631f260f7918974dec61ca7dcfec46b1caaed804 100644 (file)
@@ -1476,7 +1476,7 @@ err:
 }
 
 /*
- * Helper function to ease writing of XLogRoutine->page_read callbacks.
+ * Helper function to ease writing of XLogReaderRoutine->page_read callbacks.
  * If this function is used, caller must supply a segment_open callback in
  * 'state', as that is used here.
  *
@@ -1513,7 +1513,7 @@ WALRead(XLogReaderState *state,
                /*
                 * If the data we want is not in a segment we have open, close what we
                 * have (if anything) and open the next one, using the caller's
-                * provided openSegment callback.
+                * provided segment_open callback.
                 */
                if (state->seg.ws_file < 0 ||
                        !XLByteInSeg(recptr, state->seg.ws_segno, state->segcxt.ws_segsize) ||
index 864e35e45b4cbd6bb6a54d2d78ed36d87a539fc7..5f7ee238863ea708851365043ec38a079dac151e 100644 (file)
@@ -819,7 +819,7 @@ AlterOpFamily(AlterOpFamilyStmt *stmt)
        Oid                     amoid,                  /* our AM's oid */
                                opfamilyoid;    /* oid of opfamily */
        int                     maxOpNumber,    /* amstrategies value */
-                               optsProcNumber, /* amopclassopts value */
+                               optsProcNumber, /* amoptsprocnum value */
                                maxProcNumber;  /* amsupport value */
        HeapTuple       tup;
        Form_pg_am      amform;
@@ -1321,7 +1321,7 @@ assignProcTypes(OpFamilyMember *member, Oid amoid, Oid typeoid,
                        /*
                         * pg_amproc functions are indexed by (lefttype, righttype), but
                         * an equalimage function can only be called at CREATE INDEX time.
-                        * The same opclass opcintype OID is always used for leftype and
+                        * The same opclass opcintype OID is always used for lefttype and
                         * righttype.  Providing a cross-type routine isn't sensible.
                         * Reject cross-type ALTER OPERATOR FAMILY ...  ADD FUNCTION 4
                         * statements here.
index 56eafbff10a89b215f30c0cb9531daaf532b8283..8b3de032eee50e9d44591c5e22ab18da4859da35 100644 (file)
@@ -974,8 +974,8 @@ AlterSubscription_refresh(Subscription *sub, bool copy_data,
                                 *
                                 * Even if new worker for this particular rel is restarted it
                                 * won't be able to make any progress as we hold exclusive
-                                * lock on subscription_rel till the transaction end. It will
-                                * simply exit as there is no corresponding rel entry.
+                                * lock on pg_subscription_rel till the transaction end. It
+                                * will simply exit as there is no corresponding rel entry.
                                 *
                                 * This locking also ensures that the state of rels won't
                                 * change till we are done with this refresh operation.
index 343fe6111513ee838e4002153ec615c832495b16..c7a8a689b7c851dbc3b5a0943a0f87dbf2709265 100644 (file)
@@ -2984,7 +2984,7 @@ MergeAttributes(List *schema, List *supers, char relpersistence,
                                 * generated column, we'll take its generation expression in
                                 * preference to the parent's.  We must check that the child
                                 * column doesn't specify a default value or identity, which
-                                * matches the rules for a single column in parse_util.c.
+                                * matches the rules for a single column in parse_utilcmd.c.
                                 *
                                 * Conversely, if the parent column is not generated, the
                                 * child column can't be either.  (We used to allow that, but
@@ -8017,7 +8017,7 @@ ATPrepDropExpression(Relation rel, AlterTableCmd *cmd, bool recurse, bool recurs
         * is a bit complicated.  GENERATED clauses must be attached to the column
         * definition and cannot be added later like DEFAULT, so if a child table
         * has a generation expression that the parent does not have, the child
-        * column will necessarily be an attlocal column.  So to implement ONLY
+        * column will necessarily be an attislocal column.  So to implement ONLY
         * here, we'd need extra code to update attislocal of the direct child
         * tables, somewhat similar to how DROP COLUMN does it, so that the
         * resulting state can be properly dumped and restored.
@@ -10930,7 +10930,7 @@ ATExecAlterConstraint(Relation rel, AlterTableCmd *cmd, bool recurse,
        }
 
        /*
-        * ATExecConstrRecurse already invalidated relcache for the relations
+        * ATExecAlterConstrRecurse already invalidated relcache for the relations
         * having the constraint itself; here we also invalidate for relations
         * that have any triggers that are part of the constraint.
         */
index cfadef09420bbad84b9c1c2ccd289417718134e1..a8a57b70633b4d51d6934a2f54ab973be46590b8 100644 (file)
@@ -3004,7 +3004,7 @@ hashagg_batch_new(LogicalTape *input_tape, int setno,
 }
 
 /*
- * read_spilled_tuple
+ * hashagg_batch_read
  *             read the next tuple from a batch's tape.  Return NULL if no more.
  */
 static MinimalTuple
index a1b33d6e6cf9fc651ee164561d32413a281d7b2c..2c3d64ea6e58f24188b31db4edb4652107493bf9 100644 (file)
@@ -2121,8 +2121,8 @@ llvm_compile_expr(ExprState *state)
 
                                        /*
                                         * pergroup = &aggstate->all_pergroups
-                                        * [op->d.agg_strict_trans_check.setoff]
-                                        * [op->d.agg_init_trans_check.transno];
+                                        * [op->d.agg_trans.setoff]
+                                        * [op->d.agg_trans.transno];
                                         */
                                        v_allpergroupsp =
                                                l_load_struct_gep(b, v_aggstatep,
index d168620665c50277e507a3dc0d54d930434fa721..a6090167f5acc73a487770e02d17e3805b4be9fc 100644 (file)
@@ -386,7 +386,7 @@ build_minmax_path(PlannerInfo *root, MinMaxAggInfo *mminfo,
        ntest = makeNode(NullTest);
        ntest->nulltesttype = IS_NOT_NULL;
        ntest->arg = copyObject(mminfo->target);
-       /* we checked it wasn't a rowtype in find_minmax_aggs_walker */
+       /* we checked it wasn't a rowtype in can_minmax_aggs */
        ntest->argisrow = false;
        ntest->location = -1;
 
index acf6cf4866915bcaf1967e3bc664423551e01926..a723d9db78f0dc1cdb1382673d4b4b1407435c4b 100644 (file)
@@ -957,7 +957,7 @@ stmtmulti:  stmtmulti ';' toplevel_stmt
 
 /*
  * toplevel_stmt includes BEGIN and END.  stmt does not include them, because
- * those words have different meanings in function bodys.
+ * those words have different meanings in function bodies.
  */
 toplevel_stmt:
                        stmt
index cf1156b8427f88af44ab2728a95c18b0d55cf661..c685621416e9694d2f57eb108c3b50b1a4342dfb 100644 (file)
@@ -2340,7 +2340,7 @@ merge_default_partitions(PartitionMap *outer_map,
                /*
                 * The default partitions have to be joined with each other, so merge
                 * them.  Note that each of the default partitions isn't merged yet
-                * (see, process_outer_partition()/process_innerer_partition()), so
+                * (see, process_outer_partition()/process_inner_partition()), so
                 * they should be merged successfully.  The merged partition will act
                 * as the default partition of the join relation.
                 */
index de06caccd2de4f140156a5d92b6762f8a640bf23..7a2b5e57ff428d0e3eb48bac37e05796c1895ceb 100644 (file)
@@ -55,7 +55,7 @@ static PartitionDesc RelationBuildPartitionDesc(Relation rel,
  * RelationGetPartitionDesc -- get partition descriptor, if relation is partitioned
  *
  * We keep two partdescs in relcache: rd_partdesc includes all partitions
- * (even those being concurrently marked detached), while rd_partdesc_nodetach
+ * (even those being concurrently marked detached), while rd_partdesc_nodetached
  * omits (some of) those.  We store the pg_inherits.xmin value for the latter,
  * to determine whether it can be validly reused in each case, since that
  * depends on the active snapshot.
index 9f4497447302d4f10663c2c056e69ae270a0b5a4..b85b890010e6c37536960ff21627501a0765def0 100644 (file)
@@ -1885,7 +1885,7 @@ ReorderBufferStreamCommit(ReorderBuffer *rb, ReorderBufferTXN *txn)
                /*
                 * This is a PREPARED transaction, part of a two-phase commit. The
                 * full cleanup will happen as part of the COMMIT PREPAREDs, so now
-                * just truncate txn by removing changes and tuple_cids.
+                * just truncate txn by removing changes and tuplecids.
                 */
                ReorderBufferTruncateTXN(rb, txn, true);
                /* Reset the CheckXidAlive */
@@ -4010,7 +4010,7 @@ ReorderBufferStreamTXN(ReorderBuffer *rb, ReorderBufferTXN *txn)
         * After that we need to reuse the snapshot from the previous run.
         *
         * Unlike DecodeCommit which adds xids of all the subtransactions in
-        * snapshot's xip array via SnapBuildCommittedTxn, we can't do that here
+        * snapshot's xip array via SnapBuildCommitTxn, we can't do that here
         * but we do add them to subxip array instead via ReorderBufferCopySnap.
         * This allows the catalog changes made in subtransactions decoded till
         * now to be visible.
index 889e20b5dd5ba26cd2f7a17a0fab1e4943da70f5..c263a596901894586f525aac528cba256e15db00 100644 (file)
@@ -804,7 +804,7 @@ standby_priority_comparator(const void *a, const void *b)
 
        /*
         * We might have equal priority values; arbitrarily break ties by position
-        * in the WALSnd array.  (This is utterly bogus, since that is arrival
+        * in the WalSnd array.  (This is utterly bogus, since that is arrival
         * order dependent, but there are regression tests that rely on it.)
         */
        return sa->walsnd_index - sb->walsnd_index;
index 277a28fc137c52028333cde631e138ff440aa1e9..4f86d44d6e387a49035dd2d05afa211749c89caf 100644 (file)
@@ -3069,7 +3069,7 @@ AtEOXact_Files(bool isCommit)
 /*
  * BeforeShmemExit_Files
  *
- * before_shmem_access hook to clean up temp files during backend shutdown.
+ * before_shmem_exit hook to clean up temp files during backend shutdown.
  * Here, we want to clean up *all* temp files including interXact ones.
  */
 static void
index f4123e7de7e28a05b92229869d5ab35129342c4e..cdb95c1931add95c9d9ce0d9da73c17727e0b711 100644 (file)
@@ -151,7 +151,7 @@ struct WaitEventSet
 #endif
 };
 
-/* A common WaitEventSet used to implement WatchLatch() */
+/* A common WaitEventSet used to implement WaitLatch() */
 static WaitEventSet *LatchWaitSet;
 
 /* The position of the latch in LatchWaitSet. */
index 80153fb25035957fe663fb21236931b5edaca180..8c8d728ba8554d1745690e90b7569d0e185b45cd 100644 (file)
@@ -1754,7 +1754,7 @@ ComputeXidHorizons(ComputeXidHorizonsResult *h)
                 * current top-level xid any.
                 *
                 * Without an assigned xid we could use a horizon as aggressive as
-                * ReadNewTransactionid(), but we can get away with the much cheaper
+                * GetNewTransactionId(), but we can get away with the much cheaper
                 * latestCompletedXid + 1: If this backend has no xid there, by
                 * definition, can't be any newer changes in the temp table than
                 * latestCompletedXid.
index e406bea201d054d0cc9ddb050d32d0b4d5b15d6b..6052779d9cc8b5ff8a932c9337ac41eb60f3b1b4 100644 (file)
@@ -37,7 +37,7 @@
 #define NUM_EMULATION_SEMAPHORES (NUM_SPINLOCK_SEMAPHORES + NUM_ATOMICS_SEMAPHORES)
 #else
 #define NUM_EMULATION_SEMAPHORES (NUM_SPINLOCK_SEMAPHORES)
-#endif                                                 /* DISABLE_ATOMICS */
+#endif                                                 /* HAVE_ATOMICS */
 
 PGSemaphore *SpinlockSemaArray;
 
index 391d5de0435abb2c40faeba64d8aa80d17b2f85e..a8f927f5407ddf346ba2b85411254b2560d21679 100644 (file)
@@ -283,7 +283,7 @@ pgstat_beinit(void)
  *
  *     Apart from auxiliary processes, MyBackendId, MyDatabaseId,
  *     session userid, and application_name must be set for a
- *     backend (hence, this cannot be combined with pgbestat_beinit).
+ *     backend (hence, this cannot be combined with pgstat_beinit).
  *     Note also that we must be inside a transaction if this isn't an aux
  *     process, as we may need to do encoding conversion on some strings.
  * ----------
index 94f1a3b06e32e70ba8fa9723f243422cdf194b25..bcaed14d02ebcfe06eb441120530e41c4e75dd3f 100644 (file)
@@ -24,7 +24,7 @@
 PgStat_PendingWalStats PendingWalStats = {0};
 
 /*
- * WAL usage counters saved from pgWALUsage at the previous call to
+ * WAL usage counters saved from pgWalUsage at the previous call to
  * pgstat_report_wal(). This is used to calculate how much WAL usage
  * happens between pgstat_report_wal() calls, by subtracting
  * the previous counters from the current ones.
index 729ebd86d1462b4e99a5911b34435a70c9eb31e7..c660fd3e7018e66c9dec7f546e97d93151885959 100644 (file)
@@ -4717,8 +4717,8 @@ pg_has_role_id_id(PG_FUNCTION_ARGS)
  *             Convert text string to AclMode value.
  *
  * We use USAGE to denote whether the privileges of the role are accessible
- * (has_privs), MEMBER to denote is_member, and MEMBER WITH GRANT OPTION
- * (or ADMIN OPTION) to denote is_admin.  There is no ACL bit corresponding
+ * (has_privs_of_role), MEMBER to denote is_member, and MEMBER WITH GRANT
+ * (or ADMIN) OPTION to denote is_admin.  There is no ACL bit corresponding
  * to MEMBER so we cheat and use ACL_CREATE for that.  This convention
  * is shared only with pg_role_aclcheck, below.
  */
index 51df570ce99612d580d8cc460e98836d22fc189a..f0b6567da127e0686171e0b99f0801df03da672d 100644 (file)
@@ -1012,7 +1012,7 @@ search_locale_enum(LPWSTR pStr, DWORD dwFlags, LPARAM lparam)
        {
                /*
                 * If the enumerated locale does not have a hyphen ("en") OR the
-                * lc_message input does not have an underscore ("English"), we only
+                * locale_name input does not have an underscore ("English"), we only
                 * need to compare the <Language> tags.
                 */
                if (wcsrchr(pStr, '-') == NULL || wcsrchr(argv[0], '_') == NULL)
index fe37e65af03ad682cd1988a37a6ef5226a59610d..c4fcd0076eac0507d5c5d16aa8823e6cc2aa6edb 100644 (file)
@@ -4210,7 +4210,7 @@ estimate_multivariate_ndistinct(PlannerInfo *root, RelOptInfo *rel,
                         * Process complex expressions, not just simple Vars.
                         *
                         * First, we search for an exact match of an expression. If we
-                        * find one, we can just discard the whole GroupExprInfo, with all
+                        * find one, we can just discard the whole GroupVarInfo, with all
                         * the variables we extracted from it.
                         *
                         * Otherwise we inspect the individual vars, and try matching it
index 033647011bbe2a4a05ef40e782226dfdee0d41fa..67a1ab2ab23b7aefe2725e24c5f93db6411ee122 100644 (file)
@@ -453,7 +453,7 @@ pg_do_encoding_conversion(unsigned char *src, int len,
  *
  * The output is null-terminated.
  *
- * If destlen < srclen * MAX_CONVERSION_LENGTH + 1, the converted output
+ * If destlen < srclen * MAX_CONVERSION_INPUT_LENGTH + 1, the converted output
  * wouldn't necessarily fit in the output buffer, and the function will not
  * convert the whole input.
  *
index 69ad0e495ffd18de7000e6b4102d27b432719a49..98af3b58ee3877aed4066ffff201e94596c156fc 100644 (file)
@@ -83,4 +83,4 @@ extern rewind_source *init_libpq_source(PGconn *conn);
 /* in local_source.c */
 extern rewind_source *init_local_source(const char *datadir);
 
-#endif                                                 /* FETCH_H */
+#endif                                                 /* REWIND_SOURCE_H */
index bb6d4f03151de2957b4fe7e6f8be320bcef72cc5..b19d50ecc2ee686bb4314b3e5f987c38e1f11fac 100644 (file)
@@ -358,7 +358,7 @@ typedef struct TableAmRoutine
         * allowed by the AM.
         *
         * Implementations can assume that scan_set_tidrange is always called
-        * before can_getnextslot_tidrange or after scan_rescan and before any
+        * before scan_getnextslot_tidrange or after scan_rescan and before any
         * further calls to scan_getnextslot_tidrange.
         */
        void            (*scan_set_tidrange) (TableScanDesc scan,
index 96d8e5a685c8cc965c8a7437b78a469f240dd8ce..e971bd2c8ef64f48e34731a85c06a27fbb8d1e05 100644 (file)
@@ -43,7 +43,7 @@ typedef struct
        /*
         * Before calling toast_tuple_init, the caller must initialize the
         * following fields.  Each array must have a length equal to
-        * ttc_rel->rd_att->natts.  The tts_oldvalues and tts_oldisnull fields
+        * ttc_rel->rd_att->natts.  The ttc_oldvalues and ttc_oldisnull fields
         * should be NULL in the case of an insert.
         */
        Relation        ttc_rel;                /* the relation that contains the tuple */
@@ -53,9 +53,9 @@ typedef struct
        bool       *ttc_oldisnull;      /* null flags from previous tuple */
 
        /*
-        * Before calling toast_tuple_init, the caller should set tts_attr to
+        * Before calling toast_tuple_init, the caller should set ttc_attr to
         * point to an array of ToastAttrInfo structures of a length equal to
-        * tts_rel->rd_att->natts.  The contents of the array need not be
+        * ttc_rel->rd_att->natts.  The contents of the array need not be
         * initialized.  ttc_flags also does not need to be initialized.
         */
        uint8           ttc_flags;
index e63b399b8d9f5abc7fc08d0a64539a83a14bf527..20921b45b9e1087124743fbb5b48946ba9f70864 100644 (file)
@@ -29,7 +29,7 @@ struct PlanState;                             /* avoid including execnodes.h too */
 #define QTW_EXAMINE_RTES_AFTER         0x20    /* examine RTE nodes after their
                                                                                         * contents */
 #define QTW_DONT_COPY_QUERY                    0x40    /* do not copy top Query */
-#define QTW_EXAMINE_SORTGROUP          0x80    /* include SortGroupNode lists */
+#define QTW_EXAMINE_SORTGROUP          0x80    /* include SortGroupClause lists */
 
 /* callback function for check_functions_in_node */
 typedef bool (*check_function_callback) (Oid func_id, void *context);
index 204b8f74fd5eedde3491dc9e90695b7285c5de01..3499bfd4a098c31efcd7d5cbb19c5a6969400dd1 100644 (file)
@@ -11,8 +11,8 @@
  *
  *-------------------------------------------------------------------------
  */
-#ifndef QUERYJUBLE_H
-#define QUERYJUBLE_H
+#ifndef QUERYJUMBLE_H
+#define QUERYJUMBLE_H
 
 #include "nodes/parsenodes.h"
 
index 33ec6102c15b36db064be53f166308d705ad5cce..a1a93ad706e8cd250644971b1bf5464bafa7ef8a 100644 (file)
 
 /*
  * Recover memory used for relcache entries when invalidated.  See
- * RelationBuildDescr() in src/backend/utils/cache/relcache.c.
+ * RelationBuildDesc() in src/backend/utils/cache/relcache.c.
  *
  * This is active automatically for clobber-cache builds when clobbering is
  * active, but can be overridden here by explicitly defining
index 8ab6a8841654e12b0961a50cdda8fe18b6c51224..698124e8871327aefaac70410343d2e9428c1f11 100644 (file)
@@ -1500,7 +1500,7 @@ getNotify(PGconn *conn)
        }
 
        /*
-        * Store the strings right after the PQnotify structure so it can all be
+        * Store the strings right after the PGnotify structure so it can all be
         * freed at once.  We don't use NAMEDATALEN because we don't want to tie
         * this interface to a specific server name length.
         */
index ce0167c1b664d175bacc042f2c77f22ae4b3626a..3c9f589278eeeaafa322b47e5f701b0759c3436d 100644 (file)
@@ -872,7 +872,7 @@ extern ssize_t pg_GSS_write(PGconn *conn, const void *ptr, size_t len);
 extern ssize_t pg_GSS_read(PGconn *conn, void *ptr, size_t len);
 #endif
 
-/* === in libpq-trace.c === */
+/* === in fe-trace.c === */
 
 extern void pqTraceOutputMessage(PGconn *conn, const char *message,
                                                                 bool toServer);
index 02b89ac5f76d75f1961e5ad6f8e3793ed5cc96c8..863864253f901667b17edd0dd2a4538a6e6bdb8d 100644 (file)
@@ -2125,7 +2125,7 @@ plperl_create_sub(plperl_proc_desc *prodesc, const char *s, Oid fn_oid)
        /*
         * G_KEEPERR seems to be needed here, else we don't recognize compile
         * errors properly.  Perhaps it's because there's another level of eval
-        * inside mksafefunc?
+        * inside mkfunc?
         */
        count = call_pv("PostgreSQL::InServer::mkfunc",
                                        G_SCALAR | G_EVAL | G_KEEPERR);
index 6f5a33623fc8d7425a689cb94c361cb79a469faa..e55098ef7feb990b8cabad2d583d7f6658b7e61c 100644 (file)
@@ -1,7 +1,7 @@
 
 # Copyright (c) 2021-2023, PostgreSQL Global Development Group
 
-# Test for point-in-time-recovery (PITR) with prepared transactions
+# Test for point-in-time recovery (PITR) with prepared transactions
 use strict;
 use warnings;
 use PostgreSQL::Test::Cluster;
index 87381c08299ff31dd0b96bc62876167601610280..aa7714c533b0cc2c6486e62d5973dae788f5bef8 100644 (file)
@@ -149,7 +149,7 @@ $node_publisher->safe_psql('postgres', "DROP TABLE tab_rep_next");
 $node_subscriber->safe_psql('postgres', "DROP TABLE tab_rep_next");
 $node_subscriber->safe_psql('postgres', "DROP SUBSCRIPTION tap_sub");
 
-# Table tap_rep already has the same records on both publisher and subscriber
+# Table tab_rep already has the same records on both publisher and subscriber
 # at this time. Recreate the subscription which will do the initial copy of
 # the table again and fails due to unique constraint violation.
 $node_subscriber->safe_psql('postgres',