Skip to content

Commit 0fd2a79

Browse files
committed
Spelling adjustments
1 parent a02b8bd commit 0fd2a79

File tree

26 files changed

+39
-39
lines changed

26 files changed

+39
-39
lines changed

Diff for: doc/src/sgml/config.sgml

+4-4
Original file line numberDiff line numberDiff line change
@@ -4083,7 +4083,7 @@ ANY <replaceable class="parameter">num_sync</replaceable> ( <replaceable class="
40834083
This parameter can only be set in the <filename>postgresql.conf</filename>
40844084
file or on the server command line.
40854085
If this parameter is changed while the WAL receiver process is
4086-
running, that process is signalled to shut down and expected to
4086+
running, that process is signaled to shut down and expected to
40874087
restart with the new setting (except if <varname>primary_conninfo</varname>
40884088
is an empty string).
40894089
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="
41054105
This parameter can only be set in the <filename>postgresql.conf</filename>
41064106
file or on the server command line.
41074107
If this parameter is changed while the WAL receiver process is running,
4108-
that process is signalled to shut down and expected to restart with the
4108+
that process is signaled to shut down and expected to restart with the
41094109
new setting.
41104110
This setting has no effect if <varname>primary_conninfo</varname> is not
41114111
set or the server is not in standby mode.
@@ -4227,7 +4227,7 @@ ANY <replaceable class="parameter">num_sync</replaceable> ( <replaceable class="
42274227
The default is off. This parameter can only be set in the
42284228
<filename>postgresql.conf</filename> file or on the server command line.
42294229
If this parameter is changed while the WAL receiver process is running,
4230-
that process is signalled to shut down and expected to restart with
4230+
that process is signaled to shut down and expected to restart with
42314231
the new setting.
42324232
</para>
42334233
</listitem>
@@ -8062,7 +8062,7 @@ COPY postgres_log FROM '/full/path/to/logfile.csv' WITH csv;
80628062
treated the timeout as applying to the whole query string.)
80638063
In extended query protocol, the timeout starts running when any
80648064
query-related message (Parse, Bind, Execute, Describe) arrives, and
8065-
it is cancelled by completion of an Execute or Sync message.
8065+
it is canceled by completion of an Execute or Sync message.
80668066
</para>
80678067

80688068
<para>

Diff for: src/backend/commands/async.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -1654,7 +1654,7 @@ asyncQueueFillWarning(void)
16541654
* behind. Waken them anyway if they're far enough behind, so that they'll
16551655
* advance their queue position pointers, allowing the global tail to advance.
16561656
*
1657-
* Since we know the BackendId and the Pid the signalling is quite cheap.
1657+
* Since we know the BackendId and the Pid the signaling is quite cheap.
16581658
*/
16591659
static void
16601660
SignalBackends(void)

Diff for: src/backend/commands/vacuum.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -1638,7 +1638,7 @@ vac_truncate_clog(TransactionId frozenXID,
16381638
* Update the wrap limit for GetNewTransactionId and creation of new
16391639
* MultiXactIds. Note: these functions will also signal the postmaster
16401640
* for an(other) autovac cycle if needed. XXX should we avoid possibly
1641-
* signalling twice?
1641+
* signaling twice?
16421642
*/
16431643
SetTransactionIdLimit(frozenXID, oldestxid_datoid);
16441644
SetMultiXactIdLimit(minMulti, minmulti_datoid, false);

Diff for: src/backend/jit/llvm/llvmjit_expr.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -2448,7 +2448,7 @@ BuildV1Call(LLVMJitContext *context, LLVMBuilderRef b,
24482448
*v_fcinfo_isnull = LLVMBuildLoad(b, v_fcinfo_isnullp, "");
24492449

24502450
/*
2451-
* Add lifetime-end annotation, signalling that writes to memory don't
2451+
* Add lifetime-end annotation, signaling that writes to memory don't
24522452
* have to be retained (important for inlining potential).
24532453
*/
24542454
{

Diff for: src/backend/port/win32/socket.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -618,7 +618,7 @@ pgwin32_select(int nfds, fd_set *readfds, fd_set *writefds, fd_set *exceptfds, c
618618
if (r != WAIT_TIMEOUT && r != WAIT_IO_COMPLETION && r != (WAIT_OBJECT_0 + numevents))
619619
{
620620
/*
621-
* We scan all events, even those not signalled, in case more than one
621+
* We scan all events, even those not signaled, in case more than one
622622
* event has been tagged but Wait.. can only return one.
623623
*/
624624
WSANETWORKEVENTS resEvents;

Diff for: src/backend/port/win32/timer.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -48,7 +48,7 @@ pg_timer_thread(LPVOID param)
4848
r = WaitForSingleObjectEx(timerCommArea.event, waittime, FALSE);
4949
if (r == WAIT_OBJECT_0)
5050
{
51-
/* Event signalled from main thread, change the timer */
51+
/* Event signaled from main thread, change the timer */
5252
EnterCriticalSection(&timerCommArea.crit_sec);
5353
if (timerCommArea.value.it_value.tv_sec == 0 &&
5454
timerCommArea.value.it_value.tv_usec == 0)

Diff for: src/backend/postmaster/autovacuum.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -653,7 +653,7 @@ AutoVacLauncherMain(int argc, char *argv[])
653653
HandleAutoVacLauncherInterrupts();
654654

655655
/*
656-
* a worker finished, or postmaster signalled failure to start a
656+
* a worker finished, or postmaster signaled failure to start a
657657
* worker
658658
*/
659659
if (got_SIGUSR2)

Diff for: src/backend/postmaster/checkpointer.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -819,7 +819,7 @@ ReqCheckpointHandler(SIGNAL_ARGS)
819819
int save_errno = errno;
820820

821821
/*
822-
* The signalling process should have set ckpt_flags nonzero, so all we
822+
* The signaling process should have set ckpt_flags nonzero, so all we
823823
* need do is ensure that our main loop gets kicked out of any wait.
824824
*/
825825
SetLatch(MyLatch);

Diff for: src/backend/postmaster/pgstat.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -6251,7 +6251,7 @@ pgstat_recv_resetslrucounter(PgStat_MsgResetslrucounter *msg, int len)
62516251
/* ----------
62526252
* pgstat_recv_autovac() -
62536253
*
6254-
* Process an autovacuum signalling message.
6254+
* Process an autovacuum signaling message.
62556255
* ----------
62566256
*/
62576257
static void

Diff for: src/backend/postmaster/postmaster.c

+3-3
Original file line numberDiff line numberDiff line change
@@ -357,7 +357,7 @@ bool redirection_done = false; /* stderr redirected for syslogger? */
357357
/* received START_AUTOVAC_LAUNCHER signal */
358358
static volatile sig_atomic_t start_autovac_launcher = false;
359359

360-
/* the launcher needs to be signalled to communicate some condition */
360+
/* the launcher needs to be signaled to communicate some condition */
361361
static volatile bool avlauncher_needs_signal = false;
362362

363363
/* received START_WALRECEIVER signal */
@@ -3481,7 +3481,7 @@ HandleChildCrash(int pid, int exitstatus, const char *procname)
34813481
* We only log messages and send signals if this is the first process
34823482
* crash and we're not doing an immediate shutdown; otherwise, we're only
34833483
* here to update postmaster's idea of live processes. If we have already
3484-
* signalled children, nonzero exit status is to be expected, so don't
3484+
* signaled children, nonzero exit status is to be expected, so don't
34853485
* clutter log.
34863486
*/
34873487
take_action = !FatalError && Shutdown != ImmediateShutdown;
@@ -5615,7 +5615,7 @@ StartAutovacuumWorker(void)
56155615
* might not even be connected to shared memory, so don't try to call
56165616
* AutoVacWorkerFailed.) Note that we also need to signal it so that it
56175617
* responds to the condition, but we don't do that here, instead waiting
5618-
* for ServerLoop to do it. This way we avoid a ping-pong signalling in
5618+
* for ServerLoop to do it. This way we avoid a ping-pong signaling in
56195619
* quick succession between the autovac launcher and postmaster in case
56205620
* things get ugly.
56215621
*/

Diff for: src/backend/replication/logical/origin.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -122,7 +122,7 @@ typedef struct ReplicationState
122122
int acquired_by;
123123

124124
/*
125-
* Condition variable that's signalled when acquired_by changes.
125+
* Condition variable that's signaled when acquired_by changes.
126126
*/
127127
ConditionVariable origin_cv;
128128

Diff for: src/backend/replication/logical/reorderbuffer.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -14,7 +14,7 @@
1414
* This module gets handed individual pieces of transactions in the order
1515
* they are written to the WAL and is responsible to reassemble them into
1616
* toplevel transaction sized pieces. When a transaction is completely
17-
* reassembled - signalled by reading the transaction commit record - it
17+
* reassembled - signaled by reading the transaction commit record - it
1818
* will then call the output plugin (cf. ReorderBufferCommit()) with the
1919
* individual changes. The output plugins rely on snapshots built by
2020
* snapbuild.c which hands them to us.

Diff for: src/backend/storage/ipc/latch.c

+2-2
Original file line numberDiff line numberDiff line change
@@ -1354,7 +1354,7 @@ WaitEventSetWaitBlock(WaitEventSet *set, int cur_timeout,
13541354
* because we don't expect the pipe to become readable or to have
13551355
* any errors either, treat those cases as postmaster death, too.
13561356
*
1357-
* Be paranoid about a spurious event signalling the postmaster as
1357+
* Be paranoid about a spurious event signaling the postmaster as
13581358
* being dead. There have been reports about that happening with
13591359
* older primitives (select(2) to be specific), and a spurious
13601360
* WL_POSTMASTER_DEATH event would be painful. Re-checking doesn't
@@ -1613,7 +1613,7 @@ WaitEventSetWaitBlock(WaitEventSet *set, int cur_timeout,
16131613
* we don't expect the pipe to become readable or to have any
16141614
* errors either, treat those cases as postmaster death, too.
16151615
*
1616-
* Be paranoid about a spurious event signalling the postmaster as
1616+
* Be paranoid about a spurious event signaling the postmaster as
16171617
* being dead. There have been reports about that happening with
16181618
* older primitives (select(2) to be specific), and a spurious
16191619
* WL_POSTMASTER_DEATH event would be painful. Re-checking doesn't

Diff for: src/backend/storage/ipc/procsignal.c

+5-5
Original file line numberDiff line numberDiff line change
@@ -1,7 +1,7 @@
11
/*-------------------------------------------------------------------------
22
*
33
* procsignal.c
4-
* Routines for interprocess signalling
4+
* Routines for interprocess signaling
55
*
66
*
77
* Portions Copyright (c) 1996-2020, PostgreSQL Global Development Group
@@ -30,7 +30,7 @@
3030
#include "tcop/tcopprot.h"
3131

3232
/*
33-
* The SIGUSR1 signal is multiplexed to support signalling multiple event
33+
* The SIGUSR1 signal is multiplexed to support signaling multiple event
3434
* types. The specific reason is communicated via flags in shared memory.
3535
* We keep a boolean flag for each possible "reason", so that different
3636
* reasons can be signaled to a process concurrently. (However, if the same
@@ -40,8 +40,8 @@
4040
* Each process that wants to receive signals registers its process ID
4141
* in the ProcSignalSlots array. The array is indexed by backend ID to make
4242
* slot allocation simple, and to avoid having to search the array when you
43-
* know the backend ID of the process you're signalling. (We do support
44-
* signalling without backend ID, but it's a bit less efficient.)
43+
* know the backend ID of the process you're signaling. (We do support
44+
* signaling without backend ID, but it's a bit less efficient.)
4545
*
4646
* The flags are actually declared as "volatile sig_atomic_t" for maximum
4747
* portability. This should ensure that loads and stores of the flag
@@ -420,7 +420,7 @@ WaitForProcSignalBarrier(uint64 generation)
420420
/*
421421
* Perform global barrier related interrupt checking.
422422
*
423-
* Any backend that participates in ProcSignal signalling must arrange to
423+
* Any backend that participates in ProcSignal signaling must arrange to
424424
* call this function periodically. It is called from CHECK_FOR_INTERRUPTS(),
425425
* which is enough for normal backends, but not necessarily for all types of
426426
* background processes.

Diff for: src/backend/storage/ipc/shm_mq.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -1182,7 +1182,7 @@ shm_mq_wait_internal(shm_mq *mq, PGPROC **ptr, BackgroundWorkerHandle *handle)
11821182
}
11831183
}
11841184

1185-
/* Wait to be signalled. */
1185+
/* Wait to be signaled. */
11861186
(void) WaitLatch(MyLatch, WL_LATCH_SET | WL_EXIT_ON_PM_DEATH, 0,
11871187
WAIT_EVENT_MQ_INTERNAL);
11881188

Diff for: src/backend/storage/ipc/signalfuncs.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -1,7 +1,7 @@
11
/*-------------------------------------------------------------------------
22
*
33
* signalfuncs.c
4-
* Functions for signalling backends
4+
* Functions for signaling backends
55
*
66
* Portions Copyright (c) 1996-2020, PostgreSQL Global Development Group
77
* Portions Copyright (c) 1994, Regents of the University of California

Diff for: src/backend/storage/ipc/standby.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -92,7 +92,7 @@ InitRecoveryTransactionEnvironment(void)
9292
/*
9393
* Initialize shared invalidation management for Startup process, being
9494
* careful to register ourselves as a sendOnly process so we don't need to
95-
* read messages, nor will we get signalled when the queue starts filling
95+
* read messages, nor will we get signaled when the queue starts filling
9696
* up.
9797
*/
9898
SharedInvalBackendInit(true);

Diff for: src/backend/storage/lmgr/lock.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -759,7 +759,7 @@ LockAcquire(const LOCKTAG *locktag,
759759
* reportMemoryError specifies whether a lock request that fills the lock
760760
* table should generate an ERROR or not. Passing "false" allows the caller
761761
* to attempt to recover from lock-table-full situations, perhaps by forcibly
762-
* cancelling other lock holders and then retrying. Note, however, that the
762+
* canceling other lock holders and then retrying. Note, however, that the
763763
* return code for that is LOCKACQUIRE_NOT_AVAIL, so that it's unsafe to use
764764
* in combination with dontWait = true, as the cause of failure couldn't be
765765
* distinguished.

Diff for: src/backend/tcop/postgres.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -2750,7 +2750,7 @@ drop_unnamed_stmt(void)
27502750
*/
27512751

27522752
/*
2753-
* quickdie() occurs when signalled SIGQUIT by the postmaster.
2753+
* quickdie() occurs when signaled SIGQUIT by the postmaster.
27542754
*
27552755
* Some backend has bought the farm,
27562756
* so we need to stop what we're doing and exit.

Diff for: src/backend/utils/cache/relfilenodemap.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -64,7 +64,7 @@ RelfilenodeMapInvalidateCallback(Datum arg, Oid relid)
6464
while ((entry = (RelfilenodeMapEntry *) hash_seq_search(&status)) != NULL)
6565
{
6666
/*
67-
* If relid is InvalidOid, signalling a complete reset, we must remove
67+
* If relid is InvalidOid, signaling a complete reset, we must remove
6868
* all entries, otherwise just remove the specific relation's entry.
6969
* Always remove negative cache entries.
7070
*/

Diff for: src/include/access/tableam.h

+3-3
Original file line numberDiff line numberDiff line change
@@ -290,7 +290,7 @@ typedef struct TableAmRoutine
290290
*
291291
* *call_again is false on the first call to index_fetch_tuple for a tid.
292292
* If there potentially is another tuple matching the tid, *call_again
293-
* needs be set to true by index_fetch_tuple, signalling to the caller
293+
* needs be set to true by index_fetch_tuple, signaling to the caller
294294
* that index_fetch_tuple should be called again for the same tid.
295295
*
296296
* *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)
993993
*
994994
* *call_again needs to be false on the first call to table_index_fetch_tuple() for
995995
* a tid. If there potentially is another tuple matching the tid, *call_again
996-
* will be set to true, signalling that table_index_fetch_tuple() should be called
996+
* will be set to true, signaling that table_index_fetch_tuple() should be called
997997
* again for the same tid.
998998
*
999999
* *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,
15461546
/*
15471547
* As table_index_build_scan(), except that instead of scanning the complete
15481548
* table, only the given number of blocks are scanned. Scan to end-of-rel can
1549-
* be signalled by passing InvalidBlockNumber as numblocks. Note that
1549+
* be signaled by passing InvalidBlockNumber as numblocks. Note that
15501550
* restricting the range to scan cannot be done when requesting syncscan.
15511551
*
15521552
* When "anyvisible" mode is requested, all tuples visible to any transaction

Diff for: src/include/access/xact.h

+1-1
Original file line numberDiff line numberDiff line change
@@ -204,7 +204,7 @@ typedef struct xl_xact_assignment
204204
*
205205
* A minimal commit/abort record only consists of a xl_xact_commit/abort
206206
* struct. The presence of additional information is indicated by bits set in
207-
* 'xl_xact_xinfo->xinfo'. The presence of the xinfo field itself is signalled
207+
* 'xl_xact_xinfo->xinfo'. The presence of the xinfo field itself is signaled
208208
* by a set XLOG_XACT_HAS_INFO bit in the xl_info field.
209209
*
210210
* NB: All the individual data chunks should be sized to multiples of

Diff for: src/include/replication/slot.h

+1-1
Original file line numberDiff line numberDiff line change
@@ -142,7 +142,7 @@ typedef struct ReplicationSlot
142142
/* is somebody performing io on this slot? */
143143
LWLock io_in_progress_lock;
144144

145-
/* Condition variable signalled when active_pid changes */
145+
/* Condition variable signaled when active_pid changes */
146146
ConditionVariable active_cv;
147147

148148
/* all the remaining data is only used for logical slots */

Diff for: src/include/storage/condition_variable.h

+1-1
Original file line numberDiff line numberDiff line change
@@ -9,7 +9,7 @@
99
* on the condition variable; and (3) broadcast, which wakes up every
1010
* process sleeping on the condition variable. In our implementation,
1111
* condition variables put a process into an interruptible sleep (so it
12-
* can be cancelled prior to the fulfillment of the condition) and do not
12+
* can be canceled prior to the fulfillment of the condition) and do not
1313
* use pointers internally (so that they are safe to use within DSMs).
1414
*
1515
* Portions Copyright (c) 1996-2020, PostgreSQL Global Development Group

Diff for: src/include/storage/procsignal.h

+2-2
Original file line numberDiff line numberDiff line change
@@ -1,7 +1,7 @@
11
/*-------------------------------------------------------------------------
22
*
33
* procsignal.h
4-
* Routines for interprocess signalling
4+
* Routines for interprocess signaling
55
*
66
*
77
* Portions Copyright (c) 1996-2020, PostgreSQL Global Development Group
@@ -18,7 +18,7 @@
1818

1919

2020
/*
21-
* Reasons for signalling a Postgres child process (a backend or an auxiliary
21+
* Reasons for signaling a Postgres child process (a backend or an auxiliary
2222
* process, like checkpointer). We can cope with concurrent signals for different
2323
* reasons. However, if the same reason is signaled multiple times in quick
2424
* succession, the process is likely to observe only one notification of it.

Diff for: src/test/modules/test_shm_mq/setup.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -278,7 +278,7 @@ wait_for_workers_to_become_ready(worker_state *wstate,
278278
break;
279279
}
280280

281-
/* Wait to be signalled. */
281+
/* Wait to be signaled. */
282282
(void) WaitLatch(MyLatch, WL_LATCH_SET | WL_EXIT_ON_PM_DEATH, 0,
283283
PG_WAIT_EXTENSION);
284284

0 commit comments

Comments
 (0)