From d7c3b3cbce0ded531f9ed5f2301c2b8a73ff55a8 Mon Sep 17 00:00:00 2001 From: "Andrei V. Lepikhov" Date: Wed, 7 Jan 2026 10:54:42 +0100 Subject: [PATCH 1/6] Fix pgindent script to prevent typedef duplicates The gen-typedefs.sh script accumulated duplicates on each run because it only appended to typedefs.list. Fixed by: - Uncommenting curl to fetch fresh PostgreSQL typedefs (overwrites file) - Adding sort/uniq to remove any internal duplicates - Cleaning up typedefs.list Sorting allow us to stabilise the content in case a struct or enum has been displaced. This ensures repeated script runs produce consistent, deduplicated output. --- utils/pgindent/gen-typedefs.sh | 7 +- utils/pgindent/typedefs.list | 4348 +++++++++++++++----------------- 2 files changed, 2053 insertions(+), 2302 deletions(-) diff --git a/utils/pgindent/gen-typedefs.sh b/utils/pgindent/gen-typedefs.sh index 66c362ed..329ac01b 100755 --- a/utils/pgindent/gen-typedefs.sh +++ b/utils/pgindent/gen-typedefs.sh @@ -1,11 +1,16 @@ #!/bin/bash -#curl https://buildfarm.postgresql.org/cgi-bin/typedefs.pl > typedefs.list +# Fetch PostgreSQL core typedefs from buildfarm +curl https://buildfarm.postgresql.org/cgi-bin/typedefs.pl > typedefs.list +# Extract Spock-specific typedefs from source code and append them grep -nri "typedef struct" ../../ --include="*.c" --include="*.h" | grep -v "{" | awk '{print $3}' >> typedefs.list grep -nri "typedef enum" ../../ --include="*.c" --include="*.h" | grep -v "{" | awk '{print $3}' >> typedefs.list grep -nri "typedef union" ../../ --include="*.c" --include="*.h" | grep -v "{" | awk '{print $3}' >> typedefs.list +# Remove duplicates and sort +sort typedefs.list | uniq > typedefs.list.tmp && mv typedefs.list.tmp typedefs.list + find ../../ -type f \( -name "*.c" -o -name "*.h" \) -print0 \ | xargs -0 pgindent --typedefs typedefs.list diff --git a/utils/pgindent/typedefs.list b/utils/pgindent/typedefs.list index d05b8a10..3a67267e 100644 --- a/utils/pgindent/typedefs.list +++ b/utils/pgindent/typedefs.list @@ -1,13 +1,16 @@ -ACCESS_ALLOWED_ACE -ACL -ACL_SIZE_INFORMATION -AFFIX -ASN1_INTEGER -ASN1_OBJECT -ASN1_OCTET_STRING -ASN1_STRING -ATAlterConstraint -AV + +__m128i +__m512i +__mmask64 +__time64_t +_dev_t +_ino_t +_locale_t +_resultmap +_SPI_connection +_SPI_plan +_stringlist +/* A_ArrayExpr A_Const A_Expr @@ -16,27 +19,37 @@ A_Indices A_Indirection A_Star AbsoluteTime +ACCESS_ALLOWED_ACE +access_vector_t AccessMethodInfo AccessPriv Acl +ACL +ACL_SIZE_INFORMATION AclItem AclMaskHow AclMode AclResult +acquireLocksOnSubLinks_context AcquireSampleRowsFunc +ActionErrCallbackArg ActionList ActiveSnapshotElt +add_nulling_relids_context +addFkConstraintSides AddForeignUpdateTargets_function AddrInfo +adjust_appendrel_attrs_context +AFFIX AffixNode AffixNodeData AfterTriggerEvent AfterTriggerEventChunk AfterTriggerEventData AfterTriggerEventList +AfterTriggersData AfterTriggerShared AfterTriggerSharedData -AfterTriggersData AfterTriggersQueryData AfterTriggersTableData AfterTriggersTransData @@ -45,6 +58,8 @@ AggClauseCosts AggClauseInfo AggInfo AggPath +Aggref +AggregateInstrumentation AggSplit AggState AggStatePerAgg @@ -54,18 +69,16 @@ AggStatePerPhase AggStatePerTrans AggStrategy AggTransInfo -Aggref -AggregateInstrumentation AlenState Alias +AllocateDesc +AllocateDescKind AllocBlock AllocFreeListLink AllocPointer AllocSet AllocSetContext AllocSetFreeList -AllocateDesc -AllocateDescKind AlterCollationStmt AlterDatabaseRefreshCollStmt AlterDatabaseSetStmt @@ -73,6 +86,7 @@ AlterDatabaseStmt AlterDefaultPrivilegesStmt AlterDomainStmt AlterDomainType +AlteredTableInfo AlterEnumStmt AlterEventTrigStmt AlterExtensionContentsStmt @@ -80,10 +94,11 @@ AlterExtensionStmt AlterFdwStmt AlterForeignServerStmt AlterFunctionStmt +AlternativeSubPlan AlterObjectDependsStmt AlterObjectSchemaStmt -AlterOpFamilyStmt AlterOperatorStmt +AlterOpFamilyStmt AlterOwnerStmt AlterPolicyStmt AlterPublicationAction @@ -96,9 +111,6 @@ AlterStatsStmt AlterSubscriptionStmt AlterSubscriptionType AlterSystemStmt -AlterTSConfigType -AlterTSConfigurationStmt -AlterTSDictionaryStmt AlterTableCmd AlterTableMoveAllStmt AlterTablePass @@ -106,12 +118,39 @@ AlterTableSpaceOptionsStmt AlterTableStmt AlterTableType AlterTableUtilityContext +AlterTSConfigType +AlterTSConfigurationStmt +AlterTSDictionaryStmt AlterTypeRecurseParams AlterTypeStmt AlterUserMappingStmt -AlteredTableInfo -AlternativeSubPlan +amadjustmembers_function +ambeginscan_function +ambuild_function +ambuildempty_function +ambuildphasename_function +ambulkdelete_function +amcanreturn_function AmcheckOptions +amcostestimate_function +amendscan_function +amestimateparallelscan_function +amgetbitmap_function +amgettreeheight_function +amgettuple_function +aminitparallelscan_function +aminsert_function +aminsertcleanup_function +ammarkpos_function +amoptions_function +amparallelrescan_function +amproperty_function +amrescan_function +amrestrpos_function +amtranslate_cmptype_function +amtranslate_strategy_function +amvacuumcleanup_function +amvalidate_function AnalyzeAttrComputeStatsFunc AnalyzeAttrFetchFunc AnalyzeForeignTable_function @@ -123,7 +162,10 @@ AppendPath AppendRelInfo AppendState ApplyErrorCallbackArg +ApplyExecState ApplyExecutionData +ApplyMIState +ApplyReplayEntryData ApplySubXactData Archive ArchiveCheckConfiguredCB @@ -136,11 +178,13 @@ ArchiveModuleCallbacks ArchiveModuleInit ArchiveModuleState ArchiveOpts +ArchiverOutput +ArchiverStage ArchiveShutdownCB ArchiveStartupCB ArchiveStreamState -ArchiverOutput -ArchiverStage +array_iter +array_unnest_fctx ArrayAnalyzeExtraData ArrayBuildState ArrayBuildStateAny @@ -157,84 +201,56 @@ ArraySortCachedInfo ArraySubWorkspace ArrayToken ArrayType +ASN1_INTEGER +ASN1_OBJECT +ASN1_OCTET_STRING +ASN1_STRING +assign_collations_context +astreamer +astreamer_archive_context +astreamer_extractor +astreamer_gzip_decompressor +astreamer_gzip_writer +astreamer_lz4_frame +astreamer_member +astreamer_ops +astreamer_plain_writer +astreamer_recovery_injector +astreamer_tar_archiver +astreamer_tar_parser +astreamer_verify +astreamer_zstd_frame AsyncQueueControl AsyncQueueEntry AsyncRequest +ATAlterConstraint AttInMetadata -AttStatsSlot AttoptCacheEntry AttoptCacheKey -AttrDefInfo AttrDefault +AttrDefInfo +AttributeOpts AttrMap AttrMissing AttrNumber -AttributeOpts +AttStatsSlot +auth_password_hook_typ AuthRequest AuthToken AutoPrewarmReadStreamData AutoPrewarmSharedState +autovac_table AutoVacOpts AutoVacuumShmemStruct AutoVacuumWorkItem AutoVacuumWorkItemType -BF_ctx -BF_key -BF_word -BF_word_signed -BIGNUM -BIO -BIO_METHOD -BITVECP -BMS_Comparison -BMS_Membership -BN_CTX -BOOL -BOOLEAN -BOX -BTArrayKeyInfo -BTBuildState -BTCallbackState -BTCycleId -BTDedupInterval -BTDedupState -BTDedupStateData -BTDeletedPageData -BTIndexStat -BTInsertState -BTInsertStateData -BTLeader -BTMetaPageData -BTOneVacInfo -BTOptions -BTPS_State -BTPageOpaque -BTPageOpaqueData -BTPageStat -BTPageState -BTParallelScanDesc -BTPendingFSM -BTReadPageState -BTScanInsert -BTScanInsertData -BTScanKeyPreproc -BTScanOpaque -BTScanOpaqueData -BTScanPosData -BTScanPosItem -BTShared -BTSortArrayContext -BTSpool -BTStack -BTStackData -BTVacInfo -BTVacState -BTVacuumPosting -BTVacuumPostingData -BTWriteState -BUF_MEM -BYTE -BY_HANDLE_FILE_INFORMATION +AV +av_relation +avc_cache +avl_dbase +avl_node +avl_tree +avw_dbase BackendParameters BackendStartupData BackendState @@ -244,24 +260,52 @@ BackgroundWorker BackgroundWorkerArray BackgroundWorkerHandle BackgroundWorkerSlot +backslashResult +backup_file_entry +backup_file_hash +backup_manifest_info +backup_manifest_option +backup_wal_range BackupState Barrier +base_yy_extra_type +basebackup_options BaseBackupCmd BaseBackupTargetHandle BaseBackupTargetType +bbsink +bbsink_copystream +bbsink_gzip +bbsink_lz4 +bbsink_ops +bbsink_server +bbsink_shell +bbsink_state +bbsink_throttle +bbsink_zstd BeginDirectModify_function BeginForeignInsert_function BeginForeignModify_function BeginForeignScan_function BeginSampleScan_function BernoulliSamplerData -BgWorkerStartTime +BF_ctx +BF_key +BF_word +BF_word_signed BgwHandleStatus +bgworker_main_type +BgWorkerStartTime +bh_node_type +BIGNUM BinaryArithmFunc +binaryheap +binaryheap_comparator BinaryUpgradeClassOidItem BindParamCbData +BIO +BIO_METHOD BipartiteMatchState -BitString BitmapAnd BitmapAndPath BitmapAndState @@ -276,13 +320,23 @@ BitmapOr BitmapOrPath BitmapOrState Bitmapset +bitmapword +bits16 +bits32 +bits8 +BitString +BITVECP Block +BlockedProcData +BlockedProcsData BlockId BlockIdData BlockInfoRecord BlockNumber BlockRangeReadStreamPrivate BlockRefTable +blockreftable_hash +blockreftable_iterator BlockRefTableBuffer BlockRefTableChunk BlockRefTableEntry @@ -292,9 +346,8 @@ BlockRefTableSerializedEntry BlockRefTableWriter BlockSampler BlockSamplerData -BlockedProcData -BlockedProcsData BlocktableEntry +bloom_filter BloomBuildState BloomFilter BloomMetaPageData @@ -307,13 +360,22 @@ BloomScanOpaqueData BloomSignatureWord BloomState BloomTuple +BMS_Comparison +BMS_Membership +BN_CTX +BOOL BoolAggState +Boolean +BOOLEAN +BooleanTest BoolExpr BoolExprType +boolKEY BoolTestType -Boolean -BooleanTest +BOX BpChar +brin_column_state +brin_serialize_callback_type BrinBuildState BrinDesc BrinInsertState @@ -330,28 +392,71 @@ BrinSpecialSpace BrinStatsData BrinTuple BrinValues -BtreeCheckState -BtreeLastVisibleEntry -BtreeLevel -Bucket -BufFile -Buffer -BufferAccessStrategy -BufferAccessStrategyType -BufferCacheNumaContext -BufferCacheNumaRec -BufferCacheOsPagesContext -BufferCacheOsPagesRec -BufferCachePagesContext -BufferCachePagesRec -BufferDesc -BufferDescPadded +BTArrayKeyInfo +BTBuildState +BTCallbackState +BTCycleId +BTDedupInterval +BTDedupState +BTDedupStateData +BTDeletedPageData +BTIndexStat +BTInsertState +BTInsertStateData +BTLeader +BTMetaPageData +BTOneVacInfo +BTOptions +BTPageOpaque +BTPageOpaqueData +BTPageStat +BTPageState +BTParallelScanDesc +BTPendingFSM +BTPS_State +BTReadPageState +btree_gin_convert_function +btree_gin_leftmost_function +BtreeCheckState +BtreeLastVisibleEntry +BtreeLevel +BTScanInsert +BTScanInsertData +BTScanKeyPreproc +BTScanOpaque +BTScanOpaqueData +BTScanPosData +BTScanPosItem +BTShared +BTSortArrayContext +BTSpool +BTStack +BTStackData +BTVacInfo +BTVacState +BTVacuumPosting +BTVacuumPostingData +BTWriteState +Bucket +BUF_MEM +Buffer +BufferAccessStrategy +BufferAccessStrategyType +BufferCacheNumaContext +BufferCacheNumaRec +BufferCacheOsPagesContext +BufferCacheOsPagesRec +BufferCachePagesContext +BufferCachePagesRec +BufferDesc +BufferDescPadded BufferHeapTupleTableSlot BufferLookupEnt BufferManagerRelation BufferStrategyControl BufferTag BufferUsage +BufFile BuildAccumulator BuiltinScript BulkInsertState @@ -360,32 +465,11 @@ BulkWriteBuffer BulkWriteState BumpBlock BumpContext -CACHESIGN +BY_HANDLE_FILE_INFORMATION +BYTE +bytea CAC_state -CCFastEqualFN -CCHashFN -CEOUC_WAIT_MODE -CFuncHashTabEntry -CHAR -CHECKPOINT -CHKVAL -CIRCLE -CMPDAffix -CONTEXT -COP -CRITICAL_SECTION -CRSSnapshotAction -CState -CTECycleClause -CTEMaterialize -CTESearchClause -CURL -CURLM -CURLMcode -CURLMsg -CURLcode -CURLoption -CV +cached_re_str CachedExpression CachedFunction CachedFunctionCompileCallback @@ -394,32 +478,57 @@ CachedFunctionHashEntry CachedFunctionHashKey CachedPlan CachedPlanSource +CACHESIGN CallContext CallStmt CancelRequestPacket +canonicalize_state Cardinality CaseExpr CaseKind CaseTestExpr CaseWhen Cash +cashKEY CastInfo -CatCInProgress -CatCList -CatCTup -CatCache -CatCacheHeader CatalogId +catalogid_hash CatalogIdMapEntry CatalogIndexState +CatCache +CatCacheHeader +CatCInProgress +CatCList +CatCTup +cb_cleanup_dir +cb_options +cb_tablespace +cb_tablespace_mapping +CCFastEqualFN +CCHashFN +CEOUC_WAIT_MODE +CFuncHashTabEntry ChangeVarNodes_callback ChangeVarNodes_context +CHAR +char16_t +char32_t +check_agg_arguments_context +check_function_callback +check_network_data +check_object_relabel_type +check_password_hook_type CheckPoint -CheckPointStmt -CheckpointStatsData +CHECKPOINT CheckpointerRequest CheckpointerShmemStruct +CheckpointStatsData +CheckPointStmt +child_process_kind +CHKVAL +chr Chromosome +CIRCLE CkptSortItem CkptTsStatus ClientAuthentication_hook_type @@ -437,7 +546,10 @@ ClusterInfo ClusterParams ClusterStmt CmdType +CMPDAffix +cmpEntriesArg CoalesceExpr +codes_t CoerceParamHook CoerceToDomain CoerceToDomainValue @@ -446,14 +558,18 @@ CoercionContext CoercionForm CoercionPathType CollAliasData -CollInfo -CollParam CollateClause CollateExpr CollateStrength +collation_cache_entry +collation_cache_hash CollectedATSubcmd CollectedCommand CollectedCommandType +CollInfo +CollParam +color +colormaprange ColorTrgm ColorTrgmInfo ColumnCompareData @@ -478,6 +594,7 @@ CommitTimestampShared CommonEntry CommonTableExpr CompactAttribute +compare_context CompareScalarsContext CompareType CompiledExprState @@ -488,35 +605,51 @@ CompressFileHandle CompressionLocation CompressorState ComputeXidHorizonsResult +ConditionalStack ConditionVariable ConditionVariableMinimallyPadded -ConditionalStack +config_handle +config_var_value ConfigData ConfigVariable ConflictTupleInfo ConflictType +conn_errorMessage_func +conn_oauth_client_id_func +conn_oauth_client_secret_func +conn_oauth_discovery_uri_func +conn_oauth_issuer_id_func +conn_oauth_scope_func +conn_sasl_state_func ConnCacheEntry ConnCacheKey +ConnectionStateEnum +ConnectionTiming ConnParams ConnStatusType ConnType -ConnectionStateEnum -ConnectionTiming ConsiderSplitContext Const -ConstrCheck -ConstrType Constraint ConstraintCategory ConstraintInfo ConstraintsSetStmt +ConstrCheck +ConstrType +contain_aggs_of_level_context +contain_placeholder_references_context +CONTEXT ControlData ControlFileData -ConvInfo -ConvProcInfo ConversionLocation +convert_testexpr_context ConvertRowtypeExpr +ConvInfo +ConvProcInfo CookedConstraint +COP +copy_data_dest_cb +copy_data_source_cb CopyDest CopyFormatOptions CopyFromRoutine @@ -534,15 +667,25 @@ CopyStmt CopyToRoutine CopyToState CopyToStateData +core_yy_extra_type +core_yyscan_t +core_YYSTYPE +corrupt_items Cost +cost_qual_eval_context CostSelector +count_param_references_context Counters CoverExt CoverPos +cp_hash_func +create_upper_paths_hook_type CreateAmStmt CreateCastStmt CreateConversionStmt +createdb_failure_params CreateDBRelInfo +CreatedbStmt CreateDBStrategy CreateDomainStmt CreateEnumStmt @@ -573,14 +716,30 @@ CreateTableSpaceStmt CreateTransformStmt CreateTrigStmt CreateUserMappingStmt -CreatedbStmt CredHandle +CRITICAL_SECTION +crosstab_cat_desc +crosstab_HashEnt +CRSSnapshotAction +CState +CTECycleClause CteItem +CTEMaterialize CteScan CteScanState +CTESearchClause CteState CtlCommand CtxtHandle +CURL +curl_infotype +curl_socket_t +curl_version_info_data +CURLcode +CURLM +CURLMcode +CURLMsg +CURLoption CurrentOfExpr CustomExecMethods CustomOutPtrType @@ -588,80 +747,100 @@ CustomPath CustomScan CustomScanMethods CustomScanState +CV CycleCtr -DBState -DCHCacheEntry -DEADLOCK_INFO -DECountItem -DH -DIR -DNSServiceErrorType -DNSServiceRef -DR_copy -DR_intorel -DR_printtup -DR_sqlfunction -DR_transientrel -DSMREntryType -DSMRegistryCtxStruct -DSMRegistryEntry -DWORD +DatabaseInfo DataDirSyncMethod DataDumperPtr DataPageDeleteStack +datapagemap_iterator_t +datapagemap_t DataTypesUsageChecks DataTypesUsageVersionCheck -DatabaseInfo DateADT +dateKEY DateTimeErrorExtra +datetkn Datum DatumTupleFields DbInfo DbInfoArr DbLocaleInfo -DeClonePtrType +DBState +dce_uuid_t +DCHCacheEntry +dclist_head +DEADLOCK_INFO DeadLockState DeallocateStmt +decimal DeclareCursorStmt +DeClonePtrType DecodedBkpBlock DecodedXLogRecord DecodingOutputState +DECountItem +DefaultACLInfo DefElem DefElemAction -DefaultACLInfo DefineStmt DefnDumperPtr DeleteStmt +deparse_columns +deparse_context +deparse_expr_cxt +deparse_namespace DependencyGenerator DependencyGeneratorData DependencyType +derives_hash DeserialIOData DestReceiver -DictISpell +dev_t +DH DictInt +DictISpell DictSimple DictSnowball DictSubState DictSyn DictThesaurus DimensionInfo +DIR DirectoryMethodData DirectoryMethodFile DisableTimeoutParams +disassembledLeaf DiscardMode DiscardStmt DispatchOption DistanceValue DistinctExpr -DoState -DoStmt +dlist_head +dlist_iter +dlist_mutable_iter +dlist_node +dm_code +dm_codes +dm_letter +dm_node +DNSServiceErrorType +DNSServiceRef DocRepresentation DomainConstraintCache DomainConstraintRef DomainConstraintState DomainConstraintType DomainIOData -DropBehavior +DoState +DoStmt +DR_copy +DR_intorel +DR_printtup +DR_sqlfunction +DR_transientrel +DropBehavior +DropdbStmt DropOwnedStmt DropReplicationSlotCmd DropRoleStmt @@ -669,36 +848,65 @@ DropStmt DropSubscriptionStmt DropTableSpaceStmt DropUserMappingStmt -DropdbStmt -DumpComponents -DumpId -DumpOptions -DumpSignalInformation +ds_state +dsa_area +dsa_area_control +dsa_area_pool +dsa_area_span +dsa_handle +dsa_pointer +dsa_pointer_atomic +dsa_segment_header +dsa_segment_index +dsa_segment_map +dshash_compare_function +dshash_copy_function +dshash_hash +dshash_hash_function +dshash_parameters +dshash_partition +dshash_seq_status +dshash_table +dshash_table_control +dshash_table_handle +dshash_table_item +dsm_control_header +dsm_control_item +dsm_handle +dsm_op +dsm_segment +dsm_segment_detach_callback +DSMRegistryCtxStruct +DSMRegistryEntry +DSMREntryType DumpableAcl DumpableObject DumpableObjectType DumpableObjectWithAcl +DumpComponents +DumpCtx +DumpId +DumpOptions +DumpSignalInformation +duration +DWORD DynamicFileList DynamicZoneAbbrev +EachState +ean13 +eary +ec_matches_callback_type +ec_member_foreign_arg +ec_member_matches_arg ECDerivesEntry ECDerivesKey -EDGE -ENGINE -EOM_flatten_into_method -EOM_get_flat_size_method -EPQState -EPlan -EState -EStatus -EVP_CIPHER -EVP_CIPHER_CTX -EVP_MD -EVP_MD_CTX -EVP_PKEY -EachState Edge +EDGE EditableObjectType +element_type ElementsState +eLogType +emit_log_hook_type EnableTimeoutParams EndDataPtrType EndDirectModify_function @@ -709,21 +917,29 @@ EndLOPtrType EndLOsPtrType EndOfWalRecoveryInfo EndSampleScan_function +ENGINE EnumItem EolType -EphemeralNameRelationType +EOM_flatten_into_method +EOM_get_flat_size_method EphemeralNamedRelation EphemeralNamedRelationData EphemeralNamedRelationMetadata EphemeralNamedRelationMetadataData +EphemeralNameRelationType +EPlan +EPQState EquivalenceClass EquivalenceMember EquivalenceMemberIterator ErrorContextCallback ErrorData ErrorSaveContext +EState +EStatus EstimateDSMForeignScan_function EstimationInfo +eval_const_expressions_context EventTriggerCacheEntry EventTriggerCacheItem EventTriggerCacheStateType @@ -731,8 +947,14 @@ EventTriggerData EventTriggerEvent EventTriggerInfo EventTriggerQueryState +EVP_CIPHER +EVP_CIPHER_CTX +EVP_MD +EVP_MD_CTX +EVP_PKEY ExceptionLabelMap ExceptionMap +exec_thread_arg ExecAuxRowMark ExecEvalBoolSubroutine ExecEvalSubroutine @@ -751,17 +973,23 @@ ExecScanRecheckMtd ExecStatus ExecStatusType ExecuteStmt +execution_state ExecutorCheckPerms_hook_type ExecutorEnd_hook_type ExecutorFinish_hook_type ExecutorRun_hook_type ExecutorStart_hook_type +exit_function ExpandedArrayHeader ExpandedObjectHeader ExpandedObjectMethods ExpandedRange ExpandedRecordFieldInfo ExpandedRecordHeader +explain_get_index_name_hook_type +explain_per_node_hook_type +explain_per_plan_hook_type +explain_validate_options_hook_type ExplainDirectModify_function ExplainExtensionOption ExplainForeignModify_function @@ -776,8 +1004,8 @@ ExplainWorkersState ExportedSnapshot Expr ExprContext -ExprContextCallbackFunction ExprContext_CB +ExprContextCallbackFunction ExprDoneCond ExprEvalOp ExprEvalOpLookup @@ -792,54 +1020,83 @@ ExtensibleNodeMethods ExtensionControlFile ExtensionInfo ExtensionVersionInfo -FDWCollateState -FD_SET -FILE -FILETIME -FPI -FSMAddress -FSMPage -FSMPageData +f_smgr +FailoverSlotFilter +FailoverSlotFilterKey FakeRelCacheEntry FakeRelCacheEntryData +fasthash_state FastPathStrongRelationLockData +fd_set +FD_SET +FDWCollateState FdwInfo FdwRoutine +fe_oauth_state +fe_scram_state +fe_scram_state_enum +fetch_range_request FetchDirection FetchDirectionKeywords FetchStmt FieldSelect FieldStore File +FILE +file_action_t +file_content_type_t +file_entry_t +file_type_t FileBackupMethod FileFdwExecutionState FileFdwPlanState +filehash_hash +filehash_iterator +filemap_t FileNameMap FileSet FileTag +FILETIME +fill_string_relopt FilterCommandType FilterObjectType FilterStateData +finalize_primnode_context FinalPathExtraData +find_dependent_phvs_context +find_expr_references_context FindColsContext FindSplitData FindSplitStrat +fireRIRonSubLink_context First +fix_join_expr_context +fix_scan_expr_context +fix_upper_expr_context +fix_windowagg_cond_context FixedParallelExecutorState FixedParallelState FixedParamState FlagMode +flatten_join_alias_vars_context +flatten_rtes_walker_context Float +float4 +float4KEY +float8 +float8KEY +floating_decimal_32 +floating_decimal_64 FlushPosition +fmgr_hook_type FmgrBuiltin FmgrHookEventType FmgrInfo ForBothCellState ForBothState ForEachState -ForFiveState -ForFourState -ForThreeState +foreign_glob_cxt +foreign_loc_cxt ForeignAsyncConfigureWait_function ForeignAsyncNotify_function ForeignAsyncRequest_function @@ -853,66 +1110,9 @@ ForeignServer ForeignServerInfo ForeignTable ForeignTruncateInfo +ForFiveState +ForFourState ForkNumber -FormData_pg_aggregate -FormData_pg_am -FormData_pg_amop -FormData_pg_amproc -FormData_pg_attrdef -FormData_pg_attribute -FormData_pg_auth_members -FormData_pg_authid -FormData_pg_cast -FormData_pg_class -FormData_pg_collation -FormData_pg_constraint -FormData_pg_conversion -FormData_pg_database -FormData_pg_default_acl -FormData_pg_depend -FormData_pg_enum -FormData_pg_event_trigger -FormData_pg_extension -FormData_pg_foreign_data_wrapper -FormData_pg_foreign_server -FormData_pg_foreign_table -FormData_pg_index -FormData_pg_inherits -FormData_pg_language -FormData_pg_largeobject -FormData_pg_largeobject_metadata -FormData_pg_namespace -FormData_pg_opclass -FormData_pg_operator -FormData_pg_opfamily -FormData_pg_partitioned_table -FormData_pg_policy -FormData_pg_proc -FormData_pg_publication -FormData_pg_publication_namespace -FormData_pg_publication_rel -FormData_pg_range -FormData_pg_replication_origin -FormData_pg_rewrite -FormData_pg_sequence -FormData_pg_sequence_data -FormData_pg_shdepend -FormData_pg_statistic -FormData_pg_statistic_ext -FormData_pg_statistic_ext_data -FormData_pg_subscription -FormData_pg_subscription_rel -FormData_pg_tablespace -FormData_pg_transform -FormData_pg_trigger -FormData_pg_ts_config -FormData_pg_ts_config_map -FormData_pg_ts_dict -FormData_pg_ts_parser -FormData_pg_ts_template -FormData_pg_type -FormData_pg_user_mapping -FormExtraData_pg_attribute Form_pg_aggregate Form_pg_am Form_pg_amop @@ -972,70 +1172,121 @@ Form_pg_ts_template Form_pg_type Form_pg_user_mapping FormatNode -FreeBlockNumberArray -FreeListData -FreePageBtree -FreePageBtreeHeader -FreePageBtreeInternalKey -FreePageBtreeLeafKey -FreePageBtreeSearchResult -FreePageManager -FreePageSpanLeader -From -FromCharDateMode -FromExpr -FullTransactionId -FuncCall -FuncCallContext -FuncCandidateList -FuncDetailCode -FuncExpr -FuncInfo -FuncLookupError -FunctionCallInfo -FunctionCallInfoBaseData -FunctionParameter -FunctionParameterMode -FunctionScan -FunctionScanPerFuncState -FunctionScanState -FuzzyAttrMatchState -GBT_NUMKEY -GBT_NUMKEY_R -GBT_VARKEY -GBT_VARKEY_R -GENERAL_NAME -GISTBuildBuffers -GISTBuildState -GISTDeletedPageContents -GISTENTRY -GISTInsertStack -GISTInsertState -GISTIntArrayBigOptions -GISTIntArrayOptions -GISTNodeBuffer -GISTNodeBufferPage -GISTPageOpaque -GISTPageOpaqueData -GISTPageSplitInfo -GISTSTATE -GISTScanOpaque -GISTScanOpaqueData -GISTSearchHeapItem -GISTSearchItem -GISTTYPE -GIST_SPLITVEC -GMReaderTupleBuffer -GROUP -GUCHashEntry -GV +FormData_pg_aggregate +FormData_pg_am +FormData_pg_amop +FormData_pg_amproc +FormData_pg_attrdef +FormData_pg_attribute +FormData_pg_auth_members +FormData_pg_authid +FormData_pg_cast +FormData_pg_class +FormData_pg_collation +FormData_pg_constraint +FormData_pg_conversion +FormData_pg_database +FormData_pg_default_acl +FormData_pg_depend +FormData_pg_enum +FormData_pg_event_trigger +FormData_pg_extension +FormData_pg_foreign_data_wrapper +FormData_pg_foreign_server +FormData_pg_foreign_table +FormData_pg_index +FormData_pg_inherits +FormData_pg_language +FormData_pg_largeobject +FormData_pg_largeobject_metadata +FormData_pg_namespace +FormData_pg_opclass +FormData_pg_operator +FormData_pg_opfamily +FormData_pg_partitioned_table +FormData_pg_policy +FormData_pg_proc +FormData_pg_publication +FormData_pg_publication_namespace +FormData_pg_publication_rel +FormData_pg_range +FormData_pg_replication_origin +FormData_pg_rewrite +FormData_pg_sequence +FormData_pg_sequence_data +FormData_pg_shdepend +FormData_pg_statistic +FormData_pg_statistic_ext +FormData_pg_statistic_ext_data +FormData_pg_subscription +FormData_pg_subscription_rel +FormData_pg_tablespace +FormData_pg_transform +FormData_pg_trigger +FormData_pg_ts_config +FormData_pg_ts_config_map +FormData_pg_ts_dict +FormData_pg_ts_parser +FormData_pg_ts_template +FormData_pg_type +FormData_pg_user_mapping +FormData_spock_depend +FormExtraData_pg_attribute +ForThreeState +FPI +FreeBlockNumberArray +freefunc +FreeListData +FreePageBtree +FreePageBtreeHeader +FreePageBtreeInternalKey +FreePageBtreeLeafKey +FreePageBtreeSearchResult +FreePageManager +FreePageSpanLeader +From +FromCharDateMode +FromExpr +fsec_t +FSMAddress +FSMPage +FSMPageData +FullTransactionId +FuncCall +FuncCallContext +FuncCandidateList +FuncDetailCode +FuncExpr +FuncInfo +FuncLookupError +FunctionCallInfo +FunctionCallInfoBaseData +FunctionParameter +FunctionParameterMode +FunctionScan +FunctionScanPerFuncState +FunctionScanState +FuzzyAttrMatchState Gather GatherMerge GatherMergePath GatherMergeState GatherPath GatherState +GBT_NUMKEY +GBT_NUMKEY_R +GBT_VARKEY +GBT_VARKEY_R +gbt_vsrt_arg +gbtree_ninfo +gbtree_vinfo Gene +GENERAL_NAME +generate_series_fctx +generate_series_numeric_fctx +generate_series_timestamp_fctx +generate_series_timestamptz_fctx +generate_subscripts_fctx GeneratePruningStepsContext GenerationBlock GenerationContext @@ -1044,6 +1295,10 @@ GenericCosts GenericXLogPageData GenericXLogState GeqoPrivateData +get_attavgwidth_hook_type +get_index_stats_hook_type +get_relation_info_hook_type +get_relation_stats_hook_type GetForeignJoinPaths_function GetForeignModifyBatchSize_function GetForeignPaths_function @@ -1052,7 +1307,8 @@ GetForeignRelSize_function GetForeignRowMarkType_function GetForeignUpperPaths_function GetState -GiSTOptions +gid_t +gin_leafpage_items_state GinBtree GinBtreeData GinBtreeDataLeafInsertData @@ -1088,44 +1344,97 @@ GinTernaryValue GinTuple GinTupleCollector GinVacuumState +ginxlogCreatePostingTree +ginxlogDeleteListPages +ginxlogDeletePage +ginxlogInsert +ginxlogInsertDataInternal +ginxlogInsertEntry +ginxlogInsertListPage +ginxlogRecompressDataLeaf +ginxlogSplit +ginxlogUpdateMeta +ginxlogVacuumDataLeafPage +GIST_SPLITVEC +GISTBuildBuffers GistBuildMode +GISTBuildState +GISTDeletedPageContents +GISTENTRY GistEntryVector GistHstoreOptions GistInetKey +GISTInsertStack +GISTInsertState +GISTIntArrayBigOptions +GISTIntArrayOptions +GISTNodeBuffer +GISTNodeBufferPage GistNSN GistOptBufferingMode +GiSTOptions +GISTPageOpaque +GISTPageOpaqueData +GISTPageSplitInfo +GISTScanOpaque +GISTScanOpaqueData +GISTSearchHeapItem +GISTSearchItem GistSortedBuildLevelState GistSplitUnion GistSplitVector +GISTSTATE GistTsVectorOptions +GISTTYPE GistVacState +gistxlogDelete +gistxlogPage +gistxlogPageDelete +gistxlogPageReuse +gistxlogPageSplit +gistxlogPageUpdate GlobalTransaction GlobalVisHorizonKind GlobalVisState +GMReaderTupleBuffer GrantRoleOptions GrantRoleStmt GrantStmt GrantTargetType Group +GROUP GroupByOrdering GroupClause -GroupPath -GroupPathExtraData -GroupResultPath -GroupState -GroupVarInfo +grouping_sets_data GroupingExprInfo GroupingFunc GroupingSet GroupingSetData GroupingSetKind GroupingSetsPath +GroupPath +GroupPathExtraData +GroupProgressTupDescColumns +GroupResultPath +GroupState +GroupVarInfo +gseg_picksplit_item +gss_buffer_desc +gss_cred_id_t +gss_cred_usage_t +gss_ctx_id_t +gss_key_value_element_desc +gss_key_value_set_desc +gss_name_t +gss_OID_set +gtrgm_consistent_cache GucAction GucBoolAssignHook GucBoolCheckHook GucContext GucEnumAssignHook GucEnumCheckHook +GUCHashEntry GucIntAssignHook GucIntCheckHook GucRealAssignHook @@ -1136,37 +1445,23 @@ GucStack GucStackState GucStringAssignHook GucStringCheckHook +GV +gzFile GzipCompressorState HANDLE -HASHACTION -HASHBUCKET -HASHCTL -HASHELEMENT -HASHHDR -HASHSEGMENT -HASH_SEQ_STATUS -HE -HEntry -HIST_ENTRY -HKEY -HLOCAL -HMAC_CTX -HMODULE -HOldEntry -HRESULT -HSParser -HSpool -HStore -HTAB -HTSV_Result -HV Hash +HASH_SEQ_STATUS +HASHACTION HashAggBatch HashAggSpill HashAllocFunc +HASHBUCKET HashBuildState HashCompareFunc HashCopyFunc +HASHCTL +HASHELEMENT +HASHHDR HashIndexStat HashInstrumentation HashJoin @@ -1186,13 +1481,16 @@ HashScanOpaque HashScanOpaqueData HashScanPosData HashScanPosItem +HASHSEGMENT HashSkewBucket HashState HashValueFunc HbaLine +HE HeadlineJsonState HeadlineParsedText HeadlineWordEntry +heap_page_items_state HeapCheckContext HeapCheckReadStreamData HeapPageFreeze @@ -1206,36 +1504,45 @@ HeapTupleFreeze HeapTupleHeader HeapTupleHeaderData HeapTupleTableSlot +help_handler +HEntry +HIST_ENTRY HistControl +HKEY +hlCheck +HLOCAL +HMAC_CTX +HMODULE +HOldEntry HotStandbyState +HRESULT +HSParser +HSpool +HStore +hstoreCheckKeyLen_t +hstoreCheckValLen_t +hstorePairs_t +hstoreUniquePairs_t +hstoreUpgrade_t +HTAB +HTSV_Result +HV +hyperLogLogState I32 ICU_Convert_Func ID -INFIX -INT128 -INTERFACE_INFO -IO -IOContext -IOFuncSelector -IOObject -IOOp -IO_STATUS_BLOCK -IPCompareMethod -ITEM -IV -IdentLine IdentifierLookup IdentifySystemCmd +IdentLine IfStackElem +ifState +import_error_callback_arg +ImportForeignSchema_function ImportForeignSchemaStmt ImportForeignSchemaType -ImportForeignSchema_function ImportQual -InProgressEnt -InProgressIO IncludeWal InclusionOpaque -IncrementVarSublevelsUp_context IncrementalBackupInfo IncrementalSort IncrementalSortExecutionStatus @@ -1243,6 +1550,7 @@ IncrementalSortGroupInfo IncrementalSortInfo IncrementalSortPath IncrementalSortState +IncrementVarSublevelsUp_context Index IndexAMProperty IndexAmRoutine @@ -1258,6 +1566,7 @@ IndexClauseSet IndexDeleteCounts IndexDeletePrefetchState IndexDoCheckCallback +indexed_tlist IndexElem IndexFetchHeapData IndexFetchTableData @@ -1280,43 +1589,90 @@ IndexTupleData IndexUniqueCheck IndexVacuumInfo IndxInfo +inet +inet_struct +inetKEY InferClause InferenceElem +INFIX InfoItem -InhInfo InheritableSocket -InitSampleScan_function +InhInfo +init_function InitializeDSMForeignScan_function InitializeWorkerForeignScan_function -InjIoErrorState +initRowMethod +InitSampleScan_function InjectionPointCacheEntry InjectionPointCallback InjectionPointCondition InjectionPointConditionType InjectionPointData InjectionPointEntry -InjectionPointSharedState InjectionPointsCtl +InjectionPointSharedState +InjIoErrorState +inline_cte_walker_context +inline_error_callback_arg InlineCodeBlock +ino_t +InProgressEnt +InProgressIO +inquiry InsertStmt +instr_time Instrumentation +int_fast32_t +int_fast64_t +int128 +INT128 Int128AggState +int16 +int16_t +int16KEY +int2vector +int32 +int32_t +int32KEY +int64 +int64_t +int64KEY +int8 +int8_t Int8TransTypeData -IntRBTreeNode +int8x16_t Integer IntegerSet +INTERFACE_INFO InternalDefaultACL InternalGrant +internalPQconninfoOption Interval IntervalAggState +intmax_t IntoClause -InvalMessageArray +intptr_t +IntRBTreeNode +intset_internal_node +intset_leaf_node +intset_node +intvKEY InvalidationInfo InvalidationMsgsGroup +InvalMessageArray +IO +io_callback_fn +io_stat_col +IO_STATUS_BLOCK +IOContext +IOFuncSelector IoMethodOps +IOObject +IOOp IpcMemoryId IpcMemoryKey IpcMemoryState +IPCompareMethod IpcSemaphoreId IpcSemaphoreKey IsForeignPathAsyncCapable_function @@ -1324,19 +1680,21 @@ IsForeignRelUpdatable_function IsForeignScanParallelSafe_function IsoConnInfo IspellDict +ITEM ItemArray ItemId +itemIdCompact +itemIdCompactData ItemIdData ItemPointer ItemPointerData IterateDirectModify_function IterateForeignScan_function IterateJsonStringValuesState +iterator +IV JEntry JHashState -JOBOBJECT_BASIC_LIMIT_INFORMATION -JOBOBJECT_BASIC_UI_RESTRICTIONS -JOBOBJECT_SECURITY_LIMIT_INFORMATION JitContext JitInstrumentation JitProviderCallbacks @@ -1344,7 +1702,12 @@ JitProviderCompileExprCB JitProviderInit JitProviderReleaseContextCB JitProviderResetAfterErrorCB +jmp_buf +JOBOBJECT_BASIC_LIMIT_INFORMATION +JOBOBJECT_BASIC_UI_RESTRICTIONS +JOBOBJECT_SECURITY_LIMIT_INFORMATION Join +join_search_hook_type JoinCostWorkspace JoinDomain JoinExpr @@ -1355,16 +1718,36 @@ JoinState JoinTreeItem JoinType JsObject -JsValue +json_aelem_action +json_manifest_error_callback +json_manifest_per_file_callback +json_manifest_per_wal_range_callback +json_manifest_system_identifier_callback +json_manifest_version_callback +json_ofield_action +json_scalar_action +json_struct_action JsonAggConstructor JsonAggState JsonArgument JsonArrayAgg JsonArrayConstructor JsonArrayQueryConstructor +Jsonb +JsonbAggState JsonBaseObjectInfo +JsonbContainer JsonBehavior JsonBehaviorType +JsonbInState +JsonbIterator +JsonbIteratorToken +JsonbIterState +JsonbPair +JsonbParseState +JsonbSubWorkspace +JsonbTypeCategory +JsonbValue JsonConstructorExpr JsonConstructorExprState JsonConstructorType @@ -1446,39 +1829,68 @@ JsonValueList JsonValueListIterator JsonValueType JsonWrapper -Jsonb -JsonbAggState -JsonbContainer -JsonbInState -JsonbIterState -JsonbIterator -JsonbIteratorToken -JsonbPair -JsonbParseState -JsonbSubWorkspace -JsonbValue +JsValue JumbleState JunkFilter KAXCompressReason +keepwal_entry +keepwal_hash +key_t KeyAction KeyActions KeyArray +keyEntryData KeySuffix KeyWord +LabelProvider +LagTracker LARGE_INTEGER +LargeObjectDesc +Latch +LauncherLastStartTimesEntry +lclContext +lclTocEntry LDAP +LDAP_TIMEVAL LDAPMessage LDAPURLDesc -LDAP_TIMEVAL +leaf_item +leafSegmentInfo +LerpFunc +LexDescr +LexemeEntry +LexemeHashKey +LexemeInfo +LexemeKey +LexizeData +libpq_gettext_func +libpq_source +libpqsrv_PGresult +LibraryInfo +Limit +LimitOption +LimitPath +LimitState +LimitStateCond LINE +line_t +lineno_t +List +list_sort_comparator +ListCell +ListDictionary +ListenAction +ListenActionKind +ListenStmt +ListParsedLex LLVMAttributeRef LLVMBasicBlockRef LLVMBuilderRef LLVMContextRef LLVMErrorRef LLVMIntPredicate -LLVMJITEventListenerRef LLVMJitContext +LLVMJITEventListenerRef LLVMJitHandle LLVMMemoryBufferRef LLVMModuleRef @@ -1506,93 +1918,49 @@ LLVMTargetMachineRef LLVMTargetRef LLVMTypeRef LLVMValueRef +LoadStmt +loc_chunk +local_relopt +local_relopts +local_source +local_ts_iter +local_ts_radix_tree +LocalBufferLookupEnt +locale_t LOCALLOCK LOCALLOCKOWNER LOCALLOCKTAG -LOCALPREDICATELOCK -LOCK -LOCKMASK -LOCKMETHODID -LOCKMODE -LOCKTAG -LONG -LONG_PTR -LOOP -LPARAM -LPBYTE -LPCWSTR -LPSERVICE_STATUS -LPSTR -LPTHREAD_START_ROUTINE -LPTSTR -LPVOID -LPWSTR -LSEG -LUID -LVRelState -LVSavedErrInfo -LWLock -LWLockHandle -LWLockMode -LWLockPadded -LZ4F_compressionContext_t -LZ4F_decompressOptions_t -LZ4F_decompressionContext_t -LZ4F_errorCode_t -LZ4F_preferences_t -LZ4State -LabelProvider -LagTracker -LargeObjectDesc -Latch -LauncherLastStartTimesEntry -LerpFunc -LexDescr -LexemeEntry -LexemeHashKey -LexemeInfo -LexemeKey -LexizeData -LibraryInfo -Limit -LimitOption -LimitPath -LimitState -LimitStateCond -List -ListCell -ListDictionary -ListParsedLex -ListenAction -ListenActionKind -ListenStmt -LoInfo -LoadStmt -LocalBufferLookupEnt LocalPgBackendStatus +LOCALPREDICATELOCK LocalTransactionId +locate_agg_of_level_context +locate_var_of_level_context +locate_windowfunc_context Location LocationIndex LocationLen +LOCK LockAcquireResult LockClauseStrength LockData LockInfoData +LockingClause LockInstanceData +LOCKMASK LockMethod LockMethodData +LOCKMETHODID +LOCKMODE LockRelId LockRows LockRowsPath LockRowsState LockStmt +LOCKTAG LockTagType LockTupleMode LockViewRecurse_context LockWaitPolicy -LockingClause -LogOpts -LogStmtLevel LogicalDecodeBeginCB LogicalDecodeBeginPrepareCB LogicalDecodeChangeCB @@ -1627,9 +1995,9 @@ LogicalRepCtxStruct LogicalRepMsgType LogicalRepPartMapEntry LogicalRepPreparedTxnData +LogicalRepRelation LogicalRepRelId LogicalRepRelMapEntry -LogicalRepRelation LogicalRepRollbackPreparedTxnData LogicalRepSequenceInfo LogicalRepStreamAbortData @@ -1642,43 +2010,93 @@ LogicalSlotInfo LogicalSlotInfoArr LogicalTape LogicalTapeSet +LogLevel +LogOpts +LogStmtLevel +logstreamer_param +LoInfo +LONG +LONG_PTR LookupSet -LsnReadQueue -LsnReadQueueNextFun -LsnReadQueueNextStatus +LOOP +LPARAM +LPBYTE +LPCWSTR +LPSERVICE_STATUS +LPSTR +LPTHREAD_START_ROUTINE +LPTSTR +LPVOID +LPWSTR +lquery +lquery_level +lquery_variant +LSEG +LsnReadQueue +LsnReadQueueNextFun +LsnReadQueueNextStatus +ltree +ltree_gist +ltree_level LtreeGistOptions LtreeSignature +ltxtquery +LUID +LVRelState +LVSavedErrInfo +LWLock +LWLockHandle +LWLockMode +LWLockPadded +LZ4F_compressionContext_t +LZ4F_decompressionContext_t +LZ4F_decompressOptions_t +LZ4F_errorCode_t +LZ4F_preferences_t +LZ4State +mac8KEY +macaddr +macaddr_sortsupport_state +macaddr8 +macKEY MAGIC +manifest_data +manifest_file +manifest_files_hash +manifest_files_iterator +manifest_wal_range +manifest_writer +ManyTestResource +ManyTestResourceKind +map_variable_attnos_context +Material +MaterialPath +MaterialState +max_parallel_hazard_context +mb2wchar_with_len_converter +mbchar_verifier +mbcharacter_incrementer +mbdisplaylen_converter +mblen_converter +mbstr_verifier MBuf MCVHashContext MCVHashEntry MCVHashTable_hash MCVItem MCVList -MEMORY_BASIC_INFORMATION -MGVTBL -MINIDUMPWRITEDUMP -MINIDUMP_TYPE -MJEvalResult -MTTargetRelLookup -MVDependencies -MVDependency -MVNDistinct -MVNDistinctItem -ManyTestResource -ManyTestResourceKind -Material -MaterialPath -MaterialState -MdPathStr MdfdVec +MdPathStr Memoize +memoize_hash +memoize_iterator MemoizeEntry MemoizeInstrumentation MemoizeKey MemoizePath MemoizeState MemoizeTuple +MEMORY_BASIC_INFORMATION MemoryChunk MemoryContext MemoryContextCallback @@ -1704,24 +2122,39 @@ MergeStmt MergeSupportFunc MergeWhenClause MetaCommand +metastring +MGVTBL +MINIDUMP_TYPE +MINIDUMPWRITEDUMP +MinimalTuple +MinimalTupleData +MinimalTupleTableSlot MinMaxAggInfo MinMaxAggPath MinMaxExpr +MinmaxMultiOpaque MinMaxMultiOptions MinMaxOp -MinimalTuple -MinimalTupleData -MinimalTupleTableSlot -MinmaxMultiOpaque MinmaxOpaque +missing_cache_key +mix_data_t +MJEvalResult +mode_t ModifyTable ModifyTableContext ModifyTablePath ModifyTableState MonotonicFunction MorphOpaque +movedb_failure_params MsgType +MTTargetRelLookup MultiAssignRef +multirange_bsearch_comparison +multirange_unnest_fctx +MultirangeIOData +MultirangeParseState +MultirangeType MultiSortSupport MultiSortSupportData MultiXactId @@ -1729,69 +2162,78 @@ MultiXactMember MultiXactOffset MultiXactStateData MultiXactStatus -MultirangeIOData -MultirangeParseState -MultirangeType -NDBOX -NLSVERSIONINFOEX -NODE -NTSTATUS -NUMCacheEntry -NUMDesc -NUMProc -NV +MVDependencies +MVDependency +MVNDistinct +MVNDistinctItem +mxact +mXactCacheEnt +mxtruncinfo Name -NameData -NameHashEntry NamedArgExpr +NameData NamedDSAState NamedDSHState NamedDSMState NamedLWLockTrancheRequest NamedTuplestoreScan NamedTuplestoreScanState +NameHashEntry NamespaceInfo +NDBOX +needs_fmgr_hook_type NestLoop NestLoopParam NestLoopState NestPath +network_sortsupport_state NewColumnValue NewConstraint NextSampleBlock_function NextSampleTuple_function NextValueExpr +nl_item +NLSVERSIONINFOEX Node +NODE +NodeInterfaceTuple +nodeitem NodeTag -NonEmptyRange +NodeTuple NoneCompressorState +NonEmptyRange +normal_rand_fctx Notification NotificationList NotifyStmt NotnullHashEntry +nsphash_hash Nsrt NtDllRoutine NtFlushBuffersFileEx_t +ntile_context +NTSTATUS +NullableDatum NullIfExpr +nullingrel_info +NullingRelsMatch NullTest NullTestType -NullableDatum -NullingRelsMatch +NUMCacheEntry +NUMDesc +numeric Numeric NumericAggState NumericDigit NumericSortSupport NumericSumAccum NumericVar +NUMProc +NV OAuthValidatorCallbacks OAuthValidatorModuleInit -OM_uint32 -OP -OSAPerGroupState -OSAPerQueryState -OSInfo -OSSLCipher -OSSLDigest -OVERLAPPED +object_access_hook_type +object_access_hook_type_str ObjectAccessDrop ObjectAccessNamespaceSearch ObjectAccessPostAlter @@ -1799,265 +2241,83 @@ ObjectAccessPostCreate ObjectAccessType ObjectAddress ObjectAddressAndFlags +ObjectAddresses ObjectAddressExtra ObjectAddressStack -ObjectAddresses ObjectPropertyType ObjectType ObjectWithArgs +off_t Offset OffsetNumber OffsetVarNodes_context Oid +oidKEY OidOptions +oidvector OkeysState OldToNewMapping OldToNewMappingData +OM_uint32 +on_dsm_detach_callback +on_exit_nicely_callback OnCommitAction OnCommitItem OnConflictAction OnConflictClause OnConflictExpr OnConflictSetState +OP OpClassCacheEnt -OpExpr -OpFamilyMember -OpFamilyOpFuncGroup -OpIndexInterpretation OpclassInfo +openssl_tls_init_hook_typ Operator OperatorElement +OpExpr OpfamilyInfo +OpFamilyMember +OpFamilyOpFuncGroup +OpIndexInterpretation OprCacheEntry OprCacheKey OprInfo OprProofCacheEntry OprProofCacheKey OrArgIndexMatch +OSAPerGroupState +OSAPerQueryState +OSInfo +ossl_EVP_cipher_func +OSSLCipher +OSSLDigest +other OuterJoinClauseInfo +output_type OutputPluginCallbacks OutputPluginOptions OutputPluginOutputType +OutputPluginParam +OutputPluginParamKey +overexplain_options +OVERLAPPED OverridingKind PACE_HEADER PACL -PATH -PCtxtHandle -PERL_CONTEXT -PERL_SI -PFN -PGAlignedBlock -PGAlignedXLogBlock -PGAsyncStatusType -PGCALL2 -PGCRYPTO_SHA_t -PGChecksummablePage -PGContextVisibility -PGEvent -PGEventConnDestroy -PGEventConnReset -PGEventId -PGEventProc -PGEventRegister -PGEventResultCopy -PGEventResultCreate -PGEventResultDestroy -PGFInfoFunction -PGFileType -PGFunction -PGIOAlignedBlock -PGLZ_HistEntry -PGLZ_Strategy -PGLoadBalanceType -PGMessageField -PGModuleMagicFunction -PGNoticeHooks -PGOutputData -PGOutputTxnData -PGPROC -PGP_CFB -PGP_Context -PGP_MPI -PGP_PubKey -PGP_S2K -PGPing -PGQueryClass -PGRUsage -PGSemaphore -PGSemaphoreData -PGShmemHeader -PGTargetServerType -PGTernaryBool -PGTransactionStatusType -PGVerbosity -PG_Lock_Status -PG_init_t -PGauthData -PGcancel -PGcancelConn -PGcmdQueueEntry -PGconn -PGdataValue -PGlobjfuncs -PGnotify -PGoauthBearerRequest -PGpipelineStatus -PGpromptOAuthDevice -PGresAttDesc -PGresAttValue -PGresParamDesc -PGresult -PGresult_data -PIO_STATUS_BLOCK -PLAINTREE -PLAssignStmt -PLcword -PLpgSQL_case_when -PLpgSQL_condition -PLpgSQL_datum -PLpgSQL_datum_type -PLpgSQL_diag_item -PLpgSQL_exception -PLpgSQL_exception_block -PLpgSQL_execstate -PLpgSQL_expr -PLpgSQL_function -PLpgSQL_getdiag_kind -PLpgSQL_if_elsif -PLpgSQL_label_type -PLpgSQL_nsitem -PLpgSQL_nsitem_type -PLpgSQL_plugin -PLpgSQL_promise_type -PLpgSQL_raise_option -PLpgSQL_raise_option_type -PLpgSQL_rec -PLpgSQL_recfield -PLpgSQL_resolve_option -PLpgSQL_row -PLpgSQL_rwopt -PLpgSQL_stmt -PLpgSQL_stmt_assert -PLpgSQL_stmt_assign -PLpgSQL_stmt_block -PLpgSQL_stmt_call -PLpgSQL_stmt_case -PLpgSQL_stmt_close -PLpgSQL_stmt_commit -PLpgSQL_stmt_dynexecute -PLpgSQL_stmt_dynfors -PLpgSQL_stmt_execsql -PLpgSQL_stmt_exit -PLpgSQL_stmt_fetch -PLpgSQL_stmt_forc -PLpgSQL_stmt_foreach_a -PLpgSQL_stmt_fori -PLpgSQL_stmt_forq -PLpgSQL_stmt_fors -PLpgSQL_stmt_getdiag -PLpgSQL_stmt_if -PLpgSQL_stmt_loop -PLpgSQL_stmt_open -PLpgSQL_stmt_perform -PLpgSQL_stmt_raise -PLpgSQL_stmt_return -PLpgSQL_stmt_return_next -PLpgSQL_stmt_return_query -PLpgSQL_stmt_rollback -PLpgSQL_stmt_type -PLpgSQL_stmt_while -PLpgSQL_trigtype -PLpgSQL_type -PLpgSQL_type_type -PLpgSQL_var -PLpgSQL_variable -PLwdatum -PLword -PLyArrayToOb -PLyCursorObject -PLyDatumToOb -PLyDatumToObFunc -PLyExceptionEntry -PLyExecutionContext -PLyObToArray -PLyObToDatum -PLyObToDatumFunc -PLyObToDomain -PLyObToScalar -PLyObToTransform -PLyObToTuple -PLyObject_AsString_t -PLyPlanObject -PLyProcedure -PLyProcedureEntry -PLyProcedureKey -PLyResultObject -PLySRFState -PLySavedArgs -PLyScalarToOb -PLySubtransactionData -PLySubtransactionObject -PLyTransformToOb -PLyTrigType -PLyTupleToOb -PLyUnicode_FromStringAndSize_t -PLy_elog_impl_t -PMChild -PMChildPool -PMINIDUMP_CALLBACK_INFORMATION -PMINIDUMP_EXCEPTION_INFORMATION -PMINIDUMP_USER_STREAM_INFORMATION -PMSignalData -PMSignalReason -PMState -POLYGON -PQArgBlock -PQEnvironmentOption -PQExpBuffer -PQExpBufferData -PQauthDataHook_type -PQcommMethods -PQconninfoOption -PQnoticeProcessor -PQnoticeReceiver -PQprintOpt -PQsslKeyPassHook_OpenSSL_type -PREDICATELOCK -PREDICATELOCKTAG -PREDICATELOCKTARGET -PREDICATELOCKTARGETTAG -PROCESS_INFORMATION -PROCLOCK -PROCLOCKTAG -PROC_HDR -PSID -PSQL_COMP_CASE -PSQL_ECHO -PSQL_ECHO_HIDDEN -PSQL_ERROR_ROLLBACK -PSQL_SEND_MODE -PTEntryArray -PTIterationArray -PTOKEN_PRIVILEGES -PTOKEN_USER -PUTENVPROC -PVIndStats -PVIndVacStatus -PVOID -PVShared -PX_Alias -PX_Cipher -PX_Combo -PX_HMAC -PX_MD Page PageData PageGistNSN PageHeader PageHeaderData -PageXLogRecPtr +pagetable_hash +pagetable_iterator PagetableEntry +PageXLogRecPtr +pairingheap +pairingheap_comparator +pairingheap_node Pairs +pam_handle_t +parallel_worker_main_type ParallelAppendState ParallelApplyWorkerEntry ParallelApplyWorkerInfo @@ -2095,23 +2355,25 @@ ParamPathInfo ParamRef ParamsErrorCbData ParentMapEntry +parse_error_callback_arg ParseCallbackState +ParsedLex +ParsedScript +ParsedText +ParsedWord ParseExprKind ParseLoc ParseNamespaceColumn ParseNamespaceItem ParseParamRefHook -ParseState -ParsedLex -ParsedScript -ParsedText -ParsedWord ParserSetupHook ParserState +ParseState PartClauseInfo PartClauseMatchStatus PartClauseTarget PartialFileSetState +partition_method_t PartitionBoundInfo PartitionBoundInfoData PartitionBoundSpec @@ -2121,6 +2383,8 @@ PartitionDescData PartitionDirectory PartitionDirectoryEntry PartitionDispatch +PartitionedRelPruneInfo +PartitionedRelPruningData PartitionElem PartitionHashBound PartitionKey @@ -2141,43 +2405,120 @@ PartitionScheme PartitionSpec PartitionStrategy PartitionTupleRouting -PartitionedRelPruneInfo -PartitionedRelPruningData PartitionwiseAggregateType PasswordType Path +PATH PathClauseUsage PathCostComparison PathHashStack PathKey PathKeysComparison PathTarget -PatternInfo -PatternInfoArray Pattern_Prefix_Status Pattern_Type +PatternInfo +PatternInfoArray +PCtxtHandle +pe_test_config +pe_test_escape_func +pe_test_vector +pending_label PendingFsyncEntry +pendingPosition PendingRelDelete PendingRelSync PendingUnlinkEntry PendingWrite PendingWriteback -PerLockTagEntry -PerlInterpreter +PERL_CONTEXT Perl_ppaddr_t +PERL_SI +PerlInterpreter +PerLockTagEntry Permutation PermutationStep PermutationStepBlocker PermutationStepBlockerType +PFN +Pg_abi_values +pg_atomic_flag +pg_atomic_uint32 +pg_atomic_uint64 +pg_be_sasl_mech +pg_category_range +pg_checksum_context +pg_checksum_raw_context +pg_checksum_type +pg_compress_algorithm +pg_compress_specification +pg_conn_host +pg_conn_host_type +pg_conv_map +pg_crc32 +pg_crc32c +pg_cryptohash_ctx +pg_cryptohash_errno +pg_cryptohash_type +pg_ctype_cache +pg_enc +pg_enc2name +pg_encname +pg_fe_sasl_mech +Pg_finfo_record +pg_funcptr_t +pg_gssinfo +pg_hmac_ctx +pg_hmac_errno +PG_init_t +pg_local_to_utf_combined +pg_locale_t +PG_Lock_Status +Pg_magic_struct +pg_mb_radix_tree +pg_md5_ctx +pg_on_exit_callback +pg_prng_state +pg_re_flags +pg_regex_t +pg_regmatch_t +pg_regoff_t +pg_saslprep_rc +pg_sha1_ctx +pg_sha224_ctx +pg_sha256_ctx +pg_sha384_ctx +pg_sha512_ctx +pg_snapshot +pg_special_case +pg_stack_base_t +pg_time_t +pg_time_usec_t +pg_tz +pg_tz_cache +pg_tzenum +pg_unicode_category +pg_unicode_decompinfo +pg_unicode_decomposition +pg_unicode_norminfo +pg_unicode_normprops +pg_unicode_properties +pg_unicode_range +pg_unicode_recompinfo +pg_usec_time_t +pg_utf_to_local_combined +pg_uuid_t +pg_wchar +pg_wchar_tbl PgAioBackend PgAioCtl PgAioHandle PgAioHandleCallbackComplete PgAioHandleCallbackID PgAioHandleCallbackReport -PgAioHandleCallbackStage PgAioHandleCallbacks PgAioHandleCallbacksEntry +PgAioHandleCallbackStage PgAioHandleFlags PgAioHandleState PgAioOp @@ -2194,7 +2535,11 @@ PgAioWaitRef PgAioWorkerControl PgAioWorkerSlot PgAioWorkerSubmissionQueue -PgArchData +PGAlignedBlock +PGAlignedXLogBlock +PgArchData +PGAsyncStatusType +PGauthData PgBackendGSSStatus PgBackendSSLStatus PgBackendStatus @@ -2205,7 +2550,25 @@ PgBenchExprType PgBenchFunction PgBenchValue PgBenchValueType +PGCALL2 +PGcancel +PGcancelConn +PGChecksummablePage PgChecksumMode +PGcmdQueueEntry +PGconn +PGContextVisibility +PGCRYPTO_SHA_t +PGdataValue +PGEvent +PGEventConnDestroy +PGEventConnReset +PGEventId +PGEventProc +PGEventRegister +PGEventResultCopy +PGEventResultCreate +PGEventResultDestroy PgFdwAnalyzeState PgFdwConnState PgFdwDirectModifyState @@ -2215,23 +2578,51 @@ PgFdwPathExtraData PgFdwRelationInfo PgFdwSamplingMethod PgFdwScanState +PGFileType +PGFInfoFunction +PGFunction PgIfAddrCallback -PgStatShared_Archiver -PgStatShared_Backend -PgStatShared_BgWriter -PgStatShared_Checkpointer -PgStatShared_Common -PgStatShared_Database -PgStatShared_Function -PgStatShared_HashEntry -PgStatShared_IO -PgStatShared_InjectionPoint -PgStatShared_InjectionPointFixed -PgStatShared_Relation -PgStatShared_ReplSlot -PgStatShared_SLRU -PgStatShared_Subscription -PgStatShared_Wal +PGIOAlignedBlock +PGLoadBalanceType +PGlobjfuncs +PGLZ_HistEntry +PGLZ_Strategy +PGMessageField +PGModuleMagicFunction +PGNoticeHooks +PGnotify +PGoauthBearerRequest +PGOutputData +PGOutputTxnData +pgp_armor_headers_state +PGP_CFB +PGP_Context +PGP_MPI +PGP_PubKey +PGP_S2K +pgParameterStatus +PGPing +PGpipelineStatus +PGPROC +PGpromptOAuthDevice +PGQueryClass +PGresAttDesc +PGresAttValue +PGresParamDesc +PGresult +PGresult_data +PGRUsage +PGSemaphore +PGSemaphoreData +PGShmemHeader +pgsocket +pgsql_thing_t +pgssEntry +pgssGlobalStats +pgssHashKey +pgssSharedState +pgssStoreKind +pgssVersion PgStat_ArchiverStats PgStat_Backend PgStat_BackendPending @@ -2240,6 +2631,8 @@ PgStat_BgWriterStats PgStat_BktypeIO PgStat_CheckpointerStats PgStat_Counter +pgstat_entry_ref_hash_hash +pgstat_entry_ref_hash_iterator PgStat_EntryRef PgStat_EntryRefHashEntry PgStat_FetchConsistency @@ -2249,11 +2642,13 @@ PgStat_HashKey PgStat_IO PgStat_KindInfo PgStat_LocalState +pgstat_page PgStat_PendingDroppedStatsItem PgStat_PendingIO -PgStat_SLRUStats PgStat_ShmemControl +PgStat_SLRUStats PgStat_Snapshot +pgstat_snapshot_hash PgStat_SnapshotEntry PgStat_StatDBEntry PgStat_StatFuncEntry @@ -2268,29 +2663,178 @@ PgStat_TableStatus PgStat_TableXactStatus PgStat_WalCounters PgStat_WalStats +PgStatShared_Archiver +PgStatShared_Backend +PgStatShared_BgWriter +PgStatShared_Checkpointer +PgStatShared_Common +PgStatShared_Database +PgStatShared_Function +PgStatShared_HashEntry +PgStatShared_InjectionPoint +PgStatShared_InjectionPointFixed +PgStatShared_IO +PgStatShared_Relation +PgStatShared_ReplSlot +PgStatShared_SLRU +PgStatShared_Subscription +PgStatShared_Wal +pgstattuple_type +PGTargetServerType +PGTernaryBool +pgthreadlock_t +PGTransactionStatusType +PGVerbosity PgXmlErrorContext PgXmlStrictness -Pg_abi_values -Pg_finfo_record -Pg_magic_struct +pid_t +PIO_STATUS_BLOCK PipeProtoChunk PipeProtoHeader +pivot_field PlaceHolderInfo PlaceHolderVar +PLAINTREE Plan PlanDirectModify_function PlanForeignModify_function PlanInvalItem -PlanRowMark -PlanState PlannedStmt PlannedStmtOrigin +planner_hook_type +planner_setup_hook_type +planner_shutdown_hook_type PlannerGlobal PlannerInfo PlannerParamItem +PlanRowMark +PlanState +planstate_tree_walker_callback +PLAssignStmt +PLcword +plperl_array_info +plperl_call_data +plperl_interp_desc +plperl_proc_desc +plperl_proc_key +plperl_proc_ptr +plperl_query_desc +plperl_query_entry +PLpgSQL_case_when +plpgsql_CastExprHashEntry +plpgsql_CastHashEntry +plpgsql_CastHashKey +PLpgSQL_condition +PLpgSQL_datum +PLpgSQL_datum_type +PLpgSQL_diag_item +PLpgSQL_exception +PLpgSQL_exception_block +PLpgSQL_execstate +PLpgSQL_expr +plpgsql_expr_walker_callback +PLpgSQL_function +PLpgSQL_getdiag_kind +PLpgSQL_if_elsif +PLpgSQL_label_type +PLpgSQL_nsitem +PLpgSQL_nsitem_type +PLpgSQL_plugin +PLpgSQL_promise_type +PLpgSQL_raise_option +PLpgSQL_raise_option_type +PLpgSQL_rec +PLpgSQL_recfield +PLpgSQL_resolve_option +PLpgSQL_row +PLpgSQL_rwopt +PLpgSQL_stmt +PLpgSQL_stmt_assert +PLpgSQL_stmt_assign +PLpgSQL_stmt_block +PLpgSQL_stmt_call +PLpgSQL_stmt_case +PLpgSQL_stmt_close +PLpgSQL_stmt_commit +PLpgSQL_stmt_dynexecute +PLpgSQL_stmt_dynfors +PLpgSQL_stmt_execsql +PLpgSQL_stmt_exit +PLpgSQL_stmt_fetch +PLpgSQL_stmt_forc +PLpgSQL_stmt_foreach_a +PLpgSQL_stmt_fori +PLpgSQL_stmt_forq +PLpgSQL_stmt_fors +PLpgSQL_stmt_getdiag +PLpgSQL_stmt_if +PLpgSQL_stmt_loop +PLpgSQL_stmt_open +PLpgSQL_stmt_perform +PLpgSQL_stmt_raise +PLpgSQL_stmt_return +PLpgSQL_stmt_return_next +PLpgSQL_stmt_return_query +PLpgSQL_stmt_rollback +PLpgSQL_stmt_type +plpgsql_stmt_walker_callback +PLpgSQL_stmt_while +PLpgSQL_trigtype +PLpgSQL_type +PLpgSQL_type_type +PLpgSQL_var +PLpgSQL_variable +pltcl_call_state +pltcl_interp_desc +pltcl_proc_desc +pltcl_proc_key +pltcl_proc_ptr +pltcl_query_desc +PLwdatum +PLword +PLy_elog_impl_t +PLyArrayToOb +PLyCursorObject +PLyDatumToOb +PLyDatumToObFunc +PLyExceptionEntry +PLyExecutionContext +PLyObject_AsString_t +PLyObToArray +PLyObToDatum +PLyObToDatumFunc +PLyObToDomain +PLyObToScalar +PLyObToTransform +PLyObToTuple +PLyPlanObject +PLyProcedure +PLyProcedureEntry +PLyProcedureKey +PLyResultObject +PLySavedArgs +PLyScalarToOb +PLySRFState +PLySubtransactionData +PLySubtransactionObject +PLyTransformToOb +PLyTrigType +PLyTupleToOb +PLyUnicode_FromStringAndSize_t +PMChild +PMChildPool +PMINIDUMP_CALLBACK_INFORMATION +PMINIDUMP_EXCEPTION_INFORMATION +PMINIDUMP_USER_STREAM_INFORMATION +PMSignalData +PMSignalReason +PMState Point +pointer Pointer PolicyInfo +POLYGON +polymorphic_actuals Pool PopulateArrayContext PopulateArrayState @@ -2301,33 +2845,75 @@ Portal PortalHashEnt PortalStatus PortalStrategy -PostParseColumnRefHook -PostRewriteHook +pos_trgm +post_parse_analyze_hook_type PostgresPollingStatusType PostingItem -PreParseColumnRefHook -PredClass -PredIterInfo -PredIterInfoData -PredXactList +PostParseColumnRefHook +postprocess_result_function +PostRewriteHook +PQArgBlock +PQauthDataHook_type +pqbool +PQcommMethods +PQconninfoOption +PQEnvironmentOption +PQExpBuffer +PQExpBufferData +PQnoticeProcessor +PQnoticeReceiver +PQprintOpt +pqsigfunc +PQsslKeyPassHook_OpenSSL_type +PredClass +PREDICATELOCK PredicateLockData +PREDICATELOCKTAG +PREDICATELOCKTARGET +PREDICATELOCKTARGETTAG PredicateLockTargetType +PredIterInfo +PredIterInfoData +PredXactList PrefetchBufferResult -PrepParallelRestorePtrType -PrepareStmt PreparedStatement +PrepareStmt +PreParseColumnRefHook +PrepParallelRestorePtrType PresortedKeyData PrewarmType PrintExtraTocPtrType -PrintTocDataPtrType PrintfArgType PrintfArgValue PrintfTarget +printQueryOpt +printTableContent +printTableFooter +printTableOpt +printTextFormat +printTextLineFormat +printTextLineWrap +printTextRule +PrintTocDataPtrType PrinttupAttrInfo -PrivTarget +printXheaderWidthType +priv_map PrivateRefCountEntry +PrivTarget +PROC_HDR ProcArrayStruct +process_file_callback_t +PROCESS_INFORMATION +process_sublinks_context +ProcessingMode +ProcessUtility_hook_type +ProcessUtilityContext ProcLangInfo +proclist_head +proclist_mutable_iter +proclist_node +PROCLOCK +PROCLOCKTAG ProcNumber ProcSignalBarrierType ProcSignalHeader @@ -2335,16 +2921,14 @@ ProcSignalReason ProcSignalSlot ProcState ProcWaitStatus -ProcessUtilityContext -ProcessUtility_hook_type -ProcessingMode ProgressCommandType +ProjectionInfo +ProjectionPath ProjectSet ProjectSetPath ProjectSetState -ProjectionInfo -ProjectionPath PromptInterruptContext +promptStatus_t ProtocolVersion PrsStorage PruneFreezeParams @@ -2352,12 +2936,29 @@ PruneFreezeResult PruneReason PruneState PruneStepResult +PSID +PSQL_COMP_CASE +PSQL_ECHO +PSQL_ECHO_HIDDEN +PSQL_ERROR_ROLLBACK +PSQL_SEND_MODE PsqlScanCallbacks PsqlScanQuoteType PsqlScanResult PsqlScanState PsqlScanStateData PsqlSettings +PTEntryArray +pthread_barrier_t +pthread_cond_t +pthread_key_t +pthread_mutex_t +pthread_once_t +pthread_t +PTIterationArray +PTOKEN_PRIVILEGES +PTOKEN_USER +ptrdiff_t Publication PublicationActions PublicationAllObjSpec @@ -2371,27 +2972,48 @@ PublicationRelInfo PublicationRelKind PublicationSchemaInfo PublicationTable +published_rel PublishGencolsType +pull_var_clause_context +pull_varattnos_context +pull_varnos_context +pull_vars_context PullFilter PullFilterOps +pullup_replace_vars_context +pushdown_safe_type +pushdown_safety_info PushFilter PushFilterOps PushFunction +PUTENVPROC +PVIndStats +PVIndVacStatus +PVOID +PVShared +PX_Alias +PX_Cipher +PX_Combo +PX_HMAC +PX_MD +Py_ssize_t PyCFunction PyMethodDef PyModuleDef PyObject -PyTypeObject PyType_Slot PyType_Spec -Py_ssize_t +PyTypeObject +qc_hash_func QPRS_STATE +qsort_arg_comparator +qsort_comparator QTN2QTState QTNode -QUERYTYPE QualCost QualItem Query +query_pathkeys_callback QueryCompletion QueryDesc QueryEnvironment @@ -2404,32 +3026,23 @@ QueryOperator QueryRepresentation QueryRepresentationOperand QuerySource +QUERYTYPE QueueBackendStatus +QueuedMessage QueuePosition +QueueTuple QuitSignalReason -RBTNode -RBTOrderControl -RBTree -RBTreeIterator -REPARSE_JUNCTION_DATA_BUFFER -RIX -RI_CompareHashEntry -RI_CompareKey -RI_ConstraintInfo -RI_QueryHashEntry -RI_QueryKey -RTEKind -RTEPermissionInfo -RWConflict -RWConflictData -RWConflictPoolHeader +radius_attribute +radius_packet Range RangeBound RangeBox RangeFunction RangeIOData RangeQueryClause +Ranges RangeSubselect +rangeTableEntry_used_context RangeTableFunc RangeTableFuncCol RangeTableSample @@ -2439,15 +3052,21 @@ RangeTblRef RangeType RangeVar RangeVarGetRelidCallback -Ranges +rank_context RawColumnDefault RawParseMode RawStmt -ReInitializeDSMForeignScan_function -ReScanForeignScan_function -ReadBufPtrType +rbt_allocfunc +rbt_combiner +rbt_comparator +rbt_freefunc +RBTNode +RBTOrderControl +RBTree +RBTreeIterator ReadBufferMode ReadBuffersOperation +ReadBufPtrType ReadBytePtrType ReadExtraTocPtrType ReadFunc @@ -2472,52 +3091,81 @@ RecursionContext RecursiveUnion RecursiveUnionPath RecursiveUnionState +reduce_outer_joins_partial_state +reduce_outer_joins_pass1_state +reduce_outer_joins_pass2_state +reference RefetchForeignRow_function RefreshMatViewStmt -RegProcedure +regc_wc_probefunc +regex_arc_t +regexp +regexp_matches_ctx Regis RegisNode +registered_buffer RegisteredBgWorker +regproc +RegProcedure ReindexErrorInfo ReindexIndexInfo ReindexObjectType ReindexParams ReindexStmt ReindexType +ReInitializeDSMForeignScan_function +RelabelType RelAggInfo +Relation +RelationData +RelationInfo +RelationPtr +RelationSyncEntry +RelcacheCallbackFunction +ReleaseMatchCB RelFileLocator RelFileLocatorBackend RelFileNumber +RelfilenumberMapEntry +RelfilenumberMapKey RelIdCacheEnt +Relids RelIdToTypeIdCacheEntry RelInfo RelInfoArr RelMapFile RelMapping +RelocationBufferInfo +relopt_bool +relopt_enum +relopt_enum_elt_def +relopt_gen +relopt_int +relopt_kind +relopt_parse_elt +relopt_real +relopt_string +relopt_type +relopt_value RelOptInfo RelOptKind +relopts_validator RelPathStr +RelptrFreePageBtree +RelptrFreePageManager +RelptrFreePageSpanLeader RelStatsInfo RelSyncCallbackFunction RelToCheck RelToCluster -RelabelType -Relation -RelationData -RelationInfo -RelationPtr -RelationSyncEntry -RelcacheCallbackFunction -ReleaseMatchCB -RelfilenumberMapEntry -RelfilenumberMapKey -Relids -RelocationBufferInfo -RelptrFreePageBtree -RelptrFreePageManager -RelptrFreePageSpanLeader +remoteConn +remoteConnHashEnt +remoteDep RemoteSlot +RemoteSyncPosition +remove_nulling_relids_context RenameStmt +rendezvousHashEntry ReopenPtrType ReorderBuffer ReorderBufferApplyChangeCB @@ -2541,15 +3189,18 @@ ReorderBufferStreamPrepareCB ReorderBufferStreamStartCB ReorderBufferStreamStopCB ReorderBufferStreamTruncateCB -ReorderBufferTXN -ReorderBufferTXNByIdEnt ReorderBufferToastEnt ReorderBufferTupleCidEnt ReorderBufferTupleCidKey +ReorderBufferTXN +ReorderBufferTXNByIdEnt ReorderBufferUpdateProgressTxnCB ReorderTuple -RepOriginId +rep ReparameterizeForeignPathByChild_function +REPARSE_JUNCTION_DATA_BUFFER +replace_rte_variables_callback +replace_rte_variables_context ReplaceVarsFromTargetList_context ReplaceVarsNoMatchOption ReplaceWrapOption @@ -2564,7 +3215,12 @@ ReplicationSlotPersistentData ReplicationState ReplicationStateCtl ReplicationStateOnDisk -ResTarget +RepOriginId +report_error_fn +RepSetSeqTuple +RepSetTableTuple +RepSetTuple +ReScanForeignScan_function ReservoirState ReservoirStateData ResourceElem @@ -2574,6 +3230,7 @@ ResourceReleaseCallback ResourceReleaseCallbackItem ResourceReleasePhase ResourceReleasePriority +ResTarget RestoreOptions RestorePass RestrictInfo @@ -2581,29 +3238,44 @@ Result ResultRelInfo ResultState ResultType +ret_type RetainDeadTuplesData RetainDeadTuplesPhase -ReturnSetInfo -ReturnStmt ReturningClause ReturningExpr ReturningOption ReturningOptionKind +ReturnSetInfo +ReturnStmt RevmapContents RevokeRoleGrantAction +rewind_source +rewrite_event RewriteMappingDataEntry RewriteMappingFile RewriteRule RewriteState +rf_context +rfile +RI_CompareHashEntry +RI_CompareKey +RI_ConstraintInfo +RI_QueryHashEntry +RI_QueryKey +RIX +rm_detail_t RmgrData RmgrDescData RmgrId +role_auth_extra +rolename_hash RoleNameEntry RoleNameItem RoleSpec RoleSpecType RoleStmtType RollupData +row_security_policy_hook_type RowCompareExpr RowExpr RowIdentityVarInfo @@ -2611,6 +3283,12 @@ RowMarkClause RowMarkType RowSecurityDesc RowSecurityPolicy +rsv_callback +rt_iter +rt_node_class_test_elem +rt_radix_tree +RTEKind +RTEPermissionInfo RtlGetLastNtStatus_t RtlNtStatusToDosError_t RuleInfo @@ -2619,58 +3297,18 @@ RuleStmt RunMode RunningTransactions RunningTransactionsData +RWConflict +RWConflictData +RWConflictPoolHeader +SampleScan +SampleScanGetSampleSize_function +SampleScanState +saophash_hash SASLStatus -SC_HANDLE -SECURITY_ATTRIBUTES -SECURITY_STATUS -SEG -SERIALIZABLEXACT -SERIALIZABLEXID -SERIALIZABLEXIDTAG -SERVICE_STATUS -SERVICE_STATUS_HANDLE -SERVICE_TABLE_ENTRY -SID_AND_ATTRIBUTES -SID_IDENTIFIER_AUTHORITY -SID_NAME_USE -SISeg -SIZE_T -SMgrRelation -SMgrRelationData -SMgrSortArray -SOCKADDR -SOCKET -SPELL -SPICallbackArg -SPIExecuteOptions -SPIParseOpenOptions -SPIPlanPtr -SPIPrepareOptions -SPITupleTable -SPLITCOST -SPNode -SPNodeData -SPPageDesc -SQLDropObject -SQLFunctionCache -SQLFunctionCachePtr -SQLFunctionHashEntry -SQLFunctionParseInfo -SQLFunctionParseInfoPtr -SQLValueFunction -SQLValueFunctionOp -SSL -SSLExtensionInfoContext -SSL_CTX -STARTUPINFO -STRLEN -SV -SYNCHRONIZATION_BARRIER -SYSTEM_INFO -SampleScan -SampleScanGetSampleSize_function -SampleScanState +save_buffer +save_locale_t SavedTransactionCharacteristics +SC_HANDLE ScalarArrayOpExpr ScalarArrayOpExprHashEntry ScalarArrayOpExprHashTable @@ -2683,10 +3321,13 @@ ScanKey ScanKeyData ScanKeywordHashFunc ScanKeywordList +ScannerCallbackState ScanState ScanTypeControl -ScannerCallbackState SchemaQuery +scram_state +scram_state_enum +script_error_callback_arg SearchPathCacheEntry SearchPathCacheKey SearchPathMatcher @@ -2694,35 +3335,53 @@ SecBuffer SecBufferDesc SecLabelItem SecLabelStmt +SECURITY_ATTRIBUTES +security_class_t +SECURITY_STATUS SeenRelsEntry +SEG +Selectivity SelectLimit SelectStmt SelectStmtPassthrough -Selectivity SelfJoinCandidate -SemTPadded +sem_t SemiAntiJoinFactors +SemTPadded +sepgsql_context_info_t SeqScan SeqScanState +SeqStateTuple SeqTable SeqTableData SeqType +sequence_magic SequenceItem SerCommitSeqNo SerialControl SerialIOData +SERIALIZABLEXACT SerializableXactHandle -SerializeDestReceiver -SerializeMetrics +SERIALIZABLEXID +SERIALIZABLEXIDTAG SerializedActiveRelMaps SerializedClientConnectionInfo +SerializeDestReceiver SerializedRanges SerializedReindexState SerializedSnapshotData SerializedTransactionState +SerializeMetrics +SERVICE_STATUS +SERVICE_STATUS_HANDLE +SERVICE_TABLE_ENTRY Session SessionBackupState SessionEndType +set_conn_altsock_func +set_conn_oauth_token_func +set_join_pathlist_hook_type +set_rel_pathlist_hook_type SetConstraintState SetConstraintStateData SetConstraintTriggerData @@ -2730,19 +3389,20 @@ SetExprState SetFunctionReturnMode SetOp SetOpCmd +SetOperation +SetOperationStmt SetOpPath SetOpState SetOpStatePerGroup SetOpStatePerGroupData SetOpStatePerInput SetOpStrategy -SetOperation -SetOperationStmt SetQuantifier SetToDefault -SetVarReturningType_context SetupWorkerPtrType -ShDependObjectInfo +SetVarReturningType_context +shared_ts_iter +shared_ts_radix_tree SharedAggInfo SharedBitmapHeapInstrumentation SharedBitmapState @@ -2755,32 +3415,50 @@ SharedIncrementalSortInfo SharedIndexScanInstrumentation SharedInvalCatalogMsg SharedInvalCatcacheMsg -SharedInvalRelSyncMsg +SharedInvalidationMessage SharedInvalRelcacheMsg SharedInvalRelmapMsg +SharedInvalRelSyncMsg SharedInvalSmgrMsg SharedInvalSnapshotMsg -SharedInvalidationMessage SharedJitInstrumentation SharedMemoizeInfo SharedRecordTableEntry SharedRecordTableKey SharedRecordTypmodRegistry +Sharedsort SharedSortInfo SharedTuplestore SharedTuplestoreAccessor SharedTuplestoreChunk SharedTuplestoreParticipant SharedTypmodTableEntry -Sharedsort +ShDependObjectInfo ShellTypeInfo ShippableCacheEntry ShippableCacheKey +shm_mq +shm_mq_handle +shm_mq_iovec +shm_mq_result +shm_toc +shm_toc_entry +shm_toc_estimator +shmem_request_hook_type +shmem_startup_hook_type ShmemIndexEnt ShutdownForeignScan_function ShutdownInformation ShutdownMode +SID_AND_ATTRIBUTES +SID_IDENTIFIER_AUTHORITY +SID_NAME_USE +sig_atomic_t +sigjmp_buf +signal_worker_item +signedbitmapword SignTSVector +sigset_t SimpleActionList SimpleActionListCell SimpleEcontextStackEntry @@ -2792,13 +3470,21 @@ SimpleStats SimpleStringList SimpleStringListCell SingleBoundSortItem +SISeg Size +size_t +SIZE_T SkipPages SkipSupport SkipSupportIncDec SlabBlock SlabContext SlabSlot +slist_head +slist_iter +slist_mutable_iter +slist_node +slock_t SlotInvalidationCauseMap SlotNumber SlotSyncCtxStruct @@ -2811,6 +3497,9 @@ SlruShared SlruSharedData SlruWriteAll SlruWriteAllData +SMgrRelation +SMgrRelationData +SMgrSortArray SnapBuild SnapBuildOnDisk SnapBuildState @@ -2818,11 +3507,16 @@ Snapshot SnapshotData SnapshotType SockAddr +SOCKADDR +SOCKET +socket_set +socklen_t Sort SortBy SortByDir SortByNulls SortCoordinate +SortedPoint SortGroupClause SortItem SortPath @@ -2832,17 +3526,26 @@ SortSupport SortSupportData SortTuple SortTupleComparator -SortedPoint +SpecialJoinInfo +SPELL +spgBulkDeleteState +spgChooseIn +spgChooseOut +spgChooseResultType +spgConfigIn +spgConfigOut +spgInnerConsistentIn +spgInnerConsistentOut SpGistBuildState SpGistCache SpGistDeadTuple SpGistDeadTupleData SpGistInnerTuple SpGistInnerTupleData -SpGistLUPCache SpGistLastUsedPage SpGistLeafTuple SpGistLeafTupleData +SpGistLUPCache SpGistMetaPageData SpGistNodeTuple SpGistNodeTupleData @@ -2854,23 +3557,111 @@ SpGistScanOpaqueData SpGistSearchItem SpGistState SpGistTypeDesc -SpecialJoinInfo +spgLeafConsistentIn +spgLeafConsistentOut +spgNodePtr +spgPickSplitIn +spgPickSplitOut +spgVacPendingItem +spgxlogAddLeaf +spgxlogAddNode +spgxlogMoveLeafs +spgxlogPickSplit +spgxlogSplitTuple +spgxlogState +spgxlogVacuumLeaf +spgxlogVacuumRedirect +spgxlogVacuumRoot +SPICallbackArg +SPIExecuteOptions SpinDelayStatus +SPIParseOpenOptions +SPIPlanPtr +SPIPrepareOptions +SPITupleTable +SPKFlushPosition +SPKRelMetaCacheEntry +split_pathtarget_context +split_pathtarget_item +SPLITCOST SplitInterval SplitLR SplitPageLayout SplitPoint SplitTextOutputData SplitVar +SPNode +SPNodeData +spock_copyState +SpockApplyFunctions +SpockApplyProgress +SpockApplyWorker +SpockConflictResolution +SpockConflictType +SpockContext +SpockExceptionBehaviour +SpockExceptionLog +SpockExceptionLogging +SpockGroupEntry +SpockGroupKey +SpockInterface +SpockLocalNode +SpockNode +SpockOutputData +SpockOutputParamType +SpockOutputSlotGroup +SpockProtoAPI +SpockProtoType +SpockReadonlyMode +SpockRelation +SpockRemoteRel +SpockRepSet +SpockResFileHeader +SpockResolveOption +spockStatsEntry +spockStatsKey +spockStatsType +SpockSubscription +SpockSyncEventMessage +SpockSyncStatus +SpockSyncWorker +SpockTableRepInfo +SpockTupleData +SpockWalMessage +SpockWalMessageSimple +SpockWorker +SpockWorkerStatus +SpockWorkerType +SPPageDesc +sql_error_callback_arg +SQLDropObject +SQLFunctionCache +SQLFunctionCachePtr +SQLFunctionHashEntry +SQLFunctionParseInfo +SQLFunctionParseInfoPtr +sqlparseInfo +sqlparseState +SQLValueFunction +SQLValueFunctionOp +ss_lru_item_t +ss_scan_location_t +ss_scan_locations_t +ssize_t +SSL +SSL_CTX +SSLExtensionInfoContext StackElem +standard_qp_extra StartDataPtrType StartLOPtrType StartLOsPtrType StartReplicationCmd +STARTUPINFO StartupStatusEnum +StateFileChunk StatEntry StatExtEntry -StateFileChunk StatisticExtInfo StatsBuildData StatsData @@ -2879,41 +3670,56 @@ StatsExtInfo StdAnalyzeData StdRdOptIndexCleanup StdRdOptions +stemmer_module Step +stmtCacheEntry StopList +storeInfo +storeRes_func StrategyNumber +stream_stop_callback StreamCtl StreamStopReason +string String StringInfo StringInfoData StripnullState +STRLEN SubLink SubLinkType SubOpts SubPlan SubPlanState -SubRelInfo -SubRemoveRels -SubTransactionId -SubXactCallback -SubXactCallbackItem -SubXactEvent -SubXactInfo SubqueryScan SubqueryScanPath SubqueryScanState SubqueryScanStatus +SubRelInfo +SubRemoveRels SubscriptExecSetup SubscriptExecSteps -SubscriptRoutines -SubscriptTransform SubscriptingRef SubscriptingRefState Subscription SubscriptionInfo SubscriptionRelState -SummarizerReadLocalXLogPrivate +SubscriptionTuple +SubscriptRoutines +SubscriptTransform +substitute_actual_parameters_context +substitute_actual_parameters_in_from_context +substitute_actual_srf_parameters_context +substitute_grouped_columns_context +substitute_phv_relids_context +SubTransactionCommitTsEntry +SubTransactionId +SubXactCallback +SubXactCallbackItem +SubXactEvent +SubXactInfo +subxids_array_status +SummarizerReadLocalXLogPrivate SupportRequestCost SupportRequestIndexCondition SupportRequestInlineInFrom @@ -2923,80 +3729,25 @@ SupportRequestRows SupportRequestSelectivity SupportRequestSimplify SupportRequestWFuncMonotonic +SV +symbol Syn +SYNCHRONIZATION_BARRIER +SyncingRelationsState SyncOps SyncRepConfigData SyncRepStandbyData SyncRequestHandler SyncRequestType SyncStandbySlotsConfigData -SyncingRelationsState -SysFKRelationship -SysScanDesc SyscacheCallbackFunction +SysFKRelationship SysloggerStartupData +SysScanDesc +SYSTEM_INFO SystemRowsSamplerData SystemSamplerData SystemTimeSamplerData -TAPtype -TAR_MEMBER -TBMIterateResult -TBMIteratingState -TBMIterator -TBMPrivateIterator -TBMSharedIterator -TBMSharedIteratorState -TBMStatus -TBlockState -TCPattern -TIDBitmap -TM_FailureData -TM_IndexDelete -TM_IndexDeleteOp -TM_IndexStatus -TM_Result -TOKEN_DEFAULT_DACL -TOKEN_INFORMATION_CLASS -TOKEN_PRIVILEGES -TOKEN_USER -TParser -TParserCharTest -TParserPosition -TParserSpecial -TParserState -TParserStateAction -TParserStateActionItem -TQueueDestReceiver -TRGM -TSAnyCacheEntry -TSConfigCacheEntry -TSConfigInfo -TSDictInfo -TSDictionaryCacheEntry -TSExecuteCallback -TSLexeme -TSParserCacheEntry -TSParserInfo -TSQuery -TSQueryData -TSQueryParserState -TSQuerySign -TSReadPointer -TSTemplateInfo -TSTernaryValue -TSTokenTypeItem -TSTokenTypeStorage -TSVector -TSVectorBuildState -TSVectorData -TSVectorParseState -TSVectorStat -TState -TStatus -TStoreState -TU_UpdateIndexes -TXNEntryFile -TYPCATEGORY T_Action T_WorkerStatus TableAmRoutine @@ -3013,15 +3764,26 @@ TableSampleClause TableScanDesc TableScanDescData TableSpaceCacheEntry -TableSpaceOpts +tablespaceinfo TablespaceList TablespaceListCell +TableSpaceOpts TapeBlockTrailer TapeShare +TAPtype +tar_file +TAR_MEMBER +TargetEntry TarMethodData TarMethodFile -TargetEntry -TclExceptionNameMap +TBlockState +TBMIterateResult +TBMIteratingState +TBMIterator +TBMPrivateIterator +TBMSharedIterator +TBMSharedIteratorState +TBMStatus Tcl_CmdInfo Tcl_DString Tcl_FileProc @@ -3032,17 +3794,30 @@ Tcl_NotifierProcs Tcl_Obj Tcl_Size Tcl_Time +TclExceptionNameMap +TCPattern +td_entry +temp_tablespaces_extra TempNamespaceStatus -TestDSMRegistryHashEntry -TestDSMRegistryStruct +teSection +test_re_flags +test_regex_ctx +test_shm_mq_header +test_spec +test_start_function +test128 TestDecodingData TestDecodingTxnData +TestDSMRegistryHashEntry +TestDSMRegistryStruct TestSpec TestValueType +text TextFreq TextPositionState TheLexeme TheSubstitute +TIDBitmap TidExpr TidExprType TidHashKey @@ -3056,40 +3831,72 @@ TidScanState TidStore TidStoreIter TidStoreIterResult +time_t TimeADT +timeKEY TimeLineHistoryCmd TimeLineHistoryEntry TimeLineID TimeOffset -TimeStamp -TimeTzADT -TimeZoneAbbrevTable +timeout_handler_proc +timeout_params TimeoutId TimeoutType +timerCA Timestamp +TimeStamp TimestampTz +TimeTzADT +TimeZoneAbbrevTable +tlist_vinfo +TM_FailureData +TM_IndexDelete +TM_IndexDeleteOp +TM_IndexStatus +TM_Result TmFromChar TmToChar +toast_compress_header ToastAttrInfo ToastCompressionId -ToastTupleContext ToastedAttribute +ToastTupleContext TocEntry +TOKEN_DEFAULT_DACL +TOKEN_INFORMATION_CLASS +TOKEN_PRIVILEGES +TOKEN_USER TokenAuxData +tokenize_error_callback_arg TokenizedAuthLine +TParser +TParserCharTest +TParserPosition +TParserSpecial +TParserState +TParserStateAction +TParserStateActionItem +TQueueDestReceiver TrackItem -TransApplyAction -TransInvalidationInfo -TransState TransactionId TransactionState TransactionStateData TransactionStmt TransactionStmtKind TransamVariablesData +TransApplyAction +transfer_thread_arg +transferMode TransformInfo TransformJsonStringValuesState +TransInvalidationInfo TransitionCaptureState +TransState +tree_mutator_callback +tree_walker_callback +trgm +TRGM +trgm_mb_char TrgmArc TrgmArcInfo TrgmBound @@ -3112,21 +3919,51 @@ TriggerEvent TriggerFlags TriggerInfo TriggerTransition +trivalue TruncateStmt +ts_parserstate +ts_tokenizer +ts_tokentype +TSAnyCacheEntry +TSConfigCacheEntry +TSConfigInfo +TSDictInfo +TSDictionaryCacheEntry +tsearch_readline_state +TSExecuteCallback +tsKEY +TSLexeme TsmRoutine -TupOutputState -TupSortStatus -TupStoreStatus +TSParserCacheEntry +TSParserInfo +TSQuery +TSQueryData +TSQueryParserState +TSQuerySign +TSReadPointer +TState +TStatus +TSTemplateInfo +TSTernaryValue +TSTokenTypeItem +TSTokenTypeStorage +TStoreState +TSVector +TSVectorBuildState +TSVectorData +TSVectorParseState +TSVectorStat +TU_UpdateIndexes TupleConstr TupleConversionMap TupleDesc +tuplehash_hash +tuplehash_iterator TupleHashEntry TupleHashEntryData TupleHashIterator TupleHashTable TupleQueueReader -TupleTableSlot -TupleTableSlotOps TuplesortClusterArg TuplesortDatumArg TuplesortIndexArg @@ -3138,6 +3975,11 @@ TuplesortPublic TuplesortSpaceType Tuplesortstate Tuplestorestate +TupleTableSlot +TupleTableSlotOps +TupOutputState +TupSortStatus +TupStoreStatus TwoPhaseCallback TwoPhaseFileHeader TwoPhaseLockRecord @@ -3149,6 +3991,9 @@ TwoPhasePredicateXactRecord TwoPhaseRecordOnDisk TwoPhaseRmgrId TwoPhaseStateData +TXNEntryFile +TYPCATEGORY +type Type TypeCacheEntry TypeCacheEnumData @@ -3158,27 +4003,54 @@ TypeFuncClass TypeInfo TypeName TzAbbrevCache +tzEntry +u_char +u_int U32 U8 +ua_page_items +ua_page_stats UChar UCharIterator +uchr UColAttributeValue UCollator UConverter UErrorCode +uid_t UINT +uint_fast64_t +uint128 +uint16 +uint16_t +uint16x8_t +uint32 +uint32_t +uint32x4_t +uint64 +uint64_t +uint64x2_t +uint8 +uint8_t +uint8x16_t +uintptr_t ULARGE_INTEGER ULONG ULONG_PTR -UV -UVersionInfo +unicode_linestyle UnicodeNormalizationForm UnicodeNormalizationQC +unicodeStyleBorderFormat +unicodeStyleColumnFormat +unicodeStyleFormat +unicodeStyleRowFormat Unique UniquePath UniqueRelInfo UniqueState +unit_conversion UnlistenStmt +unlogged_relation_entry UnresolvedTup UnresolvedTupData UpdateContext @@ -3195,41 +4067,58 @@ UserAuth UserContext UserMapping UserOpts +utf_local_conversion_func +uuid_rc_t +uuid_sortsupport_state +uuid_t +uuidKEY +UV +UVersionInfo +va_list VacAttrStats VacAttrStatsP VacDeadItemsInfo VacErrPhase VacOptValue +vacuumingOptions VacuumParams VacuumRelation VacuumStmt -ValidIOData +validate_string_relopt ValidateIndexState ValidatorModuleResult ValidatorModuleState ValidatorShutdownCB ValidatorStartupCB ValidatorValidateCB +ValidIOData ValuesScan ValuesScanState Var +varatt_expanded +varattrib_1b +varattrib_1b_e +varattrib_4b VarBit VarChar -VarParamState -VarReturningType -VarString -VarStringSortSupport Variable VariableAssignHook +Variables VariableSetKind VariableSetStmt VariableShowStmt VariableSpace VariableStatData VariableSubstituteHook -Variables +VarParamState +VarReturningType +VarString +VarStringSortSupport +vartag_external +vbits Vector32 Vector8 +verifier_context VersionedQuery Vfd ViewCheckOption @@ -3241,24 +4130,6 @@ VirtualTupleTableSlot VolatileFunctionStatus Vsrt WAIT_ORDER -WALAvailability -WALInsertLock -WALInsertLockPadded -WALOpenSegment -WALReadError -WALSegmentCloseCB -WALSegmentContext -WALSegmentOpenCB -WCHAR -WCOKind -WFW_WaitOption -WIDGET -WORD -WORKSTATE -WSABUF -WSADATA -WSANETWORKEVENTS -WSAPROTOCOL_INFO WaitEvent WaitEventActivity WaitEventBufferPin @@ -3276,18 +4147,44 @@ WaitLSNState WaitLSNType WaitPMResult WaitStmt +WALAvailability WalCloseMethod WalCompression +Walfile WalInsertClass +WALInsertLock +WALInsertLockPadded WalLevel +WALOpenSegment +walrcv_alter_slot_fn +walrcv_check_conninfo_fn +walrcv_connect_fn +walrcv_create_slot_fn +walrcv_disconnect_fn +walrcv_endstreaming_fn +walrcv_exec_fn +walrcv_get_backend_pid_fn +walrcv_get_conninfo_fn +walrcv_get_dbname_from_conninfo_fn +walrcv_get_senderinfo_fn +walrcv_identify_system_fn +walrcv_readtimelinehistoryfile_fn +walrcv_receive_fn +walrcv_send_fn +walrcv_server_version_fn +walrcv_startstreaming_fn WalRcvData WalRcvExecResult WalRcvExecStatus WalRcvState WalRcvStreamOptions WalRcvWakeupReason +WALReadError WalReceiverConn WalReceiverFunctionsType +WALSegmentCloseCB +WALSegmentContext +WALSegmentOpenCB WalSnd WalSndCtlData WalSndSendDataCallback @@ -3299,7 +4196,13 @@ WalTimeSample WalUsage WalWriteMethod WalWriteMethodOps -Walfile +WCHAR +wchar_t +wchar2mb_with_len_converter +WCOKind +WFW_WaitOption +WIDGET +win32_deadchild_waitinfo WindowAgg WindowAggPath WindowAggState @@ -3316,22 +4219,30 @@ WindowObjectData WindowStatePerAgg WindowStatePerAggData WindowStatePerFunc +wint_t WithCheckOption WithClause +WORD WordBoundaryNext WordEntry WordEntryIN WordEntryPos WordEntryPosVector WordEntryPosVector1 -WorkTableScan -WorkTableScanState +worker_state WorkerInfo WorkerInfoData WorkerInstrumentation WorkerJobDumpPtrType WorkerJobRestorePtrType +Workflow Working_State +WORKSTATE +worktable +WorkTableScan +WorkTableScanState +wrap +WritebackContext WriteBufPtrType WriteBytePtrType WriteDataCallback @@ -3340,14 +4251,115 @@ WriteExtraTocPtrType WriteFunc WriteManifestState WriteTarState -WritebackContext +ws_file_info +ws_options +WSABUF +WSADATA +WSANETWORKEVENTS +WSAPROTOCOL_INFO X509 X509_EXTENSION X509_NAME X509_NAME_ENTRY X509_STORE X509_STORE_CTX -XLTW_Oper +XactCallback +XactCallbackItem +XactEvent +XactLockTableWaitInfo +XidBoundsViolation +XidCacheStatus +XidCommitStatus +XidStatus +xl_brin_createidx +xl_brin_desummarize +xl_brin_insert +xl_brin_revmap_extend +xl_brin_samepage_update +xl_brin_update +xl_btree_dedup +xl_btree_delete +xl_btree_insert +xl_btree_mark_page_halfdead +xl_btree_metadata +xl_btree_newroot +xl_btree_reuse_page +xl_btree_split +xl_btree_unlink_page +xl_btree_update +xl_btree_vacuum +xl_clog_truncate +xl_commit_ts_truncate +xl_dbase_create_file_copy_rec +xl_dbase_create_wal_log_rec +xl_dbase_drop_rec +xl_end_of_recovery +xl_hash_add_ovfl_page +xl_hash_delete +xl_hash_init_bitmap_page +xl_hash_init_meta_page +xl_hash_insert +xl_hash_move_page_contents +xl_hash_split_allocate_page +xl_hash_split_complete +xl_hash_squeeze_page +xl_hash_update_meta_page +xl_hash_vacuum_one_page +xl_heap_confirm +xl_heap_delete +xl_heap_header +xl_heap_inplace +xl_heap_insert +xl_heap_lock +xl_heap_lock_updated +xl_heap_multi_insert +xl_heap_new_cid +xl_heap_prune +xl_heap_rewrite_mapping +xl_heap_truncate +xl_heap_update +xl_heap_visible +xl_invalid_page +xl_invalid_page_key +xl_invalidations +xl_logical_message +xl_multi_insert_tuple +xl_multixact_create +xl_multixact_truncate +xl_overwrite_contrecord +xl_parameter_change +xl_relmap_update +xl_replorigin_drop +xl_replorigin_set +xl_restore_point +xl_running_xacts +xl_seq_rec +xl_smgr_create +xl_smgr_truncate +xl_standby_lock +xl_standby_locks +xl_tblspc_create_rec +xl_tblspc_drop_rec +xl_testcustomrmgrs_message +xl_xact_abort +xl_xact_assignment +xl_xact_commit +xl_xact_dbinfo +xl_xact_invals +xl_xact_origin +xl_xact_parsed_abort +xl_xact_parsed_commit +xl_xact_parsed_prepare +xl_xact_prepare +xl_xact_relfilelocators +xl_xact_stats_item +xl_xact_stats_items +xl_xact_subxacts +xl_xact_twophase +xl_xact_xinfo +xlhp_freeze_plan +xlhp_freeze_plans +xlhp_prune_items XLogCtlData XLogCtlInsert XLogDumpConfig @@ -3359,1340 +4371,74 @@ XLogPageHeaderData XLogPageReadCB XLogPageReadPrivate XLogPageReadResult -XLogPrefetchStats XLogPrefetcher XLogPrefetcherFilter +XLogPrefetchStats XLogReaderRoutine XLogReaderState XLogRecData -XLogRecPtr -XLogRecStats XLogRecord XLogRecordBlockCompressHeader XLogRecordBlockHeader XLogRecordBlockImageHeader XLogRecordBuffer XLogRecoveryCtlData +XLogRecPtr +XLogRecStats XLogRedoAction XLogSegNo XLogSource XLogStats XLogwrtResult XLogwrtRqst -XPV -XPVIV -XPVMG -XactCallback -XactCallbackItem -XactEvent -XactLockTableWaitInfo -XidBoundsViolation -XidCacheStatus -XidCommitStatus -XidStatus +XLTW_Oper +xmlBuffer +xmlBufferPtr +xmlChar +xmlDocPtr +xmlError +xmlErrorPtr XmlExpr XmlExprOp +xmlExternalEntityLoader +xmlGenericErrorFunc +xmlNodePtr +xmlNodeSetPtr XmlOptionType +xmlParserCtxtPtr +xmlParserInputPtr +xmlSaveCtxt +xmlSaveCtxtPtr XmlSerialize +xmlStructuredErrorFunc XmlTableBuilderData +xmlTextWriter +xmlTextWriterPtr +xmltype +xmlXPathCompExprPtr +xmlXPathContextPtr +xmlXPathObjectPtr +xpath_workspace +XPV +XPVIV +XPVMG +xsltSecurityPrefsPtr +xsltStylesheetPtr +xsltTransformContextPtr +YY_BUFFER_STATE +yy_parser +yy_size_t YYLTYPE +yyscan_t YYSTYPE -YY_BUFFER_STATE +z_stream +z_streamp +zic_t ZSTD_CCtx +ZSTD_cParameter ZSTD_CStream ZSTD_DCtx ZSTD_DStream -ZSTD_cParameter ZSTD_inBuffer ZSTD_outBuffer ZstdCompressorState -_SPI_connection -_SPI_plan -__m128i -__m512i -__mmask64 -__time64_t -_dev_t -_ino_t -_locale_t -_resultmap -_stringlist -access_vector_t -acquireLocksOnSubLinks_context -addFkConstraintSides -add_nulling_relids_context -adjust_appendrel_attrs_context -amadjustmembers_function -ambeginscan_function -ambuild_function -ambuildempty_function -ambuildphasename_function -ambulkdelete_function -amcanreturn_function -amcostestimate_function -amendscan_function -amestimateparallelscan_function -amgetbitmap_function -amgettreeheight_function -amgettuple_function -aminitparallelscan_function -aminsert_function -aminsertcleanup_function -ammarkpos_function -amoptions_function -amparallelrescan_function -amproperty_function -amrescan_function -amrestrpos_function -amtranslate_cmptype_function -amtranslate_strategy_function -amvacuumcleanup_function -amvalidate_function -array_iter -array_unnest_fctx -assign_collations_context -astreamer -astreamer_archive_context -astreamer_extractor -astreamer_gzip_decompressor -astreamer_gzip_writer -astreamer_lz4_frame -astreamer_member -astreamer_ops -astreamer_plain_writer -astreamer_recovery_injector -astreamer_tar_archiver -astreamer_tar_parser -astreamer_verify -astreamer_zstd_frame -auth_password_hook_typ -autovac_table -av_relation -avc_cache -avl_dbase -avl_node -avl_tree -avw_dbase -backslashResult -backup_file_entry -backup_file_hash -backup_manifest_info -backup_manifest_option -backup_wal_range -base_yy_extra_type -basebackup_options -bbsink -bbsink_copystream -bbsink_gzip -bbsink_lz4 -bbsink_ops -bbsink_server -bbsink_shell -bbsink_state -bbsink_throttle -bbsink_zstd -bgworker_main_type -bh_node_type -binaryheap -binaryheap_comparator -bitmapword -bits16 -bits32 -bits8 -blockreftable_hash -blockreftable_iterator -bloom_filter -boolKEY -brin_column_state -brin_serialize_callback_type -btree_gin_convert_function -btree_gin_leftmost_function -bytea -cached_re_str -canonicalize_state -cashKEY -catalogid_hash -cb_cleanup_dir -cb_options -cb_tablespace -cb_tablespace_mapping -char16_t -char32_t -check_agg_arguments_context -check_function_callback -check_network_data -check_object_relabel_type -check_password_hook_type -child_process_kind -chr -cmpEntriesArg -codes_t -collation_cache_entry -collation_cache_hash -color -colormaprange -compare_context -config_handle -config_var_value -conn_errorMessage_func -conn_oauth_client_id_func -conn_oauth_client_secret_func -conn_oauth_discovery_uri_func -conn_oauth_issuer_id_func -conn_oauth_scope_func -conn_sasl_state_func -contain_aggs_of_level_context -contain_placeholder_references_context -convert_testexpr_context -copy_data_dest_cb -copy_data_source_cb -core_YYSTYPE -core_yy_extra_type -core_yyscan_t -corrupt_items -cost_qual_eval_context -count_param_references_context -cp_hash_func -create_upper_paths_hook_type -createdb_failure_params -crosstab_HashEnt -crosstab_cat_desc -curl_infotype -curl_socket_t -curl_version_info_data -datapagemap_iterator_t -datapagemap_t -dateKEY -datetkn -dce_uuid_t -dclist_head -decimal -deparse_columns -deparse_context -deparse_expr_cxt -deparse_namespace -derives_hash -dev_t -disassembledLeaf -dlist_head -dlist_iter -dlist_mutable_iter -dlist_node -dm_code -dm_codes -dm_letter -dm_node -ds_state -dsa_area -dsa_area_control -dsa_area_pool -dsa_area_span -dsa_handle -dsa_pointer -dsa_pointer_atomic -dsa_segment_header -dsa_segment_index -dsa_segment_map -dshash_compare_function -dshash_copy_function -dshash_hash -dshash_hash_function -dshash_parameters -dshash_partition -dshash_seq_status -dshash_table -dshash_table_control -dshash_table_handle -dshash_table_item -dsm_control_header -dsm_control_item -dsm_handle -dsm_op -dsm_segment -dsm_segment_detach_callback -duration -eLogType -ean13 -eary -ec_matches_callback_type -ec_member_foreign_arg -ec_member_matches_arg -element_type -emit_log_hook_type -eval_const_expressions_context -exec_thread_arg -execution_state -exit_function -explain_get_index_name_hook_type -explain_per_node_hook_type -explain_per_plan_hook_type -explain_validate_options_hook_type -f_smgr -fasthash_state -fd_set -fe_oauth_state -fe_scram_state -fe_scram_state_enum -fetch_range_request -file_action_t -file_content_type_t -file_entry_t -file_type_t -filehash_hash -filehash_iterator -filemap_t -fill_string_relopt -finalize_primnode_context -find_dependent_phvs_context -find_expr_references_context -fireRIRonSubLink_context -fix_join_expr_context -fix_scan_expr_context -fix_upper_expr_context -fix_windowagg_cond_context -flatten_join_alias_vars_context -flatten_rtes_walker_context -float4 -float4KEY -float8 -float8KEY -floating_decimal_32 -floating_decimal_64 -fmgr_hook_type -foreign_glob_cxt -foreign_loc_cxt -freefunc -fsec_t -gbt_vsrt_arg -gbtree_ninfo -gbtree_vinfo -generate_series_fctx -generate_series_numeric_fctx -generate_series_timestamp_fctx -generate_series_timestamptz_fctx -generate_subscripts_fctx -get_attavgwidth_hook_type -get_index_stats_hook_type -get_relation_info_hook_type -get_relation_stats_hook_type -gid_t -gin_leafpage_items_state -ginxlogCreatePostingTree -ginxlogDeleteListPages -ginxlogDeletePage -ginxlogInsert -ginxlogInsertDataInternal -ginxlogInsertEntry -ginxlogInsertListPage -ginxlogRecompressDataLeaf -ginxlogSplit -ginxlogUpdateMeta -ginxlogVacuumDataLeafPage -gistxlogDelete -gistxlogPage -gistxlogPageDelete -gistxlogPageReuse -gistxlogPageSplit -gistxlogPageUpdate -grouping_sets_data -gseg_picksplit_item -gss_OID_set -gss_buffer_desc -gss_cred_id_t -gss_cred_usage_t -gss_ctx_id_t -gss_key_value_element_desc -gss_key_value_set_desc -gss_name_t -gtrgm_consistent_cache -gzFile -heap_page_items_state -help_handler -hlCheck -hstoreCheckKeyLen_t -hstoreCheckValLen_t -hstorePairs_t -hstoreUniquePairs_t -hstoreUpgrade_t -hyperLogLogState -ifState -import_error_callback_arg -indexed_tlist -inet -inetKEY -inet_struct -initRowMethod -init_function -inline_cte_walker_context -inline_error_callback_arg -ino_t -inquiry -instr_time -int128 -int16 -int16KEY -int16_t -int2vector -int32 -int32KEY -int32_t -int64 -int64KEY -int64_t -int8 -int8_t -int8x16_t -int_fast32_t -int_fast64_t -internalPQconninfoOption -intmax_t -intptr_t -intset_internal_node -intset_leaf_node -intset_node -intvKEY -io_callback_fn -io_stat_col -itemIdCompact -itemIdCompactData -iterator -jmp_buf -join_search_hook_type -json_aelem_action -json_manifest_error_callback -json_manifest_per_file_callback -json_manifest_per_wal_range_callback -json_manifest_system_identifier_callback -json_manifest_version_callback -json_ofield_action -json_scalar_action -json_struct_action -keepwal_entry -keepwal_hash -keyEntryData -key_t -lclContext -lclTocEntry -leafSegmentInfo -leaf_item -libpq_gettext_func -libpq_source -libpqsrv_PGresult -line_t -lineno_t -list_sort_comparator -loc_chunk -local_relopt -local_relopts -local_source -local_ts_iter -local_ts_radix_tree -locale_t -locate_agg_of_level_context -locate_var_of_level_context -locate_windowfunc_context -logstreamer_param -lquery -lquery_level -lquery_variant -ltree -ltree_gist -ltree_level -ltxtquery -mXactCacheEnt -mac8KEY -macKEY -macaddr -macaddr8 -macaddr_sortsupport_state -manifest_data -manifest_file -manifest_files_hash -manifest_files_iterator -manifest_wal_range -manifest_writer -map_variable_attnos_context -max_parallel_hazard_context -mb2wchar_with_len_converter -mbchar_verifier -mbcharacter_incrementer -mbdisplaylen_converter -mblen_converter -mbstr_verifier -memoize_hash -memoize_iterator -metastring -missing_cache_key -mix_data_t -mode_t -movedb_failure_params -multirange_bsearch_comparison -multirange_unnest_fctx -mxact -mxtruncinfo -needs_fmgr_hook_type -network_sortsupport_state -nl_item -nodeitem -normal_rand_fctx -nsphash_hash -ntile_context -nullingrel_info -numeric -object_access_hook_type -object_access_hook_type_str -off_t -oidKEY -oidvector -on_dsm_detach_callback -on_exit_nicely_callback -openssl_tls_init_hook_typ -ossl_EVP_cipher_func -other -output_type -overexplain_options -pagetable_hash -pagetable_iterator -pairingheap -pairingheap_comparator -pairingheap_node -pam_handle_t -parallel_worker_main_type -parse_error_callback_arg -partition_method_t -pe_test_config -pe_test_escape_func -pe_test_vector -pendingPosition -pending_label -pgParameterStatus -pg_atomic_flag -pg_atomic_uint32 -pg_atomic_uint64 -pg_be_sasl_mech -pg_category_range -pg_checksum_context -pg_checksum_raw_context -pg_checksum_type -pg_compress_algorithm -pg_compress_specification -pg_conn_host -pg_conn_host_type -pg_conv_map -pg_crc32 -pg_crc32c -pg_cryptohash_ctx -pg_cryptohash_errno -pg_cryptohash_type -pg_ctype_cache -pg_enc -pg_enc2name -pg_encname -pg_fe_sasl_mech -pg_funcptr_t -pg_gssinfo -pg_hmac_ctx -pg_hmac_errno -pg_local_to_utf_combined -pg_locale_t -pg_mb_radix_tree -pg_md5_ctx -pg_on_exit_callback -pg_prng_state -pg_re_flags -pg_regex_t -pg_regmatch_t -pg_regoff_t -pg_saslprep_rc -pg_sha1_ctx -pg_sha224_ctx -pg_sha256_ctx -pg_sha384_ctx -pg_sha512_ctx -pg_snapshot -pg_special_case -pg_stack_base_t -pg_time_t -pg_time_usec_t -pg_tz -pg_tz_cache -pg_tzenum -pg_unicode_category -pg_unicode_decompinfo -pg_unicode_decomposition -pg_unicode_norminfo -pg_unicode_normprops -pg_unicode_properties -pg_unicode_range -pg_unicode_recompinfo -pg_usec_time_t -pg_utf_to_local_combined -pg_uuid_t -pg_wchar -pg_wchar_tbl -pgp_armor_headers_state -pgsocket -pgsql_thing_t -pgssEntry -pgssGlobalStats -pgssHashKey -pgssSharedState -pgssStoreKind -pgssVersion -pgstat_entry_ref_hash_hash -pgstat_entry_ref_hash_iterator -pgstat_page -pgstat_snapshot_hash -pgstattuple_type -pgthreadlock_t -pid_t -pivot_field -planner_hook_type -planner_setup_hook_type -planner_shutdown_hook_type -planstate_tree_walker_callback -plperl_array_info -plperl_call_data -plperl_interp_desc -plperl_proc_desc -plperl_proc_key -plperl_proc_ptr -plperl_query_desc -plperl_query_entry -plpgsql_CastExprHashEntry -plpgsql_CastHashEntry -plpgsql_CastHashKey -plpgsql_expr_walker_callback -plpgsql_stmt_walker_callback -pltcl_call_state -pltcl_interp_desc -pltcl_proc_desc -pltcl_proc_key -pltcl_proc_ptr -pltcl_query_desc -pointer -polymorphic_actuals -pos_trgm -post_parse_analyze_hook_type -postprocess_result_function -pqbool -pqsigfunc -printQueryOpt -printTableContent -printTableFooter -printTableOpt -printTextFormat -printTextLineFormat -printTextLineWrap -printTextRule -printXheaderWidthType -priv_map -process_file_callback_t -process_sublinks_context -proclist_head -proclist_mutable_iter -proclist_node -promptStatus_t -pthread_barrier_t -pthread_cond_t -pthread_key_t -pthread_mutex_t -pthread_once_t -pthread_t -ptrdiff_t -published_rel -pull_var_clause_context -pull_varattnos_context -pull_varnos_context -pull_vars_context -pullup_replace_vars_context -pushdown_safe_type -pushdown_safety_info -qc_hash_func -qsort_arg_comparator -qsort_comparator -query_pathkeys_callback -radius_attribute -radius_packet -rangeTableEntry_used_context -rank_context -rbt_allocfunc -rbt_combiner -rbt_comparator -rbt_freefunc -reduce_outer_joins_partial_state -reduce_outer_joins_pass1_state -reduce_outer_joins_pass2_state -reference -regc_wc_probefunc -regex_arc_t -regexp -regexp_matches_ctx -registered_buffer -regproc -relopt_bool -relopt_enum -relopt_enum_elt_def -relopt_gen -relopt_int -relopt_kind -relopt_parse_elt -relopt_real -relopt_string -relopt_type -relopt_value -relopts_validator -remoteConn -remoteConnHashEnt -remoteDep -remove_nulling_relids_context -rendezvousHashEntry -rep -replace_rte_variables_callback -replace_rte_variables_context -report_error_fn -ret_type -rewind_source -rewrite_event -rf_context -rfile -rm_detail_t -role_auth_extra -rolename_hash -row_security_policy_hook_type -rsv_callback -rt_iter -rt_node_class_test_elem -rt_radix_tree -saophash_hash -save_buffer -save_locale_t -scram_state -scram_state_enum -script_error_callback_arg -security_class_t -sem_t -sepgsql_context_info_t -sequence_magic -set_conn_altsock_func -set_conn_oauth_token_func -set_join_pathlist_hook_type -set_rel_pathlist_hook_type -shared_ts_iter -shared_ts_radix_tree -shm_mq -shm_mq_handle -shm_mq_iovec -shm_mq_result -shm_toc -shm_toc_entry -shm_toc_estimator -shmem_request_hook_type -shmem_startup_hook_type -sig_atomic_t -sigjmp_buf -signedbitmapword -sigset_t -size_t -slist_head -slist_iter -slist_mutable_iter -slist_node -slock_t -socket_set -socklen_t -spgBulkDeleteState -spgChooseIn -spgChooseOut -spgChooseResultType -spgConfigIn -spgConfigOut -spgInnerConsistentIn -spgInnerConsistentOut -spgLeafConsistentIn -spgLeafConsistentOut -spgNodePtr -spgPickSplitIn -spgPickSplitOut -spgVacPendingItem -spgxlogAddLeaf -spgxlogAddNode -spgxlogMoveLeafs -spgxlogPickSplit -spgxlogSplitTuple -spgxlogState -spgxlogVacuumLeaf -spgxlogVacuumRedirect -spgxlogVacuumRoot -split_pathtarget_context -split_pathtarget_item -sql_error_callback_arg -sqlparseInfo -sqlparseState -ss_lru_item_t -ss_scan_location_t -ss_scan_locations_t -ssize_t -standard_qp_extra -stemmer_module -stmtCacheEntry -storeInfo -storeRes_func -stream_stop_callback -string -substitute_actual_parameters_context -substitute_actual_parameters_in_from_context -substitute_actual_srf_parameters_context -substitute_grouped_columns_context -substitute_phv_relids_context -subxids_array_status -symbol -tablespaceinfo -tar_file -td_entry -teSection -temp_tablespaces_extra -test128 -test_re_flags -test_regex_ctx -test_shm_mq_header -test_spec -test_start_function -text -timeKEY -time_t -timeout_handler_proc -timeout_params -timerCA -tlist_vinfo -toast_compress_header -tokenize_error_callback_arg -transferMode -transfer_thread_arg -tree_mutator_callback -tree_walker_callback -trgm -trgm_mb_char -trivalue -tsKEY -ts_parserstate -ts_tokenizer -ts_tokentype -tsearch_readline_state -tuplehash_hash -tuplehash_iterator -type -tzEntry -u_char -u_int -ua_page_items -ua_page_stats -uchr -uid_t -uint128 -uint16 -uint16_t -uint16x8_t -uint32 -uint32_t -uint32x4_t -uint64 -uint64_t -uint64x2_t -uint8 -uint8_t -uint8x16_t -uint_fast64_t -uintptr_t -unicodeStyleBorderFormat -unicodeStyleColumnFormat -unicodeStyleFormat -unicodeStyleRowFormat -unicode_linestyle -unit_conversion -unlogged_relation_entry -utf_local_conversion_func -uuidKEY -uuid_rc_t -uuid_sortsupport_state -uuid_t -va_list -vacuumingOptions -validate_string_relopt -varatt_expanded -varattrib_1b -varattrib_1b_e -varattrib_4b -vartag_external -vbits -verifier_context -walrcv_alter_slot_fn -walrcv_check_conninfo_fn -walrcv_connect_fn -walrcv_create_slot_fn -walrcv_disconnect_fn -walrcv_endstreaming_fn -walrcv_exec_fn -walrcv_get_backend_pid_fn -walrcv_get_conninfo_fn -walrcv_get_dbname_from_conninfo_fn -walrcv_get_senderinfo_fn -walrcv_identify_system_fn -walrcv_readtimelinehistoryfile_fn -walrcv_receive_fn -walrcv_send_fn -walrcv_server_version_fn -walrcv_startstreaming_fn -wchar2mb_with_len_converter -wchar_t -win32_deadchild_waitinfo -wint_t -worker_state -worktable -wrap -ws_file_info -ws_options -xl_brin_createidx -xl_brin_desummarize -xl_brin_insert -xl_brin_revmap_extend -xl_brin_samepage_update -xl_brin_update -xl_btree_dedup -xl_btree_delete -xl_btree_insert -xl_btree_mark_page_halfdead -xl_btree_metadata -xl_btree_newroot -xl_btree_reuse_page -xl_btree_split -xl_btree_unlink_page -xl_btree_update -xl_btree_vacuum -xl_clog_truncate -xl_commit_ts_truncate -xl_dbase_create_file_copy_rec -xl_dbase_create_wal_log_rec -xl_dbase_drop_rec -xl_end_of_recovery -xl_hash_add_ovfl_page -xl_hash_delete -xl_hash_init_bitmap_page -xl_hash_init_meta_page -xl_hash_insert -xl_hash_move_page_contents -xl_hash_split_allocate_page -xl_hash_split_complete -xl_hash_squeeze_page -xl_hash_update_meta_page -xl_hash_vacuum_one_page -xl_heap_confirm -xl_heap_delete -xl_heap_header -xl_heap_inplace -xl_heap_insert -xl_heap_lock -xl_heap_lock_updated -xl_heap_multi_insert -xl_heap_new_cid -xl_heap_prune -xl_heap_rewrite_mapping -xl_heap_truncate -xl_heap_update -xl_heap_visible -xl_invalid_page -xl_invalid_page_key -xl_invalidations -xl_logical_message -xl_multi_insert_tuple -xl_multixact_create -xl_multixact_truncate -xl_overwrite_contrecord -xl_parameter_change -xl_relmap_update -xl_replorigin_drop -xl_replorigin_set -xl_restore_point -xl_running_xacts -xl_seq_rec -xl_smgr_create -xl_smgr_truncate -xl_standby_lock -xl_standby_locks -xl_tblspc_create_rec -xl_tblspc_drop_rec -xl_testcustomrmgrs_message -xl_xact_abort -xl_xact_assignment -xl_xact_commit -xl_xact_dbinfo -xl_xact_invals -xl_xact_origin -xl_xact_parsed_abort -xl_xact_parsed_commit -xl_xact_parsed_prepare -xl_xact_prepare -xl_xact_relfilelocators -xl_xact_stats_item -xl_xact_stats_items -xl_xact_subxacts -xl_xact_twophase -xl_xact_xinfo -xlhp_freeze_plan -xlhp_freeze_plans -xlhp_prune_items -xmlBuffer -xmlBufferPtr -xmlChar -xmlDocPtr -xmlError -xmlErrorPtr -xmlExternalEntityLoader -xmlGenericErrorFunc -xmlNodePtr -xmlNodeSetPtr -xmlParserCtxtPtr -xmlParserInputPtr -xmlSaveCtxt -xmlSaveCtxtPtr -xmlStructuredErrorFunc -xmlTextWriter -xmlTextWriterPtr -xmlXPathCompExprPtr -xmlXPathContextPtr -xmlXPathObjectPtr -xmltype -xpath_workspace -xsltSecurityPrefsPtr -xsltStylesheetPtr -xsltTransformContextPtr -yy_parser -yy_size_t -yyscan_t -z_stream -z_streamp -zic_t -SpockTupleData -SpockSyncStatus -SpockResFileHeader -DumpCtx -SpockGroupKey -SpockApplyProgress -SpockGroupEntry -SpockExceptionLog -SpockOutputData -SpockOutputSlotGroup -SpockWalMessageSimple -SpockSyncEventMessage -SpockRepSet -SpockTableRepInfo -RepSetTableTuple -QueuedMessage -SpockNode -SpockInterface -SpockLocalNode -SpockSubscription -SpockApplyWorker -SpockSyncWorker -SpockWorker -SpockContext -spockStatsKey -spockStatsEntry -JsonbInState -UserContext -SpockApplyProgress -SpockGroupEntry -SubTransactionCommitTsEntry -SpockProtoAPI -SpockRemoteRel -SpockRelation - - - - - -Step -Workflow -FormData_spock_depend -ObjectAddressExtra -ObjectAddressStack -find_expr_references_context -signal_worker_item -SeqStateTuple -spock_copyState -SPKRelMetaCacheEntry -RepSetTuple -RepSetSeqTuple -RepSetTableTuple -OutputPluginParam -RemoteSlot -FailoverSlotFilter -QueueTuple -NodeTuple -NodeInterfaceTuple -SubscriptionTuple -ApplyExecutionData -ApplyExecState -ApplyMIState -ApplyReplayEntryData -SpockApplyFunctions -SPKFlushPosition -ApplyExecState -ActionErrCallbackArg -RemoteSyncPosition -SpockReadonlyMode -GroupProgressTupDescColumns -SpockExceptionBehaviour -SpockExceptionLogging -SpockWorkerType -SpockWorkerStatus -spockStatsType -JsonbTypeCategory -SpockProtoType -SpockConflictResolution -SpockResolveOption -SpockConflictType -LogLevel -SpockOutputParamType -OutputPluginParamKey -/* -FailoverSlotFilterKey -SpockTupleData -SpockSyncStatus -SpockResFileHeader -DumpCtx -SpockGroupKey -SpockApplyProgress -SpockGroupEntry -SpockExceptionLog -SpockOutputData -SpockOutputSlotGroup -SpockWalMessageSimple -SpockSyncEventMessage -SpockRepSet -SpockTableRepInfo -RepSetTableTuple -QueuedMessage -SpockNode -SpockInterface -SpockLocalNode -SpockSubscription -SpockApplyWorker -SpockSyncWorker -spockStatsKey -spockStatsEntry -JsonbInState -UserContext -SpockApplyProgress -SpockGroupEntry -SubTransactionCommitTsEntry -SpockProtoAPI -SpockRemoteRel -SpockRelation -Step -Workflow -FormData_spock_depend -ObjectAddressExtra -ObjectAddressStack -find_expr_references_context -signal_worker_item -SPKRelMetaCacheEntry -RepSetTuple -RepSetSeqTuple -RepSetTableTuple -OutputPluginParam -RemoteSlot -FailoverSlotFilter -QueueTuple -NodeTuple -NodeInterfaceTuple -SubscriptionTuple -ApplyExecutionData -ApplyExecState -ApplyMIState -ApplyReplayEntryData -SPKFlushPosition -ApplyExecState -ActionErrCallbackArg -RemoteSyncPosition -SpockReadonlyMode - -SpockExceptionBehaviour -SpockExceptionLogging -spockStatsType -/* -SpockProtoType -SpockConflictResolution - -SpockConflictType -SpockOutputParamType -/* -FailoverSlotFilterKey -SpockTupleData -SpockSyncStatus -SpockResFileHeader -DumpCtx -SpockGroupKey -SpockApplyProgress -SpockGroupEntry -SpockExceptionLog -SpockOutputData -SpockOutputSlotGroup -SpockWalMessageSimple -SpockSyncEventMessage -SpockRepSet -SpockTableRepInfo -RepSetTableTuple -QueuedMessage -SpockNode -SpockInterface -SpockLocalNode -SpockSubscription -SpockApplyWorker -SpockSyncWorker -SpockWorker -SpockContext -spockStatsKey -spockStatsEntry -JsonbInState -UserContext -SpockApplyProgress -SpockGroupEntry -SubTransactionCommitTsEntry -SpockProtoAPI -SpockRemoteRel -SpockRelation - - - - - -Step -Workflow -FormData_spock_depend -ObjectAddressExtra -ObjectAddressStack -find_expr_references_context -signal_worker_item -SeqStateTuple -SPKRelMetaCacheEntry -RepSetTuple -RepSetSeqTuple -RepSetTableTuple -OutputPluginParam -RemoteSlot -FailoverSlotFilter -QueueTuple -NodeTuple -NodeInterfaceTuple -SubscriptionTuple -ApplyExecutionData -ApplyExecState -ApplyMIState -ApplyReplayEntryData -SPKFlushPosition -ApplyExecState -ActionErrCallbackArg -RemoteSyncPosition -SpockReadonlyMode - -SpockExceptionBehaviour -SpockExceptionLogging - - -spockStatsType -/* -SpockProtoType -SpockConflictResolution - -SpockConflictType - -SpockOutputParamType -OutputPluginParamKey -/* -FailoverSlotFilterKey -SpockWalMessage -SpockTupleData -SpockSyncStatus -SpockResFileHeader -DumpCtx -SpockGroupKey -SpockApplyProgress -SpockGroupEntry -SpockExceptionLog -SpockOutputData -SpockOutputSlotGroup -SpockWalMessageSimple -SpockSyncEventMessage -SpockRepSet -SpockTableRepInfo -RepSetTableTuple -QueuedMessage -SpockNode -SpockInterface -SpockLocalNode -SpockSubscription -SpockApplyWorker -SpockSyncWorker -SpockWorker -SpockContext -spockStatsKey -spockStatsEntry -JsonbInState -UserContext -SpockApplyProgress -SpockGroupEntry -SubTransactionCommitTsEntry -SpockProtoAPI -SpockRemoteRel -SpockRelation - - - - - -Step -Workflow -FormData_spock_depend -ObjectAddressExtra -ObjectAddressStack -find_expr_references_context -signal_worker_item -SeqStateTuple -SPKRelMetaCacheEntry -RepSetTuple -RepSetSeqTuple -RepSetTableTuple -OutputPluginParam -RemoteSlot -FailoverSlotFilter -QueueTuple -NodeTuple -NodeInterfaceTuple -SubscriptionTuple -ApplyExecutionData -ApplyExecState -ApplyMIState -ApplyReplayEntryData -SPKFlushPosition -ApplyExecState -ActionErrCallbackArg -RemoteSyncPosition -SpockReadonlyMode - -SpockExceptionBehaviour -SpockExceptionLogging - - -spockStatsType -/* -SpockProtoType -SpockConflictResolution - -SpockConflictType - -SpockOutputParamType -OutputPluginParamKey -/* -FailoverSlotFilterKey -SpockWalMessage From 5af4d0fc22ad2f68862b29bf0601ef9bbf62d68b Mon Sep 17 00:00:00 2001 From: "Andrei V. Lepikhov" Date: Wed, 7 Jan 2026 11:10:10 +0100 Subject: [PATCH 2/6] Exclude spockctrl from pgindent processing spockctrl is a standalone CLI utility that doesn't follow PostgreSQL coding conventions. Exclude it from typedef scanning and pgindent to avoid processing errors. --- utils/pgindent/gen-typedefs.sh | 10 ++++++---- 1 file changed, 6 insertions(+), 4 deletions(-) diff --git a/utils/pgindent/gen-typedefs.sh b/utils/pgindent/gen-typedefs.sh index 329ac01b..41381a3f 100755 --- a/utils/pgindent/gen-typedefs.sh +++ b/utils/pgindent/gen-typedefs.sh @@ -4,14 +4,16 @@ curl https://buildfarm.postgresql.org/cgi-bin/typedefs.pl > typedefs.list # Extract Spock-specific typedefs from source code and append them -grep -nri "typedef struct" ../../ --include="*.c" --include="*.h" | grep -v "{" | awk '{print $3}' >> typedefs.list -grep -nri "typedef enum" ../../ --include="*.c" --include="*.h" | grep -v "{" | awk '{print $3}' >> typedefs.list -grep -nri "typedef union" ../../ --include="*.c" --include="*.h" | grep -v "{" | awk '{print $3}' >> typedefs.list +# Exclude spockctrl (standalone CLI utility, not PostgreSQL extension code) +grep -nri "typedef struct" ../../ --include="*.c" --include="*.h" --exclude-dir=spockctrl | grep -v "{" | awk '{print $3}' >> typedefs.list +grep -nri "typedef enum" ../../ --include="*.c" --include="*.h" --exclude-dir=spockctrl | grep -v "{" | awk '{print $3}' >> typedefs.list +grep -nri "typedef union" ../../ --include="*.c" --include="*.h" --exclude-dir=spockctrl | grep -v "{" | awk '{print $3}' >> typedefs.list # Remove duplicates and sort sort typedefs.list | uniq > typedefs.list.tmp && mv typedefs.list.tmp typedefs.list -find ../../ -type f \( -name "*.c" -o -name "*.h" \) -print0 \ +find ../../ -type f \( -name "*.c" -o -name "*.h" \) \ + -not -path "../../utils/spockctrl/*" -print0 \ | xargs -0 pgindent --typedefs typedefs.list From 4c32dc078bbad45e43038189290f679e52e1f867 Mon Sep 17 00:00:00 2001 From: "Andrei V. Lepikhov" Date: Wed, 7 Jan 2026 11:18:25 +0100 Subject: [PATCH 3/6] Add pgindent check workflow for pull requests Automatically validates code formatting on PRs to main branch using pgindent. Builds pg_bsd_indent from PostgreSQL source, runs gen-typedefs.sh, and fails if formatting issues are detected. --- .github/workflows/pgindent-check.yml | 54 ++++++++++++++++++++++++++++ 1 file changed, 54 insertions(+) create mode 100644 .github/workflows/pgindent-check.yml diff --git a/.github/workflows/pgindent-check.yml b/.github/workflows/pgindent-check.yml new file mode 100644 index 00000000..ce007dec --- /dev/null +++ b/.github/workflows/pgindent-check.yml @@ -0,0 +1,54 @@ +name: pgindent check + +on: + pull_request: + branches: + - main + +jobs: + pgindent: + runs-on: ubuntu-latest + + steps: + - name: Checkout code + uses: actions/checkout@v4 + + - name: Install dependencies + run: | + sudo apt-get update + sudo apt-get install -y \ + curl \ + build-essential \ + libreadline-dev \ + zlib1g-dev \ + flex \ + bison \ + libxml2-dev \ + libxslt1-dev \ + libssl-dev + + - name: Clone and build pg_bsd_indent + run: | + git clone https://git.postgresql.org/git/postgresql.git --depth 1 --branch master /tmp/postgresql + cd /tmp/postgresql + ./configure --prefix=/tmp/pg-build > /dev/null + cd src/tools/pg_bsd_indent + make > /dev/null + echo "$GITHUB_WORKSPACE/pg-install/bin" >> $GITHUB_PATH + echo "/tmp/postgresql/src/tools/pgindent" >> $GITHUB_PATH + echo "/tmp/postgresql/src/tools/pg_bsd_indent" >> $GITHUB_PATH + + - name: Run gen-typedefs.sh and check formatting + working-directory: utils/pgindent + run: | + chmod +x gen-typedefs.sh + ./gen-typedefs.sh + + - name: Check for formatting changes + run: | + if ! git diff --quiet; then + echo "::error::Code formatting issues detected. Please run gen-typedefs.sh locally." + git diff + exit 1 + fi + echo "All files are properly formatted." From acc92b130d35edd40e4b3c37cb37c88346fde6b3 Mon Sep 17 00:00:00 2001 From: "Andrei V. Lepikhov" Date: Wed, 7 Jan 2026 11:41:27 +0100 Subject: [PATCH 4/6] Rename gen-typedefs.sh to run-pgindent.sh Better name reflects the script's actual purpose: running pgindent on all source files. Updated README and GitHub workflow accordingly. --- .github/workflows/pgindent-check.yml | 6 +++--- utils/pgindent/README.md | 21 +++++++++++-------- .../{gen-typedefs.sh => run-pgindent.sh} | 0 3 files changed, 15 insertions(+), 12 deletions(-) rename utils/pgindent/{gen-typedefs.sh => run-pgindent.sh} (100%) diff --git a/.github/workflows/pgindent-check.yml b/.github/workflows/pgindent-check.yml index ce007dec..ee9b97e4 100644 --- a/.github/workflows/pgindent-check.yml +++ b/.github/workflows/pgindent-check.yml @@ -38,11 +38,11 @@ jobs: echo "/tmp/postgresql/src/tools/pgindent" >> $GITHUB_PATH echo "/tmp/postgresql/src/tools/pg_bsd_indent" >> $GITHUB_PATH - - name: Run gen-typedefs.sh and check formatting + - name: Run pgindent and check formatting working-directory: utils/pgindent run: | - chmod +x gen-typedefs.sh - ./gen-typedefs.sh + chmod +x run-pgindent.sh + ./run-pgindent.sh - name: Check for formatting changes run: | diff --git a/utils/pgindent/README.md b/utils/pgindent/README.md index 958ab073..81337a16 100644 --- a/utils/pgindent/README.md +++ b/utils/pgindent/README.md @@ -1,12 +1,15 @@ ## Running pgindent on spock files -1. Generate typedefs.list by running `./gen-typedefs.sh`. This will pull the latest postgres typedefs from postgres buildfarm and add Spock-related typedefs to it by scanning the source code. -2. Install pg_bsd_indent: navigate to src/tools/pg_bsd_indent in your postgres source code and run: - ``` - make install prefix=/usr/local - ``` -3. Assuming you have pgindent in your path, run this from spock base directory: - ``` - pgindent --typedefs=pgindent/typedefs.list - ``` +1. Run `./run-pgindent.sh` to format all code. This script will: + - Pull the latest PostgreSQL typedefs from buildfarm + - Extract Spock-specific typedefs by scanning the source code + - Run pgindent on all .c and .h files (excluding spockctrl) +2. Prerequisites: + - Install pg_bsd_indent: navigate to src/tools/pg_bsd_indent in your postgres source code and run: + ``` + make install prefix=/usr/local + ``` + - Ensure pgindent is in your PATH (from PostgreSQL source: src/tools/pgindent/pgindent) + +3. File typedefs.list stays in repository to log changes in the struct set of the core and the Spock. diff --git a/utils/pgindent/gen-typedefs.sh b/utils/pgindent/run-pgindent.sh similarity index 100% rename from utils/pgindent/gen-typedefs.sh rename to utils/pgindent/run-pgindent.sh From 5d9007edaff0337db6b2e7a2283d3c13e06ba64b Mon Sep 17 00:00:00 2001 From: "Andrei V. Lepikhov" Date: Wed, 7 Jan 2026 11:42:41 +0100 Subject: [PATCH 5/6] pgindent run The workflow now ignores typedefs.list changes. Note: Spock is used with different PostgreSQL versions, which can cause different pgindent results due to varying typedef lists from the buildfarm. This is inevitable - contributors should simply run run-pgindent.sh on their current master branch to ensure consistency. --- .github/workflows/pgindent-check.yml | 4 +- include/spock.h | 2 +- include/spock_conflict.h | 44 +++++++------- include/spock_group.h | 2 +- include/spock_jsonb_utils.h | 2 +- include/spock_proto_native.h | 1 - include/spock_relcache.h | 2 +- include/spock_worker.h | 4 +- src/compat/18/spock_compat.c | 8 +-- src/spock.c | 2 +- src/spock_apply.c | 19 +++--- src/spock_apply_heap.c | 34 ++++++----- src/spock_autoddl.c | 28 +++++---- src/spock_conflict.c | 4 +- src/spock_dependency.c | 4 +- src/spock_executor.c | 15 ++--- src/spock_functions.c | 89 ++++++++++++++-------------- src/spock_output_plugin.c | 4 +- src/spock_proto_json.c | 2 +- src/spock_proto_native.c | 2 +- src/spock_relcache.c | 34 +++++------ src/spock_repset.c | 4 +- src/spock_sync.c | 4 +- src/spock_worker.c | 4 +- utils/pgindent/typedefs.list | 65 ++++++++++++++------ 25 files changed, 209 insertions(+), 174 deletions(-) diff --git a/.github/workflows/pgindent-check.yml b/.github/workflows/pgindent-check.yml index ee9b97e4..c5b33481 100644 --- a/.github/workflows/pgindent-check.yml +++ b/.github/workflows/pgindent-check.yml @@ -46,8 +46,10 @@ jobs: - name: Check for formatting changes run: | + # Ignore changes in typedefs.list (it's expected to update) + git checkout utils/pgindent/typedefs.list if ! git diff --quiet; then - echo "::error::Code formatting issues detected. Please run gen-typedefs.sh locally." + echo "::error::Code formatting issues detected. Please run run-pgindent.sh locally." git diff exit 1 fi diff --git a/include/spock.h b/include/spock.h index 4725e860..67c640e8 100644 --- a/include/spock.h +++ b/include/spock.h @@ -52,7 +52,7 @@ extern int restart_delay_default; extern int restart_delay_on_exception; extern int spock_replay_queue_size; /* Deprecated - no longer used */ extern bool check_all_uc_indexes; -extern bool spock_enable_quiet_mode; +extern bool spock_enable_quiet_mode; extern char *shorten_hash(const char *str, int maxlen); diff --git a/include/spock_conflict.h b/include/spock_conflict.h index 7605e3c2..a6b03cff 100644 --- a/include/spock_conflict.h +++ b/include/spock_conflict.h @@ -37,7 +37,7 @@ typedef enum SPOCK_RESOLVE_KEEP_LOCAL, SPOCK_RESOLVE_LAST_UPDATE_WINS, SPOCK_RESOLVE_FIRST_UPDATE_WINS -} SpockResolveOption; +} SpockResolveOption; extern int spock_conflict_resolver; extern int spock_conflict_log_level; @@ -53,35 +53,35 @@ extern bool spock_save_resolutions; */ typedef enum { - /* The row to be inserted violates unique constraint */ - CT_INSERT_EXISTS, + /* The row to be inserted violates unique constraint */ + CT_INSERT_EXISTS, - /* The row to be updated was modified by a different origin */ - CT_UPDATE_ORIGIN_DIFFERS, + /* The row to be updated was modified by a different origin */ + CT_UPDATE_ORIGIN_DIFFERS, - /* The updated row value violates unique constraint */ - CT_UPDATE_EXISTS, + /* The updated row value violates unique constraint */ + CT_UPDATE_EXISTS, - /* The row to be updated is missing */ - CT_UPDATE_MISSING, + /* The row to be updated is missing */ + CT_UPDATE_MISSING, - /* The row to be deleted was modified by a different origin */ - CT_DELETE_ORIGIN_DIFFERS, + /* The row to be deleted was modified by a different origin */ + CT_DELETE_ORIGIN_DIFFERS, - /* The row to be deleted is missing */ - CT_DELETE_MISSING + /* The row to be deleted is missing */ + CT_DELETE_MISSING - /* - * Other conflicts, such as exclusion constraint violations, involve more - * complex rules than simple equality checks. These conflicts are left for - * future improvements. - */ + /* + * Other conflicts, such as exclusion constraint violations, involve more + * complex rules than simple equality checks. These conflicts are left for + * future improvements. + */ } ConflictType; #endif -extern int spock_conflict_resolver; -extern int spock_conflict_log_level; -extern bool spock_save_resolutions; +extern int spock_conflict_resolver; +extern int spock_conflict_log_level; +extern bool spock_save_resolutions; extern bool get_tuple_origin(SpockRelation *rel, HeapTuple local_tuple, ItemPointer tid, TransactionId *xmin, @@ -125,4 +125,4 @@ extern bool spock_conflict_resolver_check_hook(int *newval, void **extra, extern void tuple_to_stringinfo(StringInfo s, TupleDesc tupdesc, HeapTuple tuple); -#endif /* SPOCK_CONFLICT_H */ +#endif /* SPOCK_CONFLICT_H */ diff --git a/include/spock_group.h b/include/spock_group.h index c98fed39..650f4d5e 100644 --- a/include/spock_group.h +++ b/include/spock_group.h @@ -81,7 +81,7 @@ typedef enum /* The last value */ _GP_LAST_ -} GroupProgressTupDescColumns; +} GroupProgressTupDescColumns; /* * Logical Replication Progress has made by a group of apply workers. diff --git a/include/spock_jsonb_utils.h b/include/spock_jsonb_utils.h index d5678665..2c9b1a7c 100644 --- a/include/spock_jsonb_utils.h +++ b/include/spock_jsonb_utils.h @@ -20,7 +20,7 @@ typedef enum /* type categories for datum_to_jsonb */ JSONBTYPE_COMPOSITE, /* composite */ JSONBTYPE_JSONCAST, /* something with an explicit cast to JSON */ JSONBTYPE_OTHER /* all else */ -} JsonbTypeCategory; +} JsonbTypeCategory; typedef struct JsonbInState { diff --git a/include/spock_proto_native.h b/include/spock_proto_native.h index 04837998..77d335ff 100644 --- a/include/spock_proto_native.h +++ b/include/spock_proto_native.h @@ -76,4 +76,3 @@ extern void spock_apply_set_proto_version(uint32 version); extern uint32 spock_apply_get_proto_version(void); #endif /* SPOCK_PROTO_NATIVE_H */ - diff --git a/include/spock_relcache.h b/include/spock_relcache.h index a9a689de..2d507416 100644 --- a/include/spock_relcache.h +++ b/include/spock_relcache.h @@ -69,7 +69,7 @@ extern void spock_relation_cache_reset(void); extern Oid spock_lookup_delta_function(char *fname, Oid typeoid); -extern Oid get_replication_identity(Relation rel); +extern Oid get_replication_identity(Relation rel); struct SpockTupleData; diff --git a/include/spock_worker.h b/include/spock_worker.h index 42c870e4..f77f335b 100644 --- a/include/spock_worker.h +++ b/include/spock_worker.h @@ -26,7 +26,7 @@ typedef enum SPOCK_WORKER_APPLY, /* Apply. */ SPOCK_WORKER_SYNC /* Special type of Apply that synchronizes one * table. */ -} SpockWorkerType; +} SpockWorkerType; typedef enum { @@ -36,7 +36,7 @@ typedef enum SPOCK_WORKER_STATUS_STOPPING, /* Stopping. */ SPOCK_WORKER_STATUS_STOPPED, /* Stopped. */ SPOCK_WORKER_STATUS_FAILED, /* Failed. */ -} SpockWorkerStatus; +} SpockWorkerStatus; typedef struct SpockApplyWorker { diff --git a/src/compat/18/spock_compat.c b/src/compat/18/spock_compat.c index 90e432c7..7adba757 100644 --- a/src/compat/18/spock_compat.c +++ b/src/compat/18/spock_compat.c @@ -130,10 +130,10 @@ check_simple_rowfilter_expr_walker(Node *node, ParseState *pstate) } /* - * Check if the row filter expression is a "simple expression". - * - * See check_simple_rowfilter_expr_walker for details. - */ + * Check if the row filter expression is a "simple expression". + * + * See check_simple_rowfilter_expr_walker for details. + */ bool check_simple_rowfilter_expr(Node *node, ParseState *pstate) { diff --git a/src/spock.c b/src/spock.c index 09741621..d8f248ea 100644 --- a/src/spock.c +++ b/src/spock.c @@ -910,7 +910,7 @@ log_message_filter(ErrorData *edata) static void spock_object_relabel(const ObjectAddress *object, const char *seclabel) { - Oid extoid; + Oid extoid; extoid = get_extension_oid(EXTENSION_NAME, true); if (!OidIsValid(extoid)) diff --git a/src/spock_apply.c b/src/spock_apply.c index 51f496d2..3683e866 100644 --- a/src/spock_apply.c +++ b/src/spock_apply.c @@ -3128,10 +3128,10 @@ apply_work(PGconn *streamConn) * we still need to ensure proper cleanup (e.g., disabling the * subscription). * - * Handle SUB_DISABLE mode for both cases: xact_had_exception means DML - * operations failed during exception handling, while use_try_block - * without xact_had_exception means an error occurred after successful - * retry (e.g., TRANSDISCARD throwing ERROR). + * Handle SUB_DISABLE mode for both cases: xact_had_exception means + * DML operations failed during exception handling, while + * use_try_block without xact_had_exception means an error occurred + * after successful retry (e.g., TRANSDISCARD throwing ERROR). * * Note: spock_disable_subscription() handles transaction management * internally, so no need to wrap it in StartTransactionCommand(). @@ -3156,9 +3156,9 @@ apply_work(PGconn *streamConn) /* * For other exceptions with use_try_block, where xact_had_exception - * is false, this indicates an ERROR occurred during exception handling - * (e.g., connection died, CommitTransactionCommand failure during - * TRANSDISCARD logging, etc.). + * is false, this indicates an ERROR occurred during exception + * handling (e.g., connection died, CommitTransactionCommand failure + * during TRANSDISCARD logging, etc.). * * We log the error and re-throw to exit the worker. The background * worker infrastructure will restart the worker automatically. This @@ -3424,9 +3424,8 @@ spock_execute_sql_command(char *cmdstr, char *role, bool isTopLevel) /* * check if it's a DDL statement. we only do this for - * in_spock_replicate_ddl_command - * SECURITY LABEL command is not a DDL, just an utility one. Hence, let - * spock execute this command. + * in_spock_replicate_ddl_command SECURITY LABEL command is not a DDL, + * just an utility one. Hence, let spock execute this command. */ if (in_spock_replicate_ddl_command && GetCommandLogLevel(command->stmt) != LOGSTMT_DDL && diff --git a/src/spock_apply_heap.c b/src/spock_apply_heap.c index cdc917ca..1e7aa8fe 100644 --- a/src/spock_apply_heap.c +++ b/src/spock_apply_heap.c @@ -611,20 +611,20 @@ build_delta_tuple(SpockRelation *rel, SpockTupleData *oldtup, } /* - * This shouldn't happen: creating delta_apply column we must check that - * NOT NULL constraint is set on this column or reject. But just to - * survive in case of a bug we complain and send the apply worker to - * exception behavior path way. + * This shouldn't happen: creating delta_apply column we must check + * that NOT NULL constraint is set on this column or reject. But just + * to survive in case of a bug we complain and send the apply worker + * to exception behavior path way. */ if (oldtup->nulls[remoteattnum] || newtup->nulls[remoteattnum]) ereport(ERROR, (errcode(ERRCODE_NULL_VALUE_NOT_ALLOWED), - errmsg("delta apply column can't operate NULL values"), - errdetail("attribute %d for remote tuple is %s, and for the local tuple is %s", - remoteattnum + 1, - newtup->nulls[remoteattnum] ? "NULL" : "NOT NULL", - oldtup->nulls[remoteattnum] ? "NULL" : "NOT NULL" - ))); + errmsg("delta apply column can't operate NULL values"), + errdetail("attribute %d for remote tuple is %s, and for the local tuple is %s", + remoteattnum + 1, + newtup->nulls[remoteattnum] ? "NULL" : "NOT NULL", + oldtup->nulls[remoteattnum] ? "NULL" : "NOT NULL" + ))); loc_value = heap_getattr(TTS_TUP(localslot), remoteattnum + 1, tupdesc, &loc_isnull); @@ -746,8 +746,9 @@ spock_handle_conflict_and_apply(SpockRelation *rel, EState *estate, } /* - * See if we need to log any conflict to the server log and spock.resolutions - * Calling this does not necessarily mean that there is a conflict + * See if we need to log any conflict to the server log and + * spock.resolutions Calling this does not necessarily mean that there is + * a conflict */ spock_report_conflict(is_insert ? CT_INSERT_EXISTS : CT_UPDATE_EXISTS, rel, TTS_TUP(localslot), oldtup, @@ -1054,8 +1055,8 @@ spock_apply_heap_update(SpockRelation *rel, SpockTupleData *oldtup, * * Note this will fail if there are other conflicting unique indexes. * - * spock_handle_conflict_and_apply is a misnomer as it is called for - * the normal UPDATE case, too. + * spock_handle_conflict_and_apply is a misnomer as it is called for the + * normal UPDATE case, too. */ if (found) { @@ -1065,7 +1066,10 @@ spock_apply_heap_update(SpockRelation *rel, SpockTupleData *oldtup, } else { - /* CT_UPDATE_MISSING case gets logged in exception_log, not resolutions */ + /* + * CT_UPDATE_MISSING case gets logged in exception_log, not + * resolutions + */ SpockExceptionLog *exception_log = &exception_log_ptr[my_exception_log_index]; /* diff --git a/src/spock_autoddl.c b/src/spock_autoddl.c index cb4e37b3..e1ec390f 100644 --- a/src/spock_autoddl.c +++ b/src/spock_autoddl.c @@ -80,8 +80,9 @@ spock_autoddl_process(PlannedStmt *pstmt, PushActiveSnapshot(GetTransactionSnapshot()); /* - * Elevate access rights: Utility hook is called under the session user, who - * does not necessarily have access permission to Spock extension objects. + * Elevate access rights: Utility hook is called under the session user, + * who does not necessarily have access permission to Spock extension + * objects. */ GetUserIdAndSecContext(&save_userid, &save_sec_context); SetUserIdAndSecContext(BOOTSTRAP_SUPERUSERID, @@ -121,14 +122,14 @@ spock_autoddl_process(PlannedStmt *pstmt, void add_ddl_to_repset(Node *parsetree) { - Relation targetrel; - SpockRepSet *repset; + Relation targetrel; + SpockRepSet *repset; SpockLocalNode *node; - Oid reloid = InvalidOid; - RangeVar *relation = NULL; - List *reloids = NIL; - ListCell *lc; - bool missing_ok = false; + Oid reloid = InvalidOid; + RangeVar *relation = NULL; + List *reloids = NIL; + ListCell *lc; + bool missing_ok = false; /* no need to proceed if spock_include_ddl_repset is off */ if (!spock_include_ddl_repset) @@ -223,10 +224,11 @@ add_ddl_to_repset(Node *parsetree) { targetrel = table_openrv_extended(relation, AccessShareLock, missing_ok); if (targetrel == NULL) - /* - * If relation doesn't exist - quietly exit. It is assumed that the core - * already produced an INFO message. - */ + + /* + * If relation doesn't exist - quietly exit. It is assumed that + * the core already produced an INFO message. + */ return; } diff --git a/src/spock_conflict.c b/src/spock_conflict.c index 0987ecd9..f619a805 100644 --- a/src/spock_conflict.c +++ b/src/spock_conflict.c @@ -700,8 +700,8 @@ tuple_to_stringinfo(StringInfo s, TupleDesc tupdesc, HeapTuple tuple) attr = TupleDescAttr(tupdesc, natt); /* - * don't print dropped or generated columns, we can't be sure everything - * is available for them + * don't print dropped or generated columns, we can't be sure + * everything is available for them */ if (attr->attisdropped || attr->attgenerated) continue; diff --git a/src/spock_dependency.c b/src/spock_dependency.c index a53ca168..c83063a1 100644 --- a/src/spock_dependency.c +++ b/src/spock_dependency.c @@ -716,8 +716,8 @@ reportDependentObjects(const ObjectAddresses *targetObjects, * operating environment. */ if (spock_enable_quiet_mode || (behavior == DROP_CASCADE && - msglevel < my_client_min_messages && - (msglevel < my_log_min_messages || my_log_min_messages == LOG))) + msglevel < my_client_min_messages && + (msglevel < my_log_min_messages || my_log_min_messages == LOG))) return; /* diff --git a/src/spock_executor.c b/src/spock_executor.c index 0cc291a1..a820a1f2 100644 --- a/src/spock_executor.c +++ b/src/spock_executor.c @@ -239,7 +239,7 @@ spock_object_access(ObjectAccessType access, { Oid save_userid = 0; int save_sec_context = 0; - ObjectAddress object; + ObjectAddress object; if (next_object_access_hook) (*next_object_access_hook) (access, classId, objectId, subId, arg); @@ -313,14 +313,15 @@ spock_object_access(ObjectAccessType access, /* SECURITY LABEL related section (see delta_apply for more details) */ else if (access == OAT_POST_ALTER && subId > 0) { - char *label; + char *label; /* - * Something changes in the definition of the column. We have not enough - * data at the moment to check if the column will satisfy delta_apply - * type requirements. So, just warn and drop security label, if exists. - * TODO: the direction of further improvement is discovery of syscache - * or querying the table definition in attempt to identify the new type. + * Something changes in the definition of the column. We have not + * enough data at the moment to check if the column will satisfy + * delta_apply type requirements. So, just warn and drop security + * label, if exists. TODO: the direction of further improvement is + * discovery of syscache or querying the table definition in attempt + * to identify the new type. */ ObjectAddressSubSet(object, classId, objectId, subId); label = GetSecurityLabel(&object, "spock"); diff --git a/src/spock_functions.c b/src/spock_functions.c index aed5f8ee..c914c2b0 100644 --- a/src/spock_functions.c +++ b/src/spock_functions.c @@ -2154,12 +2154,12 @@ spock_auto_replicate_ddl(const char *query, List *replication_sets, /* * Filter local commands and decide on search path setting. * - * We label command as 'local' sometimes to state the fact that the protocol - * does not support its replication. + * We label command as 'local' sometimes to state the fact that the + * protocol does not support its replication. */ switch (nodeTag(stmt)) { - /* Purely local commands */ + /* Purely local commands */ case T_FetchStmt: case T_NotifyStmt: case T_ListenStmt: @@ -2167,9 +2167,10 @@ spock_auto_replicate_ddl(const char *query, List *replication_sets, goto skip_ddl; break; - /* - * We don't want to replicate statements that run outside of transactions - */ + /* + * We don't want to replicate statements that run outside of + * transactions + */ case T_CreateTableSpaceStmt: case T_DropTableSpaceStmt: case T_VacuumStmt: @@ -2233,33 +2234,33 @@ spock_auto_replicate_ddl(const char *query, List *replication_sets, break; case T_ClusterStmt: - { - ClusterStmt *cstmt = (ClusterStmt *) stmt; - bool skip_cluster = true; - - if (cstmt->relation != NULL) { - Relation rel; - Oid tableOid; + ClusterStmt *cstmt = (ClusterStmt *) stmt; + bool skip_cluster = true; - /* - * Single relation case may be allowed if it is not a - * partitioned table. Don't care about errors - if we replicate - * this command it means everything must be ok, or we are in - * trouble and deserve an ERROR. - */ - tableOid = RangeVarGetRelidExtended(cstmt->relation, - AccessShareLock, 0, NULL, NULL); - rel = table_open(tableOid, NoLock); - skip_cluster = (rel->rd_rel->relkind == RELKIND_PARTITIONED_TABLE); - table_close(rel, AccessShareLock); - } + if (cstmt->relation != NULL) + { + Relation rel; + Oid tableOid; - if (skip_cluster) - goto skip_ddl; + /* + * Single relation case may be allowed if it is not a + * partitioned table. Don't care about errors - if we + * replicate this command it means everything must be ok, + * or we are in trouble and deserve an ERROR. + */ + tableOid = RangeVarGetRelidExtended(cstmt->relation, + AccessShareLock, 0, NULL, NULL); + rel = table_open(tableOid, NoLock); + skip_cluster = (rel->rd_rel->relkind == RELKIND_PARTITIONED_TABLE); + table_close(rel, AccessShareLock); + } - add_search_path = false; - } + if (skip_cluster) + goto skip_ddl; + + add_search_path = false; + } break; case T_AlterTableSpaceOptionsStmt: @@ -2287,22 +2288,22 @@ spock_auto_replicate_ddl(const char *query, List *replication_sets, goto skip_ddl; break; case T_ReindexStmt: - { - ReindexStmt *rstmt = (ReindexStmt *) stmt; - bool concurrently = false; - - foreach(lc, rstmt->params) { - DefElem *opt = (DefElem *) lfirst(lc); + ReindexStmt *rstmt = (ReindexStmt *) stmt; + bool concurrently = false; - if (strcmp(opt->defname, "concurrently") != 0) - continue; - concurrently = defGetBoolean(opt); - } + foreach(lc, rstmt->params) + { + DefElem *opt = (DefElem *) lfirst(lc); - if (concurrently) - goto skip_ddl; - } + if (strcmp(opt->defname, "concurrently") != 0) + continue; + concurrently = defGetBoolean(opt); + } + + if (concurrently) + goto skip_ddl; + } break; case T_DropStmt: @@ -2344,8 +2345,8 @@ spock_auto_replicate_ddl(const char *query, List *replication_sets, } /* - * Report replication status. In quiet mode, downgrade INFO/WARNING to - * LOG level to reduce output verbosity. + * Report replication status. In quiet mode, downgrade INFO/WARNING to LOG + * level to reduce output verbosity. */ if (warn) elog(spock_enable_quiet_mode ? LOG : WARNING, diff --git a/src/spock_output_plugin.c b/src/spock_output_plugin.c index ab45a463..4abb812d 100644 --- a/src/spock_output_plugin.c +++ b/src/spock_output_plugin.c @@ -1363,8 +1363,8 @@ spock_output_plugin_shmem_request(void) prev_shmem_request_hook(); /* - * This is kludge for Windows (Postgres does not define the GUC variable as - * PGDDLIMPORT) + * This is kludge for Windows (Postgres does not define the GUC variable + * as PGDDLIMPORT) */ nworkers = atoi(GetConfigOptionByName("max_worker_processes", NULL, false)); diff --git a/src/spock_proto_json.c b/src/spock_proto_json.c index b6baed0c..662852db 100644 --- a/src/spock_proto_json.c +++ b/src/spock_proto_json.c @@ -522,7 +522,7 @@ static void array_to_json_internal(Datum array, StringInfo result, bool use_line_feeds) { ArrayType *v = DatumGetArrayTypeP(array); - Oid element_type = ARR_ELEMTYPE(v); + Oid element_type = ARR_ELEMTYPE(v); int *dim; int ndim; int nitems; diff --git a/src/spock_proto_native.c b/src/spock_proto_native.c index 4a209342..4ef3aca1 100644 --- a/src/spock_proto_native.c +++ b/src/spock_proto_native.c @@ -613,7 +613,7 @@ spock_write_message(StringInfo out, TransactionId xid, XLogRecPtr lsn, if (spock_get_proto_version() >= 5) pq_sendint64(out, GetXLogWriteRecPtr()); - pq_sendbyte(out, 'M'); /* message type field */ + pq_sendbyte(out, 'M'); /* message type field */ /* send out message contents */ pq_sendint32(out, xid); diff --git a/src/spock_relcache.c b/src/spock_relcache.c index 2758b5d4..e0fff36c 100644 --- a/src/spock_relcache.c +++ b/src/spock_relcache.c @@ -85,9 +85,9 @@ spock_relation_open(uint32 remoteid, LOCKMODE lockmode) /* Need to update the local cache? */ if (!OidIsValid(entry->reloid)) { - RangeVar *rv = makeNode(RangeVar); - int i; - ResultRelInfo *relinfo; + RangeVar *rv = makeNode(RangeVar); + int i; + ResultRelInfo *relinfo; rv->schemaname = (char *) entry->nspname; rv->relname = (char *) entry->relname; @@ -98,9 +98,9 @@ spock_relation_open(uint32 remoteid, LOCKMODE lockmode) for (i = 0; i < entry->natts; i++) { - ObjectAddress object; - char *seclabel; - TupleDesc desc; + ObjectAddress object; + char *seclabel; + TupleDesc desc; desc = RelationGetDescr(entry->rel); entry->attmap[i] = tupdesc_get_att_by_name(desc, entry->attnames[i]); @@ -109,8 +109,8 @@ spock_relation_open(uint32 remoteid, LOCKMODE lockmode) continue; /* - * Read security labels for each attname. For each such an attribute - * choose corresponding delta function. + * Read security labels for each attname. For each such an + * attribute choose corresponding delta function. * * XXX: What about non-existing columns on remote side? */ @@ -120,8 +120,8 @@ spock_relation_open(uint32 remoteid, LOCKMODE lockmode) seclabel = GetSecurityLabel(&object, SPOCK_SECLABEL_PROVIDER); if (seclabel != NULL) { - Form_pg_attribute att; - Oid dfunc; + Form_pg_attribute att; + Oid dfunc; att = TupleDescAttr(desc, entry->attmap[i]); dfunc = spock_lookup_delta_function(seclabel, att->atttypid); @@ -149,11 +149,11 @@ spock_relation_open(uint32 remoteid, LOCKMODE lockmode) if (entry->has_delta_columns) { /* - * It looks like a hack — which, in fact, it is. - * We assume that delta_apply may be used for the DEFAULT identity - * only and will be immediately removed after altering the table. - * Also, if an ERROR happens here we will stay with an inconsistent - * value of the relreplident field. But it is just a cache ... + * It looks like a hack — which, in fact, it is. We assume that + * delta_apply may be used for the DEFAULT identity only and will + * be immediately removed after altering the table. Also, if an + * ERROR happens here we will stay with an inconsistent value of + * the relreplident field. But it is just a cache ... */ relinfo->ri_RelationDesc->rd_rel->relreplident = REPLICA_IDENTITY_DEFAULT; entry->idxoid = RelationGetReplicaIndex(relinfo->ri_RelationDesc); @@ -448,8 +448,8 @@ get_replication_identity(Relation rel) for (i = 0; i < tupDesc->natts; i++) { - char *seclabel; - ObjectAddress object; + char *seclabel; + ObjectAddress object; ObjectAddressSubSet(object, RelationRelationId, RelationGetRelid(rel), i + 1); diff --git a/src/spock_repset.c b/src/spock_repset.c index e3e88cd0..099def3c 100644 --- a/src/spock_repset.c +++ b/src/spock_repset.c @@ -1088,7 +1088,7 @@ replication_set_add_table(Oid setid, Oid reloid, List *att_list, SpockRepSet *repset = get_replication_set(setid); ObjectAddress referenced; ObjectAddress myself; - LOCKTAG tag; + LOCKTAG tag; /* Open the relation. */ SET_LOCKTAG_RELATION(tag, MyDatabaseId, reloid); @@ -1193,7 +1193,7 @@ replication_set_add_seq(Oid setid, Oid seqoid) SpockRepSet *repset = get_replication_set(setid); ObjectAddress referenced; ObjectAddress myself; - LOCKTAG tag; + LOCKTAG tag; /* Open the relation. */ SET_LOCKTAG_RELATION(tag, MyDatabaseId, seqoid); diff --git a/src/spock_sync.c b/src/spock_sync.c index 733a2eb8..3d515dbf 100644 --- a/src/spock_sync.c +++ b/src/spock_sync.c @@ -575,8 +575,8 @@ start_copy_target_tx(PGconn *conn, const char *origin_name) /* * Set correct origin if target db supports it. We must do this before - * starting the transaction otherwise the status code below would get - * much more complicated. + * starting the transaction otherwise the status code below would get much + * more complicated. */ if (PQserverVersion(conn) >= 90500) { diff --git a/src/spock_worker.c b/src/spock_worker.c index b2a3cb3a..0ad9740c 100644 --- a/src/spock_worker.c +++ b/src/spock_worker.c @@ -804,8 +804,8 @@ spock_worker_shmem_request(void) prev_shmem_request_hook(); /* - * This is kludge for Windows (Postgres does not define the GUC variable as - * PGDDLIMPORT) + * This is kludge for Windows (Postgres does not define the GUC variable + * as PGDDLIMPORT) */ nworkers = atoi(GetConfigOptionByName("max_worker_processes", NULL, false)); diff --git a/utils/pgindent/typedefs.list b/utils/pgindent/typedefs.list index 3a67267e..89327af0 100644 --- a/utils/pgindent/typedefs.list +++ b/utils/pgindent/typedefs.list @@ -63,10 +63,15 @@ AggregateInstrumentation AggSplit AggState AggStatePerAgg +AggStatePerAggData AggStatePerGroup +AggStatePerGroupData AggStatePerHash +AggStatePerHashData AggStatePerPhase +AggStatePerPhaseData AggStatePerTrans +AggStatePerTransData AggStrategy AggTransInfo AlenState @@ -195,6 +200,7 @@ ArrayExpr ArrayExprIterState ArrayIOData ArrayIterator +ArrayIteratorData ArrayMapState ArrayMetaState ArraySortCachedInfo @@ -312,6 +318,7 @@ BitmapAndState BitmapHeapPath BitmapHeapScan BitmapHeapScanDesc +BitmapHeapScanDescData BitmapHeapScanInstrumentation BitmapHeapScanState BitmapIndexScan @@ -442,8 +449,6 @@ BUF_MEM Buffer BufferAccessStrategy BufferAccessStrategyType -BufferCacheNumaContext -BufferCacheNumaRec BufferCacheOsPagesContext BufferCacheOsPagesRec BufferCachePagesContext @@ -451,6 +456,7 @@ BufferCachePagesRec BufferDesc BufferDescPadded BufferHeapTupleTableSlot +BufferLockMode BufferLookupEnt BufferManagerRelation BufferStrategyControl @@ -468,6 +474,7 @@ BumpContext BY_HANDLE_FILE_INFORMATION BYTE bytea +ByteaSortSupport CAC_state cached_re_str CachedExpression @@ -790,6 +797,8 @@ deparse_columns deparse_context deparse_expr_cxt deparse_namespace +DependenciesParseState +DependenciesSemanticState DependencyGenerator DependencyGeneratorData DependencyType @@ -1019,6 +1028,7 @@ ExtensibleNodeEntry ExtensibleNodeMethods ExtensionControlFile ExtensionInfo +ExtensionLocation ExtensionVersionInfo f_smgr FailoverSlotFilter @@ -1332,6 +1342,7 @@ GinPostingList GinPostingTreeScanItem GinQualCounts GinScanEntry +GinScanEntryData GinScanItem GinScanKey GinScanKeyData @@ -1394,6 +1405,7 @@ gistxlogPageReuse gistxlogPageSplit gistxlogPageUpdate GlobalTransaction +GlobalTransactionData GlobalVisHorizonKind GlobalVisState GMReaderTupleBuffer @@ -1414,7 +1426,6 @@ GroupingSetKind GroupingSetsPath GroupPath GroupPathExtraData -GroupProgressTupDescColumns GroupResultPath GroupState GroupVarInfo @@ -1580,6 +1591,7 @@ IndexPath IndexRuntimeKeyInfo IndexScan IndexScanDesc +IndexScanDescData IndexScanInstrumentation IndexScanState IndexStateFlagsAction @@ -1746,7 +1758,6 @@ JsonbIterState JsonbPair JsonbParseState JsonbSubWorkspace -JsonbTypeCategory JsonbValue JsonConstructorExpr JsonConstructorExprState @@ -1983,6 +1994,7 @@ LogicalDecodeStreamStopCB LogicalDecodeStreamTruncateCB LogicalDecodeTruncateCB LogicalDecodingContext +LogicalDecodingCtlData LogicalErrorCallbackState LogicalOutputPluginInit LogicalOutputPluginWriterPrepareWrite @@ -2010,7 +2022,6 @@ LogicalSlotInfo LogicalSlotInfoArr LogicalTape LogicalTapeSet -LogLevel LogOpts LogStmtLevel logstreamer_param @@ -2038,6 +2049,7 @@ LsnReadQueueNextStatus ltree ltree_gist ltree_level +ltree_prefix_eq_func LtreeGistOptions LtreeSignature ltxtquery @@ -2147,7 +2159,6 @@ ModifyTableState MonotonicFunction MorphOpaque movedb_failure_params -MsgType MTTargetRelLookup MultiAssignRef multirange_bsearch_comparison @@ -2160,6 +2171,7 @@ MultiSortSupportData MultiXactId MultiXactMember MultiXactOffset +MultiXactOffset32 MultiXactStateData MultiXactStatus MVDependencies @@ -2181,6 +2193,8 @@ NamedTuplestoreScanState NameHashEntry NamespaceInfo NDBOX +NDistinctParseState +NDistinctSemanticState needs_fmgr_hook_type NestLoop NestLoopParam @@ -2252,10 +2266,12 @@ Offset OffsetNumber OffsetVarNodes_context Oid +Oid8 oidKEY OidOptions oidvector OkeysState +OldMultiXactReader OldToNewMapping OldToNewMappingData OM_uint32 @@ -2381,6 +2397,7 @@ PartitionCmd PartitionDesc PartitionDescData PartitionDirectory +PartitionDirectoryData PartitionDirectoryEntry PartitionDispatch PartitionedRelPruneInfo @@ -2402,6 +2419,7 @@ PartitionRangeBound PartitionRangeDatum PartitionRangeDatumKind PartitionScheme +PartitionSchemeData PartitionSpec PartitionStrategy PartitionTupleRouting @@ -2592,6 +2610,7 @@ PGModuleMagicFunction PGNoticeHooks PGnotify PGoauthBearerRequest +pgoff_t PGOutputData PGOutputTxnData pgp_armor_headers_state @@ -2650,11 +2669,12 @@ PgStat_SLRUStats PgStat_Snapshot pgstat_snapshot_hash PgStat_SnapshotEntry +PgStat_StatCustomFixedEntry +PgStat_StatCustomVarEntry PgStat_StatDBEntry PgStat_StatFuncEntry -PgStat_StatInjEntry -PgStat_StatInjFixedEntry PgStat_StatReplSlotEntry +PgStat_StatsFileOp PgStat_StatSubEntry PgStat_StatTabEntry PgStat_SubXactStatus @@ -2668,11 +2688,11 @@ PgStatShared_Backend PgStatShared_BgWriter PgStatShared_Checkpointer PgStatShared_Common +PgStatShared_CustomFixedEntry +PgStatShared_CustomVarEntry PgStatShared_Database PgStatShared_Function PgStatShared_HashEntry -PgStatShared_InjectionPoint -PgStatShared_InjectionPointFixed PgStatShared_IO PgStatShared_Relation PgStatShared_ReplSlot @@ -2898,6 +2918,7 @@ PrintTocDataPtrType PrinttupAttrInfo printXheaderWidthType priv_map +PrivateRefCountData PrivateRefCountEntry PrivTarget PROC_HDR @@ -3255,6 +3276,7 @@ RewriteMappingDataEntry RewriteMappingFile RewriteRule RewriteState +RewriteStateData rf_context rfile RI_CompareHashEntry @@ -3470,12 +3492,14 @@ SimpleStats SimpleStringList SimpleStringListCell SingleBoundSortItem +SinglePartitionSpec SISeg Size size_t SIZE_T SkipPages SkipSupport +SkipSupportData SkipSupportIncDec SlabBlock SlabContext @@ -3488,11 +3512,13 @@ slock_t SlotInvalidationCauseMap SlotNumber SlotSyncCtxStruct +SlotSyncSkipReason SlruCtl SlruCtlData SlruErrorCause SlruPageStatus SlruScanCallback +SlruSegState SlruShared SlruSharedData SlruWriteAll @@ -3500,6 +3526,7 @@ SlruWriteAllData SMgrRelation SMgrRelationData SMgrSortArray +SN_local SnapBuild SnapBuildOnDisk SnapBuildState @@ -3516,6 +3543,7 @@ SortBy SortByDir SortByNulls SortCoordinate +SortCoordinateData SortedPoint SortGroupClause SortItem @@ -3587,17 +3615,15 @@ SPLITCOST SplitInterval SplitLR SplitPageLayout +SplitPartitionContext SplitPoint SplitTextOutputData SplitVar SPNode SPNodeData -spock_copyState -SpockApplyFunctions SpockApplyProgress SpockApplyWorker SpockConflictResolution -SpockConflictType SpockContext SpockExceptionBehaviour SpockExceptionLog @@ -3617,7 +3643,6 @@ SpockRelation SpockRemoteRel SpockRepSet SpockResFileHeader -SpockResolveOption spockStatsEntry spockStatsKey spockStatsType @@ -3630,8 +3655,6 @@ SpockTupleData SpockWalMessage SpockWalMessageSimple SpockWorker -SpockWorkerStatus -SpockWorkerType SPPageDesc sql_error_callback_arg SQLDropObject @@ -3709,7 +3732,6 @@ SubscriptRoutines SubscriptTransform substitute_actual_parameters_context substitute_actual_parameters_in_from_context -substitute_actual_srf_parameters_context substitute_grouped_columns_context substitute_phv_relids_context SubTransactionCommitTsEntry @@ -3728,6 +3750,7 @@ SupportRequestOptimizeWindowClause SupportRequestRows SupportRequestSelectivity SupportRequestSimplify +SupportRequestSimplifyAggref SupportRequestWFuncMonotonic SV symbol @@ -3744,6 +3767,7 @@ SyscacheCallbackFunction SysFKRelationship SysloggerStartupData SysScanDesc +SysScanDescData SYSTEM_INFO SystemRowsSamplerData SystemSamplerData @@ -3963,6 +3987,7 @@ TupleHashEntry TupleHashEntryData TupleHashIterator TupleHashTable +TupleHashTableData TupleQueueReader TuplesortClusterArg TuplesortDatumArg @@ -4010,6 +4035,7 @@ U32 U8 ua_page_items ua_page_stats +UCaseMap UChar UCharIterator uchr @@ -4033,6 +4059,7 @@ uint64x2_t uint8 uint8_t uint8x16_t +uintmax_t uintptr_t ULARGE_INTEGER ULONG @@ -4132,7 +4159,7 @@ Vsrt WAIT_ORDER WaitEvent WaitEventActivity -WaitEventBufferPin +WaitEventBuffer WaitEventClient WaitEventCustomCounterData WaitEventCustomEntryByInfo @@ -4219,6 +4246,7 @@ WindowObjectData WindowStatePerAgg WindowStatePerAggData WindowStatePerFunc +WindowStatePerFuncData wint_t WithCheckOption WithClause @@ -4235,7 +4263,6 @@ WorkerInfoData WorkerInstrumentation WorkerJobDumpPtrType WorkerJobRestorePtrType -Workflow Working_State WORKSTATE worktable From 966a4b353cd910707089a54af860fa2842016b30 Mon Sep 17 00:00:00 2001 From: "Andrei V. Lepikhov" Date: Fri, 9 Jan 2026 12:33:50 +0100 Subject: [PATCH 6/6] Improve type safety and code consistency - Name anonymous enums (SpockResolveOption, GroupProgressTupDescColumns) - Change spock_conflict_resolver from int to SpockResolveOption type - Remove duplicate extern declarations in spock_conflict.h - Update pgindent typedefs list with new enum types --- include/spock_conflict.h | 10 +++------- include/spock_group.h | 4 ++-- src/spock_conflict.c | 2 +- utils/pgindent/typedefs.list | 2 ++ 4 files changed, 8 insertions(+), 10 deletions(-) diff --git a/include/spock_conflict.h b/include/spock_conflict.h index a6b03cff..cc430dcb 100644 --- a/include/spock_conflict.h +++ b/include/spock_conflict.h @@ -30,16 +30,16 @@ typedef enum SpockConflictResolution SpockResolution_Skip } SpockConflictResolution; -typedef enum +typedef enum SpockResolveOption { SPOCK_RESOLVE_ERROR, SPOCK_RESOLVE_APPLY_REMOTE, SPOCK_RESOLVE_KEEP_LOCAL, SPOCK_RESOLVE_LAST_UPDATE_WINS, SPOCK_RESOLVE_FIRST_UPDATE_WINS -} SpockResolveOption; +} SpockResolveOption; -extern int spock_conflict_resolver; +extern SpockResolveOption spock_conflict_resolver; extern int spock_conflict_log_level; extern bool spock_save_resolutions; @@ -79,10 +79,6 @@ typedef enum } ConflictType; #endif -extern int spock_conflict_resolver; -extern int spock_conflict_log_level; -extern bool spock_save_resolutions; - extern bool get_tuple_origin(SpockRelation *rel, HeapTuple local_tuple, ItemPointer tid, TransactionId *xmin, RepOriginId *local_origin, TimestampTz *local_ts); diff --git a/include/spock_group.h b/include/spock_group.h index 650f4d5e..3b361d76 100644 --- a/include/spock_group.h +++ b/include/spock_group.h @@ -66,7 +66,7 @@ typedef struct SpockGroupKey /* * Columns for the UI routine get_apply_group_progress. */ -typedef enum +typedef enum GroupProgressTupDescColumns { GP_DBOID = 0, GP_NODE_ID, @@ -81,7 +81,7 @@ typedef enum /* The last value */ _GP_LAST_ -} GroupProgressTupDescColumns; +} GroupProgressTupDescColumns; /* * Logical Replication Progress has made by a group of apply workers. diff --git a/src/spock_conflict.c b/src/spock_conflict.c index f619a805..350f1780 100644 --- a/src/spock_conflict.c +++ b/src/spock_conflict.c @@ -67,7 +67,7 @@ static const char *const ConflictTypeNames[] = { }; -int spock_conflict_resolver = SPOCK_RESOLVE_LAST_UPDATE_WINS; +SpockResolveOption spock_conflict_resolver = SPOCK_RESOLVE_LAST_UPDATE_WINS; int spock_conflict_log_level = LOG; bool spock_save_resolutions = false; diff --git a/utils/pgindent/typedefs.list b/utils/pgindent/typedefs.list index 89327af0..e73188a3 100644 --- a/utils/pgindent/typedefs.list +++ b/utils/pgindent/typedefs.list @@ -1426,6 +1426,7 @@ GroupingSetKind GroupingSetsPath GroupPath GroupPathExtraData +GroupProgressTupDescColumns GroupResultPath GroupState GroupVarInfo @@ -3643,6 +3644,7 @@ SpockRelation SpockRemoteRel SpockRepSet SpockResFileHeader +SpockResolveOption spockStatsEntry spockStatsKey spockStatsType