1
0
mirror of https://github.com/postgres/postgres.git synced 2025-07-28 23:42:10 +03:00

Update typedefs.list and re-run pgindent

Discussion: http://postgr.es/m/CA+TgmoaA9=1RWKtBWpDaj+sF3Stgc8sHgf5z=KGtbjwPLQVDMA@mail.gmail.com
This commit is contained in:
Robert Haas
2017-11-29 09:24:24 -05:00
parent 801386af62
commit eaedf0df71
52 changed files with 224 additions and 197 deletions

View File

@ -1314,8 +1314,8 @@ brinsummarize(Relation index, Relation heapRel, BlockNumber pageRange,
/* /*
* Unless requested to summarize even a partial range, go away now if * Unless requested to summarize even a partial range, go away now if
* we think the next range is partial. Caller would pass true when * we think the next range is partial. Caller would pass true when it
* it is typically run once bulk data loading is done * is typically run once bulk data loading is done
* (brin_summarize_new_values), and false when it is typically the * (brin_summarize_new_values), and false when it is typically the
* result of arbitrarily-scheduled maintenance command (vacuuming). * result of arbitrarily-scheduled maintenance command (vacuuming).
*/ */

View File

@ -6586,10 +6586,10 @@ StartupXLOG(void)
else else
{ {
/* /*
* We used to attempt to go back to a secondary checkpoint * We used to attempt to go back to a secondary checkpoint record
* record here, but only when not in standby_mode. We now * here, but only when not in standby_mode. We now just fail if we
* just fail if we can't read the last checkpoint because * can't read the last checkpoint because this allows us to
* this allows us to simplify processing around checkpoints. * simplify processing around checkpoints.
*/ */
ereport(PANIC, ereport(PANIC,
(errmsg("could not locate a valid checkpoint record"))); (errmsg("could not locate a valid checkpoint record")));
@ -8888,7 +8888,8 @@ CreateCheckPoint(int flags)
(errmsg("concurrent write-ahead log activity while database system is shutting down"))); (errmsg("concurrent write-ahead log activity while database system is shutting down")));
/* /*
* Remember the prior checkpoint's redo ptr for UpdateCheckPointDistanceEstimate() * Remember the prior checkpoint's redo ptr for
* UpdateCheckPointDistanceEstimate()
*/ */
PriorRedoPtr = ControlFile->checkPointCopy.redo; PriorRedoPtr = ControlFile->checkPointCopy.redo;
@ -9211,7 +9212,8 @@ CreateRestartPoint(int flags)
CheckPointGuts(lastCheckPoint.redo, flags); CheckPointGuts(lastCheckPoint.redo, flags);
/* /*
* Remember the prior checkpoint's redo ptr for UpdateCheckPointDistanceEstimate() * Remember the prior checkpoint's redo ptr for
* UpdateCheckPointDistanceEstimate()
*/ */
PriorRedoPtr = ControlFile->checkPointCopy.redo; PriorRedoPtr = ControlFile->checkPointCopy.redo;

View File

@ -2548,8 +2548,7 @@ get_partition_for_tuple(Relation relation, Datum *values, bool *isnull)
/* /*
* No range includes NULL, so this will be accepted by the * No range includes NULL, so this will be accepted by the
* default partition if there is one, and otherwise * default partition if there is one, and otherwise rejected.
* rejected.
*/ */
for (i = 0; i < key->partnatts; i++) for (i = 0; i < key->partnatts; i++)
{ {
@ -2585,8 +2584,8 @@ get_partition_for_tuple(Relation relation, Datum *values, bool *isnull)
} }
/* /*
* part_index < 0 means we failed to find a partition of this parent. * part_index < 0 means we failed to find a partition of this parent. Use
* Use the default partition, if there is one. * the default partition, if there is one.
*/ */
if (part_index < 0) if (part_index < 0)
part_index = partdesc->boundinfo->default_index; part_index = partdesc->boundinfo->default_index;

View File

@ -1518,8 +1518,8 @@ ExecSetupTransitionCaptureState(ModifyTableState *mtstate, EState *estate)
if (mtstate->mt_partition_dispatch_info != NULL) if (mtstate->mt_partition_dispatch_info != NULL)
{ {
/* /*
* For tuple routing among partitions, we need TupleDescs based * For tuple routing among partitions, we need TupleDescs based on
* on the partition routing table. * the partition routing table.
*/ */
ResultRelInfo **resultRelInfos = mtstate->mt_partitions; ResultRelInfo **resultRelInfos = mtstate->mt_partitions;

View File

@ -791,6 +791,7 @@ read_client_first_message(scram_state *state, char *input)
switch (*input) switch (*input)
{ {
case 'n': case 'n':
/* /*
* The client does not support channel binding or has simply * The client does not support channel binding or has simply
* decided to not use it. In that case just let it go. * decided to not use it. In that case just let it go.
@ -805,6 +806,7 @@ read_client_first_message(scram_state *state, char *input)
input++; input++;
break; break;
case 'y': case 'y':
/* /*
* The client supports channel binding and thinks that the server * The client supports channel binding and thinks that the server
* does not. In this case, the server must fail authentication if * does not. In this case, the server must fail authentication if
@ -827,6 +829,7 @@ read_client_first_message(scram_state *state, char *input)
input++; input++;
break; break;
case 'p': case 'p':
/* /*
* The client requires channel binding. Channel binding type * The client requires channel binding. Channel binding type
* follows, e.g., "p=tls-unique". * follows, e.g., "p=tls-unique".
@ -1139,8 +1142,8 @@ read_client_final_message(scram_state *state, char *input)
b64_message[b64_message_len] = '\0'; b64_message[b64_message_len] = '\0';
/* /*
* Compare the value sent by the client with the value expected by * Compare the value sent by the client with the value expected by the
* the server. * server.
*/ */
if (strcmp(channel_binding, b64_message) != 0) if (strcmp(channel_binding, b64_message) != 0)
ereport(ERROR, ereport(ERROR,

View File

@ -100,7 +100,8 @@ static struct pam_conv pam_passw_conv = {
NULL NULL
}; };
static const char *pam_passwd = NULL; /* Workaround for Solaris 2.6 brokenness */ static const char *pam_passwd = NULL; /* Workaround for Solaris 2.6
* brokenness */
static Port *pam_port_cludge; /* Workaround for passing "Port *port" into static Port *pam_port_cludge; /* Workaround for passing "Port *port" into
* pam_passwd_conv_proc */ * pam_passwd_conv_proc */
#endif /* USE_PAM */ #endif /* USE_PAM */
@ -914,6 +915,7 @@ CheckSCRAMAuth(Port *port, char *shadow_pass, char **logdetail)
pfree(sasl_mechs); pfree(sasl_mechs);
#ifdef USE_SSL #ifdef USE_SSL
/* /*
* Get data for channel binding. * Get data for channel binding.
*/ */

View File

@ -2421,9 +2421,9 @@ apply_projection_to_path(PlannerInfo *root,
* It seems unlikely at present that there could be any other * It seems unlikely at present that there could be any other
* references to the subpath, but better safe than sorry. * references to the subpath, but better safe than sorry.
* *
* Note that we don't change the parallel path's cost estimates; it might * Note that we don't change the parallel path's cost estimates; it
* be appropriate to do so, to reflect the fact that the bulk of the * might be appropriate to do so, to reflect the fact that the bulk of
* target evaluation will happen in workers. * the target evaluation will happen in workers.
*/ */
if (IsA(path, GatherPath)) if (IsA(path, GatherPath))
{ {

View File

@ -1890,8 +1890,8 @@ find_partition_scheme(PlannerInfo *root, Relation relation)
/* /*
* Did not find matching partition scheme. Create one copying relevant * Did not find matching partition scheme. Create one copying relevant
* information from the relcache. We need to copy the contents of the array * information from the relcache. We need to copy the contents of the
* since the relcache entry may not survive after we have closed the * array since the relcache entry may not survive after we have closed the
* relation. * relation.
*/ */
part_scheme = (PartitionScheme) palloc0(sizeof(PartitionSchemeData)); part_scheme = (PartitionScheme) palloc0(sizeof(PartitionSchemeData));

View File

@ -873,11 +873,11 @@ build_joinrel_tlist(PlannerInfo *root, RelOptInfo *joinrel,
continue; continue;
/* /*
* Otherwise, anything in a baserel or joinrel targetlist ought to be a * Otherwise, anything in a baserel or joinrel targetlist ought to be
* Var. Children of a partitioned table may have ConvertRowtypeExpr * a Var. Children of a partitioned table may have ConvertRowtypeExpr
* translating whole-row Var of a child to that of the parent. Children * translating whole-row Var of a child to that of the parent.
* of an inherited table or subquery child rels can not directly * Children of an inherited table or subquery child rels can not
* participate in a join, so other kinds of nodes here. * directly participate in a join, so other kinds of nodes here.
*/ */
if (IsA(var, Var)) if (IsA(var, Var))
{ {
@ -1672,12 +1672,13 @@ build_joinrel_partition_info(RelOptInfo *joinrel, RelOptInfo *outer_rel,
* Construct partition keys for the join. * Construct partition keys for the join.
* *
* An INNER join between two partitioned relations can be regarded as * An INNER join between two partitioned relations can be regarded as
* partitioned by either key expression. For example, A INNER JOIN B ON A.a = * partitioned by either key expression. For example, A INNER JOIN B ON
* B.b can be regarded as partitioned on A.a or on B.b; they are equivalent. * A.a = B.b can be regarded as partitioned on A.a or on B.b; they are
* equivalent.
* *
* For a SEMI or ANTI join, the result can only be regarded as being * For a SEMI or ANTI join, the result can only be regarded as being
* partitioned in the same manner as the outer side, since the inner columns * partitioned in the same manner as the outer side, since the inner
* are not retained. * columns are not retained.
* *
* An OUTER join like (A LEFT JOIN B ON A.a = B.b) may produce rows with * An OUTER join like (A LEFT JOIN B ON A.a = B.b) may produce rows with
* B.b NULL. These rows may not fit the partitioning conditions imposed on * B.b NULL. These rows may not fit the partitioning conditions imposed on
@ -1686,11 +1687,12 @@ build_joinrel_partition_info(RelOptInfo *joinrel, RelOptInfo *outer_rel,
* expressions from the OUTER side only. However, because all * expressions from the OUTER side only. However, because all
* commonly-used comparison operators are strict, the presence of nulls on * commonly-used comparison operators are strict, the presence of nulls on
* the outer side doesn't cause any problem; they can't match anything at * the outer side doesn't cause any problem; they can't match anything at
* future join levels anyway. Therefore, we track two sets of expressions: * future join levels anyway. Therefore, we track two sets of
* those that authentically partition the relation (partexprs) and those * expressions: those that authentically partition the relation
* that partition the relation with the exception that extra nulls may be * (partexprs) and those that partition the relation with the exception
* present (nullable_partexprs). When the comparison operator is strict, * that extra nulls may be present (nullable_partexprs). When the
* the latter is just as good as the former. * comparison operator is strict, the latter is just as good as the
* former.
*/ */
for (cnt = 0; cnt < partnatts; cnt++) for (cnt = 0; cnt < partnatts; cnt++)
{ {

View File

@ -2161,8 +2161,8 @@ retry1:
/* /*
* If the client requested a newer protocol version or if the client * If the client requested a newer protocol version or if the client
* requested any protocol options we didn't recognize, let them know * requested any protocol options we didn't recognize, let them know
* the newest minor protocol version we do support and the names of any * the newest minor protocol version we do support and the names of
* unrecognized options. * any unrecognized options.
*/ */
if (PG_PROTOCOL_MINOR(proto) > PG_PROTOCOL_MINOR(PG_PROTOCOL_LATEST) || if (PG_PROTOCOL_MINOR(proto) > PG_PROTOCOL_MINOR(PG_PROTOCOL_LATEST) ||
unrecognized_protocol_options != NIL) unrecognized_protocol_options != NIL)
@ -4316,8 +4316,8 @@ BackendInitialize(Port *port)
* *
* postgres: walsender <user> <host> <activity> * postgres: walsender <user> <host> <activity>
* *
* To achieve that, we pass "walsender" as username and username * To achieve that, we pass "walsender" as username and username as dbname
* as dbname to init_ps_display(). XXX: should add a new variant of * to init_ps_display(). XXX: should add a new variant of
* init_ps_display() to avoid abusing the parameters like this. * init_ps_display() to avoid abusing the parameters like this.
*/ */
if (am_walsender) if (am_walsender)

View File

@ -2952,14 +2952,14 @@ ProcessInterrupts(void)
/* /*
* Don't allow query cancel interrupts while reading input from the * Don't allow query cancel interrupts while reading input from the
* client, because we might lose sync in the FE/BE protocol. (Die * client, because we might lose sync in the FE/BE protocol. (Die
* interrupts are OK, because we won't read any further messages from * interrupts are OK, because we won't read any further messages from the
* the client in that case.) * client in that case.)
*/ */
if (QueryCancelPending && QueryCancelHoldoffCount != 0) if (QueryCancelPending && QueryCancelHoldoffCount != 0)
{ {
/* /*
* Re-arm InterruptPending so that we process the cancel request * Re-arm InterruptPending so that we process the cancel request as
* as soon as we're done reading the message. * soon as we're done reading the message.
*/ */
InterruptPending = true; InterruptPending = true;
} }

View File

@ -1591,8 +1591,7 @@ puttuple_common(Tuplesortstate *state, SortTuple *tuple)
case TSS_BUILDRUNS: case TSS_BUILDRUNS:
/* /*
* Save the tuple into the unsorted array (there must be * Save the tuple into the unsorted array (there must be space)
* space)
*/ */
state->memtuples[state->memtupcount++] = *tuple; state->memtuples[state->memtupcount++] = *tuple;
@ -2742,8 +2741,8 @@ dumptuples(Tuplesortstate *state, bool alltuples)
int i; int i;
/* /*
* Nothing to do if we still fit in available memory and have array * Nothing to do if we still fit in available memory and have array slots,
* slots, unless this is the final call during initial run generation. * unless this is the final call during initial run generation.
*/ */
if (state->memtupcount < state->memtupsize && !LACKMEM(state) && if (state->memtupcount < state->memtupsize && !LACKMEM(state) &&
!alltuples) !alltuples)

View File

@ -496,7 +496,8 @@ main(int argc, char **argv)
int c; int c;
int option_index; int option_index;
char *db_name; char *db_name;
uint32 hi, lo; uint32 hi,
lo;
progname = get_progname(argv[0]); progname = get_progname(argv[0]);
set_pglocale_pgservice(argv[0], PG_TEXTDOMAIN("pg_basebackup")); set_pglocale_pgservice(argv[0], PG_TEXTDOMAIN("pg_basebackup"));

View File

@ -55,7 +55,8 @@ garbage_left(enum ARRAY_TYPE isarray, char **scan_length, enum COMPAT_MODE compa
if (INFORMIX_MODE(compat) && **scan_length == '.') if (INFORMIX_MODE(compat) && **scan_length == '.')
{ {
/* skip invalid characters */ /* skip invalid characters */
do { do
{
(*scan_length)++; (*scan_length)++;
} while (isdigit((unsigned char) **scan_length)); } while (isdigit((unsigned char) **scan_length));
} }

View File

@ -569,6 +569,7 @@ pg_SASL_init(PGconn *conn, int payloadlen)
} }
#ifdef USE_SSL #ifdef USE_SSL
/* /*
* Get data for channel binding. * Get data for channel binding.
*/ */
@ -581,8 +582,8 @@ pg_SASL_init(PGconn *conn, int payloadlen)
#endif #endif
/* /*
* Initialize the SASL state information with all the information * Initialize the SASL state information with all the information gathered
* gathered during the initial exchange. * during the initial exchange.
* *
* Note: Only tls-unique is supported for the moment. * Note: Only tls-unique is supported for the moment.
*/ */

View File

@ -34,6 +34,9 @@ AfterTriggerEventList
AfterTriggerShared AfterTriggerShared
AfterTriggerSharedData AfterTriggerSharedData
AfterTriggersData AfterTriggersData
AfterTriggersQueryData
AfterTriggersTableData
AfterTriggersTransData
Agg Agg
AggClauseCosts AggClauseCosts
AggInfo AggInfo
@ -125,7 +128,6 @@ ArrayMetaState
ArrayParseState ArrayParseState
ArrayRef ArrayRef
ArrayRefState ArrayRefState
ArrayRemapInfo
ArrayType ArrayType
AsyncQueueControl AsyncQueueControl
AsyncQueueEntry AsyncQueueEntry
@ -143,7 +145,6 @@ AutoVacOpts
AutoVacuumShmemStruct AutoVacuumShmemStruct
AutoVacuumWorkItem AutoVacuumWorkItem
AutoVacuumWorkItemType AutoVacuumWorkItemType
AutovacWorkItems
AuxProcType AuxProcType
BF_ctx BF_ctx
BF_key BF_key
@ -274,6 +275,8 @@ BuiltinScript
BulkInsertState BulkInsertState
CACHESIGN CACHESIGN
CAC_state CAC_state
CCFastEqualFN
CCHashFN
CEOUC_WAIT_MODE CEOUC_WAIT_MODE
CFuncHashTabEntry CFuncHashTabEntry
CHAR CHAR
@ -302,8 +305,6 @@ CatCache
CatCacheHeader CatCacheHeader
CatalogId CatalogId
CatalogIndexState CatalogIndexState
CCHashFN
CCFastEqualFN
ChangeVarNodes_context ChangeVarNodes_context
CheckPoint CheckPoint
CheckPointStmt CheckPointStmt
@ -344,6 +345,7 @@ ColumnCompareData
ColumnDef ColumnDef
ColumnIOData ColumnIOData
ColumnRef ColumnRef
ColumnsHashData
CombinationGenerator CombinationGenerator
ComboCidEntry ComboCidEntry
ComboCidEntryData ComboCidEntryData
@ -632,9 +634,9 @@ FieldStore
File File
FileFdwExecutionState FileFdwExecutionState
FileFdwPlanState FileFdwPlanState
FileName
FileNameMap FileNameMap
FindSplitData FindSplitData
FixedParallelExecutorState
FixedParallelState FixedParallelState
FixedParamState FixedParamState
FlagMode FlagMode
@ -824,6 +826,10 @@ GatherMergeState
GatherPath GatherPath
GatherState GatherState
Gene Gene
GenerationBlock
GenerationChunk
GenerationContext
GenerationPointer
GenericCosts GenericCosts
GenericXLogState GenericXLogState
GeqoPrivateData GeqoPrivateData
@ -941,6 +947,7 @@ HashPageStat
HashPath HashPath
HashScanOpaque HashScanOpaque
HashScanOpaqueData HashScanOpaqueData
HashScanPosData
HashScanPosItem HashScanPosItem
HashSkewBucket HashSkewBucket
HashState HashState
@ -1021,13 +1028,13 @@ InsertStmt
Instrumentation Instrumentation
Int128AggState Int128AggState
Int8TransTypeData Int8TransTypeData
IntRBTreeNode
InternalDefaultACL InternalDefaultACL
InternalGrant InternalGrant
Interval Interval
IntoClause IntoClause
InvalidationChunk InvalidationChunk
InvalidationListHeader InvalidationListHeader
InvertedWalkNextStep
IpcMemoryId IpcMemoryId
IpcMemoryKey IpcMemoryKey
IpcSemaphoreId IpcSemaphoreId
@ -1217,6 +1224,7 @@ MergeJoinClause
MergeJoinState MergeJoinState
MergePath MergePath
MergeScanSelCache MergeScanSelCache
MetaCommand
MinMaxAggInfo MinMaxAggInfo
MinMaxAggPath MinMaxAggPath
MinMaxExpr MinMaxExpr
@ -1454,13 +1462,18 @@ PLpgSQL_var
PLpgSQL_variable PLpgSQL_variable
PLwdatum PLwdatum
PLword PLword
PLyArrayToOb
PLyCursorObject PLyCursorObject
PLyDatumToOb PLyDatumToOb
PLyDatumToObFunc PLyDatumToObFunc
PLyExceptionEntry PLyExceptionEntry
PLyExecutionContext PLyExecutionContext
PLyObToArray
PLyObToDatum PLyObToDatum
PLyObToDatumFunc PLyObToDatumFunc
PLyObToDomain
PLyObToScalar
PLyObToTransform
PLyObToTuple PLyObToTuple
PLyObject_AsString_t PLyObject_AsString_t
PLyPlanObject PLyPlanObject
@ -1470,12 +1483,11 @@ PLyProcedureKey
PLyResultObject PLyResultObject
PLySRFState PLySRFState
PLySavedArgs PLySavedArgs
PLyScalarToOb
PLySubtransactionData PLySubtransactionData
PLySubtransactionObject PLySubtransactionObject
PLyTransformToOb
PLyTupleToOb PLyTupleToOb
PLyTypeInfo
PLyTypeInput
PLyTypeOutput
PLyUnicode_FromStringAndSize_t PLyUnicode_FromStringAndSize_t
PMINIDUMP_CALLBACK_INFORMATION PMINIDUMP_CALLBACK_INFORMATION
PMINIDUMP_EXCEPTION_INFORMATION PMINIDUMP_EXCEPTION_INFORMATION
@ -1565,12 +1577,13 @@ PartitionDescData
PartitionDispatch PartitionDispatch
PartitionDispatchData PartitionDispatchData
PartitionElem PartitionElem
PartitionKey
PartitionHashBound PartitionHashBound
PartitionKey
PartitionListValue PartitionListValue
PartitionRangeBound PartitionRangeBound
PartitionRangeDatum PartitionRangeDatum
PartitionRangeDatumKind PartitionRangeDatumKind
PartitionScheme
PartitionSpec PartitionSpec
PartitionedChildRelInfo PartitionedChildRelInfo
PasswordType PasswordType
@ -1670,6 +1683,7 @@ Pool
PopulateArrayContext PopulateArrayContext
PopulateArrayState PopulateArrayState
PopulateRecordCache PopulateRecordCache
PopulateRecordsetCache
PopulateRecordsetState PopulateRecordsetState
Port Port
Portal Portal
@ -1781,7 +1795,6 @@ RangeBox
RangeFunction RangeFunction
RangeIOData RangeIOData
RangeQueryClause RangeQueryClause
RangeRemapInfo
RangeSubselect RangeSubselect
RangeTableFunc RangeTableFunc
RangeTableFuncCol RangeTableFuncCol
@ -1794,6 +1807,7 @@ RangeVar
RangeVarGetRelidCallback RangeVarGetRelidCallback
RawColumnDefault RawColumnDefault
RawStmt RawStmt
ReInitializeDSMForeignScan_function
ReScanForeignScan_function ReScanForeignScan_function
ReadBufPtrType ReadBufPtrType
ReadBufferMode ReadBufferMode
@ -1805,8 +1819,6 @@ RecheckForeignScan_function
RecordCacheEntry RecordCacheEntry
RecordCompareData RecordCompareData
RecordIOData RecordIOData
RecordRemapInfo
RecordTypmodMap
RecoveryTargetAction RecoveryTargetAction
RecoveryTargetType RecoveryTargetType
RectBox RectBox
@ -1866,6 +1878,7 @@ ReorderBufferTupleCidEnt
ReorderBufferTupleCidKey ReorderBufferTupleCidKey
ReorderTuple ReorderTuple
RepOriginId RepOriginId
ReparameterizeForeignPathByChild_function
ReplaceVarsFromTargetList_context ReplaceVarsFromTargetList_context
ReplaceVarsNoMatchOption ReplaceVarsNoMatchOption
ReplicaIdentityStmt ReplicaIdentityStmt
@ -2020,9 +2033,10 @@ SharedInvalRelmapMsg
SharedInvalSmgrMsg SharedInvalSmgrMsg
SharedInvalSnapshotMsg SharedInvalSnapshotMsg
SharedInvalidationMessage SharedInvalidationMessage
SharedRecordTableKey
SharedRecordTableEntry SharedRecordTableEntry
SharedRecordTableKey
SharedRecordTypmodRegistry SharedRecordTypmodRegistry
SharedSortInfo
SharedTypmodTableEntry SharedTypmodTableEntry
ShellTypeInfo ShellTypeInfo
ShippableCacheEntry ShippableCacheEntry
@ -2297,9 +2311,10 @@ TupleHashEntryData
TupleHashIterator TupleHashIterator
TupleHashTable TupleHashTable
TupleQueueReader TupleQueueReader
TupleRemapClass
TupleRemapInfo
TupleTableSlot TupleTableSlot
TuplesortInstrumentation
TuplesortMethod
TuplesortSpaceType
Tuplesortstate Tuplesortstate
Tuplestorestate Tuplestorestate
TwoPhaseCallback TwoPhaseCallback
@ -2329,7 +2344,6 @@ UChar
UCharIterator UCharIterator
UCollator UCollator
UConverter UConverter
UEnumeration
UErrorCode UErrorCode
UINT UINT
ULARGE_INTEGER ULARGE_INTEGER
@ -2353,6 +2367,7 @@ UserOpts
VacAttrStats VacAttrStats
VacAttrStatsP VacAttrStatsP
VacuumParams VacuumParams
VacuumRelation
VacuumStmt VacuumStmt
Value Value
ValuesScan ValuesScan
@ -2547,6 +2562,7 @@ bgworker_main_type
binaryheap binaryheap
binaryheap_comparator binaryheap_comparator
bitmapword bitmapword
bits16
bits32 bits32
bits8 bits8
bool bool
@ -2561,7 +2577,6 @@ check_network_data
check_object_relabel_type check_object_relabel_type
check_password_hook_type check_password_hook_type
check_ungrouped_columns_context check_ungrouped_columns_context
chkpass
chr chr
clock_t clock_t
cmpEntriesArg cmpEntriesArg
@ -2612,7 +2627,9 @@ dsa_pointer
dsa_segment_header dsa_segment_header
dsa_segment_index dsa_segment_index
dsa_segment_map dsa_segment_map
dshash_compare_function
dshash_hash dshash_hash
dshash_hash_function
dshash_parameters dshash_parameters
dshash_partition dshash_partition
dshash_table dshash_table