Fix inconsistencies and typos in the tree, take 10

This addresses some issues with unnecessary code comments, fixes various
typos in docs and comments, and removes some orphaned structures and
definitions.

Author: Alexander Lakhin
Discussion: https://postgr.es/m/9aabc775-5494-b372-8bcb-4dfc0bd37c68@gmail.com
This commit is contained in:
Michael Paquier 2019-08-13 13:53:41 +09:00
parent 2d7d67cc74
commit 66bde49d96
74 changed files with 93 additions and 141 deletions

View File

@ -191,7 +191,7 @@ dmetaphone_alt(PG_FUNCTION_ARGS)
(v = (t*)repalloc((v),((n)*sizeof(t))))
/*
* Don't do pfree - it seems to cause a segv sometimes - which might have just
* Don't do pfree - it seems to cause a SIGSEGV sometimes - which might have just
* been caused by reloading the module in development.
* So we rely on context cleanup - Tom Lane says pfree shouldn't be necessary
* in a case like this.

View File

@ -166,7 +166,7 @@ pushquery(QPRS_STATE *state, int32 type, int32 val, int32 distance, int32 lenval
}
/*
* This function is used for query_txt parsing
* This function is used for query text parsing
*/
static void
pushval_asis(QPRS_STATE *state, int type, char *strval, int lenval, uint16 flag)

View File

@ -39,25 +39,6 @@
#include "blf.h"
#include "rijndael.h"
/*
* System reseeds should be separated at least this much.
*/
#define SYSTEM_RESEED_MIN (20*60) /* 20 min */
/*
* How often to roll dice.
*/
#define SYSTEM_RESEED_CHECK_TIME (10*60) /* 10 min */
/*
* The chance is x/256 that the reseed happens.
*/
#define SYSTEM_RESEED_CHANCE (4) /* 256/4 * 10min ~ 10h */
/*
* If this much time has passed, force reseed.
*/
#define SYSTEM_RESEED_MAX (12*60*60) /* 12h */
#ifndef MD5_DIGEST_LENGTH
#define MD5_DIGEST_LENGTH 16
#endif

View File

@ -423,7 +423,7 @@ static struct PullFilterOps mdc_filter = {
/*
* Combined Pkt reader and MDC hasher.
*
* For the case of SYMENCRYPTED_MDC packet, where
* For the case of SYMENCRYPTED_DATA_MDC packet, where
* the data part has 'context length', which means
* that data packet ends 22 bytes before end of parent
* packet, which is silly.
@ -894,7 +894,10 @@ process_data_packets(PGP_Context *ctx, MBuf *dst, PullFilter *src,
break;
}
/* context length inside SYMENC_MDC needs special handling */
/*
* Context length inside SYMENCRYPTED_DATA_MDC packet needs special
* handling.
*/
if (need_mdc && res == PKT_CONTEXT)
res = pullf_create(&pkt, &mdcbuf_filter, ctx, src);
else

View File

@ -618,7 +618,7 @@ pgp_encrypt(PGP_Context *ctx, MBuf *src, MBuf *dst)
goto out;
/*
* initialize symkey
* initialize sym_key
*/
if (ctx->sym_key)
{

View File

@ -279,7 +279,7 @@ int pgp_s2k_process(PGP_S2K *s2k, int cipher, const uint8 *key, int klen);
typedef struct PGP_CFB PGP_CFB;
int pgp_cfb_create(PGP_CFB **ctx_p, int algo,
const uint8 *key, int key_len, int recync, uint8 *iv);
const uint8 *key, int key_len, int resync, uint8 *iv);
void pgp_cfb_free(PGP_CFB *ctx);
int pgp_cfb_encrypt(PGP_CFB *ctx, const uint8 *data, int len, uint8 *dst);
int pgp_cfb_decrypt(PGP_CFB *ctx, const uint8 *data, int len, uint8 *dst);

View File

@ -653,7 +653,7 @@ sepgsql_mcstrans_out(PG_FUNCTION_ARGS)
}
/*
* quote_object_names
* quote_object_name
*
* It tries to quote the supplied identifiers
*/

View File

@ -657,10 +657,8 @@ sepgsql_getenforce(void)
/*
* sepgsql_audit_log
*
* It generates a security audit record. In the default, it writes out
* audit records into standard PG's logfile. It also allows to set up
* external audit log receiver, such as auditd in Linux, using the
* sepgsql_audit_hook.
* It generates a security audit record. It writes out audit records
* into standard PG's logfile.
*
* SELinux can control what should be audited and should not using
* "auditdeny" and "auditallow" rules in the security policy. In the

View File

@ -5,7 +5,7 @@ CREATE TABLE A (
);
CREATE UNIQUE INDEX AI ON A (ID);
--Columns REFB of table B and REFC of C are foreign keys referenting ID of A:
--Columns REFB of table B and REFC of C are foreign keys referencing ID of A:
CREATE TABLE B (
REFB int4

View File

@ -5011,7 +5011,7 @@ struct
<para>
The fields <structfield>sqlcaid</structfield>,
<structfield>sqlcabc</structfield>,
<structfield>sqlabc</structfield>,
<structfield>sqlerrp</structfield>, and the remaining elements of
<structfield>sqlerrd</structfield> and
<structfield>sqlwarn</structfield> currently contain no useful

View File

@ -3740,9 +3740,9 @@ RAISE unique_violation USING MESSAGE = 'Duplicate user ID: ' || user_id;
<para>
If no condition name nor SQLSTATE is specified in a
<command>RAISE EXCEPTION</command> command, the default is to use
<literal>RAISE_EXCEPTION</literal> (<literal>P0001</literal>). If no message
text is specified, the default is to use the condition name or
SQLSTATE as message text.
<literal>ERRCODE_RAISE_EXCEPTION</literal> (<literal>P0001</literal>).
If no message text is specified, the default is to use the condition
name or SQLSTATE as message text.
</para>
<note>
@ -5626,7 +5626,7 @@ BEGIN
INSERT INTO cs_active_job(job_id) VALUES (v_job_id);
BEGIN
INSERT INTO cs_jobs (job_id, start_stamp) VALUES (v_job_id, sysdate);
INSERT INTO cs_jobs (job_id, start_stamp) VALUES (v_job_id, now());
EXCEPTION
WHEN dup_val_on_index THEN NULL; -- don't worry if it already exists
END;

View File

@ -884,7 +884,7 @@ BETTER: unrecognized node type: 42
features can be used, if a fallback is provided.
</para>
<para>
For example <literal>_StaticAssert()</literal> and
For example <literal>_Static_assert()</literal> and
<literal>__builtin_constant_p</literal> are currently used, even though
they are from newer revisions of the C standard and a
<productname>GCC</productname> extension respectively. If not available

View File

@ -395,9 +395,10 @@ brinRevmapDesummarizeRange(Relation idxrel, BlockNumber heapBlk)
*/
/*
* Because of SUE lock, this function shouldn't run concurrently with
* summarization. Placeholder tuples can only exist as leftovers from
* crashed summarization, so if we detect any, we complain but proceed.
* Because of ShareUpdateExclusive lock, this function shouldn't run
* concurrently with summarization. Placeholder tuples can only exist as
* leftovers from crashed summarization, so if we detect any, we complain
* but proceed.
*/
if (BrinTupleIsPlaceholder(tup))
ereport(WARNING,

View File

@ -37,7 +37,7 @@ static bool gistinserttuples(GISTInsertState *state, GISTInsertStack *stack,
Buffer leftchild, Buffer rightchild,
bool unlockbuf, bool unlockleftchild);
static void gistfinishsplit(GISTInsertState *state, GISTInsertStack *stack,
GISTSTATE *giststate, List *splitinfo, bool releasebuf);
GISTSTATE *giststate, List *splitinfo, bool unlockbuf);
static void gistprunepage(Relation rel, Page page, Buffer buffer,
Relation heapRel);
@ -1047,7 +1047,7 @@ gistFindCorrectParent(Relation r, GISTInsertStack *child)
{
/*
* End of chain and still didn't find parent. It's a very-very
* rare situation when root splited.
* rare situation when root splitted.
*/
break;
}

View File

@ -1510,7 +1510,7 @@ _hash_getcachedmetap(Relation rel, Buffer *metabuf, bool force_refresh)
* It's important that we don't set rd_amcache to an invalid value.
* Either MemoryContextAlloc or _hash_getbuf could fail, so don't
* install a pointer to the newly-allocated storage in the actual
* relcache entry until both have succeeeded.
* relcache entry until both have succeeded.
*/
if (rel->rd_amcache == NULL)
cache = MemoryContextAlloc(rel->rd_indexcxt,

View File

@ -3029,7 +3029,7 @@ heap_update(Relation relation, ItemPointer otid, HeapTuple newtup,
* the value ends up being the same, this test will fail and we will use
* the stronger lock. This is acceptable; the important case to optimize
* is updates that don't manipulate key columns, not those that
* serendipitiously arrive at the same key values.
* serendipitously arrive at the same key values.
*/
if (!bms_overlap(modified_attrs, key_attrs))
{

View File

@ -664,7 +664,7 @@ _bt_restore_array_keys(IndexScanDesc scan)
* scan->numberOfKeys is the number of input keys, so->numberOfKeys gets
* the number of output keys (possibly less, never greater).
*
* The output keys are marked with additional sk_flag bits beyond the
* The output keys are marked with additional sk_flags bits beyond the
* system-standard bits supplied by the caller. The DESC and NULLS_FIRST
* indoption bits for the relevant index attribute are copied into the flags.
* Also, for a DESC column, we commute (flip) all the sk_strategy numbers

View File

@ -1364,7 +1364,7 @@ SlruScanDirCbDeleteAll(SlruCtl ctl, char *filename, int segpage, void *data)
}
/*
* Scan the SimpleLRU directory and apply a callback to each file found in it.
* Scan the SimpleLru directory and apply a callback to each file found in it.
*
* If the callback returns true, the scan is stopped. The last return value
* from the callback is returned.

View File

@ -1232,7 +1232,7 @@ RecordTransactionCommit(void)
if (!markXidCommitted)
{
/*
* We expect that every smgrscheduleunlink is followed by a catalog
* We expect that every RelationDropStorage is followed by a catalog
* update, and hence XID assignment, so we shouldn't get here with any
* pending deletes. Use a real test not just an Assert to check this,
* since it's a bit fragile.

View File

@ -702,7 +702,7 @@ ValidXLogRecordHeader(XLogReaderState *state, XLogRecPtr RecPtr,
* We assume all of the record (that is, xl_tot_len bytes) has been read
* into memory at *record. Also, ValidXLogRecordHeader() has accepted the
* record's header, which means in particular that xl_tot_len is at least
* SizeOfXlogRecord.
* SizeOfXLogRecord.
*/
static bool
ValidXLogRecord(XLogReaderState *state, XLogRecord *record, XLogRecPtr recptr)

View File

@ -317,13 +317,6 @@ IsSharedRelation(Oid relationId)
* consecutive existing OIDs. This is a mostly reasonable assumption for
* system catalogs.
*
* This is exported separately because there are cases where we want to use
* an index that will not be recognized by RelationGetOidIndex: TOAST tables
* have indexes that are usable, but have multiple columns and are on
* ordinary columns rather than a true OID column. This code will work
* anyway, so long as the OID is the index's first column. The caller must
* pass in the actual heap attnum of the OID column, however.
*
* Caller must have a suitable lock on the relation.
*/
Oid

View File

@ -580,7 +580,7 @@ RemoveConstraintById(Oid conId)
rel = table_open(con->conrelid, AccessExclusiveLock);
/*
* We need to update the relcheck count if it is a check constraint
* We need to update the relchecks count if it is a check constraint
* being dropped. This update will force backends to rebuild relcache
* entries when we commit.
*/

View File

@ -1522,7 +1522,7 @@ finish_heap_swap(Oid OIDOldHeap, Oid OIDNewHeap,
/*
* Get a list of tables that the current user owns and
* have indisclustered set. Return the list in a List * of rvsToCluster
* have indisclustered set. Return the list in a List * of RelToCluster
* with the tableOid and the indexOid on which the table is already
* clustered.
*/

View File

@ -1115,7 +1115,7 @@ init_sequence(Oid relid, SeqTable *p_elm, Relation *p_rel)
/*
* Initialize the new hash table entry if it did not exist already.
*
* NOTE: seqtable entries are stored for the life of a backend (unless
* NOTE: seqhashtab entries are stored for the life of a backend (unless
* explicitly discarded with DISCARD). If the sequence itself is deleted
* then the entry becomes wasted memory, but it's small enough that this
* should not matter.

View File

@ -2603,7 +2603,7 @@ _SPI_cursor_operation(Portal portal, FetchDirection direction, long count,
/*
* Think not to combine this store with the preceding function call. If
* the portal contains calls to functions that use SPI, then SPI_stack is
* the portal contains calls to functions that use SPI, then _SPI_stack is
* likely to move around while the portal runs. When control returns,
* _SPI_current will point to the correct stack entry... but the pointer
* may be different than it was beforehand. So we must be sure to re-fetch
@ -2733,7 +2733,7 @@ _SPI_make_plan_non_temp(SPIPlanPtr plan)
ALLOCSET_SMALL_SIZES);
oldcxt = MemoryContextSwitchTo(plancxt);
/* Copy the SPI_plan struct and subsidiary data into the new context */
/* Copy the _SPI_plan struct and subsidiary data into the new context */
newplan = (SPIPlanPtr) palloc0(sizeof(_SPI_plan));
newplan->magic = _SPI_PLAN_MAGIC;
newplan->plancxt = plancxt;

View File

@ -1797,7 +1797,7 @@ interpret_ident_response(const char *ident_response,
/*
* Talk to the ident server on "remote_addr" and find out who
* owns the tcp connection to "local_addr"
* It the username successfully retrieved, check the usermap.
* If the username is successfully retrieved, check the usermap.
*
* XXX: Using WaitLatchOrSocket() and doing a CHECK_FOR_INTERRUPTS() if the
* latch was set would improve the responsiveness to timeouts/cancellations.

View File

@ -485,10 +485,10 @@ StreamServerPort(int family, char *hostName, unsigned short portNumber,
* error on TCP ports.
*
* On win32, however, this behavior only happens if the
* SO_EXLUSIVEADDRUSE is set. With SO_REUSEADDR, win32 allows multiple
* servers to listen on the same address, resulting in unpredictable
* behavior. With no flags at all, win32 behaves as Unix with
* SO_REUSEADDR.
* SO_EXCLUSIVEADDRUSE is set. With SO_REUSEADDR, win32 allows
* multiple servers to listen on the same address, resulting in
* unpredictable behavior. With no flags at all, win32 behaves as Unix
* with SO_REUSEADDR.
*/
if (!IS_AF_UNIX(addr->ai_family))
{

View File

@ -1811,7 +1811,7 @@ append_nonpartial_cost(List *subpaths, int numpaths, int parallel_workers)
return 0;
/*
* Array length is number of workers or number of relevants paths,
* Array length is number of workers or number of relevant paths,
* whichever is less.
*/
arrlen = Min(parallel_workers, numpaths);

View File

@ -1514,7 +1514,7 @@ partition_rbound_cmp(int partnatts, FmgrInfo *partsupfunc,
/*
* partition_rbound_datum_cmp
*
* Return whether range bound (specified in rb_datums, rb_kind, and rb_lower)
* Return whether range bound (specified in rb_datums and rb_kind)
* is <, =, or > partition key of tuple (tuple_datums)
*
* n_tuple_datums, partsupfunc and partcollation give number of attributes in

View File

@ -2127,7 +2127,7 @@ match_clause_to_partition_key(GeneratePruningStepsContext *context,
/*
* Now generate a list of clauses, one for each array element, of the
* form saop_leftop saop_op elem_expr
* form leftop saop_op elem_expr
*/
elem_clauses = NIL;
foreach(lc1, elem_exprs)

View File

@ -189,7 +189,7 @@ PGSemaphoreShmemSize(int maxSemas)
* maxSemas parameter is just used to size the arrays. For unnamed
* semaphores, there is an array of PGSemaphoreData structs in shared memory.
* For named semaphores, we keep a postmaster-local array of sem_t pointers,
* which we use for releasing the semphores when done.
* which we use for releasing the semaphores when done.
* (This design minimizes the dependency of postmaster shutdown on the
* contents of shared memory, which a failed backend might have clobbered.
* We can't do much about the possibility of sem_destroy() crashing, but

View File

@ -102,7 +102,7 @@ pgwin32_signal_initialize(void)
/*
* Dispatch all signals currently queued and not blocked
* Blocked signals are ignored, and will be fired at the time of
* the sigsetmask() call.
* the pqsigsetmask() call.
*/
void
pgwin32_dispatch_queued_signals(void)

View File

@ -750,7 +750,7 @@ IsCheckpointOnSchedule(double progress)
* We compare the current WAL insert location against the location
* computed before calling CreateCheckPoint. The code in XLogInsert that
* actually triggers a checkpoint when CheckPointSegments is exceeded
* compares against RedoRecptr, so this is not completely accurate.
* compares against RedoRecPtr, so this is not completely accurate.
* However, it's good enough for our purposes, we're only calculating an
* estimate anyway.
*

View File

@ -792,7 +792,7 @@ SendBackupHeader(List *tablespaces)
pq_sendint32(&buf, 0); /* typmod */
pq_sendint16(&buf, 0); /* format code */
/* Second field - spcpath */
/* Second field - spclocation */
pq_sendstring(&buf, "spclocation");
pq_sendint32(&buf, 0);
pq_sendint16(&buf, 0);

View File

@ -269,7 +269,7 @@ static void SnapBuildSnapIncRefcount(Snapshot snap);
static void SnapBuildDistributeNewCatalogSnapshot(SnapBuild *builder, XLogRecPtr lsn);
/* xlog reading helper functions for SnapBuildProcessRecord */
/* xlog reading helper functions for SnapBuildProcessRunningXacts */
static bool SnapBuildFindSnapshot(SnapBuild *builder, XLogRecPtr lsn, xl_running_xacts *running);
static void SnapBuildWaitSnapshot(xl_running_xacts *running, TransactionId cutoff);

View File

@ -1658,7 +1658,7 @@ ApplyWorkerMain(Datum main_arg)
{
char *syncslotname;
/* This is table synchroniation worker, call initial sync. */
/* This is table synchronization worker, call initial sync. */
syncslotname = LogicalRepSyncTableStart(&origin_startpos);
/* The slot name needs to be allocated in permanent memory context. */

View File

@ -108,7 +108,7 @@ static void CreateSlotOnDisk(ReplicationSlot *slot);
static void SaveSlotToPath(ReplicationSlot *slot, const char *path, int elevel);
/*
* Report shared-memory space needed by ReplicationSlotShmemInit.
* Report shared-memory space needed by ReplicationSlotsShmemInit.
*/
Size
ReplicationSlotsShmemSize(void)
@ -298,7 +298,7 @@ ReplicationSlotCreate(const char *name, bool db_specific,
* We need to briefly prevent any other backend from iterating over the
* slots while we flip the in_use flag. We also need to set the active
* flag while holding the ControlLock as otherwise a concurrent
* SlotAcquire() could acquire the slot as well.
* ReplicationSlotAcquire() could acquire the slot as well.
*/
LWLockAcquire(ReplicationSlotControlLock, LW_EXCLUSIVE);

View File

@ -1971,10 +1971,6 @@ retry:
{
/*
* Maintain fileSize and temporary_files_size if it's a temp file.
*
* If seekPos is -1 (unknown), this will do nothing; but we could only
* get here in that state if we're not enforcing temporary_files_size,
* so we don't care.
*/
if (vfdP->fdstate & FD_TEMP_FILE_LIMIT)
{

View File

@ -734,8 +734,6 @@ ProcArrayApplyRecoveryInfo(RunningTransactions running)
Assert(standbyState == STANDBY_INITIALIZED);
/*
* OK, we need to initialise from the RunningTransactionsData record.
*
* NB: this can be reached at least twice, so make sure new code can deal
* with that.
*/
@ -750,11 +748,11 @@ ProcArrayApplyRecoveryInfo(RunningTransactions running)
* sort them first.
*
* Some of the new xids are top-level xids and some are subtransactions.
* We don't call SubtransSetParent because it doesn't matter yet. If we
* We don't call SubTransSetParent because it doesn't matter yet. If we
* aren't overflowed then all xids will fit in snapshot and so we don't
* need subtrans. If we later overflow, an xid assignment record will add
* xids to subtrans. If RunningXacts is overflowed then we don't have
* enough information to correctly update subtrans anyway.
* xids to subtrans. If RunningTransactionsData is overflowed then we
* don't have enough information to correctly update subtrans anyway.
*/
/*

View File

@ -1075,8 +1075,8 @@ LWLockDequeueSelf(LWLock *lock)
*/
/*
* Reset releaseOk if somebody woke us before we removed ourselves -
* they'll have set it to false.
* Reset RELEASE_OK flag if somebody woke us before we removed
* ourselves - they'll have set it to false.
*/
pg_atomic_fetch_or_u32(&lock->state, LW_FLAG_RELEASE_OK);

View File

@ -849,7 +849,7 @@ OldSerXidInit(void)
/*
* Record a committed read write serializable xid and the minimum
* commitSeqNo of any transactions to which this xid had a rw-conflict out.
* An invalid seqNo means that there were no conflicts out from xid.
* An invalid commitSeqNo means that there were no conflicts out from xid.
*/
static void
OldSerXidAdd(TransactionId xid, SerCommitSeqNo minConflictCommitSeqNo)
@ -1685,7 +1685,7 @@ SetSerializableTransactionSnapshot(Snapshot snapshot,
/*
* Guts of GetSerializableTransactionSnapshot
*
* If sourcexid is valid, this is actually an import operation and we should
* If sourcevxid is valid, this is actually an import operation and we should
* skip calling GetSnapshotData, because the snapshot contents are already
* loaded up. HOWEVER: to avoid race conditions, we must check that the
* source xact is still running after we acquire SerializableXactHashLock.

View File

@ -79,7 +79,7 @@
#undef StrNCpy
#include <shlwapi.h>
#ifdef StrNCpy
#undef STrNCpy
#undef StrNCpy
#endif
#endif

View File

@ -1,6 +1,6 @@
/*-------------------------------------------------------------------------
*
* ragetypes_typanalyze.c
* rangetypes_typanalyze.c
* Functions for gathering statistics from range columns
*
* For a range type column, histograms of lower and upper bounds, and

View File

@ -705,7 +705,7 @@ txid_snapshot_xip(PG_FUNCTION_ARGS)
TxidSnapshot *snap;
txid value;
/* on first call initialize snap_state and get copy of snapshot */
/* on first call initialize fctx and get copy of snapshot */
if (SRF_IS_FIRSTCALL())
{
TxidSnapshot *arg = (TxidSnapshot *) PG_GETARG_VARLENA_P(0);

View File

@ -2052,7 +2052,7 @@ varstr_sortsupport(SortSupport ssup, Oid typid, Oid collid)
/*
* If we're using abbreviated keys, or if we're using a locale-aware
* comparison, we need to initialize a StringSortSupport object. Both
* comparison, we need to initialize a VarStringSortSupport object. Both
* cases will make use of the temporary buffers we initialize here for
* scratch space (and to detect requirement for BpChar semantics from
* caller), and the abbreviation case requires additional state.

View File

@ -3987,7 +3987,7 @@ xml_xpathobjtoxmlarray(xmlXPathObjectPtr xpathobj,
/*
* Common code for xpath() and xmlexists()
*
* Evaluate XPath expression and return number of nodes in res_items
* Evaluate XPath expression and return number of nodes in res_nitems
* and array of XML values in astate. Either of those pointers can be
* NULL if the corresponding result isn't wanted.
*

View File

@ -18,7 +18,7 @@
## can be ignored
INTENTIONALLY_NOT_INCLUDED="debug_deadlocks \
is_superuser lc_collate lc_ctype lc_messages lc_monetary lc_numeric lc_time \
pre_auth_delay role seed server_encoding server_version server_version_int \
pre_auth_delay role seed server_encoding server_version server_version_num \
session_authorization trace_lock_oidmin trace_lock_table trace_locks trace_lwlocks \
trace_notify trace_userlocks transaction_isolation transaction_read_only \
zero_damaged_pages"

View File

@ -182,7 +182,7 @@ static const MemoryContextMethods SlabMethods = {
* chunkSize: allocation chunk size
*
* The chunkSize may not exceed:
* MAXALIGN_DOWN(SIZE_MAX) - MAXALIGN(sizeof(SlabBlock)) - SLAB_CHUNKHDRSZ
* MAXALIGN_DOWN(SIZE_MAX) - MAXALIGN(sizeof(SlabBlock)) - sizeof(SlabChunk)
*/
MemoryContext
SlabContextCreate(MemoryContext parent,

View File

@ -1150,7 +1150,7 @@ tuplesort_begin_datum(Oid datumType, Oid sortOperator, Oid sortCollation,
* to compare. In a tuple sort, we could support that, because we can
* always extract the original datum from the tuple as needed. Here, we
* can't, because a datum sort only stores a single copy of the datum; the
* "tuple" field of each sortTuple is NULL.
* "tuple" field of each SortTuple is NULL.
*/
state->sortKeys->abbreviate = !typbyval;

View File

@ -1989,7 +1989,7 @@ WriteInt(ArchiveHandle *AH, int i)
* This is a bit yucky, but I don't want to make the binary format very
* dependent on representation, and not knowing much about it, I write out
* a sign byte. If you change this, don't forget to change the file
* version #, and modify readInt to read the new format AS WELL AS the old
* version #, and modify ReadInt to read the new format AS WELL AS the old
* formats.
*/

View File

@ -404,7 +404,7 @@ sanityChecks(void)
{
/* TODO Check that there's no backup_label in either cluster */
/* Check system_id match */
/* Check system_identifier match */
if (ControlFile_target.system_identifier != ControlFile_source.system_identifier)
pg_fatal("source and target clusters are from different systems");

View File

@ -138,7 +138,7 @@ typedef struct
char *nspname; /* namespace name */
char *relname; /* relation name */
Oid reloid; /* relation OID */
Oid relfilenode; /* relation relfile node */
Oid relfilenode; /* relation file node */
Oid indtable; /* if index, OID of its table, else 0 */
Oid toastheap; /* if toast table, OID of base table, else 0 */
char *tablespace; /* tablespace path; "" for cluster default */

View File

@ -31,7 +31,7 @@ extern void brinRevmapExtend(BrinRevmap *revmap,
BlockNumber heapBlk);
extern Buffer brinLockRevmapPageForUpdate(BrinRevmap *revmap,
BlockNumber heapBlk);
extern void brinSetHeapBlockItemptr(Buffer rmbuf, BlockNumber pagesPerRange,
extern void brinSetHeapBlockItemptr(Buffer buf, BlockNumber pagesPerRange,
BlockNumber heapBlk, ItemPointerData tid);
extern BrinTuple *brinGetTupleForHeapBlock(BrinRevmap *revmap,
BlockNumber heapBlk, Buffer *buf, OffsetNumber *off,

View File

@ -51,19 +51,6 @@
#define XLH_SPLIT_META_UPDATE_MASKS (1<<0)
#define XLH_SPLIT_META_UPDATE_SPLITPOINT (1<<1)
/*
* This is what we need to know about a HASH index create.
*
* Backup block 0: metapage
*/
typedef struct xl_hash_createidx
{
double num_tuples;
RegProcedure procid;
uint16 ffactor;
} xl_hash_createidx;
#define SizeOfHashCreateIdx (offsetof(xl_hash_createidx, ffactor) + sizeof(uint16))
/*
* This is what we need to know about simple (without split) insert.
*

View File

@ -237,7 +237,7 @@ typedef struct
/*
* For use by code reading options already parsed: get a pointer to the string
* value itself. "optstruct" is the StdRdOption struct or equivalent, "member"
* value itself. "optstruct" is the StdRdOptions struct or equivalent, "member"
* is the struct member corresponding to the string option
*/
#define GET_STRING_RELOPTION(optstruct, member) \

View File

@ -248,7 +248,7 @@ extern bool DecodeXLogRecord(XLogReaderState *state, XLogRecord *record,
extern FullTransactionId XLogRecGetFullXid(XLogReaderState *record);
#endif
extern bool RestoreBlockImage(XLogReaderState *recoder, uint8 block_id, char *dst);
extern bool RestoreBlockImage(XLogReaderState *record, uint8 block_id, char *page);
extern char *XLogRecGetBlockData(XLogReaderState *record, uint8 block_id, Size *len);
extern bool XLogRecGetBlockTag(XLogReaderState *record, uint8 block_id,
RelFileNode *rnode, ForkNumber *forknum,

View File

@ -105,7 +105,7 @@ extern Oid ConversionGetConid(const char *conname);
extern bool ConversionIsVisible(Oid conid);
extern Oid get_statistics_object_oid(List *names, bool missing_ok);
extern bool StatisticsObjIsVisible(Oid stxid);
extern bool StatisticsObjIsVisible(Oid relid);
extern Oid get_ts_parser_oid(List *names, bool missing_ok);
extern bool TSParserIsVisible(Oid prsId);

View File

@ -768,8 +768,8 @@ typedef enum AggStrategy
/* Primitive options supported by nodeAgg.c: */
#define AGGSPLITOP_COMBINE 0x01 /* substitute combinefn for transfn */
#define AGGSPLITOP_SKIPFINAL 0x02 /* skip finalfn, return state as-is */
#define AGGSPLITOP_SERIALIZE 0x04 /* apply serializefn to output */
#define AGGSPLITOP_DESERIALIZE 0x08 /* apply deserializefn to input */
#define AGGSPLITOP_SERIALIZE 0x04 /* apply serialfn to output */
#define AGGSPLITOP_DESERIALIZE 0x08 /* apply deserialfn to input */
/* Supported operating modes (i.e., useful combinations of these options): */
typedef enum AggSplit

View File

@ -451,7 +451,7 @@ int pgwin32_bind(SOCKET s, struct sockaddr *addr, int addrlen);
int pgwin32_listen(SOCKET s, int backlog);
SOCKET pgwin32_accept(SOCKET s, struct sockaddr *addr, int *addrlen);
int pgwin32_connect(SOCKET s, const struct sockaddr *name, int namelen);
int pgwin32_select(int nfds, fd_set *readfs, fd_set *writefds, fd_set *exceptfds, const struct timeval *timeout);
int pgwin32_select(int nfds, fd_set *readfds, fd_set *writefds, fd_set *exceptfds, const struct timeval *timeout);
int pgwin32_recv(SOCKET s, char *buf, int len, int flags);
int pgwin32_send(SOCKET s, const void *buf, int len, int flags);
int pgwin32_waitforsinglesocket(SOCKET s, int what, int timeout);

View File

@ -43,4 +43,4 @@ typedef struct RuleLock
RewriteRule **rules;
} RuleLock;
#endif /* REWRITE_H */
#endif /* PRS2LOCK_H */

View File

@ -1,6 +1,6 @@
/*-------------------------------------------------------------------------
*
* standbydef.h
* standbydefs.h
* Frontend exposed definitions for hot standby mode.
*
*

View File

@ -63,7 +63,7 @@
(PGSIXBIT(ch1) + (PGSIXBIT(ch2) << 6) + (PGSIXBIT(ch3) << 12) + \
(PGSIXBIT(ch4) << 18) + (PGSIXBIT(ch5) << 24))
/* These macros depend on the fact that '0' becomes a zero in SIXBIT */
/* These macros depend on the fact that '0' becomes a zero in PGSIXBIT */
#define ERRCODE_TO_CATEGORY(ec) ((ec) & ((1 << 12) - 1))
#define ERRCODE_IS_CATEGORY(ec) (((ec) & ~((1 << 12) - 1)) == 0)

View File

@ -365,7 +365,7 @@ extern int set_config_option(const char *name, const char *value,
GucContext context, GucSource source,
GucAction action, bool changeVal, int elevel,
bool is_reload);
extern void AlterSystemSetConfigFile(AlterSystemStmt *setstmt);
extern void AlterSystemSetConfigFile(AlterSystemStmt *altersysstmt);
extern char *GetConfigOptionByName(const char *name, const char **varname,
bool missing_ok);
extern void GetConfigOptionByNum(int varnum, const char **values, bool *noshow);

View File

@ -75,7 +75,7 @@ typedef struct RelationData
* when a relation has multiple new relfilenodes within a single
* transaction, with one of them occurring in a subsequently aborted
* subtransaction, e.g. BEGIN; TRUNCATE t; SAVEPOINT save; TRUNCATE t;
* ROLLBACK TO save; -- rd_newRelfilenode is now forgotten
* ROLLBACK TO save; -- rd_newRelfilenodeSubid is now forgotten
*/
SubTransactionId rd_createSubid; /* rel was created in current xact */
SubTransactionId rd_newRelfilenodeSubid; /* new relfilenode assigned in

View File

@ -109,7 +109,7 @@ typedef struct
double numIndexPages; /* number of leaf pages visited */
double numIndexTuples; /* number of leaf tuples visited */
double spc_random_page_cost; /* relevant random_page_cost value */
double num_sa_scans; /* # indexscans from ScalarArrayOps */
double num_sa_scans; /* # indexscans from ScalarArrayOpExprs */
} GenericCosts;
/* Hooks for plugins to get control when we ask for stats */

View File

@ -679,11 +679,6 @@ intoasc(interval * i, char *str)
return 0;
}
/*
* rfmt.c - description
* by Carsten Wolff <carsten.wolff@credativ.de>, Wed Apr 2 2003
*/
static struct
{
long val;
@ -745,7 +740,7 @@ initValue(long lng_val)
return 0;
}
/* return the position oft the right-most dot in some string */
/* return the position of the right-most dot in some string */
static int
getRightMostDot(const char *str)
{

View File

@ -287,7 +287,7 @@ extern PQconninfoOption *PQconninfo(PGconn *conn);
extern void PQconninfoFree(PQconninfoOption *connOptions);
/*
* close the current connection and restablish a new one with the same
* close the current connection and reestablish a new one with the same
* parameters
*/
/* Asynchronous (non-blocking) */

View File

@ -132,7 +132,7 @@ PLy_subtransaction_enter(PyObject *self, PyObject *unused)
*
* Exit an explicit subtransaction. exc_type is an exception type, exc
* is the exception object, tb is the traceback. If exc_type is None,
* commit the subtransactiony, if not abort it.
* commit the subtransaction, if not abort it.
*
* The method signature is chosen to allow subtransaction objects to
* be used as context managers as described in

View File

@ -49,8 +49,8 @@ typedef void (__stdcall * freeaddrinfo_ptr_t) (struct addrinfo *ai);
typedef int (__stdcall * getnameinfo_ptr_t) (const struct sockaddr *sa,
int salen,
char *host, int hostlen,
char *serv, int servlen,
char *node, int nodelen,
char *service, int servicelen,
int flags);
/* static pointers to the native routines, so we only do the lookup once. */

View File

@ -29,7 +29,7 @@ permutation "s1alter" "s1commit" "s2nv"
# change, but now it waits.
permutation "s1alter" "s2nv" "s1commit"
# Prior to PG10, the s2nv step would see the uncommitted s1reset
# Prior to PG10, the s2nv step would see the uncommitted s1restart
# change, but now it waits.
permutation "s1restart" "s2nv" "s1commit"

View File

@ -76,7 +76,7 @@ is($psql_out, '6', "Check nextXid handling for prepared subtransactions");
###############################################################################
# Check that replay will correctly set 2PC with more than
# PGPROC_MAX_CACHED_SUBXIDS subtransations and also show data properly
# PGPROC_MAX_CACHED_SUBXIDS subtransactions and also show data properly
# on promotion
###############################################################################
$node_master->psql('postgres', "DELETE FROM t_012_tbl");

View File

@ -6,6 +6,6 @@
/results/
/log/
# Note: regreesion.* are only left behind on a failure; that's why they're not ignored
# Note: regression.* are only left behind on a failure; that's why they're not ignored
#/regression.diffs
#/regression.out

View File

@ -357,7 +357,7 @@ pg_tzset_offset(long gmtoffset)
* is to ensure that log_timezone has a valid value before any logging GUC
* variables could become set to values that require elog.c to provide
* timestamps (e.g., log_line_prefix). We may as well initialize
* session_timestamp to something valid, too.
* session_timezone to something valid, too.
*/
void
pg_timezone_initialize(void)

View File

@ -31,7 +31,7 @@ DOING THE INDENT RUN:
wget -O src/tools/pgindent/typedefs.list https://buildfarm.postgresql.org/cgi-bin/typedefs.pl
(See https://www.pgbuildfarm.org/cgi-bin/typedefs.pl?show_list for a full
(See https://buildfarm.postgresql.org/cgi-bin/typedefs.pl?show_list for a full
list of typedef files, if you want to indent some back branch.)
3) Run pgindent on the C files: