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
* we think the next range is partial. Caller would pass true when
* it is typically run once bulk data loading is done
* we think the next range is partial. Caller would pass true when it
* is typically run once bulk data loading is done
* (brin_summarize_new_values), and false when it is typically the
* result of arbitrarily-scheduled maintenance command (vacuuming).
*/

View File

@ -6586,10 +6586,10 @@ StartupXLOG(void)
else
{
/*
* We used to attempt to go back to a secondary checkpoint
* record here, but only when not in standby_mode. We now
* just fail if we can't read the last checkpoint because
* this allows us to simplify processing around checkpoints.
* We used to attempt to go back to a secondary checkpoint record
* here, but only when not in standby_mode. We now just fail if we
* can't read the last checkpoint because this allows us to
* simplify processing around checkpoints.
*/
ereport(PANIC,
(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")));
/*
* Remember the prior checkpoint's redo ptr for UpdateCheckPointDistanceEstimate()
* Remember the prior checkpoint's redo ptr for
* UpdateCheckPointDistanceEstimate()
*/
PriorRedoPtr = ControlFile->checkPointCopy.redo;
@ -9211,7 +9212,8 @@ CreateRestartPoint(int 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;

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
* default partition if there is one, and otherwise
* rejected.
* default partition if there is one, and otherwise rejected.
*/
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.
* Use the default partition, if there is one.
* part_index < 0 means we failed to find a partition of this parent. Use
* the default partition, if there is one.
*/
if (part_index < 0)
part_index = partdesc->boundinfo->default_index;

View File

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

View File

@ -791,6 +791,7 @@ read_client_first_message(scram_state *state, char *input)
switch (*input)
{
case 'n':
/*
* The client does not support channel binding or has simply
* 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++;
break;
case 'y':
/*
* The client supports channel binding and thinks that the server
* 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++;
break;
case 'p':
/*
* The client requires channel binding. Channel binding type
* 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';
/*
* Compare the value sent by the client with the value expected by
* the server.
* Compare the value sent by the client with the value expected by the
* server.
*/
if (strcmp(channel_binding, b64_message) != 0)
ereport(ERROR,

View File

@ -100,7 +100,8 @@ static struct pam_conv pam_passw_conv = {
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
* pam_passwd_conv_proc */
#endif /* USE_PAM */
@ -914,6 +915,7 @@ CheckSCRAMAuth(Port *port, char *shadow_pass, char **logdetail)
pfree(sasl_mechs);
#ifdef USE_SSL
/*
* Get data for channel binding.
*/
@ -2514,7 +2516,7 @@ CheckLDAPAuth(Port *port)
char *filter;
LDAPMessage *search_message;
LDAPMessage *entry;
char *attributes[] = { LDAP_NO_ATTRS, NULL };
char *attributes[] = {LDAP_NO_ATTRS, NULL};
char *dn;
char *c;
int count;

View File

@ -1795,7 +1795,7 @@ set_upper_references(PlannerInfo *root, Plan *plan, int rtoffset)
static void
set_param_references(PlannerInfo *root, Plan *plan)
{
Assert(IsA(plan, Gather) || IsA(plan, GatherMerge));
Assert(IsA(plan, Gather) ||IsA(plan, GatherMerge));
if (plan->lefttree->extParam)
{

View File

@ -2412,7 +2412,7 @@ apply_projection_to_path(PlannerInfo *root,
* workers can help project. But if there is something that is not
* parallel-safe in the target expressions, then we can't.
*/
if ((IsA(path, GatherPath) || IsA(path, GatherMergePath)) &&
if ((IsA(path, GatherPath) ||IsA(path, GatherMergePath)) &&
is_parallel_safe(root, (Node *) target->exprs))
{
/*
@ -2421,9 +2421,9 @@ apply_projection_to_path(PlannerInfo *root,
* It seems unlikely at present that there could be any other
* references to the subpath, but better safe than sorry.
*
* Note that we don't change the parallel path's cost estimates; it might
* be appropriate to do so, to reflect the fact that the bulk of the
* target evaluation will happen in workers.
* Note that we don't change the parallel path's cost estimates; it
* might be appropriate to do so, to reflect the fact that the bulk of
* the target evaluation will happen in workers.
*/
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
* information from the relcache. We need to copy the contents of the array
* since the relcache entry may not survive after we have closed the
* information from the relcache. We need to copy the contents of the
* array since the relcache entry may not survive after we have closed the
* relation.
*/
part_scheme = (PartitionScheme) palloc0(sizeof(PartitionSchemeData));

View File

@ -873,11 +873,11 @@ build_joinrel_tlist(PlannerInfo *root, RelOptInfo *joinrel,
continue;
/*
* Otherwise, anything in a baserel or joinrel targetlist ought to be a
* Var. Children of a partitioned table may have ConvertRowtypeExpr
* translating whole-row Var of a child to that of the parent. Children
* of an inherited table or subquery child rels can not directly
* participate in a join, so other kinds of nodes here.
* Otherwise, anything in a baserel or joinrel targetlist ought to be
* a Var. Children of a partitioned table may have ConvertRowtypeExpr
* translating whole-row Var of a child to that of the parent.
* Children of an inherited table or subquery child rels can not
* directly participate in a join, so other kinds of nodes here.
*/
if (IsA(var, Var))
{
@ -901,7 +901,7 @@ build_joinrel_tlist(PlannerInfo *root, RelOptInfo *joinrel,
child_expr = (ConvertRowtypeExpr *) childvar;
childvar = (Var *) child_expr->arg;
}
Assert(IsA(childvar, Var) && childvar->varattno == 0);
Assert(IsA(childvar, Var) &&childvar->varattno == 0);
baserel = find_base_rel(root, childvar->varno);
ndx = 0 - baserel->min_attr;
@ -1666,18 +1666,19 @@ build_joinrel_partition_info(RelOptInfo *joinrel, RelOptInfo *outer_rel,
partnatts = joinrel->part_scheme->partnatts;
joinrel->partexprs = (List **) palloc0(sizeof(List *) * partnatts);
joinrel->nullable_partexprs =
(List **) palloc0(sizeof(List *) *partnatts);
(List **) palloc0(sizeof(List *) * partnatts);
/*
* Construct partition keys for the join.
*
* 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 =
* B.b can be regarded as partitioned on A.a or on B.b; they are equivalent.
* partitioned by either key expression. For example, A INNER JOIN B ON
* 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
* partitioned in the same manner as the outer side, since the inner columns
* are not retained.
* partitioned in the same manner as the outer side, since the inner
* columns are not retained.
*
* 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
@ -1686,11 +1687,12 @@ build_joinrel_partition_info(RelOptInfo *joinrel, RelOptInfo *outer_rel,
* expressions from the OUTER side only. However, because all
* 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
* future join levels anyway. Therefore, we track two sets of expressions:
* those that authentically partition the relation (partexprs) and those
* that partition the relation with the exception that extra nulls may be
* present (nullable_partexprs). When the comparison operator is strict,
* the latter is just as good as the former.
* future join levels anyway. Therefore, we track two sets of
* expressions: those that authentically partition the relation
* (partexprs) and those that partition the relation with the exception
* that extra nulls may be present (nullable_partexprs). When the
* comparison operator is strict, the latter is just as good as the
* former.
*/
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
* requested any protocol options we didn't recognize, let them know
* the newest minor protocol version we do support and the names of any
* unrecognized options.
* the newest minor protocol version we do support and the names of
* any unrecognized options.
*/
if (PG_PROTOCOL_MINOR(proto) > PG_PROTOCOL_MINOR(PG_PROTOCOL_LATEST) ||
unrecognized_protocol_options != NIL)
@ -4316,8 +4316,8 @@ BackendInitialize(Port *port)
*
* postgres: walsender <user> <host> <activity>
*
* To achieve that, we pass "walsender" as username and username
* as dbname to init_ps_display(). XXX: should add a new variant of
* To achieve that, we pass "walsender" as username and username as dbname
* to init_ps_display(). XXX: should add a new variant of
* init_ps_display() to avoid abusing the parameters like this.
*/
if (am_walsender)

View File

@ -2952,14 +2952,14 @@ ProcessInterrupts(void)
/*
* Don't allow query cancel interrupts while reading input from the
* client, because we might lose sync in the FE/BE protocol. (Die
* interrupts are OK, because we won't read any further messages from
* the client in that case.)
* interrupts are OK, because we won't read any further messages from the
* client in that case.)
*/
if (QueryCancelPending && QueryCancelHoldoffCount != 0)
{
/*
* Re-arm InterruptPending so that we process the cancel request
* as soon as we're done reading the message.
* Re-arm InterruptPending so that we process the cancel request as
* soon as we're done reading the message.
*/
InterruptPending = true;
}
@ -4495,7 +4495,7 @@ ShowUsage(const char *title)
"!\t%ld kB max resident size\n",
#if defined(__darwin__)
/* in bytes on macOS */
r.ru_maxrss/1024
r.ru_maxrss / 1024
#else
/* in kilobytes on most other platforms */
r.ru_maxrss

View File

@ -474,7 +474,7 @@ GenerationFree(MemoryContext context, void *pointer)
if (chunk->requested_size < chunk->size)
if (!sentinel_ok(pointer, chunk->requested_size))
elog(WARNING, "detected write past chunk end in %s %p",
((MemoryContext)set)->name, chunk);
((MemoryContext) set)->name, chunk);
#endif
#ifdef CLOBBER_FREED_MEMORY
@ -535,7 +535,7 @@ GenerationRealloc(MemoryContext context, void *pointer, Size size)
if (chunk->requested_size < oldsize)
if (!sentinel_ok(pointer, chunk->requested_size))
elog(WARNING, "detected write past chunk end in %s %p",
((MemoryContext)set)->name, chunk);
((MemoryContext) set)->name, chunk);
#endif
/*
@ -699,7 +699,7 @@ GenerationStats(MemoryContext context, int level, bool print,
fprintf(stderr, " ");
fprintf(stderr,
"Generation: %s: %zu total in %zd blocks (%zd chunks); %zu free (%zd chunks); %zu used\n",
((MemoryContext)set)->name, totalspace, nblocks, nchunks, freespace,
((MemoryContext) set)->name, totalspace, nblocks, nchunks, freespace,
nfreechunks, totalspace - freespace);
}

View File

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

View File

@ -496,7 +496,8 @@ main(int argc, char **argv)
int c;
int option_index;
char *db_name;
uint32 hi, lo;
uint32 hi,
lo;
progname = get_progname(argv[0]);
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 == '.')
{
/* skip invalid characters */
do {
do
{
(*scan_length)++;
} while (isdigit((unsigned char) **scan_length));
}

View File

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

View File

@ -6617,7 +6617,7 @@ exec_save_simple_expr(PLpgSQL_expr *expr, CachedPlan *cplan)
if (IsA(tle_expr, Const))
break;
/* Otherwise, it had better be a Param or an outer Var */
Assert(IsA(tle_expr, Param) || (IsA(tle_expr, Var) &&
Assert(IsA(tle_expr, Param) ||(IsA(tle_expr, Var) &&
((Var *) tle_expr)->varno == OUTER_VAR));
/* Descend to the child node */
plan = plan->lefttree;

View File

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