]> granicus.if.org Git - postgresql/commitdiff
Fix inconsistencies and typos in the tree
authorMichael Paquier <michael@paquier.xyz>
Mon, 29 Jul 2019 03:28:30 +0000 (12:28 +0900)
committerMichael Paquier <michael@paquier.xyz>
Mon, 29 Jul 2019 03:28:30 +0000 (12:28 +0900)
This is numbered take 8, and addresses again a set of issues with code
comments, variable names and unreferenced variables.

Author: Alexander Lakhin
Discussion: https://postgr.es/m/b137b5eb-9c95-9c2f-586e-38aba7d59788@gmail.com

42 files changed:
contrib/pgcrypto/pgp-decrypt.c
doc/src/sgml/custom-scan.sgml
doc/src/sgml/ref/create_aggregate.sgml
doc/src/sgml/xplang.sgml
src/Makefile.global.in
src/backend/access/common/bufmask.c
src/backend/access/gin/gindatapage.c
src/backend/access/heap/rewriteheap.c
src/backend/access/spgist/spgvacuum.c
src/backend/access/transam/xact.c
src/backend/access/transam/xlog.c
src/backend/catalog/pg_aggregate.c
src/backend/commands/dbcommands.c
src/backend/commands/operatorcmds.c
src/backend/libpq/auth.c
src/backend/postmaster/bgwriter.c
src/backend/replication/walsender.c
src/backend/storage/ipc/procarray.c
src/backend/storage/ipc/standby.c
src/backend/storage/lmgr/lwlock.c
src/backend/storage/smgr/md.c
src/backend/tcop/pquery.c
src/backend/utils/adt/arrayfuncs.c
src/backend/utils/adt/like_match.c
src/backend/utils/mmgr/aset.c
src/bin/initdb/initdb.c
src/bin/pg_controldata/pg_controldata.c
src/bin/pg_ctl/pg_ctl.c
src/bin/pg_upgrade/pg_upgrade.h
src/bin/pgevent/README
src/common/unicode_norm.c
src/include/access/gist_private.h
src/include/commands/dbcommands.h
src/include/replication/logicalproto.h
src/include/statistics/statistics.h
src/include/storage/bufpage.h
src/include/storage/lock.h
src/include/storage/lockdefs.h
src/include/storage/lwlock.h
src/interfaces/libpq/fe-exec.c
src/pl/plperl/plperl.c
src/tools/FAQ2txt [deleted file]

index 7d8951cda4161c797184eda05e17d34adbd122e7..eed0f6ad2d5faf1d8d3446e71e961e2f42dd2c1c 100644 (file)
@@ -355,7 +355,7 @@ mdc_finish(PGP_Context *ctx, PullFilter *src, int len)
        if (len != 20)
                return PXE_PGP_CORRUPT_DATA;
 
-       /* mdc_read should not call md_update */
+       /* mdc_read should not call px_md_update */
        ctx->in_mdc_pkt = 1;
 
        /* read data */
index ab9b055d9a9e1edbc15455d63ea204be78a5774d..b8963a28eb15a8fbf4300d6b0825c5296d2cb14a 100644 (file)
@@ -83,10 +83,7 @@ typedef struct CustomPath
     by <literal>nodeToString</literal>, so that debugging routines that attempt to
     print the custom path will work as designed.  <structfield>methods</structfield> must
     point to a (usually statically allocated) object implementing the required
-    custom path methods, of which there is currently only one.  The
-    <structfield>LibraryName</structfield> and <structfield>SymbolName</structfield> fields must also
-    be initialized so that the dynamic loader can resolve them to locate the
-    method table.
+    custom path methods, of which there is currently only one.
   </para>
 
   <para>
index ca0e9db8b139d8578c2fae39cb4819bcbfbaae60..644657dd5efd54b9562a3e86acfcd9169b3cae8a 100644 (file)
@@ -211,7 +211,7 @@ CREATE [ OR REPLACE ] AGGREGATE <replaceable class="parameter">name</replaceable
    as described in <xref linkend="xaggr-moving-aggregates"/>.  This requires
    specifying the <literal>MSFUNC</literal>, <literal>MINVFUNC</literal>,
    and <literal>MSTYPE</literal> parameters, and optionally
-   the <literal>MSPACE</literal>, <literal>MFINALFUNC</literal>,
+   the <literal>MSSPACE</literal>, <literal>MFINALFUNC</literal>,
    <literal>MFINALFUNC_EXTRA</literal>, <literal>MFINALFUNC_MODIFY</literal>,
    and <literal>MINITCOND</literal> parameters.  Except for <literal>MINVFUNC</literal>,
    these parameters work like the corresponding simple-aggregate parameters
index d215ce82d08565aa0d3caa8842c7a4a82e93c952..60e0430751066e7531dc09a927679d14597b88d9 100644 (file)
@@ -137,7 +137,7 @@ CREATE FUNCTION <replaceable>validator_function_name</replaceable>(oid)
      <para>
       Finally, the PL must be declared with the command
 <synopsis>
-CREATE <optional>TRUSTED</optional> LANGUAGE <replaceable>language-name</replaceable>
+CREATE <optional>TRUSTED</optional> LANGUAGE <replaceable>language_name</replaceable>
     HANDLER <replaceable>handler_function_name</replaceable>
     <optional>INLINE <replaceable>inline_function_name</replaceable></optional>
     <optional>VALIDATOR <replaceable>validator_function_name</replaceable></optional> ;
index 321af38b0c32e5acd242291b53ec2750ab37eb79..dc3f207e1c4fbc48baa2bcf1a868c249af78216e 100644 (file)
@@ -23,7 +23,7 @@ standard_targets = all install installdirs uninstall distprep clean distclean ma
 # these targets should recurse even into subdirectories not being built:
 standard_always_targets = distprep clean distclean maintainer-clean
 
-.PHONY: $(standard_targets) install-strip html man installcheck-parallel maintainer-check
+.PHONY: $(standard_targets) install-strip html man installcheck-parallel
 
 # make `all' the default target
 all:
index ee1c6f234a21cbfe5e5804479a262e93f463f808..bcd9bd007b70bf66c999657e2cf4378d42df6936 100644 (file)
@@ -20,7 +20,7 @@
 #include "access/bufmask.h"
 
 /*
- * mask_page_lsn
+ * mask_page_lsn_and_checksum
  *
  * In consistency checks, the LSN of the two pages compared will likely be
  * different because of concurrent operations when the WAL is generated and
index 21de8ed714df17baa5b3ee4147b2472e536efcea..e8c34d6b1f6d57b8c2654a5c60a97d97048fbfd4 100644 (file)
@@ -1371,7 +1371,7 @@ disassembleLeaf(Page page)
        if (GinPageIsCompressed(page))
        {
                /*
-                * Create a leafSegment entry for each segment.
+                * Create a leafSegmentInfo entry for each segment.
                 */
                seg = GinDataLeafPageGetPostingList(page);
                segbegin = (Pointer) seg;
index 72a448ad31677d01f52aee2b032003f28abd15bd..a17508a82fb3c4c1269caeecd28690258cf1853a 100644 (file)
@@ -237,7 +237,7 @@ static void logical_end_heap_rewrite(RewriteState state);
  * new_heap            new, locked heap relation to insert tuples to
  * oldest_xmin xid used by the caller to determine which tuples are dead
  * freeze_xid  xid before which tuples will be frozen
- * min_multi   multixact before which multis will be removed
+ * cutoff_multi        multixact before which multis will be removed
  * use_wal             should the inserts to the new heap be WAL-logged?
  *
  * Returns an opaque RewriteState, allocated in current memory context,
@@ -787,7 +787,7 @@ raw_heap_insert(RewriteState state, HeapTuple tup)
  * Instead we simply write the mapping files out to disk, *before* the
  * XLogInsert() is performed. That guarantees that either the XLogInsert() is
  * inserted after the checkpoint's redo pointer or that the checkpoint (via
- * LogicalRewriteHeapCheckpoint()) has flushed the (partial) mapping file to
+ * CheckPointLogicalRewriteHeap()) has flushed the (partial) mapping file to
  * disk. That leaves the tail end that has not yet been flushed open to
  * corruption, which is solved by including the current offset in the
  * xl_heap_rewrite_mapping records and truncating the mapping file to it
index 2b1662a267dccf06dc1db064ece0a732097a43d9..478d4c0d612e5ccb74ad6d00278f2bf787f3d689 100644 (file)
@@ -842,7 +842,7 @@ spgvacuumscan(spgBulkDeleteState *bds)
                }
        }
 
-       /* Propagate local lastUsedPage cache to metablock */
+       /* Propagate local lastUsedPages cache to metablock */
        SpGistUpdateMetaPage(index);
 
        /*
index d7930c077de028a76f94ec18e0786457e921f4f0..1bbaeeebf4d6f349cdfb887a0fe239320f98d951 100644 (file)
@@ -1988,7 +1988,7 @@ StartTransaction(void)
 
        /*
         * Advertise it in the proc array.  We assume assignment of
-        * LocalTransactionID is atomic, and the backendId should be set already.
+        * localTransactionId is atomic, and the backendId should be set already.
         */
        Assert(MyProc->backendId == vxid.backendId);
        MyProc->lxid = vxid.localTransactionId;
index da3d25098608f86e3a932124a3cb9c5cf112cde8..f55352385732c6b0124eff5265462f3883fe7435 100644 (file)
@@ -1796,11 +1796,11 @@ WaitXLogInsertionsToFinish(XLogRecPtr upto)
                do
                {
                        /*
-                        * See if this insertion is in progress. LWLockWait will wait for
-                        * the lock to be released, or for the 'value' to be set by a
-                        * LWLockUpdateVar call.  When a lock is initially acquired, its
-                        * value is 0 (InvalidXLogRecPtr), which means that we don't know
-                        * where it's inserting yet.  We will have to wait for it.  If
+                        * See if this insertion is in progress.  LWLockWaitForVar will
+                        * wait for the lock to be released, or for the 'value' to be set
+                        * by a LWLockUpdateVar call.  When a lock is initially acquired,
+                        * its value is 0 (InvalidXLogRecPtr), which means that we don't
+                        * know where it's inserting yet.  We will have to wait for it. If
                         * it's a small insertion, the record will most likely fit on the
                         * same page and the inserter will release the lock without ever
                         * calling LWLockUpdateVar.  But if it has to sleep, it will
@@ -6024,7 +6024,10 @@ recoveryApplyDelay(XLogReaderState *record)
                TimestampDifference(GetCurrentTimestamp(), recoveryDelayUntilTime,
                                                        &secs, &microsecs);
 
-               /* NB: We're ignoring waits below min_apply_delay's resolution. */
+               /*
+                * NB: We're ignoring waits below recovery_min_apply_delay's
+                * resolution.
+                */
                if (secs <= 0 && microsecs / 1000 <= 0)
                        break;
 
index 7cab039dedcdf117761ca301f16bb5f7f5d8e63b..201242e7965ccfb936087a5c33ba24efda0075f3 100644 (file)
@@ -733,7 +733,7 @@ AggregateCreate(const char *aggName,
         * Create dependencies for the aggregate (above and beyond those already
         * made by ProcedureCreate).  Note: we don't need an explicit dependency
         * on aggTransType since we depend on it indirectly through transfn.
-        * Likewise for aggmTransType using the mtransfunc, if it exists.
+        * Likewise for aggmTransType using the mtransfn, if it exists.
         *
         * If we're replacing an existing definition, ProcedureCreate deleted all
         * our existing dependencies, so we have to do the same things here either
index fc1e1564a6188384355e1b3e6ce23efba7b1e106..95881a85509bae3854bced2082fbee82e4bd1a36 100644 (file)
@@ -1854,7 +1854,7 @@ get_db_info(const char *name, LOCKMODE lockmode,
                                /* limit of frozen XIDs */
                                if (dbFrozenXidP)
                                        *dbFrozenXidP = dbform->datfrozenxid;
-                               /* minimum MultixactId */
+                               /* minimum MultiXactId */
                                if (dbMinMultiP)
                                        *dbMinMultiP = dbform->datminmxid;
                                /* default tablespace for this database */
index 17f54410a005efbd0efb4a434e5d995f22042a65..d733aa4826bc5a14ad2641000fdba0a46fd17080 100644 (file)
@@ -27,9 +27,6 @@
  *             "create operator":
  *                             operators
  *
- *             Most of the parse-tree manipulation routines are defined in
- *             commands/manip.c.
- *
  *-------------------------------------------------------------------------
  */
 #include "postgres.h"
index 9358219aa60a37f61b0391db890c9cee637eb1ce..e17fd9a317ff27d94c8f96bd6376da21515ce827 100644 (file)
@@ -1796,14 +1796,9 @@ interpret_ident_response(const char *ident_response,
 
 
 /*
- *     Talk to the ident server on host "remote_ip_addr" and find out who
- *     owns the tcp connection from his port "remote_port" to port
- *     "local_port_addr" on host "local_ip_addr".  Return the user name the
- *     ident server gives as "*ident_user".
- *
- *     IP addresses and port numbers are in network byte order.
- *
- *     But iff we're unable to get the information from ident, return false.
+ *     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.
  *
  *     XXX: Using WaitLatchOrSocket() and doing a CHECK_FOR_INTERRUPTS() if the
  *     latch was set would improve the responsiveness to timeouts/cancellations.
index e6b6c549de54ab226e6cae322cc9848f0214b319..8ec16a3fb8d0f4502bc7f7e255321c482e124a95 100644 (file)
@@ -291,10 +291,10 @@ BackgroundWriterMain(void)
                 * significantly bigger than BgWriterDelay, so we don't complicate the
                 * overall timeout handling but just assume we're going to get called
                 * often enough even if hibernation mode is active. It's not that
-                * important that log_snap_interval_ms is met strictly. To make sure
-                * we're not waking the disk up unnecessarily on an idle system we
-                * check whether there has been any WAL inserted since the last time
-                * we've logged a running xacts.
+                * important that LOG_SNAPSHOT_INTERVAL_MS is met strictly. To make
+                * sure we're not waking the disk up unnecessarily on an idle system
+                * we check whether there has been any WAL inserted since the last
+                * time we've logged a running xacts.
                 *
                 * We do this logging in the bgwriter as it is the only process that
                 * is run regularly and returns to its mainloop all the time. E.g.
index e7a59b0a9215f58a33b19c4bab662a950df43624..e172dad07f4a163e29d1f0091d1df99f4bc11f35 100644 (file)
@@ -2259,7 +2259,7 @@ WalSndLoop(WalSndSendDataCallback send_data)
                                WL_SOCKET_READABLE;
 
                        /*
-                        * Use fresh timestamp, not last_processed, to reduce the chance
+                        * Use fresh timestamp, not last_processing, to reduce the chance
                         * of reaching wal_sender_timeout before sending a keepalive.
                         */
                        sleeptime = WalSndComputeSleeptime(GetCurrentTimestamp());
@@ -2666,7 +2666,7 @@ XLogSendPhysical(void)
         * very close to together here so that we'll get a later position if it is
         * still moving.
         *
-        * Because LagTrackerWriter ignores samples when the LSN hasn't advanced,
+        * Because LagTrackerWrite ignores samples when the LSN hasn't advanced,
         * this gives us a cheap approximation for the WAL flush time for this
         * LSN.
         *
index ae6780011b895ce8ba3cff655671e5b7d05df566..fadab62950d65a4f5c6561996c71c2b40851c620 100644 (file)
@@ -3169,7 +3169,7 @@ DisplayXidCache(void)
  *
  * When we throw away subXIDs from KnownAssignedXids, we need to keep track of
  * that, similarly to tracking overflow of a PGPROC's subxids array.  We do
- * that by remembering the lastOverflowedXID, ie the last thrown-away subXID.
+ * that by remembering the lastOverflowedXid, ie the last thrown-away subXID.
  * As long as that is within the range of interesting XIDs, we have to assume
  * that subXIDs are missing from snapshots.  (Note that subXID overflow occurs
  * on primary when 65th subXID arrives, whereas on standby it occurs when 64th
index 25b7e314afc417f3e6cd9439c80f7e4ea4ee20b8..01ddffec40024f3ac27606310ef9f3a053218d22 100644 (file)
@@ -99,7 +99,7 @@ InitRecoveryTransactionEnvironment(void)
         * Lock a virtual transaction id for Startup process.
         *
         * We need to do GetNextLocalTransactionId() because
-        * SharedInvalBackendInit() leaves localTransactionid invalid and the lock
+        * SharedInvalBackendInit() leaves localTransactionId invalid and the lock
         * manager doesn't like that at all.
         *
         * Note that we don't need to run XactLockTableInsert() because nobody
index bc1aa88322b0c8fbf40676a8e4ce27d304ac0f02..c77d47c01c6e2a3d2f8eed510ace4910b130d36f 100644 (file)
@@ -232,7 +232,7 @@ LOG_LWDEBUG(const char *where, LWLock *lock, const char *msg)
 
 static void init_lwlock_stats(void);
 static void print_lwlock_stats(int code, Datum arg);
-static lwlock_stats * get_lwlock_stats_entry(LWLock *lockid);
+static lwlock_stats * get_lwlock_stats_entry(LWLock *lock);
 
 static void
 init_lwlock_stats(void)
index 52136ad55800e1c51d945ac44c7fe378441cde80..07f3c93d3fedfb581fd58dcb6629de74076dea9c 100644 (file)
@@ -731,7 +731,7 @@ mdwrite(SMgrRelation reln, ForkNumber forknum, BlockNumber blocknum,
  *     mdnblocks() -- Get the number of blocks stored in a relation.
  *
  *             Important side effect: all active segments of the relation are opened
- *             and added to the mdfd_seg_fds array.  If this routine has not been
+ *             and added to the md_seg_fds array.  If this routine has not been
  *             called, then only segments up to the last one actually touched
  *             are present in the array.
  */
index 1ed2838ad4584411267d3fbd47510bc82a883bcb..9e48adc53ce9c0ecbadb46650b433f9567405143 100644 (file)
@@ -1023,8 +1023,8 @@ FillPortalStore(Portal portal, bool isTopLevel)
 
                        /*
                         * Run the portal to completion just as for the default
-                        * MULTI_QUERY case, but send the primary query's output to the
-                        * tuplestore.  Auxiliary query outputs are discarded.  Set the
+                        * PORTAL_MULTI_QUERY case, but send the primary query's output to
+                        * the tuplestore.  Auxiliary query outputs are discarded. Set the
                         * portal's holdSnapshot to the snapshot used (or a copy of it).
                         */
                        PortalRunMulti(portal, isTopLevel, true,
index 8fcdf829229131febb75a8bc8939731b40081fb7..ec8fbb9a7da6bccf2fcaa074c8290f00c9414f11 100644 (file)
@@ -139,7 +139,7 @@ static void array_insert_slice(ArrayType *destArray, ArrayType *origArray,
                                                           int *st, int *endp,
                                                           int typlen, bool typbyval, char typalign);
 static int     array_cmp(FunctionCallInfo fcinfo);
-static ArrayType *create_array_envelope(int ndims, int *dimv, int *lbv, int nbytes,
+static ArrayType *create_array_envelope(int ndims, int *dimv, int *lbsv, int nbytes,
                                                                                Oid elmtype, int dataoffset);
 static ArrayType *array_fill_internal(ArrayType *dims, ArrayType *lbs,
                                                                          Datum value, bool isnull, Oid elmtype,
index 9055a938132bb948146c45e0974e6909d9f3bfcc..5b322559aa4cbeb31dd747c74711192161f18dec 100644 (file)
@@ -27,7 +27,8 @@
 /*
  *     Originally written by Rich $alz, mirror!rs, Wed Nov 26 19:03:17 EST 1986.
  *     Rich $alz is now <rsalz@bbn.com>.
- *     Special thanks to Lars Mathiesen <thorinn@diku.dk> for the LABORT code.
+ *     Special thanks to Lars Mathiesen <thorinn@diku.dk> for the
+ *     LIKE_ABORT code.
  *
  *     This code was shamelessly stolen from the "pql" code by myself and
  *     slightly modified :)
index 6e4a3434394ea1806465a96c99fd2829d4a2df7e..6b63d6f85d042b073d3cd5c504366e25aa217978 100644 (file)
@@ -915,7 +915,7 @@ AllocSetAlloc(MemoryContext context, Size size)
 
                /*
                 * We could be asking for pretty big blocks here, so cope if malloc
-                * fails.  But give up if there's less than a meg or so available...
+                * fails.  But give up if there's less than 1 MB or so available...
                 */
                while (block == NULL && blksize > 1024 * 1024)
                {
index 04d77ad70069a76b5b7a697a3d9c0594f1740902..09eabfbe5ab02842334512f7474a01658e0c053f 100644 (file)
@@ -2024,7 +2024,7 @@ make_template0(FILE *cmdfd)
                "CREATE DATABASE template0 IS_TEMPLATE = true ALLOW_CONNECTIONS = false;\n\n",
 
                /*
-                * We use the OID of template0 to determine lastsysoid
+                * We use the OID of template0 to determine datlastsysoid
                 */
                "UPDATE pg_database SET datlastsysoid = "
                "    (SELECT oid FROM pg_database "
index 390ea0a93974a73dce05dab759695932632b5dfe..ff17804723e5220e39d6dcd2216dd709dc00aebb 100644 (file)
@@ -4,7 +4,7 @@
  * reads the data from $PGDATA/global/pg_control
  *
  * copyright (c) Oliver Elphick <olly@lfix.co.uk>, 2001;
- * licence: BSD
+ * license: BSD
  *
  * src/bin/pg_controldata/pg_controldata.c
  */
index 3a9a65d31d7aa7c1afd83162d15907453055a306..068b65a2af765b75420efcf6c09470f7d908b8b2 100644 (file)
@@ -1725,7 +1725,7 @@ pgwin32_doRunAsService(void)
 /*
  * Mingw headers are incomplete, and so are the libraries. So we have to load
  * a whole lot of API functions dynamically. Since we have to do this anyway,
- * also load the couple of functions that *do* exist in minwg headers but not
+ * also load the couple of functions that *do* exist in mingw headers but not
  * on NT4. That way, we don't break on NT4.
  */
 typedef BOOL (WINAPI * __CreateRestrictedToken) (HANDLE, DWORD, DWORD, PSID_AND_ATTRIBUTES, DWORD, PLUID_AND_ATTRIBUTES, DWORD, PSID_AND_ATTRIBUTES, PHANDLE);
index ca6a9efd9c4508d132668243d79ddca5fea149aa..57c4ed69132b96c1ccc4b2749b8211d78da369e4 100644 (file)
 #define USER_NAME_SIZE         128
 
 #define MAX_STRING                     1024
-#define LINE_ALLOC                     4096
 #define QUERY_ALLOC                    8192
 
-#define MIGRATOR_API_VERSION   1
-
 #define MESSAGE_WIDTH          60
 
 #define GET_MAJOR_VERSION(v)   ((v) / 100)
index 3d0329ec33007d09af7e28f3c0ad17aebb951c18..10ec8d2d62be69228593837ad92e9b438a2c53ed 100644 (file)
@@ -3,7 +3,7 @@ src/bin/pgevent/README
 pgevent
 =======
 
-MSG000001.bin is a binary file, result of Microsoft MC compiler. MC compiler
+MSG00001.bin is a binary file, result of Microsoft MC compiler. MC compiler
 can be downloaded for free with MS Core SDK but it is not included with MSYS
 tools and I didn't find an alternative way to compile MC file.
 
index 6281f2222fe2f64f0e702fa036b85b78bfa4a515..89c553321286e4c194b708532e76293853ca1170 100644 (file)
@@ -178,7 +178,7 @@ recompose_code(uint32 start, uint32 code, uint32 *result)
                         ((start - SBASE) % TCOUNT) == 0 &&
                         code >= TBASE && code < (TBASE + TCOUNT))
        {
-               /* make syllable of from LVT */
+               /* make syllable of form LVT */
                uint32          tindex = code - TBASE;
 
                *result = start + tindex;
index 0488d01c9b815d8dc9877a72fe1cd8e2830df3a1..acebe6c93b0c16a551ac0b51353f3526ff8ba20d 100644 (file)
@@ -417,7 +417,7 @@ extern bool gistplacetopage(Relation rel, Size freespace, GISTSTATE *giststate,
                                                        OffsetNumber oldoffnum, BlockNumber *newblkno,
                                                        Buffer leftchildbuf,
                                                        List **splitinfo,
-                                                       bool markleftchild,
+                                                       bool markfollowright,
                                                        Relation heapRel,
                                                        bool is_build);
 
index 28bf21153d891fde679fe0642c4753860683f076..154c8157ee227b4a60f645fb5f69ad8447bbf948 100644 (file)
@@ -26,7 +26,7 @@ extern Oid    AlterDatabase(ParseState *pstate, AlterDatabaseStmt *stmt, bool isTop
 extern Oid     AlterDatabaseSet(AlterDatabaseSetStmt *stmt);
 extern ObjectAddress AlterDatabaseOwner(const char *dbname, Oid newOwnerId);
 
-extern Oid     get_database_oid(const char *dbname, bool missingok);
+extern Oid     get_database_oid(const char *dbname, bool missing_ok);
 extern char *get_database_name(Oid dbid);
 
 extern void check_encoding_locale_matches(int encoding, const char *collate, const char *ctype);
index 9c0000cc593571fd49eb81bb7ae0eb32208bcb23..3fc430af013d01d5d1304a68124b8dd2a97e5532 100644 (file)
@@ -19,8 +19,8 @@
 /*
  * Protocol capabilities
  *
- * LOGICAL_PROTO_VERSION_NUM is our native protocol and the greatest version
- * we can support. PGLOGICAL_PROTO_MIN_VERSION_NUM is the oldest version we
+ * LOGICALREP_PROTO_VERSION_NUM is our native protocol and the greatest version
+ * we can support. LOGICALREP_PROTO_MIN_VERSION_NUM is the oldest version we
  * have backwards compatibility for. The client requests protocol version at
  * connect time.
  */
@@ -106,4 +106,4 @@ extern LogicalRepRelation *logicalrep_read_rel(StringInfo in);
 extern void logicalrep_write_typ(StringInfo out, Oid typoid);
 extern void logicalrep_read_typ(StringInfo out, LogicalRepTyp *ltyp);
 
-#endif                                                 /* LOGICALREP_PROTO_H */
+#endif                                                 /* LOGICAL_PROTO_H */
index cb7bc630e98b3fab55997bbc5fc3178c7624309b..3b7da3be6094fd3b772430c4293a2e3e59ced046 100644 (file)
@@ -22,7 +22,7 @@
 #define STATS_NDISTINCT_MAGIC          0xA352BFA4      /* struct identifier */
 #define STATS_NDISTINCT_TYPE_BASIC     1       /* struct version */
 
-/* MVDistinctItem represents a single combination of columns */
+/* MVNDistinctItem represents a single combination of columns */
 typedef struct MVNDistinctItem
 {
        double          ndistinct;              /* ndistinct value for this combination */
index 34b68ad0e0027a117b6647a663c2575c820b6042..4ef6d8ddd4a73d190c641f28bc9f60dfe378351d 100644 (file)
@@ -306,7 +306,7 @@ typedef PageHeaderData *PageHeader;
  * This is intended to catch use of the pointer before page initialization.
  * It is implemented as a function due to the limitations of the MSVC
  * compiler, which choked on doing all these tests within another macro.  We
- * return true so that MacroAssert() can be used while still getting the
+ * return true so that AssertMacro() can be used while still getting the
  * specifics from the macro failure within this function.
  */
 static inline bool
index 986bb6433a0557db8dee32fd4cb6bb6556525d32..6efb7a96481f53c19a6603f5224f3d9b5a02630e 100644 (file)
@@ -594,4 +594,4 @@ extern void VirtualXactLockTableInsert(VirtualTransactionId vxid);
 extern void VirtualXactLockTableCleanup(void);
 extern bool VirtualXactLock(VirtualTransactionId vxid, bool wait);
 
-#endif                                                 /* LOCK_H */
+#endif                                                 /* LOCK_H_ */
index 3c2c47dc6ae77e6abdcd1df53a447d4eb5396ab7..bda08edcfdb1b8dcbfd2459b9bf9dd577c7ba705 100644 (file)
@@ -56,4 +56,4 @@ typedef struct xl_standby_lock
        Oid                     relOid;                 /* OID of table */
 } xl_standby_lock;
 
-#endif                                                 /* LOCKDEF_H_ */
+#endif                                                 /* LOCKDEFS_H_ */
index 08e0dc8144bb947d8b8f7f241b12638cc351d043..f627dfedc5c27008c95600e45ea37abc7480ccae 100644 (file)
@@ -133,7 +133,7 @@ typedef enum LWLockMode
 {
        LW_EXCLUSIVE,
        LW_SHARED,
-       LW_WAIT_UNTIL_FREE                      /* A special mode used in PGPROC->lwlockMode,
+       LW_WAIT_UNTIL_FREE                      /* A special mode used in PGPROC->lwWaitMode,
                                                                 * when waiting for lock to become free. Not
                                                                 * to be used as LWLockAcquire argument */
 } LWLockMode;
index 3a8cddf4ff456f6d0d8288f06d22e496e5b1600e..48d4ebdd96cd766e77a0fefc934819a8efba0451 100644 (file)
@@ -2250,7 +2250,7 @@ PQsendDescribe(PGconn *conn, char desc_type, const char *desc_target)
        /* remember we are doing a Describe */
        conn->queryclass = PGQUERY_DESCRIBE;
 
-       /* reset last-query string (not relevant now) */
+       /* reset last_query string (not relevant now) */
        if (conn->last_query)
        {
                free(conn->last_query);
index 2db13d303089ca3c4d66586d38272e8b87b50fbc..c480999c51d9d5dbe349af231bb07c72c081efa2 100644 (file)
@@ -2091,7 +2091,7 @@ plperlu_validator(PG_FUNCTION_ARGS)
 
 
 /*
- * Uses mksafefunc/mkunsafefunc to create a subroutine whose text is
+ * Uses mkfunc to create a subroutine whose text is
  * supplied in s, and returns a reference to it
  */
 static void
diff --git a/src/tools/FAQ2txt b/src/tools/FAQ2txt
deleted file mode 100755 (executable)
index ab61d4d..0000000
+++ /dev/null
@@ -1,7 +0,0 @@
-#!/bin/sh
-
-# src/tools/FAQ2txt:
-
-# Converts doc/src/FAQ/FAQ.html to text file doc/FAQ
-
-lynx -force_html -dont_wrap_pre -dump -hiddenlinks=ignore -nolist "$@"