API compatibility report between postgres (X) and postgres (Y) objects on x86_64


Binary
Compatibility
Source
Compatibility

Test Info


Module NamelibTest
Version #1X
Version #2Y
Archx86_64
GCC Version12.2.0
SubjectBinary Compatibility

Test Results


Total Header Files538
Total Source Files695
Total Objects1
Total Symbols / Types8879 / 2781
Compatibility 94%

Problem Summary


SeverityCount
Added Symbols-89
Removed SymbolsHigh15
Problems with
Data Types
High3
Medium16
Low64
Problems with
Symbols
High78
Medium26
Low7
Problems with
Constants
Low0
Other Changes
in Data Types
-2

Added Symbols  89 


acl.h, postgres
recordDependencyOnNewAcl ( Oid classId, Oid objectId, int32 objsubId, Oid ownerId, Acl* acl )

array.h, postgres
ArrayCheckBounds ( int ndim, int const* dims, int const* lb )

bgworker_internals.h, postgres
ForgetUnstartedBackgroundWorkers ( )

bufpage.h, postgres
PageIsVerifiedExtended ( Page page, BlockNumber blkno, int flags )

builtins.h, postgres
xidLogicalComparator ( void const* arg1, void const* arg2 )

clauses.h, postgres
contain_exec_param ( Node* clause, List* param_ids )

createplan.c, postgres
change_plan_targetlist ( Plan* subplan, List* tlist, _Bool tlist_parallel_safe )

date.h, postgres
float_time_overflows ( int hour, int min, double sec )
time_overflows ( int hour, int min, int sec, fsec_t fsec )

dependency.h, postgres
AcquireDeletionLock ( ObjectAddress const* object, int flags )
changeDependencyOnTablespace ( Oid classId, Oid objectId, Oid newTablespaceId )
checkMembershipInCurrentExtension ( ObjectAddress const* object )
getAutoExtensionsOfObject ( Oid classId, Oid objectId )
recordDependencyOnTablespace ( Oid classId, Oid objectId, Oid tablespace )
ReleaseDeletionLock ( ObjectAddress const* object )

executor.h, postgres
BuildTupleHashTableExt ( PlanState* parent, TupleDesc inputDesc, int numCols, AttrNumber* keyColIdx, Oid* eqfuncoids, FmgrInfo* hashfunctions, long nbuckets, Size additionalsize, MemoryContext metacxt, MemoryContext tablecxt, MemoryContext tempcxt, _Bool use_variable_hash_iv )
ExecBuildProjectionInfoExt ( List* targetList, ExprContext* econtext, TupleTableSlot* slot, _Bool assignJunkEntries, PlanState* parent, TupleDesc inputDesc )
ExecGetInsertedCols ( ResultRelInfo* relinfo, EState* estate )
ExecGetUpdatedCols ( ResultRelInfo* relinfo, EState* estate )
ResetTupleHashTable ( TupleHashTable hashtable )

fd.h, postgres
data_sync_elevel ( int elevel )
data_sync_retry [data]

htup_details.h, postgres
getmissingattr ( TupleDesc tupleDesc, int attnum, _Bool* isnull )

index.h, postgres
BuildDummyIndexInfo ( Relation index )
ResetReindexState ( int nestLevel )

inval.c, postgres
InvalidateSystemCachesExtended ( _Bool debug_discard )

libpq.h, postgres
pq_buffer_has_data ( )

lmgr.h, postgres
LockDatabaseFrozenIds ( LOCKMODE lockmode )

lsyscache.h, postgres
get_index_isclustered ( Oid index_oid )
get_index_isreplident ( Oid index_oid )
get_range_collation ( Oid rangeOid )

lwlock.h, postgres
LWLockAnyHeldByMe ( LWLock* l, int nlocks, size_t stride )

namespace.h, postgres
checkTempNamespaceStatus ( Oid namespaceId )
TypenameGetTypidExtended ( char const* typname, _Bool temp_ok )

paramassign.h, postgres
assign_special_exec_param ( PlannerInfo* root )
generate_new_exec_param ( PlannerInfo* root, Oid paramtype, int32 paramtypmod, Oid paramcollation )
identify_current_nestloop_params ( PlannerInfo* root, Relids leftrelids )
process_subquery_nestloop_params ( PlannerInfo* root, List* subplan_params )
replace_nestloop_param_placeholdervar ( PlannerInfo* root, PlaceHolderVar* phv )
replace_nestloop_param_var ( PlannerInfo* root, Var* var )
replace_outer_agg ( PlannerInfo* root, Aggref* agg )
replace_outer_grouping ( PlannerInfo* root, GroupingFunc* grp )
replace_outer_placeholdervar ( PlannerInfo* root, PlaceHolderVar* phv )
replace_outer_var ( PlannerInfo* root, Var* var )

parse_type.h, postgres
LookupTypeNameExtended ( ParseState* pstate, TypeName const* typeName, int32* typmod_p, _Bool temp_ok, _Bool missing_ok )

parse_utilcmd.h, postgres
expandTableLikeClause ( RangeVar* heapRel, TableLikeClause* table_like_clause )
transformCreateSchemaStmtElements ( List* schemaElts, char const* schemaName )

pg_constraint.h, postgres
DeconstructFkConstraintRow ( HeapTuple tuple, int* numfks, AttrNumber* conkey, AttrNumber* confkey, Oid* pf_eq_oprs, Oid* pp_eq_oprs, Oid* ff_eq_oprs )

port.h, postgres
pg_mkdir_p ( char* path, int omode )
pg_strsignal ( int signum )
wait_result_is_any_signal ( int exit_status, _Bool include_command_not_found )
wait_result_is_signal ( int exit_status, int signum )

portal.h, postgres
ForgetPortalSnapshots ( )

pqsignal.h, postgres
pqsignal_pm ( int signo, pqsigfunc func )

pquery.h, postgres
EnsurePortalSnapshotExists ( )
PlannedStmtRequiresSnapshot ( PlannedStmt* pstmt )

procarray.h, postgres
GetVirtualXIDsDelayingChkptEnd ( int* nvxids )
HaveVirtualXIDsDelayingChkptEnd ( VirtualTransactionId* vxids, int nvxids )
KnownAssignedTransactionIdsIdleMaintenance ( )
SignalVirtualTransaction ( struct VirtualTransactionId vxid, enum ProcSignalReason sigmode, _Bool conflictPending )

rbtree.c, postgres
rbt_delete ( RBTree* rbt, RBTNode* node )
rbt_find ( RBTree* rbt, RBTNode const* data )
rbt_leftmost ( RBTree* rbt )

rbtree.h, postgres
rbt_begin_iterate ( RBTree* rbt, RBTOrderControl ctrl, RBTreeIterator* iter )
rbt_create ( Size node_size, rbt_comparator comparator, rbt_combiner combiner, rbt_allocfunc allocfunc, rbt_freefunc freefunc, void* arg )
rbt_insert ( RBTree* rbt, RBTNode const* data, _Bool* isNew )
rbt_iterate ( RBTreeIterator* iter )

relation.h, postgres
is_dummy_rel ( RelOptInfo* rel )

relcache.h, postgres
RelationGetDummyIndexExpressions ( Relation relation )

scram.h, postgres
parse_scram_verifier ( char const* verifier, int* iterations, char** salt, uint8* stored_key, uint8* server_key )

simplehash.h, postgres
tuplehash_reset ( tuplehash_hash* tb )

slru.h, postgres
SlruPagePrecedesUnitTests ( SlruCtl ctl, int per_page )

snapbuild.h, postgres
SnapBuildResetExportedSnapshotState ( )
SnapBuildXidSetCatalogChanges ( SnapBuild* builder, TransactionId xid, int subxcnt, TransactionId* subxacts, XLogRecPtr lsn )

snapmgr.h, postgres
PushActiveSnapshotWithLevel ( Snapshot snap, int snap_level )

syncrep.h, postgres
SyncRepGetCandidateStandbys ( SyncRepStandbyData** standbys )

tablecmds.h, postgres
ResetRelRewrite ( Oid myrelid )

tablespace.h, postgres
allow_in_place_tablespaces [data]

timestamp.h, postgres
TimestampDifferenceMilliseconds ( TimestampTz start_time, TimestampTz stop_time )

trigger.h, postgres
CreateTriggerFiringOn ( CreateTrigStmt* stmt, char const* queryString, Oid relOid, Oid refRelOid, Oid constraintOid, Oid indexOid, Oid funcoid, Oid parentTriggerOid, Node* whenClause, _Bool isInternal, _Bool in_partition, char trigger_fires_when )
EnableDisableTriggerNew ( Relation rel, char const* tgname, char fires_when, _Bool skip_system, _Bool recurse, LOCKMODE lockmode )

tupconvert.h, postgres
execute_attr_map_cols ( Bitmapset* in_cols, TupleConversionMap* map )

twophase.h, postgres
TwoPhaseGetXidByVirtualXID ( struct VirtualTransactionId vxid, _Bool* have_more )

walreceiver.c, postgres
ProcessWalRcvInterrupts ( )

walsender_private.h, postgres
replication_scanner_is_replication_command ( )

worker_internal.h, postgres
LogRepWorkerWalRcvConn [data]

xlog.h, postgres
GetRecoveryState ( )
register_persistent_abort_backup_handler ( )

xloginsert.c, postgres
log_newpage_range ( Relation rel, ForkNumber forkNum, BlockNumber startblk, BlockNumber endblk, _Bool page_std )

to the top

Removed Symbols  15 


logicalrelation.h, postgres
logicalrep_typmap_gettypname ( Oid remoteid )
logicalrep_typmap_update ( LogicalRepTyp* remotetyp )

parse_utilcmd.h, postgres
transformCreateSchemaStmt ( CreateSchemaStmt* stmt )

port.h, postgres
pqsignal_no_restart ( int signo, pqsigfunc func )

rbtree.c, postgres
rb_delete ( RBTree* rb, RBNode* node )
rb_find ( RBTree* rb, RBNode const* data )
rb_leftmost ( RBTree* rb )

rbtree.h, postgres
rb_begin_iterate ( RBTree* rb, RBOrderControl ctrl, RBTreeIterator* iter )
rb_create ( Size node_size, rb_comparator comparator, rb_combiner combiner, rb_allocfunc allocfunc, rb_freefunc freefunc, void* arg )
rb_insert ( RBTree* rb, RBNode const* data, _Bool* isNew )
rb_iterate ( RBTreeIterator* iter )

rel.h, postgres
RelationHasUnloggedIndex ( Relation rel )

subselect.h, postgres
assign_nestloop_param_placeholdervar ( PlannerInfo* root, PlaceHolderVar* phv )
assign_nestloop_param_var ( PlannerInfo* root, Var* var )

worker_internal.h, postgres
wrconn [data]

to the top

Problems with Data Types, High Severity  3 


execExpr.h
[+] struct anon-struct-execExpr.h-519  2 

execPartition.h
[+] struct PartitionedRelPruningData  1 

to the top

Problems with Symbols, High Severity  78 


bufmgr.h, postgres
[+] ReadBufferExtended ( Relation reln, ForkNumber forkNum, BlockNumber blockNum, enum ReadBufferMode mode, BufferAccessStrategy strategy )  3 

dsa.h, postgres
[+] dsa_allocate_extended ( dsa_area* area, size_t size, int flags )  1 

dshash.c, postgres
[+] dshash_delete_entry ( dshash_table* hash_table, void* entry )  1 

execExprInterp.c, postgres
[+] ExecAggTransReparent ( AggState* aggstate, AggStatePerTrans pertrans, Datum newValue, _Bool newValueIsNull, Datum oldValue, _Bool oldValueIsNull )  1 

execPartition.h, postgres
[+] ExecFindPartition ( ResultRelInfo* resultRelInfo, PartitionDispatch* pd, TupleTableSlot* slot, EState* estate )  1 

freespace.h, postgres
[+] FreeSpaceMapTruncateRel ( Relation rel, BlockNumber nblocks )  1 

funcapi.h, postgres
[+] get_func_trftypes ( HeapTuple procTup, Oid** p_trftypes )  1 

gin_private.h, postgres
[+] ginFindLeafPage ( GinBtree btree, _Bool searchMode, Snapshot snapshot )  1 

gist_private.h, postgres
[+] gistGetNodeBuffer ( GISTBuildBuffers* gfbb, GISTSTATE* giststate, BlockNumber nodeBlocknum, int level )  1 

guc-file.l, postgres
[+] ParseConfigFile ( char const* config_file, _Bool strict, char const* calling_file, int calling_lineno, int depth, int elevel, ConfigVariable** head_p, ConfigVariable** tail_p )  1 

heap.h, postgres
[+] CheckAttributeType ( char const* attname, Oid atttypid, Oid attcollation, List* containing_rowtypes, _Bool allow_system_table_mods )  1 
[+] heap_create ( char const* relname, Oid relnamespace, Oid reltablespace, Oid relid, Oid relfilenode, TupleDesc tupDesc, char relkind, char relpersistence, _Bool shared_relation, _Bool mapped_relation, _Bool allow_system_table_mods )  2 
[+] StoreAttrDefault ( Relation rel, AttrNumber attnum, Node* expr, _Bool is_internal, _Bool add_column_mode )  1 

heapam.h, postgres
[+] heap_hot_search_buffer ( ItemPointer tid, Relation relation, Buffer buffer, Snapshot snapshot, HeapTuple heapTuple, _Bool* all_dead, _Bool first_call )  2 
[+] heap_update ( Relation relation, ItemPointer otid, HeapTuple newtup, CommandId cid, Snapshot crosscheck, _Bool wait, HeapUpdateFailureData* hufd, LockTupleMode* lockmode )  1 

index.h, postgres
[+] IndexSetParentIndex ( Relation partitionIdx, Oid parentOid )  2 

ipc.h, postgres
[+] CreateSharedMemoryAndSemaphores ( _Bool makePrivate, int port )  1 

large_object.h, postgres
[+] inv_open ( Oid lobjId, int flags, MemoryContext mcxt )  2 

lock.h, postgres
[+] VirtualXactLock ( struct VirtualTransactionId vxid, _Bool wait )  1 

memutils.h, postgres
[+] SlabContextCreate ( MemoryContext parent, char const* name, Size blockSize, Size chunkSize )  1 

nbtree.h, postgres
[+] _bt_pagedel ( Relation rel, Buffer buf )  1 

nodeFuncs.h, postgres
[+] query_tree_mutator ( Query* query, Node*(*mutator)(...), void* context, int flags )  2 

nodeHash.h, postgres
[+] ExecHashTableDetach ( HashJoinTable hashtable )  1 

nodes.h, postgres
[+] equal ( void const* a, void const* b )  1 

parse_relation.h, postgres
[+] addRangeTableEntryForJoin ( ParseState* pstate, List* colnames, JoinType jointype, List* aliasvars, Alias* alias, _Bool inFromCl )  2 
[+] addRangeTableEntryForTableFunc ( ParseState* pstate, TableFunc* tf, Alias* alias, _Bool lateral, _Bool inFromCl )  1 

pathnode.h, postgres
[+] get_appendrel_parampathinfo ( RelOptInfo* appendrel, Relids required_outer )  2 
[+] get_baserel_parampathinfo ( PlannerInfo* root, RelOptInfo* baserel, Relids required_outer )  1 

paths.h, postgres
[+] generate_partitionwise_join_paths ( PlannerInfo* root, RelOptInfo* rel )  1 

pg_collation.h, postgres
[+] CollationCreate ( char const* collname, Oid collnamespace, Oid collowner, char collprovider, int32 collencoding, char const* collcollate, char const* collctype, char const* collversion, _Bool if_not_exists, _Bool quiet )  1 

pg_constraint.h, postgres
[+] ConstraintSetParentConstraint ( Oid childConstrId, Oid parentConstrId )  1 

pg_namespace.h, postgres
[+] NamespaceCreate ( char const* nspName, Oid ownerId, _Bool isTemp )  1 

pg_operator.h, postgres
[+] makeOperatorDependencies ( HeapTuple tuple, _Bool isUpdate )  1 

pg_shmem.h, postgres
[+] PGSharedMemoryCreate ( Size size, _Bool makePrivate, int port, PGShmemHeader** shim )  1 

pg_type.h, postgres
[+] GenerateTypeDependencies ( Oid typeNamespace, Oid typeObjectId, Oid relationOid, char relationKind, Oid owner, Oid inputProcedure, Oid outputProcedure, Oid receiveProcedure, Oid sendProcedure, Oid typmodinProcedure, Oid typmodoutProcedure, Oid analyzeProcedure, Oid elementType, _Bool isImplicitArray, Oid baseType, Oid typeCollation, Node* defaultExpr, _Bool rebuild )  9 
[+] TypeCreate ( Oid newTypeOid, char const* typeName, Oid typeNamespace, Oid relationOid, char relationKind, Oid ownerId, int16 internalSize, char typeType, char typeCategory, _Bool typePreferred, char typDelim, Oid inputProcedure, Oid outputProcedure, Oid receiveProcedure, Oid sendProcedure, Oid typmodinProcedure, Oid typmodoutProcedure, Oid analyzeProcedure, Oid elementType, _Bool isImplicitArray, Oid arrayType, Oid baseType, char const* defaultTypeValue, char* defaultTypeBin, _Bool passedByValue, char alignment, char storage, int32 typeMod, int32 typNDims, _Bool typeNotNull, Oid typeCollation )  1 

pg_wchar.h, postgres
[+] pg_do_encoding_conversion ( unsigned char* src, int len, int src_encoding, int dest_encoding )  1 

pgtime.h, postgres
[+] pg_strftime ( char* s, size_t maxsize, char const* format, struct pg_tm const* t )  1 

pgtz.h, postgres
[+] tzparse ( char const* name, struct state* sp, _Bool lastditch )  1 

portal.h, postgres
[+] AtSubCommit_Portals ( SubTransactionId mySubid, SubTransactionId parentSubid, ResourceOwner parentXactOwner )  1 

procarray.h, postgres
[+] CancelVirtualTransaction ( struct VirtualTransactionId vxid, enum ProcSignalReason sigmode )  1 
[+] TransactionIdIsInProgress ( TransactionId xid )  1 

relcache.h, postgres
[+] AtEOSubXact_RelationCache ( _Bool isCommit, SubTransactionId mySubid, SubTransactionId parentSubid )  3 

rewriteHandler.h, postgres
[+] relation_is_updatable ( Oid reloid, _Bool include_triggers, Bitmapset* include_cols )  1 

selfuncs.h, postgres
[+] examine_variable ( PlannerInfo* root, Node* node, int varRelid, VariableStatData* vardata )  1 

simplehash.h, postgres
[+] tuplehash_grow ( tuplehash_hash* tb, uint32 newsize )  1 

slru.h, postgres
[+] SimpleLruDoesPhysicalPageExist ( SlruCtl ctl, int pageno )  2 

smgr.h, postgres
[+] smgrsetowner ( SMgrRelation* owner, SMgrRelation reln )  2 

snapbuild.h, postgres
[+] AllocateSnapshotBuilder ( ReorderBuffer* reorder, TransactionId xmin_horizon, XLogRecPtr start_lsn, _Bool need_full_snapshot )  1 

spgist_private.h, postgres
[+] spgdoinsert ( Relation index, SpGistState* state, ItemPointer heapPtr, Datum datum, _Bool isnull )  1 

trigger.h, postgres
[+] ExecASUpdateTriggers ( EState* estate, ResultRelInfo* relinfo, TransitionCaptureState* transition_capture )  3 

variable.h, postgres
[+] check_session_authorization ( char** newval, void** extra, enum GucSource source )  1 

walsender.h, postgres
[+] exec_replication_command ( char const* cmd_string )  1 

xact.h, postgres
[+] PreventInTransactionBlock ( _Bool isTopLevel, char const* stmtType )  1 

xlogreader.h, postgres
[+] XLogReadRecord ( XLogReaderState* state, XLogRecPtr RecPtr, char** errormsg )  1 

to the top

Problems with Data Types, Medium Severity  16 


dshash.c
[+] struct dshash_table  2 

execExpr.h
[+] struct anon-struct-execExpr.h-341  1 
[+] struct anon-struct-execExpr.h-465  1 
[+] struct anon-struct-execExpr.h-519  2 
[+] union anon-union-execExpr.h-258  1 

execPartition.h
[+] struct PartitionedRelPruningData  3 

partprune.h
[+] struct PartitionPruneContext  2 

smgr.h
[+] struct SMgrRelationData  1 

spell.h
[+] struct aff_struct  1 
[+] union anon-union-spell.h-98  2 

to the top

Problems with Symbols, Medium Severity  26 


bgworker_internals.h, postgres
[+] BackgroundWorkerStateChange ( )  1 

execPartition.h, postgres
[+] ExecSetupPartitionTupleRouting ( ModifyTableState* mtstate, Relation rel )  1 

executor.h, postgres
[+] BuildTupleHashTable ( PlanState* parent, TupleDesc inputDesc, int numCols, AttrNumber* keyColIdx, Oid* eqfuncoids, FmgrInfo* hashfunctions, long nbuckets, Size additionalsize, MemoryContext tablecxt, MemoryContext tempcxt, _Bool use_variable_hash_iv )  4 
[+] InitResultRelInfo ( ResultRelInfo* resultRelInfo, Relation resultRelationDesc, Index resultRelationIndex, Relation partition_root, int instrument_options )  1 

gist_private.h, postgres
[+] gistdoinsert ( Relation r, IndexTuple itup, Size freespace, GISTSTATE* giststate )  1 
[+] gistplacetopage ( Relation rel, Size freespace, GISTSTATE* giststate, Buffer buffer, IndexTuple* itup, int ntup, OffsetNumber oldoffnum, BlockNumber* newblkno, Buffer leftchildbuf, List** splitinfo, _Bool markfollowright )  1 
[+] gistXLogUpdate ( Buffer buffer, OffsetNumber* todelete, int ntodelete, IndexTuple* itup, int ituplen, Buffer leftchildbuf )  1 

lock.h, postgres
[+] LockTagTypeNames [data]  2 

lwlock.h, postgres
[+] MainLWLockNames [data]  1 

nbtree.h, postgres
[+] _bt_pagedel ( Relation rel, Buffer buf )  1 

pg_type.h, postgres
[+] GenerateTypeDependencies ( Oid typeNamespace, Oid typeObjectId, Oid relationOid, char relationKind, Oid owner, Oid inputProcedure, Oid outputProcedure, Oid receiveProcedure, Oid sendProcedure, Oid typmodinProcedure, Oid typmodoutProcedure, Oid analyzeProcedure, Oid elementType, _Bool isImplicitArray, Oid baseType, Oid typeCollation, Node* defaultExpr, _Bool rebuild )  7 

pgstat.h, postgres
[+] AtEOXact_PgStat ( _Bool isCommit )  1 

relcache.h, postgres
[+] RelationCacheInvalidate ( )  1 

toasting.h, postgres
[+] NewHeapCreateToastTable ( Oid relOid, Datum reloptions, LOCKMODE lockmode )  1 

xlog.h, postgres
[+] do_pg_abort_backup ( )  2 

to the top

Problems with Data Types, Low Severity  64 


copy.c
[+] struct CopyStateData  2 

dshash.c
[+] struct dshash_table  1 

execExpr.h
[+] struct anon-struct-execExpr.h-341  2 
[+] struct anon-struct-execExpr.h-465  2 
[+] struct anon-struct-execExpr.h-474  1 
[+] struct anon-struct-execExpr.h-519  4 
[+] union anon-union-execExpr.h-258  2 

execnodes.h
[+] struct IndexOnlyScanState  1 
[+] struct ResultRelInfo  1 
[+] struct SubPlanState  2 
[+] struct ValuesScanState  2 

execPartition.h
[+] struct PartitionedRelPruningData  5 

gin_private.h
[+] struct GinEntryAccumulator  1 

hba.h
[+] struct HbaLine  3 

libpq-be.h
[+] enum CAC_state  1 

logical.h
[+] struct LogicalDecodingContext  1 

logicalrelation.h
[+] struct LogicalRepRelMapEntry  1 

partbounds.h
[+] struct PartitionBoundInfoData  2 

partprune.h
[+] struct PartitionPruneContext  1 

plannodes.h
[+] struct IndexOnlyScan  2 

portal.h
[+] struct PortalData  3 

primnodes.h
[+] struct SubPlan  2 

proc.h
[+] struct PGPROC  1 

rbtree.c
[+] struct RBTree  5 

rbtree.h
[+] struct RBTreeIterator  3 

rel.h
[+] struct RelationData  4 

relation.h
[+] struct IndexOptInfo  1 

smgr.h
[+] struct SMgrRelationData  2 

spell.h
[+] struct aff_struct  1 
[+] union anon-union-spell.h-98  1 

xlogreader.h
[+] struct XLogReaderState  4 

to the top

Problems with Symbols, Low Severity  7 


buffile.h, postgres
[+] BufFileSize ( BufFile* file )  1 

dependency.h, postgres
[+] recordDependencyOnSingleRelExpr ( ObjectAddress const* depender, Node* expr, Oid relId, DependencyType behavior, DependencyType self_behavior, _Bool ignore_self )  1 

execPartition.h, postgres
[+] ExecInitPartitionInfo ( ModifyTableState* mtstate, ResultRelInfo* resultRelInfo, PartitionTupleRouting* proute, EState* estate, int partidx )  1 
[+] ExecSetupPartitionTupleRouting ( ModifyTableState* mtstate, Relation rel )  1 

executor.h, postgres
[+] InitResultRelInfo ( ResultRelInfo* resultRelInfo, Relation resultRelationDesc, Index resultRelationIndex, Relation partition_root, int instrument_options )  1 

nbtree.h, postgres
[+] _bt_pagedel ( Relation rel, Buffer buf )  2 

to the top

Other Changes in Data Types  2 


dependency.h
[+] enum SharedDependencyType  1 

reorderbuffer.h
[+] enum ReorderBufferChangeType  1 

to the top

Header Files  538 



__locale_t.h
__sigset_t.h
acl.h
aclchk_internal.h
alter.h
amapi.h
amvalidate.h
analyze.h
arch-x86.h
array.h
ascii.h
async.h
attnum.h
attoptcache.h
auth.h
autovacuum.h
backend_random.h
backendid.h
barrier.h
base64.h
basebackup.h
be-fsstubs.h
bgworker.h
bgworker_internals.h
bgwriter.h
binary_upgrade.h
binaryheap.h
bipartite_match.h
bitmapset.h
block.h
bloomfilter.h
bootstrap.h
brin.h
brin_internal.h
brin_pageops.h
brin_revmap.h
brin_tuple.h
brin_xlog.h
buf.h
buf_internals.h
buffile.h
bufmask.h
bufmgr.h
bufpage.h
builtins.h
bytea.h
c.h
catalog.h
catcache.h
checksum_impl.h
chvalid.h
clauses.h
clog.h
cluster.h
collationcmds.h
combocid.h
comment.h
commit_ts.h
condition_variable.h
config_info.h
controldata_utils.h
conversioncmds.h
copy.h
copydir.h
cost.h
createas.h
crypt.h
date.h
datetime.h
datum.h
dbcommands.h
dbcommands_xlog.h
decode.h
defrem.h
dependency.h
dest.h
dict.h
dirent.h
discard.h
dsa.h
dshash.h
dsm.h
dsm_impl.h
dynahash.h
elog.h
encoding.h
entities.h
epoll.h
event_trigger.h
evtcache.h
execdesc.h
execExpr.h
execnodes.h
execParallel.h
execPartition.h
executor.h
expandeddatum.h
expandedrecord.h
explain.h
extended_stats_internal.h
extensible.h
extension.h
fastpath.h
fd.h
fdwapi.h
FILE.h
file_perm.h
fmgr.h
fmgrprotos.h
fmgrtab.h
foreign.h
fork_process.h
formatting.h
freepage.h
freespace.h
fsm_internals.h
funcapi.h
functions.h
genam.h
generic_xlog.h
geo_decls.h
geqo.h
geqo_copy.h
geqo_gene.h
geqo_pool.h
geqo_random.h
geqo_recombination.h
geqo_selection.h
getopt_core.h
gin.h
gin_private.h
ginblock.h
ginxlog.h
gist.h
gist_private.h
gistscan.h
gistxlog.h
globals.h
gramparse.h
guc.h
guc_tables.h
hash.h
hash_xlog.h
hashjoin.h
hba.h
heap.h
heapam.h
heapam_xlog.h
help_config.h
hio.h
hsearch.h
htup.h
htup_details.h
hyperloglog.h
iconv.h
ifaddr.h
ilist.h
in.h
index.h
index_selfuncs.h
indexfsm.h
indexing.h
inet.h
instr_time.h
instrument.h
int8.h
inval.h
ip.h
ipc.h
item.h
itemptr.h
itup.h
jit.h
joininfo.h
json.h
jsonapi.h
jsonb.h
keywords.h
knapsack.h
large_object.h
latch.h
libpq-be.h
libpq.h
lmgr.h
locale.h
locale_t.h
lock.h
lockcmds.h
lockdefs.h
lockoptions.h
logical.h
logicalfuncs.h
logicallauncher.h
logicalproto.h
logicalrelation.h
logicalworker.h
logtape.h
lsyscache.h
lwlock.h
makefuncs.h
matview.h
md5.h
memnodes.h
memutils.h
message.h
miscadmin.h
multixact.h
nabstime.h
namespace.h
nbtree.h
nbtxlog.h
netdb.h
nodeAgg.h
nodeAppend.h
nodeBitmapAnd.h
nodeBitmapHeapscan.h
nodeBitmapIndexscan.h
nodeBitmapOr.h
nodeCtescan.h
nodeCustom.h
nodeForeignscan.h
nodeFuncs.h
nodeFunctionscan.h
nodeGather.h
nodeGatherMerge.h
nodeGroup.h
nodeHash.h
nodeHashjoin.h
nodeIndexonlyscan.h
nodeIndexscan.h
nodeLimit.h
nodeLockRows.h
nodeMaterial.h
nodeMergeAppend.h
nodeMergejoin.h
nodeModifyTable.h
nodeNamedtuplestorescan.h
nodeNestloop.h
nodeProjectSet.h
nodeRecursiveunion.h
nodeResult.h
nodes.h
nodeSamplescan.h
nodeSeqscan.h
nodeSetOp.h
nodeSort.h
nodeSubplan.h
nodeSubqueryscan.h
nodeTableFuncscan.h
nodeTidscan.h
nodeUnique.h
nodeValuesscan.h
nodeWindowAgg.h
nodeWorktablescan.h
numeric.h
objectaccess.h
objectaddress.h
off.h
orclauses.h
origin.h
output_plugin.h
pairingheap.h
palloc.h
parallel.h
params.h
parse_agg.h
parse_clause.h
parse_coerce.h
parse_collate.h
parse_cte.h
parse_enr.h
parse_expr.h
parse_func.h
parse_node.h
parse_oper.h
parse_param.h
parse_relation.h
parse_target.h
parse_type.h
parse_utilcmd.h
parsenodes.h
parser.h
parsetree.h
partbounds.h
partcache.h
partdefs.h
partition.h
partprune.h
pathnode.h
paths.h
pg_aggregate.h
pg_attribute.h
pg_class.h
pg_collation.h
pg_constraint.h
pg_control.h
pg_conversion.h
pg_crc.h
pg_crc32c.h
pg_db_role_setting.h
pg_enum.h
pg_index.h
pg_inherits.h
pg_largeobject.h
pg_list.h
pg_locale.h
pg_lzcompress.h
pg_namespace.h
pg_operator.h
pg_proc.h
pg_publication.h
pg_range.h
pg_rusage.h
pg_sema.h
pg_shmem.h
pg_subscription.h
pg_subscription_rel.h
pg_type.h
pg_wchar.h
pgarch.h
pgstat.h
pgtar.h
pgtime.h
pgtz.h
placeholder.h
plancache.h
plancat.h
planmain.h
planner.h
plannodes.h
pmsignal.h
policy.h
port.h
portal.h
portalcmds.h
postgres.h
postgres_ext.h
postmaster.h
pqcomm.h
pqformat.h
pqmq.h
pqsignal.h
pquery.h
predicate.h
predicate_internals.h
predtest.h
prep.h
prepare.h
primnodes.h
print.h
printsimple.h
printtup.h
proc.h
procarray.h
proclang.h
proclist_types.h
procsignal.h
prs2lock.h
ps_status.h
publicationcmds.h
pwd.h
queryenvironment.h
rangetypes.h
rbtree.h
readfuncs.h
regcustom.h
regex.h
regexport.h
regguts.h
regis.h
regproc.h
reinit.h
rel.h
relation.h
relcache.h
relfilenode.h
relfilenodemap.h
relmapper.h
reloptions.h
relpath.h
relscan.h
reltrigger.h
reorderbuffer.h
replnodes.h
resowner.h
resowner_private.h
restrictinfo.h
rewriteDefine.h
rewriteHandler.h
rewriteheap.h
rewriteManip.h
rewriteRemove.h
rewriteSupport.h
rls.h
rmgr.h
rowsecurity.h
ruleutils.h
s_lock.h
sampling.h
saslprep.h
scanner.h
scansup.h
schemacmds.h
scram-common.h
scram.h
sdir.h
seclabel.h
selfuncs.h
semaphore.h
sequence.h
session.h
setjmp.h
sha.h
sha2.h
sharedfileset.h
sharedtuplestore.h
shm_mq.h
shm_toc.h
shmem.h
sig_atomic_t.h
sigset_t.h
simplehash.h
sinval.h
sinvaladt.h
skey.h
slot.h
slru.h
smgr.h
snapbuild.h
snapmgr.h
snapshot.h
sockaddr.h
socket.h
sortsupport.h
spccache.h
spell.h
spgist.h
spgist_private.h
spgxlog.h
spi.h
spi_priv.h
spin.h
standby.h
standbydefs.h
startup.h
statistics.h
stddef.h
stdint-uintn.h
stdint.h
stdio.h
storage.h
storage_xlog.h
stratnum.h
string.h
stringinfo.h
struct___jmp_buf_tag.h
struct_FILE.h
struct_rusage.h
struct_timespec.h
struct_timeval.h
subscriptioncmds.h
subselect.h
subtrans.h
syncrep.h
syscache.h
syslogger.h
tablecmds.h
tablefunc.h
tablespace.h
tcopprot.h
tidbitmap.h
time_t.h
timeline.h
timeout.h
timestamp.h
tlist.h
toasting.h
tqual.h
tqueue.h
transam.h
tree.h
trigger.h
ts_cache.h
ts_locale.h
ts_public.h
ts_type.h
ts_utils.h
tsmapi.h
tstoreReceiver.h
tupconvert.h
tupdesc.h
tupdesc_details.h
tuplesort.h
tuplestore.h
tuptable.h
tuptoaster.h
twophase.h
twophase_rmgr.h
typcache.h
typecmds.h
types.h
tzparser.h
ucnv_err.h
umachine.h
unicode_norm.h
unistd.h
user.h
username.h
utility.h
vacuum.h
valid.h
value.h
var.h
variable.h
varlena.h
view.h
visibilitymap.h
walreceiver.h
walsender.h
walsender_private.h
walwriter.h
windowapi.h
worker_internal.h
xact.h
xlog.h
xlog_internal.h
xlogdefs.h
xloginsert.h
xlogreader.h
xlogrecord.h
xlogutils.h
xml.h
xmlautomata.h
xmlerror.h
xmlIO.h
xmlmemory.h
xmlstring.h

to the top

Source Files  695 


acl.c
aclchk.c
aggregatecmds.c
allpaths.c
alter.c
amapi.c
amcmds.c
amutils.c
amvalidate.c
analyze.c
analyzejoins.c
array_expanded.c
array_selfuncs.c
array_typanalyze.c
array_userfuncs.c
arrayfuncs.c
arrayutils.c
ascii.c
aset.c
assert.c
async.c
attoptcache.c
auth-scram.c
auth.c
autovacuum.c
backend_random.c
barrier.c
base64.c
basebackup.c
be-fsstubs.c
be-secure-common.c
be-secure-openssl.c
be-secure.c
bernoulli.c
bgworker.c
bgwriter.c
binaryheap.c
bipartite_match.c
bitmapset.c
bloomfilter.c
bool.c
bootparse.c
bootscanner.c
bootscanner.l
bootstrap.c
brin.c
brin_inclusion.c
brin_minmax.c
brin_pageops.c
brin_revmap.c
brin_tuple.c
brin_validate.c
brin_xlog.c
brindesc.c
buf_init.c
buf_table.c
buffile.c
bufmask.c
bufmgr.c
bufpage.c
cash.c
catalog.c
catcache.c
char.c
checkpointer.c
chklocale.c
clauses.c
clausesel.c
clog.c
clogdesc.c
cluster.c
collationcmds.c
combocid.c
comment.c
commit_ts.c
committsdesc.c
condition_variable.c
config_info.c
constraint.c
controldata_utils.c
conv.c
conversioncmds.c
copy.c
copydir.c
copyfuncs.c
costsize.c
createas.c
createplan.c
crypt.c
cryptohashes.c
date.c
datetime.c
datum.c
dbasedesc.c
dbcommands.c
dbsize.c
deadlock.c
decode.c
define.c
dependencies.c
dependency.c
dest.c
dfmgr.c
dict.c
dict_ispell.c
dict_simple.c
dict_synonym.c
dict_thesaurus.c
discard.c
domains.c
dropcmds.c
dsa.c
dshash.c
dsm.c
dsm_impl.c
dynahash.c
elog.c
encnames.c
encode.c
enum.c
equalfuncs.c
equivclass.c
erand48.c
event_trigger.c
evtcache.c
exec.c
execAmi.c
execCurrent.c
execExpr.c
execExprInterp.c
execGrouping.c
execIndexing.c
execJunk.c
execMain.c
execParallel.c
execPartition.c
execProcnode.c
execReplication.c
execScan.c
execSRF.c
execTuples.c
execUtils.c
expandeddatum.c
expandedrecord.c
explain.c
extended_stats.c
extensible.c
extension.c
fastpath.c
fd.c
file_perm.c
float.c
fls.c
fmgr.c
fmgrtab.c
foreign.c
foreigncmds.c
fork_process.c
format_type.c
formatting.c
freelist.c
freepage.c
freespace.c
fsmpage.c
funcapi.c
functioncmds.c
functions.c
genam.c
generation.c
generic_xlog.c
genericdesc.c
genfile.c
geo_ops.c
geo_selfuncs.c
geo_spgist.c
geqo_copy.c
geqo_erx.c
geqo_eval.c
geqo_main.c
geqo_pool.c
geqo_random.c
geqo_recombination.c
geqo_selection.c
getpeereid.c
ginarrayproc.c
ginbtree.c
ginbulk.c
gindatapage.c
gindesc.c
ginentrypage.c
ginfast.c
ginget.c
gininsert.c
ginlogic.c
ginpostinglist.c
ginscan.c
ginutil.c
ginvacuum.c
ginvalidate.c
ginxlog.c
gist.c
gistbuild.c
gistbuildbuffers.c
gistdesc.c
gistget.c
gistproc.c
gistscan.c
gistsplit.c
gistutil.c
gistvacuum.c
gistvalidate.c
gistxlog.c
globals.c
gram.c
gram.y
guc-file.c
guc-file.l
guc.c
hash.c
hash_xlog.c
hashdesc.c
hashfn.c
hashfunc.c
hashinsert.c
hashovfl.c
hashpage.c
hashsearch.c
hashsort.c
hashutil.c
hashvalidate.c
hba.c
heap.c
heapam.c
heapdesc.c
heaptuple.c
help_config.c
hio.c
hyperloglog.c
ifaddr.c
ilist.c
index.c
indexam.c
indexcmds.c
indexfsm.c
indexing.c
indextuple.c
indxpath.c
inet_cidr_ntop.c
initsplan.c
instrument.c
int.c
int8.c
inv_api.c
inval.c
ip.c
ipc.c
ipci.c
itemptr.c
jit.c
joininfo.c
joinpath.c
joinrels.c
json.c
jsonb.c
jsonb_gin.c
jsonb_op.c
jsonb_util.c
jsonfuncs.c
keywords.c
knapsack.c
latch.c
launcher.c
levenshtein.c
like.c
list.c
lmgr.c
localbuf.c
localtime.c
lock.c
lockcmds.c
lockfuncs.c
logical.c
logicalfuncs.c
logicalmsgdesc.c
logtape.c
lsyscache.c
lwlock.c
lwlocknames.c
mac.c
mac8.c
main.c
makefuncs.c
matview.c
mbutils.c
mcxt.c
md.c
md5.c
message.c
misc.c
miscinit.c
multixact.c
mvdistinct.c
mxactdesc.c
nabstime.c
name.c
namespace.c
nbtcompare.c
nbtdesc.c
nbtinsert.c
nbtpage.c
nbtree.c
nbtsearch.c
nbtsort.c
nbtutils.c
nbtvalidate.c
nbtxlog.c
network.c
network_gist.c
network_selfuncs.c
network_spgist.c
noblock.c
nodeAgg.c
nodeAppend.c
nodeBitmapAnd.c
nodeBitmapHeapscan.c
nodeBitmapIndexscan.c
nodeBitmapOr.c
nodeCtescan.c
nodeCustom.c
nodeForeignscan.c
nodeFuncs.c
nodeFunctionscan.c
nodeGather.c
nodeGatherMerge.c
nodeGroup.c
nodeHash.c
nodeHashjoin.c
nodeIndexonlyscan.c
nodeIndexscan.c
nodeLimit.c
nodeLockRows.c
nodeMaterial.c
nodeMergeAppend.c
nodeMergejoin.c
nodeModifyTable.c
nodeNamedtuplestorescan.c
nodeNestloop.c
nodeProjectSet.c
nodeRecursiveunion.c
nodeResult.c
nodes.c
nodeSamplescan.c
nodeSeqscan.c
nodeSetOp.c
nodeSort.c
nodeSubplan.c
nodeSubqueryscan.c
nodeTableFuncscan.c
nodeTidscan.c
nodeUnique.c
nodeValuesscan.c
nodeWindowAgg.c
nodeWorktablescan.c
numeric.c
numutils.c
objectaccess.c
objectaddress.c
oid.c
opclasscmds.c
operatorcmds.c
oracle_compat.c
orclauses.c
orderedsetaggs.c
origin.c
outfuncs.c
pairingheap.c
parallel.c
params.c
parse_agg.c
parse_clause.c
parse_coerce.c
parse_collate.c
parse_cte.c
parse_enr.c
parse_expr.c
parse_func.c
parse_node.c
parse_oper.c
parse_param.c
parse_relation.c
parse_target.c
parse_type.c
parse_utilcmd.c
parser.c
partbounds.c
partcache.c
partition.c
partprune.c
path.c
pathkeys.c
pathnode.c
pg_aggregate.c
pg_collation.c
pg_config.c
pg_constraint.c
pg_controldata.c
pg_conversion.c
pg_crc.c
pg_crc32c_sb8.c
pg_crc32c_sse42.c
pg_crc32c_sse42_choose.c
pg_db_role_setting.c
pg_depend.c
pg_enum.c
pg_inherits.c
pg_largeobject.c
pg_locale.c
pg_lsn.c
pg_lzcompress.c
pg_namespace.c
pg_operator.c
pg_proc.c
pg_publication.c
pg_range.c
pg_rusage.c
pg_sema.c
pg_shdepend.c
pg_shmem.c
pg_strong_random.c
pg_subscription.c
pg_type.c
pg_upgrade_support.c
pgarch.c
pgfnames.c
pgsleep.c
pgstat.c
pgstatfuncs.c
pgstrcasecmp.c
pgtz.c
placeholder.c
planagg.c
plancache.c
plancat.c
planmain.c
planner.c
pmsignal.c
policy.c
portalcmds.c
portalmem.c
postgres.c
postinit.c
postmaster.c
pqcomm.c
pqformat.c
pqmq.c
pqsignal.c
pquery.c
predicate.c
predtest.c
prepare.c
prepjointree.c
prepqual.c
preptlist.c
prepunion.c
print.c
printsimple.c
printtup.c
proc.c
procarray.c
proclang.c
procsignal.c
proto.c
pruneheap.c
ps_status.c
pseudotypes.c
psprintf.c
publicationcmds.c
qsort.c
qsort_arg.c
queryenvironment.c
quote.c
quotes.c
rangetypes.c
rangetypes_gist.c
rangetypes_selfuncs.c
rangetypes_spgist.c
rangetypes_typanalyze.c
rbtree.c
read.c
readfuncs.c
regc_color.c
regc_pg_locale.c
regcomp.c
regerror.c
regexec.c
regexp.c
regexport.c
regfree.c
regis.c
regprefix.c
regproc.c
reinit.c
relation.c
relcache.c
relfilenodemap.c
relmapdesc.c
relmapper.c
relnode.c
reloptions.c
relpath.c
reorderbuffer.c
repl_gram.c
repl_gram.y
repl_scanner.c
repl_scanner.l
replorigindesc.c
resowner.c
restrictinfo.c
rewriteDefine.c
rewriteHandler.c
rewriteheap.c
rewriteManip.c
rewriteRemove.c
rewriteSupport.c
ri_triggers.c
rls.c
rmgr.c
rmtree.c
rowsecurity.c
rowtypes.c
ruleutils.c
s_lock.c
sampling.c
saslprep.c
scan.c
scan.l
scankey.c
scansup.c
schemacmds.c
scram-common.c
seclabel.c
selfuncs.c
seqdesc.c
sequence.c
session.c
setrefs.c
sha2_openssl.c
sharedfileset.c
sharedtuplestore.c
shm_mq.c
shm_toc.c
shmem.c
shmqueue.c
sinval.c
sinvaladt.c
slab.c
slot.c
slotfuncs.c
slru.c
smgr.c
smgrdesc.c
smgrtype.c
snapbuild.c
snapmgr.c
sortsupport.c
spccache.c
spell.c
spgdesc.c
spgdoinsert.c
spginsert.c
spgkdtreeproc.c
spgquadtreeproc.c
spgscan.c
spgtextproc.c
spgutils.c
spgvacuum.c
spgvalidate.c
spgxlog.c
spi.c
spin.c
standby.c
standbydesc.c
startup.c
statscmds.c
storage.c
strftime.c
string.c
stringinfo.c
strlcat.c
strlcpy.c
subscriptioncmds.c
subselect.c
subtrans.c
superuser.c
syncrep.c
syncrep_gram.c
syncrep_gram.y
syncrep_scanner.c
syncrep_scanner.l
syncscan.c
syscache.c
syslogger.c
system.c
tablecmds.c
tablesample.c
tablespace.c
tablesync.c
tar.c
tblspcdesc.c
thread.c
tid.c
tidbitmap.c
tidpath.c
timeline.c
timeout.c
timestamp.c
tlist.c
to_tsany.c
toasting.c
tqual.c
tqueue.c
transam.c
trigfuncs.c
trigger.c
ts_cache.c
ts_locale.c
ts_parse.c
ts_selfuncs.c
ts_typanalyze.c
ts_utils.c
tsearchcmds.c
tsginidx.c
tsgistidx.c
tsquery.c
tsquery_cleanup.c
tsquery_gist.c
tsquery_op.c
tsquery_rewrite.c
tsquery_util.c
tsrank.c
tstoreReceiver.c
tsvector.c
tsvector_op.c
tsvector_parser.c
tupconvert.c
tupdesc.c
tuplesort.c
tuplestore.c
tuptoaster.c
twophase.c
twophase_rmgr.c
txid.c
typcache.c
typecmds.c
tzparser.c
unicode_norm.c
user.c
username.c
utility.c
uuid.c
vacuum.c
vacuumlazy.c
value.c
var.c
varbit.c
varchar.c
variable.c
varlena.c
varsup.c
version.c
view.c
visibilitymap.c
wait_error.c
walreceiver.c
walreceiverfuncs.c
walsender.c
walwriter.c
wchar.c
windowfuncs.c
worker.c
wparser.c
wparser_def.c
wstrcmp.c
wstrncmp.c
xact.c
xactdesc.c
xid.c
xlog.c
xlogarchive.c
xlogdesc.c
xlogfuncs.c
xloginsert.c
xlogreader.c
xlogutils.c
xml.c

to the top

Objects  1 


postgres

to the top



Test Info


Module NamelibTest
Version #1X
Version #2Y
Archx86_64
SubjectSource Compatibility

Test Results


Total Header Files538
Total Source Files695
Total Objects1
Total Symbols / Types8879 / 2781
Compatibility 90.3%

Problem Summary


SeverityCount
Added Symbols-89
Removed SymbolsHigh15
Problems with
Data Types
High23
Medium0
Low37
Problems with
Symbols
High14
Medium19
Low4
Problems with
Constants
Low0
Other Changes
in Data Types
-3
Other Changes
in Symbols
-5

Added Symbols  89 


acl.h
recordDependencyOnNewAcl ( Oid classId, Oid objectId, int32 objsubId, Oid ownerId, Acl* acl )

array.h
ArrayCheckBounds ( int ndim, int const* dims, int const* lb )

bgworker_internals.h
ForgetUnstartedBackgroundWorkers ( )

bufpage.h
PageIsVerifiedExtended ( Page page, BlockNumber blkno, int flags )

builtins.h
xidLogicalComparator ( void const* arg1, void const* arg2 )

clauses.h
contain_exec_param ( Node* clause, List* param_ids )

createplan.c
change_plan_targetlist ( Plan* subplan, List* tlist, _Bool tlist_parallel_safe )

date.h
float_time_overflows ( int hour, int min, double sec )
time_overflows ( int hour, int min, int sec, fsec_t fsec )

dependency.h
AcquireDeletionLock ( ObjectAddress const* object, int flags )
changeDependencyOnTablespace ( Oid classId, Oid objectId, Oid newTablespaceId )
checkMembershipInCurrentExtension ( ObjectAddress const* object )
getAutoExtensionsOfObject ( Oid classId, Oid objectId )
recordDependencyOnTablespace ( Oid classId, Oid objectId, Oid tablespace )
ReleaseDeletionLock ( ObjectAddress const* object )

executor.h
BuildTupleHashTableExt ( PlanState* parent, TupleDesc inputDesc, int numCols, AttrNumber* keyColIdx, Oid* eqfuncoids, FmgrInfo* hashfunctions, long nbuckets, Size additionalsize, MemoryContext metacxt, MemoryContext tablecxt, MemoryContext tempcxt, _Bool use_variable_hash_iv )
ExecBuildProjectionInfoExt ( List* targetList, ExprContext* econtext, TupleTableSlot* slot, _Bool assignJunkEntries, PlanState* parent, TupleDesc inputDesc )
ExecGetInsertedCols ( ResultRelInfo* relinfo, EState* estate )
ExecGetUpdatedCols ( ResultRelInfo* relinfo, EState* estate )
ResetTupleHashTable ( TupleHashTable hashtable )

fd.h
data_sync_elevel ( int elevel )
data_sync_retry [data]

htup_details.h
getmissingattr ( TupleDesc tupleDesc, int attnum, _Bool* isnull )

index.h
BuildDummyIndexInfo ( Relation index )
ResetReindexState ( int nestLevel )

inval.c
InvalidateSystemCachesExtended ( _Bool debug_discard )

libpq.h
pq_buffer_has_data ( )

lmgr.h
LockDatabaseFrozenIds ( LOCKMODE lockmode )

lsyscache.h
get_index_isclustered ( Oid index_oid )
get_index_isreplident ( Oid index_oid )
get_range_collation ( Oid rangeOid )

lwlock.h
LWLockAnyHeldByMe ( LWLock* l, int nlocks, size_t stride )

namespace.h
checkTempNamespaceStatus ( Oid namespaceId )
TypenameGetTypidExtended ( char const* typname, _Bool temp_ok )

paramassign.h
assign_special_exec_param ( PlannerInfo* root )
generate_new_exec_param ( PlannerInfo* root, Oid paramtype, int32 paramtypmod, Oid paramcollation )
identify_current_nestloop_params ( PlannerInfo* root, Relids leftrelids )
process_subquery_nestloop_params ( PlannerInfo* root, List* subplan_params )
replace_nestloop_param_placeholdervar ( PlannerInfo* root, PlaceHolderVar* phv )
replace_nestloop_param_var ( PlannerInfo* root, Var* var )
replace_outer_agg ( PlannerInfo* root, Aggref* agg )
replace_outer_grouping ( PlannerInfo* root, GroupingFunc* grp )
replace_outer_placeholdervar ( PlannerInfo* root, PlaceHolderVar* phv )
replace_outer_var ( PlannerInfo* root, Var* var )

parse_type.h
LookupTypeNameExtended ( ParseState* pstate, TypeName const* typeName, int32* typmod_p, _Bool temp_ok, _Bool missing_ok )

parse_utilcmd.h
expandTableLikeClause ( RangeVar* heapRel, TableLikeClause* table_like_clause )
transformCreateSchemaStmtElements ( List* schemaElts, char const* schemaName )

pg_constraint.h
DeconstructFkConstraintRow ( HeapTuple tuple, int* numfks, AttrNumber* conkey, AttrNumber* confkey, Oid* pf_eq_oprs, Oid* pp_eq_oprs, Oid* ff_eq_oprs )

port.h
pg_mkdir_p ( char* path, int omode )
pg_strsignal ( int signum )
wait_result_is_any_signal ( int exit_status, _Bool include_command_not_found )
wait_result_is_signal ( int exit_status, int signum )

portal.h
ForgetPortalSnapshots ( )

pqsignal.h
pqsignal_pm ( int signo, pqsigfunc func )

pquery.h
EnsurePortalSnapshotExists ( )
PlannedStmtRequiresSnapshot ( PlannedStmt* pstmt )

procarray.h
GetVirtualXIDsDelayingChkptEnd ( int* nvxids )
HaveVirtualXIDsDelayingChkptEnd ( VirtualTransactionId* vxids, int nvxids )
KnownAssignedTransactionIdsIdleMaintenance ( )
SignalVirtualTransaction ( struct VirtualTransactionId vxid, enum ProcSignalReason sigmode, _Bool conflictPending )

rbtree.c
rbt_delete ( RBTree* rbt, RBTNode* node )
rbt_find ( RBTree* rbt, RBTNode const* data )
rbt_leftmost ( RBTree* rbt )

rbtree.h
rbt_begin_iterate ( RBTree* rbt, RBTOrderControl ctrl, RBTreeIterator* iter )
rbt_create ( Size node_size, rbt_comparator comparator, rbt_combiner combiner, rbt_allocfunc allocfunc, rbt_freefunc freefunc, void* arg )
rbt_insert ( RBTree* rbt, RBTNode const* data, _Bool* isNew )
rbt_iterate ( RBTreeIterator* iter )

relation.h
is_dummy_rel ( RelOptInfo* rel )

relcache.h
RelationGetDummyIndexExpressions ( Relation relation )

scram.h
parse_scram_verifier ( char const* verifier, int* iterations, char** salt, uint8* stored_key, uint8* server_key )

simplehash.h
tuplehash_reset ( tuplehash_hash* tb )

slru.h
SlruPagePrecedesUnitTests ( SlruCtl ctl, int per_page )

snapbuild.h
SnapBuildResetExportedSnapshotState ( )
SnapBuildXidSetCatalogChanges ( SnapBuild* builder, TransactionId xid, int subxcnt, TransactionId* subxacts, XLogRecPtr lsn )

snapmgr.h
PushActiveSnapshotWithLevel ( Snapshot snap, int snap_level )

syncrep.h
SyncRepGetCandidateStandbys ( SyncRepStandbyData** standbys )

tablecmds.h
ResetRelRewrite ( Oid myrelid )

tablespace.h
allow_in_place_tablespaces [data]

timestamp.h
TimestampDifferenceMilliseconds ( TimestampTz start_time, TimestampTz stop_time )

trigger.h
CreateTriggerFiringOn ( CreateTrigStmt* stmt, char const* queryString, Oid relOid, Oid refRelOid, Oid constraintOid, Oid indexOid, Oid funcoid, Oid parentTriggerOid, Node* whenClause, _Bool isInternal, _Bool in_partition, char trigger_fires_when )
EnableDisableTriggerNew ( Relation rel, char const* tgname, char fires_when, _Bool skip_system, _Bool recurse, LOCKMODE lockmode )

tupconvert.h
execute_attr_map_cols ( Bitmapset* in_cols, TupleConversionMap* map )

twophase.h
TwoPhaseGetXidByVirtualXID ( struct VirtualTransactionId vxid, _Bool* have_more )

walreceiver.c
ProcessWalRcvInterrupts ( )

walsender_private.h
replication_scanner_is_replication_command ( )

worker_internal.h
LogRepWorkerWalRcvConn [data]

xlog.h
GetRecoveryState ( )
register_persistent_abort_backup_handler ( )

xloginsert.c
log_newpage_range ( Relation rel, ForkNumber forkNum, BlockNumber startblk, BlockNumber endblk, _Bool page_std )

to the top

Removed Symbols  15 


logicalrelation.h
logicalrep_typmap_gettypname ( Oid remoteid )
logicalrep_typmap_update ( LogicalRepTyp* remotetyp )

parse_utilcmd.h
transformCreateSchemaStmt ( CreateSchemaStmt* stmt )

port.h
pqsignal_no_restart ( int signo, pqsigfunc func )

rbtree.c
rb_delete ( RBTree* rb, RBNode* node )
rb_find ( RBTree* rb, RBNode const* data )
rb_leftmost ( RBTree* rb )

rbtree.h
rb_begin_iterate ( RBTree* rb, RBOrderControl ctrl, RBTreeIterator* iter )
rb_create ( Size node_size, rb_comparator comparator, rb_combiner combiner, rb_allocfunc allocfunc, rb_freefunc freefunc, void* arg )
rb_insert ( RBTree* rb, RBNode const* data, _Bool* isNew )
rb_iterate ( RBTreeIterator* iter )

rel.h
RelationHasUnloggedIndex ( Relation rel )

subselect.h
assign_nestloop_param_placeholdervar ( PlannerInfo* root, PlaceHolderVar* phv )
assign_nestloop_param_var ( PlannerInfo* root, Var* var )

worker_internal.h
wrconn [data]

to the top

Problems with Data Types, High Severity  23 


copy.c
[+] struct CopyStateData  1 

dshash.c
[+] struct dshash_table  2 

execExpr.h
[+] struct anon-struct-execExpr.h-341  1 
[+] struct anon-struct-execExpr.h-465  1 
[+] struct anon-struct-execExpr.h-474  1 
[+] struct anon-struct-execExpr.h-519  4 

execnodes.h
[+] struct IndexOnlyScanState  1 
[+] struct ResultRelInfo  1 

execPartition.h
[+] struct PartitionedRelPruningData  4 

gin_private.h
[+] struct GinEntryAccumulator  1 

libpq-be.h
[+] enum CAC_state  1 

partprune.h
[+] struct PartitionPruneContext  2 

rbtree.h
[+] struct RBTreeIterator  1 

smgr.h
[+] struct SMgrRelationData  1 

spell.h
[+] union anon-union-spell.h-98  1 

to the top

Problems with Symbols, High Severity  14 


gin_private.h
[+] ginFindLeafPage ( GinBtree btree, _Bool searchMode, Snapshot snapshot )  1 

ipc.h
[+] CreateSharedMemoryAndSemaphores ( _Bool makePrivate, int port )  1 

pg_shmem.h
[+] PGSharedMemoryCreate ( Size size, _Bool makePrivate, int port, PGShmemHeader** shim )  1 

pg_type.h
[+] GenerateTypeDependencies ( Oid typeNamespace, Oid typeObjectId, Oid relationOid, char relationKind, Oid owner, Oid inputProcedure, Oid outputProcedure, Oid receiveProcedure, Oid sendProcedure, Oid typmodinProcedure, Oid typmodoutProcedure, Oid analyzeProcedure, Oid elementType, _Bool isImplicitArray, Oid baseType, Oid typeCollation, Node* defaultExpr, _Bool rebuild )  9 

portal.h
[+] AtSubCommit_Portals ( SubTransactionId mySubid, SubTransactionId parentSubid, ResourceOwner parentXactOwner )  1 

rewriteHandler.h
[+] relation_is_updatable ( Oid reloid, _Bool include_triggers, Bitmapset* include_cols )  1 

to the top

Problems with Symbols, Medium Severity  19 


bgworker_internals.h
[+] BackgroundWorkerStateChange ( )  1 

execPartition.h
[+] ExecSetupPartitionTupleRouting ( ModifyTableState* mtstate, Relation rel )  1 

executor.h
[+] InitResultRelInfo ( ResultRelInfo* resultRelInfo, Relation resultRelationDesc, Index resultRelationIndex, Relation partition_root, int instrument_options )  1 

gist_private.h
[+] gistdoinsert ( Relation r, IndexTuple itup, Size freespace, GISTSTATE* giststate )  1 
[+] gistplacetopage ( Relation rel, Size freespace, GISTSTATE* giststate, Buffer buffer, IndexTuple* itup, int ntup, OffsetNumber oldoffnum, BlockNumber* newblkno, Buffer leftchildbuf, List** splitinfo, _Bool markfollowright )  1 
[+] gistXLogUpdate ( Buffer buffer, OffsetNumber* todelete, int ntodelete, IndexTuple* itup, int ituplen, Buffer leftchildbuf )  1 

nbtree.h
[+] _bt_pagedel ( Relation rel, Buffer buf )  1 

pg_type.h
[+] GenerateTypeDependencies ( Oid typeNamespace, Oid typeObjectId, Oid relationOid, char relationKind, Oid owner, Oid inputProcedure, Oid outputProcedure, Oid receiveProcedure, Oid sendProcedure, Oid typmodinProcedure, Oid typmodoutProcedure, Oid analyzeProcedure, Oid elementType, _Bool isImplicitArray, Oid baseType, Oid typeCollation, Node* defaultExpr, _Bool rebuild )  7 

pgstat.h
[+] AtEOXact_PgStat ( _Bool isCommit )  1 

relcache.h
[+] RelationCacheInvalidate ( )  1 

toasting.h
[+] NewHeapCreateToastTable ( Oid relOid, Datum reloptions, LOCKMODE lockmode )  1 

xlog.h
[+] do_pg_abort_backup ( )  2 

to the top

Problems with Data Types, Low Severity  37 


copy.c
[+] struct CopyStateData  1 

execExpr.h
[+] struct anon-struct-execExpr.h-341  1 
[+] struct anon-struct-execExpr.h-465  1 
[+] struct anon-struct-execExpr.h-519  3 

execnodes.h
[+] struct SubPlanState  1 
[+] struct ValuesScanState  1 

execPartition.h
[+] struct PartitionedRelPruningData  4 

hba.h
[+] struct HbaLine  2 

logical.h
[+] struct LogicalDecodingContext  1 

logicalrelation.h
[+] struct LogicalRepRelMapEntry  1 

partbounds.h
[+] struct PartitionBoundInfoData  1 

plannodes.h
[+] struct IndexOnlyScan  1 

portal.h
[+] struct PortalData  2 

primnodes.h
[+] struct SubPlan  1 

proc.h
[+] struct PGPROC  1 

rbtree.c
[+] struct RBTree  5 

rbtree.h
[+] struct RBTreeIterator  2 

rel.h
[+] struct RelationData  3 

relation.h
[+] struct IndexOptInfo  1 

smgr.h
[+] struct SMgrRelationData  1 

xlogreader.h
[+] struct XLogReaderState  3 

to the top

Problems with Symbols, Low Severity  4 


buffile.h
[+] BufFileSize ( BufFile* file )  1 

lock.h
[+] LockTagTypeNames [data]  1 

nbtree.h
[+] _bt_pagedel ( Relation rel, Buffer buf )  1 

simplehash.h
[+] tuplehash_grow ( tuplehash_hash* tb, uint32 newsize )  1 

to the top

Other Changes in Data Types  3 


dependency.h
[+] enum SharedDependencyType  1 

reorderbuffer.h
[+] enum ReorderBufferChangeType  1 

spell.h
[+] union anon-union-spell.h-98  1 

to the top

Other Changes in Symbols  5 


dependency.h
[+] recordDependencyOnSingleRelExpr ( ObjectAddress const* depender, Node* expr, Oid relId, DependencyType behavior, DependencyType self_behavior, _Bool ignore_self )  1 

execPartition.h
[+] ExecInitPartitionInfo ( ModifyTableState* mtstate, ResultRelInfo* resultRelInfo, PartitionTupleRouting* proute, EState* estate, int partidx )  1 
[+] ExecSetupPartitionTupleRouting ( ModifyTableState* mtstate, Relation rel )  1 

executor.h
[+] InitResultRelInfo ( ResultRelInfo* resultRelInfo, Relation resultRelationDesc, Index resultRelationIndex, Relation partition_root, int instrument_options )  1 

nbtree.h
[+] _bt_pagedel ( Relation rel, Buffer buf )  1 

to the top

Header Files  538 



__locale_t.h
__sigset_t.h
acl.h
aclchk_internal.h
alter.h
amapi.h
amvalidate.h
analyze.h
arch-x86.h
array.h
ascii.h
async.h
attnum.h
attoptcache.h
auth.h
autovacuum.h
backend_random.h
backendid.h
barrier.h
base64.h
basebackup.h
be-fsstubs.h
bgworker.h
bgworker_internals.h
bgwriter.h
binary_upgrade.h
binaryheap.h
bipartite_match.h
bitmapset.h
block.h
bloomfilter.h
bootstrap.h
brin.h
brin_internal.h
brin_pageops.h
brin_revmap.h
brin_tuple.h
brin_xlog.h
buf.h
buf_internals.h
buffile.h
bufmask.h
bufmgr.h
bufpage.h
builtins.h
bytea.h
c.h
catalog.h
catcache.h
checksum_impl.h
chvalid.h
clauses.h
clog.h
cluster.h
collationcmds.h
combocid.h
comment.h
commit_ts.h
condition_variable.h
config_info.h
controldata_utils.h
conversioncmds.h
copy.h
copydir.h
cost.h
createas.h
crypt.h
date.h
datetime.h
datum.h
dbcommands.h
dbcommands_xlog.h
decode.h
defrem.h
dependency.h
dest.h
dict.h
dirent.h
discard.h
dsa.h
dshash.h
dsm.h
dsm_impl.h
dynahash.h
elog.h
encoding.h
entities.h
epoll.h
event_trigger.h
evtcache.h
execdesc.h
execExpr.h
execnodes.h
execParallel.h
execPartition.h
executor.h
expandeddatum.h
expandedrecord.h
explain.h
extended_stats_internal.h
extensible.h
extension.h
fastpath.h
fd.h
fdwapi.h
FILE.h
file_perm.h
fmgr.h
fmgrprotos.h
fmgrtab.h
foreign.h
fork_process.h
formatting.h
freepage.h
freespace.h
fsm_internals.h
funcapi.h
functions.h
genam.h
generic_xlog.h
geo_decls.h
geqo.h
geqo_copy.h
geqo_gene.h
geqo_pool.h
geqo_random.h
geqo_recombination.h
geqo_selection.h
getopt_core.h
gin.h
gin_private.h
ginblock.h
ginxlog.h
gist.h
gist_private.h
gistscan.h
gistxlog.h
globals.h
gramparse.h
guc.h
guc_tables.h
hash.h
hash_xlog.h
hashjoin.h
hba.h
heap.h
heapam.h
heapam_xlog.h
help_config.h
hio.h
hsearch.h
htup.h
htup_details.h
hyperloglog.h
iconv.h
ifaddr.h
ilist.h
in.h
index.h
index_selfuncs.h
indexfsm.h
indexing.h
inet.h
instr_time.h
instrument.h
int8.h
inval.h
ip.h
ipc.h
item.h
itemptr.h
itup.h
jit.h
joininfo.h
json.h
jsonapi.h
jsonb.h
keywords.h
knapsack.h
large_object.h
latch.h
libpq-be.h
libpq.h
lmgr.h
locale.h
locale_t.h
lock.h
lockcmds.h
lockdefs.h
lockoptions.h
logical.h
logicalfuncs.h
logicallauncher.h
logicalproto.h
logicalrelation.h
logicalworker.h
logtape.h
lsyscache.h
lwlock.h
makefuncs.h
matview.h
md5.h
memnodes.h
memutils.h
message.h
miscadmin.h
multixact.h
nabstime.h
namespace.h
nbtree.h
nbtxlog.h
netdb.h
nodeAgg.h
nodeAppend.h
nodeBitmapAnd.h
nodeBitmapHeapscan.h
nodeBitmapIndexscan.h
nodeBitmapOr.h
nodeCtescan.h
nodeCustom.h
nodeForeignscan.h
nodeFuncs.h
nodeFunctionscan.h
nodeGather.h
nodeGatherMerge.h
nodeGroup.h
nodeHash.h
nodeHashjoin.h
nodeIndexonlyscan.h
nodeIndexscan.h
nodeLimit.h
nodeLockRows.h
nodeMaterial.h
nodeMergeAppend.h
nodeMergejoin.h
nodeModifyTable.h
nodeNamedtuplestorescan.h
nodeNestloop.h
nodeProjectSet.h
nodeRecursiveunion.h
nodeResult.h
nodes.h
nodeSamplescan.h
nodeSeqscan.h
nodeSetOp.h
nodeSort.h
nodeSubplan.h
nodeSubqueryscan.h
nodeTableFuncscan.h
nodeTidscan.h
nodeUnique.h
nodeValuesscan.h
nodeWindowAgg.h
nodeWorktablescan.h
numeric.h
objectaccess.h
objectaddress.h
off.h
orclauses.h
origin.h
output_plugin.h
pairingheap.h
palloc.h
parallel.h
params.h
parse_agg.h
parse_clause.h
parse_coerce.h
parse_collate.h
parse_cte.h
parse_enr.h
parse_expr.h
parse_func.h
parse_node.h
parse_oper.h
parse_param.h
parse_relation.h
parse_target.h
parse_type.h
parse_utilcmd.h
parsenodes.h
parser.h
parsetree.h
partbounds.h
partcache.h
partdefs.h
partition.h
partprune.h
pathnode.h
paths.h
pg_aggregate.h
pg_attribute.h
pg_class.h
pg_collation.h
pg_constraint.h
pg_control.h
pg_conversion.h
pg_crc.h
pg_crc32c.h
pg_db_role_setting.h
pg_enum.h
pg_index.h
pg_inherits.h
pg_largeobject.h
pg_list.h
pg_locale.h
pg_lzcompress.h
pg_namespace.h
pg_operator.h
pg_proc.h
pg_publication.h
pg_range.h
pg_rusage.h
pg_sema.h
pg_shmem.h
pg_subscription.h
pg_subscription_rel.h
pg_type.h
pg_wchar.h
pgarch.h
pgstat.h
pgtar.h
pgtime.h
pgtz.h
placeholder.h
plancache.h
plancat.h
planmain.h
planner.h
plannodes.h
pmsignal.h
policy.h
port.h
portal.h
portalcmds.h
postgres.h
postgres_ext.h
postmaster.h
pqcomm.h
pqformat.h
pqmq.h
pqsignal.h
pquery.h
predicate.h
predicate_internals.h
predtest.h
prep.h
prepare.h
primnodes.h
print.h
printsimple.h
printtup.h
proc.h
procarray.h
proclang.h
proclist_types.h
procsignal.h
prs2lock.h
ps_status.h
publicationcmds.h
pwd.h
queryenvironment.h
rangetypes.h
rbtree.h
readfuncs.h
regcustom.h
regex.h
regexport.h
regguts.h
regis.h
regproc.h
reinit.h
rel.h
relation.h
relcache.h
relfilenode.h
relfilenodemap.h
relmapper.h
reloptions.h
relpath.h
relscan.h
reltrigger.h
reorderbuffer.h
replnodes.h
resowner.h
resowner_private.h
restrictinfo.h
rewriteDefine.h
rewriteHandler.h
rewriteheap.h
rewriteManip.h
rewriteRemove.h
rewriteSupport.h
rls.h
rmgr.h
rowsecurity.h
ruleutils.h
s_lock.h
sampling.h
saslprep.h
scanner.h
scansup.h
schemacmds.h
scram-common.h
scram.h
sdir.h
seclabel.h
selfuncs.h
semaphore.h
sequence.h
session.h
setjmp.h
sha.h
sha2.h
sharedfileset.h
sharedtuplestore.h
shm_mq.h
shm_toc.h
shmem.h
sig_atomic_t.h
sigset_t.h
simplehash.h
sinval.h
sinvaladt.h
skey.h
slot.h
slru.h
smgr.h
snapbuild.h
snapmgr.h
snapshot.h
sockaddr.h
socket.h
sortsupport.h
spccache.h
spell.h
spgist.h
spgist_private.h
spgxlog.h
spi.h
spi_priv.h
spin.h
standby.h
standbydefs.h
startup.h
statistics.h
stddef.h
stdint-uintn.h
stdint.h
stdio.h
storage.h
storage_xlog.h
stratnum.h
string.h
stringinfo.h
struct___jmp_buf_tag.h
struct_FILE.h
struct_rusage.h
struct_timespec.h
struct_timeval.h
subscriptioncmds.h
subselect.h
subtrans.h
syncrep.h
syscache.h
syslogger.h
tablecmds.h
tablefunc.h
tablespace.h
tcopprot.h
tidbitmap.h
time_t.h
timeline.h
timeout.h
timestamp.h
tlist.h
toasting.h
tqual.h
tqueue.h
transam.h
tree.h
trigger.h
ts_cache.h
ts_locale.h
ts_public.h
ts_type.h
ts_utils.h
tsmapi.h
tstoreReceiver.h
tupconvert.h
tupdesc.h
tupdesc_details.h
tuplesort.h
tuplestore.h
tuptable.h
tuptoaster.h
twophase.h
twophase_rmgr.h
typcache.h
typecmds.h
types.h
tzparser.h
ucnv_err.h
umachine.h
unicode_norm.h
unistd.h
user.h
username.h
utility.h
vacuum.h
valid.h
value.h
var.h
variable.h
varlena.h
view.h
visibilitymap.h
walreceiver.h
walsender.h
walsender_private.h
walwriter.h
windowapi.h
worker_internal.h
xact.h
xlog.h
xlog_internal.h
xlogdefs.h
xloginsert.h
xlogreader.h
xlogrecord.h
xlogutils.h
xml.h
xmlautomata.h
xmlerror.h
xmlIO.h
xmlmemory.h
xmlstring.h

to the top

Source Files  695 


acl.c
aclchk.c
aggregatecmds.c
allpaths.c
alter.c
amapi.c
amcmds.c
amutils.c
amvalidate.c
analyze.c
analyzejoins.c
array_expanded.c
array_selfuncs.c
array_typanalyze.c
array_userfuncs.c
arrayfuncs.c
arrayutils.c
ascii.c
aset.c
assert.c
async.c
attoptcache.c
auth-scram.c
auth.c
autovacuum.c
backend_random.c
barrier.c
base64.c
basebackup.c
be-fsstubs.c
be-secure-common.c
be-secure-openssl.c
be-secure.c
bernoulli.c
bgworker.c
bgwriter.c
binaryheap.c
bipartite_match.c
bitmapset.c
bloomfilter.c
bool.c
bootparse.c
bootscanner.c
bootscanner.l
bootstrap.c
brin.c
brin_inclusion.c
brin_minmax.c
brin_pageops.c
brin_revmap.c
brin_tuple.c
brin_validate.c
brin_xlog.c
brindesc.c
buf_init.c
buf_table.c
buffile.c
bufmask.c
bufmgr.c
bufpage.c
cash.c
catalog.c
catcache.c
char.c
checkpointer.c
chklocale.c
clauses.c
clausesel.c
clog.c
clogdesc.c
cluster.c
collationcmds.c
combocid.c
comment.c
commit_ts.c
committsdesc.c
condition_variable.c
config_info.c
constraint.c
controldata_utils.c
conv.c
conversioncmds.c
copy.c
copydir.c
copyfuncs.c
costsize.c
createas.c
createplan.c
crypt.c
cryptohashes.c
date.c
datetime.c
datum.c
dbasedesc.c
dbcommands.c
dbsize.c
deadlock.c
decode.c
define.c
dependencies.c
dependency.c
dest.c
dfmgr.c
dict.c
dict_ispell.c
dict_simple.c
dict_synonym.c
dict_thesaurus.c
discard.c
domains.c
dropcmds.c
dsa.c
dshash.c
dsm.c
dsm_impl.c
dynahash.c
elog.c
encnames.c
encode.c
enum.c
equalfuncs.c
equivclass.c
erand48.c
event_trigger.c
evtcache.c
exec.c
execAmi.c
execCurrent.c
execExpr.c
execExprInterp.c
execGrouping.c
execIndexing.c
execJunk.c
execMain.c
execParallel.c
execPartition.c
execProcnode.c
execReplication.c
execScan.c
execSRF.c
execTuples.c
execUtils.c
expandeddatum.c
expandedrecord.c
explain.c
extended_stats.c
extensible.c
extension.c
fastpath.c
fd.c
file_perm.c
float.c
fls.c
fmgr.c
fmgrtab.c
foreign.c
foreigncmds.c
fork_process.c
format_type.c
formatting.c
freelist.c
freepage.c
freespace.c
fsmpage.c
funcapi.c
functioncmds.c
functions.c
genam.c
generation.c
generic_xlog.c
genericdesc.c
genfile.c
geo_ops.c
geo_selfuncs.c
geo_spgist.c
geqo_copy.c
geqo_erx.c
geqo_eval.c
geqo_main.c
geqo_pool.c
geqo_random.c
geqo_recombination.c
geqo_selection.c
getpeereid.c
ginarrayproc.c
ginbtree.c
ginbulk.c
gindatapage.c
gindesc.c
ginentrypage.c
ginfast.c
ginget.c
gininsert.c
ginlogic.c
ginpostinglist.c
ginscan.c
ginutil.c
ginvacuum.c
ginvalidate.c
ginxlog.c
gist.c
gistbuild.c
gistbuildbuffers.c
gistdesc.c
gistget.c
gistproc.c
gistscan.c
gistsplit.c
gistutil.c
gistvacuum.c
gistvalidate.c
gistxlog.c
globals.c
gram.c
gram.y
guc-file.c
guc-file.l
guc.c
hash.c
hash_xlog.c
hashdesc.c
hashfn.c
hashfunc.c
hashinsert.c
hashovfl.c
hashpage.c
hashsearch.c
hashsort.c
hashutil.c
hashvalidate.c
hba.c
heap.c
heapam.c
heapdesc.c
heaptuple.c
help_config.c
hio.c
hyperloglog.c
ifaddr.c
ilist.c
index.c
indexam.c
indexcmds.c
indexfsm.c
indexing.c
indextuple.c
indxpath.c
inet_cidr_ntop.c
initsplan.c
instrument.c
int.c
int8.c
inv_api.c
inval.c
ip.c
ipc.c
ipci.c
itemptr.c
jit.c
joininfo.c
joinpath.c
joinrels.c
json.c
jsonb.c
jsonb_gin.c
jsonb_op.c
jsonb_util.c
jsonfuncs.c
keywords.c
knapsack.c
latch.c
launcher.c
levenshtein.c
like.c
list.c
lmgr.c
localbuf.c
localtime.c
lock.c
lockcmds.c
lockfuncs.c
logical.c
logicalfuncs.c
logicalmsgdesc.c
logtape.c
lsyscache.c
lwlock.c
lwlocknames.c
mac.c
mac8.c
main.c
makefuncs.c
matview.c
mbutils.c
mcxt.c
md.c
md5.c
message.c
misc.c
miscinit.c
multixact.c
mvdistinct.c
mxactdesc.c
nabstime.c
name.c
namespace.c
nbtcompare.c
nbtdesc.c
nbtinsert.c
nbtpage.c
nbtree.c
nbtsearch.c
nbtsort.c
nbtutils.c
nbtvalidate.c
nbtxlog.c
network.c
network_gist.c
network_selfuncs.c
network_spgist.c
noblock.c
nodeAgg.c
nodeAppend.c
nodeBitmapAnd.c
nodeBitmapHeapscan.c
nodeBitmapIndexscan.c
nodeBitmapOr.c
nodeCtescan.c
nodeCustom.c
nodeForeignscan.c
nodeFuncs.c
nodeFunctionscan.c
nodeGather.c
nodeGatherMerge.c
nodeGroup.c
nodeHash.c
nodeHashjoin.c
nodeIndexonlyscan.c
nodeIndexscan.c
nodeLimit.c
nodeLockRows.c
nodeMaterial.c
nodeMergeAppend.c
nodeMergejoin.c
nodeModifyTable.c
nodeNamedtuplestorescan.c
nodeNestloop.c
nodeProjectSet.c
nodeRecursiveunion.c
nodeResult.c
nodes.c
nodeSamplescan.c
nodeSeqscan.c
nodeSetOp.c
nodeSort.c
nodeSubplan.c
nodeSubqueryscan.c
nodeTableFuncscan.c
nodeTidscan.c
nodeUnique.c
nodeValuesscan.c
nodeWindowAgg.c
nodeWorktablescan.c
numeric.c
numutils.c
objectaccess.c
objectaddress.c
oid.c
opclasscmds.c
operatorcmds.c
oracle_compat.c
orclauses.c
orderedsetaggs.c
origin.c
outfuncs.c
pairingheap.c
parallel.c
params.c
parse_agg.c
parse_clause.c
parse_coerce.c
parse_collate.c
parse_cte.c
parse_enr.c
parse_expr.c
parse_func.c
parse_node.c
parse_oper.c
parse_param.c
parse_relation.c
parse_target.c
parse_type.c
parse_utilcmd.c
parser.c
partbounds.c
partcache.c
partition.c
partprune.c
path.c
pathkeys.c
pathnode.c
pg_aggregate.c
pg_collation.c
pg_config.c
pg_constraint.c
pg_controldata.c
pg_conversion.c
pg_crc.c
pg_crc32c_sb8.c
pg_crc32c_sse42.c
pg_crc32c_sse42_choose.c
pg_db_role_setting.c
pg_depend.c
pg_enum.c
pg_inherits.c
pg_largeobject.c
pg_locale.c
pg_lsn.c
pg_lzcompress.c
pg_namespace.c
pg_operator.c
pg_proc.c
pg_publication.c
pg_range.c
pg_rusage.c
pg_sema.c
pg_shdepend.c
pg_shmem.c
pg_strong_random.c
pg_subscription.c
pg_type.c
pg_upgrade_support.c
pgarch.c
pgfnames.c
pgsleep.c
pgstat.c
pgstatfuncs.c
pgstrcasecmp.c
pgtz.c
placeholder.c
planagg.c
plancache.c
plancat.c
planmain.c
planner.c
pmsignal.c
policy.c
portalcmds.c
portalmem.c
postgres.c
postinit.c
postmaster.c
pqcomm.c
pqformat.c
pqmq.c
pqsignal.c
pquery.c
predicate.c
predtest.c
prepare.c
prepjointree.c
prepqual.c
preptlist.c
prepunion.c
print.c
printsimple.c
printtup.c
proc.c
procarray.c
proclang.c
procsignal.c
proto.c
pruneheap.c
ps_status.c
pseudotypes.c
psprintf.c
publicationcmds.c
qsort.c
qsort_arg.c
queryenvironment.c
quote.c
quotes.c
rangetypes.c
rangetypes_gist.c
rangetypes_selfuncs.c
rangetypes_spgist.c
rangetypes_typanalyze.c
rbtree.c
read.c
readfuncs.c
regc_color.c
regc_pg_locale.c
regcomp.c
regerror.c
regexec.c
regexp.c
regexport.c
regfree.c
regis.c
regprefix.c
regproc.c
reinit.c
relation.c
relcache.c
relfilenodemap.c
relmapdesc.c
relmapper.c
relnode.c
reloptions.c
relpath.c
reorderbuffer.c
repl_gram.c
repl_gram.y
repl_scanner.c
repl_scanner.l
replorigindesc.c
resowner.c
restrictinfo.c
rewriteDefine.c
rewriteHandler.c
rewriteheap.c
rewriteManip.c
rewriteRemove.c
rewriteSupport.c
ri_triggers.c
rls.c
rmgr.c
rmtree.c
rowsecurity.c
rowtypes.c
ruleutils.c
s_lock.c
sampling.c
saslprep.c
scan.c
scan.l
scankey.c
scansup.c
schemacmds.c
scram-common.c
seclabel.c
selfuncs.c
seqdesc.c
sequence.c
session.c
setrefs.c
sha2_openssl.c
sharedfileset.c
sharedtuplestore.c
shm_mq.c
shm_toc.c
shmem.c
shmqueue.c
sinval.c
sinvaladt.c
slab.c
slot.c
slotfuncs.c
slru.c
smgr.c
smgrdesc.c
smgrtype.c
snapbuild.c
snapmgr.c
sortsupport.c
spccache.c
spell.c
spgdesc.c
spgdoinsert.c
spginsert.c
spgkdtreeproc.c
spgquadtreeproc.c
spgscan.c
spgtextproc.c
spgutils.c
spgvacuum.c
spgvalidate.c
spgxlog.c
spi.c
spin.c
standby.c
standbydesc.c
startup.c
statscmds.c
storage.c
strftime.c
string.c
stringinfo.c
strlcat.c
strlcpy.c
subscriptioncmds.c
subselect.c
subtrans.c
superuser.c
syncrep.c
syncrep_gram.c
syncrep_gram.y
syncrep_scanner.c
syncrep_scanner.l
syncscan.c
syscache.c
syslogger.c
system.c
tablecmds.c
tablesample.c
tablespace.c
tablesync.c
tar.c
tblspcdesc.c
thread.c
tid.c
tidbitmap.c
tidpath.c
timeline.c
timeout.c
timestamp.c
tlist.c
to_tsany.c
toasting.c
tqual.c
tqueue.c
transam.c
trigfuncs.c
trigger.c
ts_cache.c
ts_locale.c
ts_parse.c
ts_selfuncs.c
ts_typanalyze.c
ts_utils.c
tsearchcmds.c
tsginidx.c
tsgistidx.c
tsquery.c
tsquery_cleanup.c
tsquery_gist.c
tsquery_op.c
tsquery_rewrite.c
tsquery_util.c
tsrank.c
tstoreReceiver.c
tsvector.c
tsvector_op.c
tsvector_parser.c
tupconvert.c
tupdesc.c
tuplesort.c
tuplestore.c
tuptoaster.c
twophase.c
twophase_rmgr.c
txid.c
typcache.c
typecmds.c
tzparser.c
unicode_norm.c
user.c
username.c
utility.c
uuid.c
vacuum.c
vacuumlazy.c
value.c
var.c
varbit.c
varchar.c
variable.c
varlena.c
varsup.c
version.c
view.c
visibilitymap.c
wait_error.c
walreceiver.c
walreceiverfuncs.c
walsender.c
walwriter.c
wchar.c
windowfuncs.c
worker.c
wparser.c
wparser_def.c
wstrcmp.c
wstrncmp.c
xact.c
xactdesc.c
xid.c
xlog.c
xlogarchive.c
xlogdesc.c
xlogfuncs.c
xloginsert.c
xlogreader.c
xlogutils.c
xml.c

to the top

Objects  1 


postgres

to the top