Spelling adjustments
authorPeter Eisentraut <peter@eisentraut.org>
Sun, 7 Jun 2020 13:06:51 +0000 (15:06 +0200)
committerPeter Eisentraut <peter@eisentraut.org>
Sun, 7 Jun 2020 13:06:51 +0000 (15:06 +0200)
26 files changed:
doc/src/sgml/config.sgml
src/backend/commands/async.c
src/backend/commands/vacuum.c
src/backend/jit/llvm/llvmjit_expr.c
src/backend/port/win32/socket.c
src/backend/port/win32/timer.c
src/backend/postmaster/autovacuum.c
src/backend/postmaster/checkpointer.c
src/backend/postmaster/pgstat.c
src/backend/postmaster/postmaster.c
src/backend/replication/logical/origin.c
src/backend/replication/logical/reorderbuffer.c
src/backend/storage/ipc/latch.c
src/backend/storage/ipc/procsignal.c
src/backend/storage/ipc/shm_mq.c
src/backend/storage/ipc/signalfuncs.c
src/backend/storage/ipc/standby.c
src/backend/storage/lmgr/lock.c
src/backend/tcop/postgres.c
src/backend/utils/cache/relfilenodemap.c
src/include/access/tableam.h
src/include/access/xact.h
src/include/replication/slot.h
src/include/storage/condition_variable.h
src/include/storage/procsignal.h
src/test/modules/test_shm_mq/setup.c

index 31b466016097408b60f54878c3b4f189eb7a5b40..aca8f73a50db78bbafe0932ccfdbe6b491a4020a 100644 (file)
@@ -4083,7 +4083,7 @@ ANY <replaceable class="parameter">num_sync</replaceable> ( <replaceable class="
           This parameter can only be set in the <filename>postgresql.conf</filename>
           file or on the server command line.
           If this parameter is changed while the WAL receiver process is
-          running, that process is signalled to shut down and expected to
+          running, that process is signaled to shut down and expected to
           restart with the new setting (except if <varname>primary_conninfo</varname>
           is an empty string).
           This setting has no effect if the server is not in standby mode.
@@ -4105,7 +4105,7 @@ ANY <replaceable class="parameter">num_sync</replaceable> ( <replaceable class="
           This parameter can only be set in the <filename>postgresql.conf</filename>
           file or on the server command line.
           If this parameter is changed while the WAL receiver process is running,
-          that process is signalled to shut down and expected to restart with the
+          that process is signaled to shut down and expected to restart with the
           new setting.
           This setting has no effect if <varname>primary_conninfo</varname> is not
           set or the server is not in standby mode.
@@ -4227,7 +4227,7 @@ ANY <replaceable class="parameter">num_sync</replaceable> ( <replaceable class="
         The default is off.  This parameter can only be set in the
         <filename>postgresql.conf</filename> file or on the server command line.
         If this parameter is changed while the WAL receiver process is running,
-        that process is signalled to shut down and expected to restart with
+        that process is signaled to shut down and expected to restart with
         the new setting.
        </para>
       </listitem>
@@ -8062,7 +8062,7 @@ COPY postgres_log FROM '/full/path/to/logfile.csv' WITH csv;
         treated the timeout as applying to the whole query string.)
         In extended query protocol, the timeout starts running when any
         query-related message (Parse, Bind, Execute, Describe) arrives, and
-        it is cancelled by completion of an Execute or Sync message.
+        it is canceled by completion of an Execute or Sync message.
        </para>
 
        <para>
index a3ba88d7ff4c4a2e27dbeace4e3604b59f607197..71b7577afc067ff7814bd199f023f231e299b9a6 100644 (file)
@@ -1654,7 +1654,7 @@ asyncQueueFillWarning(void)
  * behind.  Waken them anyway if they're far enough behind, so that they'll
  * advance their queue position pointers, allowing the global tail to advance.
  *
- * Since we know the BackendId and the Pid the signalling is quite cheap.
+ * Since we know the BackendId and the Pid the signaling is quite cheap.
  */
 static void
 SignalBackends(void)
index 5a110edb072ca2df40e866c0ce8e2ac9ec5801bf..d32de23e6268f2c087329099cdca2a5c8914ce5c 100644 (file)
@@ -1638,7 +1638,7 @@ vac_truncate_clog(TransactionId frozenXID,
     * Update the wrap limit for GetNewTransactionId and creation of new
     * MultiXactIds.  Note: these functions will also signal the postmaster
     * for an(other) autovac cycle if needed.   XXX should we avoid possibly
-    * signalling twice?
+    * signaling twice?
     */
    SetTransactionIdLimit(frozenXID, oldestxid_datoid);
    SetMultiXactIdLimit(minMulti, minmulti_datoid, false);
index 0bc7a06aee354917e249577ca5c4466bd4489308..4d8836cfb3fdb5b462f038eeffb2babff623d33e 100644 (file)
@@ -2448,7 +2448,7 @@ BuildV1Call(LLVMJitContext *context, LLVMBuilderRef b,
        *v_fcinfo_isnull = LLVMBuildLoad(b, v_fcinfo_isnullp, "");
 
    /*
-    * Add lifetime-end annotation, signalling that writes to memory don't
+    * Add lifetime-end annotation, signaling that writes to memory don't
     * have to be retained (important for inlining potential).
     */
    {
index 4843507880cec1b9a443876b02db77ac86784f71..6fbd1ed6fb49f5ecc6f98c0aca9c98f248007783 100644 (file)
@@ -618,7 +618,7 @@ pgwin32_select(int nfds, fd_set *readfds, fd_set *writefds, fd_set *exceptfds, c
    if (r != WAIT_TIMEOUT && r != WAIT_IO_COMPLETION && r != (WAIT_OBJECT_0 + numevents))
    {
        /*
-        * We scan all events, even those not signalled, in case more than one
+        * We scan all events, even those not signaled, in case more than one
         * event has been tagged but Wait.. can only return one.
         */
        WSANETWORKEVENTS resEvents;
index 891241863b4f55c0e18f7628cf6923ac0026f272..bb98178fe1d0591579bbb087e0bbeb52b161a88f 100644 (file)
@@ -48,7 +48,7 @@ pg_timer_thread(LPVOID param)
        r = WaitForSingleObjectEx(timerCommArea.event, waittime, FALSE);
        if (r == WAIT_OBJECT_0)
        {
-           /* Event signalled from main thread, change the timer */
+           /* Event signaled from main thread, change the timer */
            EnterCriticalSection(&timerCommArea.crit_sec);
            if (timerCommArea.value.it_value.tv_sec == 0 &&
                timerCommArea.value.it_value.tv_usec == 0)
index a8d4dfdd7cc00050261bae9400546f66ae632f5e..38dc97de11f9be933a280b855b59988857112f56 100644 (file)
@@ -653,7 +653,7 @@ AutoVacLauncherMain(int argc, char *argv[])
        HandleAutoVacLauncherInterrupts();
 
        /*
-        * a worker finished, or postmaster signalled failure to start a
+        * a worker finished, or postmaster signaled failure to start a
         * worker
         */
        if (got_SIGUSR2)
index 34ed9f7887815496e6e8ccf655a5e536eec3acc0..624a3238b804cd64aab3f8b2d1da6440b88daf2a 100644 (file)
@@ -819,7 +819,7 @@ ReqCheckpointHandler(SIGNAL_ARGS)
    int         save_errno = errno;
 
    /*
-    * The signalling process should have set ckpt_flags nonzero, so all we
+    * The signaling process should have set ckpt_flags nonzero, so all we
     * need do is ensure that our main loop gets kicked out of any wait.
     */
    SetLatch(MyLatch);
index d7f99d9944c20d3e4011223b2c0a25f52d3ea169..309378ae54e4e033b33f762b9b8f8fea349ad1c3 100644 (file)
@@ -6251,7 +6251,7 @@ pgstat_recv_resetslrucounter(PgStat_MsgResetslrucounter *msg, int len)
 /* ----------
  * pgstat_recv_autovac() -
  *
- * Process an autovacuum signalling message.
+ * Process an autovacuum signaling message.
  * ----------
  */
 static void
index 160afe9f39291ad924b0001646a2f71e9012dd8f..b4d475bb0ba2e051ed6c797612ad85eb3bc15e1d 100644 (file)
@@ -357,7 +357,7 @@ bool        redirection_done = false;   /* stderr redirected for syslogger? */
 /* received START_AUTOVAC_LAUNCHER signal */
 static volatile sig_atomic_t start_autovac_launcher = false;
 
-/* the launcher needs to be signalled to communicate some condition */
+/* the launcher needs to be signaled to communicate some condition */
 static volatile bool avlauncher_needs_signal = false;
 
 /* received START_WALRECEIVER signal */
@@ -3481,7 +3481,7 @@ HandleChildCrash(int pid, int exitstatus, const char *procname)
     * We only log messages and send signals if this is the first process
     * crash and we're not doing an immediate shutdown; otherwise, we're only
     * here to update postmaster's idea of live processes.  If we have already
-    * signalled children, nonzero exit status is to be expected, so don't
+    * signaled children, nonzero exit status is to be expected, so don't
     * clutter log.
     */
    take_action = !FatalError && Shutdown != ImmediateShutdown;
@@ -5615,7 +5615,7 @@ StartAutovacuumWorker(void)
     * might not even be connected to shared memory, so don't try to call
     * AutoVacWorkerFailed.)  Note that we also need to signal it so that it
     * responds to the condition, but we don't do that here, instead waiting
-    * for ServerLoop to do it.  This way we avoid a ping-pong signalling in
+    * for ServerLoop to do it.  This way we avoid a ping-pong signaling in
     * quick succession between the autovac launcher and postmaster in case
     * things get ugly.
     */
index 981d60f135d39e846659dd7b72dcc10604348352..1ca4479605c53309c5179b5e378ff10c3a2a2362 100644 (file)
@@ -122,7 +122,7 @@ typedef struct ReplicationState
    int         acquired_by;
 
    /*
-    * Condition variable that's signalled when acquired_by changes.
+    * Condition variable that's signaled when acquired_by changes.
     */
    ConditionVariable origin_cv;
 
index 4594cf9509783fdc9a32cd7b6c20dbe74f0c43db..84fcd29ac9d23c1b86e2bdc870ad3a0439b458e0 100644 (file)
@@ -14,7 +14,7 @@
  *   This module gets handed individual pieces of transactions in the order
  *   they are written to the WAL and is responsible to reassemble them into
  *   toplevel transaction sized pieces. When a transaction is completely
- *   reassembled - signalled by reading the transaction commit record - it
+ *   reassembled - signaled by reading the transaction commit record - it
  *   will then call the output plugin (cf. ReorderBufferCommit()) with the
  *   individual changes. The output plugins rely on snapshots built by
  *   snapbuild.c which hands them to us.
index 05df5017c41e74c997a3df60c52f446a78c21214..91fa4b619b8c5c96cb99e7d3407d98686dd44ca1 100644 (file)
@@ -1354,7 +1354,7 @@ WaitEventSetWaitBlock(WaitEventSet *set, int cur_timeout,
             * because we don't expect the pipe to become readable or to have
             * any errors either, treat those cases as postmaster death, too.
             *
-            * Be paranoid about a spurious event signalling the postmaster as
+            * Be paranoid about a spurious event signaling the postmaster as
             * being dead.  There have been reports about that happening with
             * older primitives (select(2) to be specific), and a spurious
             * WL_POSTMASTER_DEATH event would be painful. Re-checking doesn't
@@ -1613,7 +1613,7 @@ WaitEventSetWaitBlock(WaitEventSet *set, int cur_timeout,
             * we don't expect the pipe to become readable or to have any
             * errors either, treat those cases as postmaster death, too.
             *
-            * Be paranoid about a spurious event signalling the postmaster as
+            * Be paranoid about a spurious event signaling the postmaster as
             * being dead.  There have been reports about that happening with
             * older primitives (select(2) to be specific), and a spurious
             * WL_POSTMASTER_DEATH event would be painful. Re-checking doesn't
index 7b0c6ffce7a7c3ce3283b46df74e2ef3a40250ba..c809196d06a41094d111753cf0005185cea81594 100644 (file)
@@ -1,7 +1,7 @@
 /*-------------------------------------------------------------------------
  *
  * procsignal.c
- *   Routines for interprocess signalling
+ *   Routines for interprocess signaling
  *
  *
  * Portions Copyright (c) 1996-2020, PostgreSQL Global Development Group
@@ -30,7 +30,7 @@
 #include "tcop/tcopprot.h"
 
 /*
- * The SIGUSR1 signal is multiplexed to support signalling multiple event
+ * The SIGUSR1 signal is multiplexed to support signaling multiple event
  * types. The specific reason is communicated via flags in shared memory.
  * We keep a boolean flag for each possible "reason", so that different
  * reasons can be signaled to a process concurrently.  (However, if the same
@@ -40,8 +40,8 @@
  * Each process that wants to receive signals registers its process ID
  * in the ProcSignalSlots array. The array is indexed by backend ID to make
  * slot allocation simple, and to avoid having to search the array when you
- * know the backend ID of the process you're signalling.  (We do support
- * signalling without backend ID, but it's a bit less efficient.)
+ * know the backend ID of the process you're signaling.  (We do support
+ * signaling without backend ID, but it's a bit less efficient.)
  *
  * The flags are actually declared as "volatile sig_atomic_t" for maximum
  * portability.  This should ensure that loads and stores of the flag
@@ -420,7 +420,7 @@ WaitForProcSignalBarrier(uint64 generation)
 /*
  * Perform global barrier related interrupt checking.
  *
- * Any backend that participates in ProcSignal signalling must arrange to
+ * Any backend that participates in ProcSignal signaling must arrange to
  * call this function periodically. It is called from CHECK_FOR_INTERRUPTS(),
  * which is enough for normal backends, but not necessarily for all types of
  * background processes.
index 1c4e720d107f80ade5abf74b80a45058e9e539fb..6f40fb165d2859f2551068447ede96c412450590 100644 (file)
@@ -1182,7 +1182,7 @@ shm_mq_wait_internal(shm_mq *mq, PGPROC **ptr, BackgroundWorkerHandle *handle)
            }
        }
 
-       /* Wait to be signalled. */
+       /* Wait to be signaled. */
        (void) WaitLatch(MyLatch, WL_LATCH_SET | WL_EXIT_ON_PM_DEATH, 0,
                         WAIT_EVENT_MQ_INTERNAL);
 
index 9dd5a27204568209cd6ee42f3cd60e4e67696232..d822e82cb98d18f933781d2b2ef6215a4a731e33 100644 (file)
@@ -1,7 +1,7 @@
 /*-------------------------------------------------------------------------
  *
  * signalfuncs.c
- *   Functions for signalling backends
+ *   Functions for signaling backends
  *
  * Portions Copyright (c) 1996-2020, PostgreSQL Global Development Group
  * Portions Copyright (c) 1994, Regents of the University of California
index bdaf10a4b1f76cffe184ba66a2b334457b4aabb3..9e0d5ec257ff89fd92b3f2538a57932838fd46c1 100644 (file)
@@ -92,7 +92,7 @@ InitRecoveryTransactionEnvironment(void)
    /*
     * Initialize shared invalidation management for Startup process, being
     * careful to register ourselves as a sendOnly process so we don't need to
-    * read messages, nor will we get signalled when the queue starts filling
+    * read messages, nor will we get signaled when the queue starts filling
     * up.
     */
    SharedInvalBackendInit(true);
index e1e623db15377f58cf4f87080a20fde40e3536c4..7fecb381625236c47abf136ebe5870df02a21ffb 100644 (file)
@@ -759,7 +759,7 @@ LockAcquire(const LOCKTAG *locktag,
  * reportMemoryError specifies whether a lock request that fills the lock
  * table should generate an ERROR or not.  Passing "false" allows the caller
  * to attempt to recover from lock-table-full situations, perhaps by forcibly
- * cancelling other lock holders and then retrying.  Note, however, that the
+ * canceling other lock holders and then retrying.  Note, however, that the
  * return code for that is LOCKACQUIRE_NOT_AVAIL, so that it's unsafe to use
  * in combination with dontWait = true, as the cause of failure couldn't be
  * distinguished.
index 8958ec8103ef2bc91331200e42b87c0dfe4837e0..c9424f167c8d9c40b244d695020a0716e4a08c2f 100644 (file)
@@ -2750,7 +2750,7 @@ drop_unnamed_stmt(void)
  */
 
 /*
- * quickdie() occurs when signalled SIGQUIT by the postmaster.
+ * quickdie() occurs when signaled SIGQUIT by the postmaster.
  *
  * Some backend has bought the farm,
  * so we need to stop what we're doing and exit.
index 3fc3e34c05004cf03796c96cea0bdecd6a073f61..68b01ca68fe76cc95511cd94a0cc430365cee298 100644 (file)
@@ -64,7 +64,7 @@ RelfilenodeMapInvalidateCallback(Datum arg, Oid relid)
    while ((entry = (RelfilenodeMapEntry *) hash_seq_search(&status)) != NULL)
    {
        /*
-        * If relid is InvalidOid, signalling a complete reset, we must remove
+        * If relid is InvalidOid, signaling a complete reset, we must remove
         * all entries, otherwise just remove the specific relation's entry.
         * Always remove negative cache entries.
         */
index 8c34935c343432b03b4f799ca42def861ef25e0a..30a21c9bc51518b68bad61884eb87e0e6dd0d52c 100644 (file)
@@ -290,7 +290,7 @@ typedef struct TableAmRoutine
     *
     * *call_again is false on the first call to index_fetch_tuple for a tid.
     * If there potentially is another tuple matching the tid, *call_again
-    * needs be set to true by index_fetch_tuple, signalling to the caller
+    * needs be set to true by index_fetch_tuple, signaling to the caller
     * that index_fetch_tuple should be called again for the same tid.
     *
     * *all_dead, if all_dead is not NULL, should be set to true by
@@ -993,7 +993,7 @@ table_index_fetch_end(struct IndexFetchTableData *scan)
  *
  * *call_again needs to be false on the first call to table_index_fetch_tuple() for
  * a tid. If there potentially is another tuple matching the tid, *call_again
- * will be set to true, signalling that table_index_fetch_tuple() should be called
+ * will be set to true, signaling that table_index_fetch_tuple() should be called
  * again for the same tid.
  *
  * *all_dead, if all_dead is not NULL, will be set to true by
@@ -1546,7 +1546,7 @@ table_index_build_scan(Relation table_rel,
 /*
  * As table_index_build_scan(), except that instead of scanning the complete
  * table, only the given number of blocks are scanned.  Scan to end-of-rel can
- * be signalled by passing InvalidBlockNumber as numblocks.  Note that
+ * be signaled by passing InvalidBlockNumber as numblocks.  Note that
  * restricting the range to scan cannot be done when requesting syncscan.
  *
  * When "anyvisible" mode is requested, all tuples visible to any transaction
index 7ee04babc2fbc7e740b10bbbb344074976a1435a..88025b1cc2f9cbbb0adcdc72d5be924a767ed032 100644 (file)
@@ -204,7 +204,7 @@ typedef struct xl_xact_assignment
  *
  * A minimal commit/abort record only consists of a xl_xact_commit/abort
  * struct. The presence of additional information is indicated by bits set in
- * 'xl_xact_xinfo->xinfo'. The presence of the xinfo field itself is signalled
+ * 'xl_xact_xinfo->xinfo'. The presence of the xinfo field itself is signaled
  * by a set XLOG_XACT_HAS_INFO bit in the xl_info field.
  *
  * NB: All the individual data chunks should be sized to multiples of
index e7649d4723e700f08c21e3d1cf1b10ce41f37290..917876010eb8e6301d02fd9fb47a455a012e284e 100644 (file)
@@ -142,7 +142,7 @@ typedef struct ReplicationSlot
    /* is somebody performing io on this slot? */
    LWLock      io_in_progress_lock;
 
-   /* Condition variable signalled when active_pid changes */
+   /* Condition variable signaled when active_pid changes */
    ConditionVariable active_cv;
 
    /* all the remaining data is only used for logical slots */
index bfe5c89b5446ceee63b3d06657be218b567dcf50..c2be198f28e6e20a9f585dcaf8bdbcbc86719d87 100644 (file)
@@ -9,7 +9,7 @@
  * on the condition variable; and (3) broadcast, which wakes up every
  * process sleeping on the condition variable.  In our implementation,
  * condition variables put a process into an interruptible sleep (so it
- * can be cancelled prior to the fulfillment of the condition) and do not
+ * can be canceled prior to the fulfillment of the condition) and do not
  * use pointers internally (so that they are safe to use within DSMs).
  *
  * Portions Copyright (c) 1996-2020, PostgreSQL Global Development Group
index 90607df1060b9e95d07f16c7af332469675fd9c1..a0c0bc3ce55348eb07bf485bfcc38d8711d35c4c 100644 (file)
@@ -1,7 +1,7 @@
 /*-------------------------------------------------------------------------
  *
  * procsignal.h
- *   Routines for interprocess signalling
+ *   Routines for interprocess signaling
  *
  *
  * Portions Copyright (c) 1996-2020, PostgreSQL Global Development Group
@@ -18,7 +18,7 @@
 
 
 /*
- * Reasons for signalling a Postgres child process (a backend or an auxiliary
+ * Reasons for signaling a Postgres child process (a backend or an auxiliary
  * process, like checkpointer).  We can cope with concurrent signals for different
  * reasons.  However, if the same reason is signaled multiple times in quick
  * succession, the process is likely to observe only one notification of it.
index d4808d8361e58e75d68c3acf535575e5005d1a06..509a90fa91c4c26ac1cbecfbd797c5a07adaddc1 100644 (file)
@@ -278,7 +278,7 @@ wait_for_workers_to_become_ready(worker_state *wstate,
            break;
        }
 
-       /* Wait to be signalled. */
+       /* Wait to be signaled. */
        (void) WaitLatch(MyLatch, WL_LATCH_SET | WL_EXIT_ON_PM_DEATH, 0,
                         PG_WAIT_EXTENSION);