diff options
Diffstat (limited to 'src/tools')
| -rw-r--r-- | src/tools/msvc/Install.pm | 3 | ||||
| -rw-r--r-- | src/tools/msvc/Mkvcbuild.pm | 23 | ||||
| -rw-r--r-- | src/tools/msvc/Solution.pm | 2 | ||||
| -rw-r--r-- | src/tools/msvc/vcregress.pl | 16 | ||||
| -rw-r--r-- | src/tools/pgindent/typedefs.list | 211 |
5 files changed, 188 insertions, 67 deletions
diff --git a/src/tools/msvc/Install.pm b/src/tools/msvc/Install.pm index 2ff6b0784fa..de22c9ba2c7 100644 --- a/src/tools/msvc/Install.pm +++ b/src/tools/msvc/Install.pm @@ -371,8 +371,7 @@ sub GenerateTimezoneFiles print "Generating timezone files..."; - my @args = ( - "$conf/zic/zic", '-d', "$target/share/timezone"); + my @args = ("$conf/zic/zic", '-d', "$target/share/timezone"); foreach (@tzfiles) { my $tzfile = $_; diff --git a/src/tools/msvc/Mkvcbuild.pm b/src/tools/msvc/Mkvcbuild.pm index 5a1ab33b3d4..233ddbf4c25 100644 --- a/src/tools/msvc/Mkvcbuild.pm +++ b/src/tools/msvc/Mkvcbuild.pm @@ -40,9 +40,9 @@ my @contrib_uselibpq = ('dblink', 'oid2name', 'postgres_fdw', 'vacuumlo', 'libpq_pipeline'); my @contrib_uselibpgport = ('libpq_pipeline', 'oid2name', 'vacuumlo'); my @contrib_uselibpgcommon = ('libpq_pipeline', 'oid2name', 'vacuumlo'); -my $contrib_extralibs = { 'libpq_pipeline' => ['ws2_32.lib'] }; -my $contrib_extraincludes = { 'dblink' => ['src/backend'] }; -my $contrib_extrasource = { +my $contrib_extralibs = { 'libpq_pipeline' => ['ws2_32.lib'] }; +my $contrib_extraincludes = { 'dblink' => ['src/backend'] }; +my $contrib_extrasource = { 'cube' => [ 'contrib/cube/cubescan.l', 'contrib/cube/cubeparse.y' ], 'seg' => [ 'contrib/seg/segscan.l', 'contrib/seg/segparse.y' ], }; @@ -58,15 +58,18 @@ my @contrib_excludes = ( # Set of variables for frontend modules my $frontend_defines = { 'initdb' => 'FRONTEND' }; -my @frontend_uselibpq = ('pg_amcheck', 'pg_ctl', 'pg_upgrade', 'pgbench', 'psql', 'initdb'); +my @frontend_uselibpq = + ('pg_amcheck', 'pg_ctl', 'pg_upgrade', 'pgbench', 'psql', 'initdb'); my @frontend_uselibpgport = ( - 'pg_amcheck', 'pg_archivecleanup', 'pg_test_fsync', - 'pg_test_timing', 'pg_upgrade', - 'pg_waldump', 'pgbench'); + 'pg_amcheck', 'pg_archivecleanup', + 'pg_test_fsync', 'pg_test_timing', + 'pg_upgrade', 'pg_waldump', + 'pgbench'); my @frontend_uselibpgcommon = ( - 'pg_amcheck', 'pg_archivecleanup', 'pg_test_fsync', - 'pg_test_timing', 'pg_upgrade', - 'pg_waldump', 'pgbench'); + 'pg_amcheck', 'pg_archivecleanup', + 'pg_test_fsync', 'pg_test_timing', + 'pg_upgrade', 'pg_waldump', + 'pgbench'); my $frontend_extralibs = { 'initdb' => ['ws2_32.lib'], 'pg_amcheck' => ['ws2_32.lib'], diff --git a/src/tools/msvc/Solution.pm b/src/tools/msvc/Solution.pm index 85af28fe0bd..3c5fe5dddcb 100644 --- a/src/tools/msvc/Solution.pm +++ b/src/tools/msvc/Solution.pm @@ -184,7 +184,7 @@ sub GenerateFiles elsif (/\bAC_DEFINE\(OPENSSL_API_COMPAT, \[([0-9xL]+)\]/) { $ac_define_openssl_api_compat_found = 1; - $openssl_api_compat = $1; + $openssl_api_compat = $1; } } close($c); diff --git a/src/tools/msvc/vcregress.pl b/src/tools/msvc/vcregress.pl index a09b60fc858..1852c341091 100644 --- a/src/tools/msvc/vcregress.pl +++ b/src/tools/msvc/vcregress.pl @@ -109,8 +109,8 @@ sub installcheck_internal # for backwards compatibility, "serial" runs the tests in # parallel_schedule one by one. my $maxconn = $maxconn; - $maxconn = "--max-connections=1" if $schedule eq 'serial'; - $schedule = 'parallel' if $schedule eq 'serial'; + $maxconn = "--max-connections=1" if $schedule eq 'serial'; + $schedule = 'parallel' if $schedule eq 'serial'; my @args = ( "../../../$Config/pg_regress/pg_regress", @@ -141,8 +141,8 @@ sub check # for backwards compatibility, "serial" runs the tests in # parallel_schedule one by one. my $maxconn = $maxconn; - $maxconn = "--max-connections=1" if $schedule eq 'serial'; - $schedule = 'parallel' if $schedule eq 'serial'; + $maxconn = "--max-connections=1" if $schedule eq 'serial'; + $schedule = 'parallel' if $schedule eq 'serial'; InstallTemp(); chdir "${topdir}/src/test/regress"; @@ -225,9 +225,9 @@ sub tap_check # Fetch and adjust PROVE_TESTS, applying glob() to each element # defined to build a list of all the tests matching patterns. - my $prove_tests_val = $ENV{PROVE_TESTS} || "t/*.pl"; + my $prove_tests_val = $ENV{PROVE_TESTS} || "t/*.pl"; my @prove_tests_array = split(/\s+/, $prove_tests_val); - my @prove_tests = (); + my @prove_tests = (); foreach (@prove_tests_array) { push(@prove_tests, glob($_)); @@ -235,7 +235,7 @@ sub tap_check # Fetch and adjust PROVE_FLAGS, handling multiple arguments. my $prove_flags_val = $ENV{PROVE_FLAGS} || ""; - my @prove_flags = split(/\s+/, $prove_flags_val); + my @prove_flags = split(/\s+/, $prove_flags_val); my @args = ("prove", @flags, @prove_tests, @prove_flags); @@ -598,7 +598,7 @@ sub upgradecheck $ENV{PGDATA} = "$data.old"; my $outputdir = "$tmp_root/regress"; my @EXTRA_REGRESS_OPTS = ("--outputdir=$outputdir"); - mkdir "$outputdir" || die $!; + mkdir "$outputdir" || die $!; my $logdir = "$topdir/src/bin/pg_upgrade/log"; rmtree($logdir); diff --git a/src/tools/pgindent/typedefs.list b/src/tools/pgindent/typedefs.list index 1196febfa25..abdb08319ca 100644 --- a/src/tools/pgindent/typedefs.list +++ b/src/tools/pgindent/typedefs.list @@ -49,7 +49,9 @@ AggStatePerHash AggStatePerPhase AggStatePerTrans AggStrategy +AggTransInfo Aggref +AggregateInstrumentation AlenState Alias AllocBlock @@ -100,10 +102,11 @@ AlterTypeStmt AlterUserMappingStmt AlteredTableInfo AlternativeSubPlan -AlternativeSubPlanState +AmcheckOptions AnalyzeAttrComputeStatsFunc AnalyzeAttrFetchFunc AnalyzeForeignTable_function +AnlExprData AnlIndexData AnyArrayType Append @@ -132,9 +135,11 @@ ArrayIterator ArrayMapState ArrayMetaState ArrayParseState +ArraySubWorkspace ArrayType AsyncQueueControl AsyncQueueEntry +AsyncRequest AttInMetadata AttStatsSlot AttoptCacheEntry @@ -172,6 +177,7 @@ BTCycleId BTDedupInterval BTDedupState BTDedupStateData +BTDeletedPageData BTIndexStat BTInsertState BTInsertStateData @@ -185,6 +191,7 @@ BTPageOpaqueData BTPageStat BTPageState BTParallelScanDesc +BTPendingFSM BTScanInsert BTScanInsertData BTScanOpaque @@ -202,7 +209,9 @@ BTVacState BTVacuumPosting BTVacuumPostingData BTWriteState +BUF_MEM BYTE +BY_HANDLE_FILE_INFORMATION Backend BackendId BackendParameters @@ -223,6 +232,7 @@ BernoulliSamplerData BgWorkerStartTime BgwHandleStatus BinaryArithmFunc +BindParamCbData BipartiteMatchState BitmapAnd BitmapAndPath @@ -247,7 +257,9 @@ BlockSamplerData BlockedProcData BlockedProcsData BloomBuildState +BloomFilter BloomMetaPageData +BloomOpaque BloomOptions BloomPageOpaque BloomPageOpaqueData @@ -311,7 +323,9 @@ COP CRITICAL_SECTION CRSSnapshotAction CState +CTECycleClause CTEMaterialize +CTESearchClause CV CachedExpression CachedPlan @@ -341,6 +355,7 @@ CkptSortItem CkptTsStatus ClientAuthentication_hook_type ClientCertMode +ClientCertName ClientData ClonePtrType ClosePortalStmt @@ -408,6 +423,7 @@ ConnParams ConnStatusType ConnType ConnectionStateEnum +ConnsAllowedState ConsiderSplitContext Const ConstrCheck @@ -424,12 +440,16 @@ ConversionLocation ConvertRowtypeExpr CookedConstraint CopyDest +CopyFormatOptions +CopyFromState +CopyFromStateData CopyInsertMethod CopyMultiInsertBuffer CopyMultiInsertInfo -CopyState -CopyStateData +CopySource CopyStmt +CopyToState +CopyToStateData Cost CostSelector Counters @@ -500,6 +520,7 @@ DSA DWORD DataDumperPtr DataPageDeleteStack +DatabaseInfo DateADT Datum DatumTupleFields @@ -533,6 +554,7 @@ DirectoryMethodFile DisableTimeoutParams DiscardMode DiscardStmt +DistanceValue DistinctExpr DoStmt DocRepresentation @@ -596,6 +618,7 @@ EquivalenceMember ErrorContextCallback ErrorData EstimateDSMForeignScan_function +EstimationInfo EventTriggerCacheEntry EventTriggerCacheItem EventTriggerCacheStateType @@ -607,9 +630,12 @@ ExceptionLabelMap ExceptionMap ExclusiveBackupState ExecAuxRowMark +ExecEvalBoolSubroutine ExecEvalSubroutine +ExecForeignBatchInsert_function ExecForeignDelete_function ExecForeignInsert_function +ExecForeignTruncate_function ExecForeignUpdate_function ExecParallelEstimateContext ExecParallelInitializeDSMContext @@ -629,6 +655,7 @@ ExecutorStart_hook_type ExpandedArrayHeader ExpandedObjectHeader ExpandedObjectMethods +ExpandedRange ExpandedRecordFieldInfo ExpandedRecordHeader ExplainDirectModify_function @@ -647,6 +674,7 @@ ExprContext_CB ExprDoneCond ExprEvalOp ExprEvalOpLookup +ExprEvalRowtypeCache ExprEvalStep ExprState ExprStateEvalFunc @@ -661,6 +689,8 @@ FDWCollateState FD_SET FILE FILETIME +FILE_INFORMATION_CLASS +FILE_STANDARD_INFORMATION FSMAddress FSMPage FSMPageData @@ -679,6 +709,7 @@ FileFdwPlanState FileNameMap FileTag FinalPathExtraData +FindColsContext FindSplitData FindSplitStrat FixedParallelExecutorState @@ -695,6 +726,9 @@ ForEachState ForFiveState ForFourState ForThreeState +ForeignAsyncConfigureWait_function +ForeignAsyncNotify_function +ForeignAsyncRequest_function ForeignDataWrapper ForeignKeyCacheInfo ForeignKeyOptInfo @@ -838,7 +872,6 @@ FuncDetailCode FuncExpr FuncInfo FuncLookupError -Function FunctionCallInfo FunctionCallInfoBaseData FunctionParameter @@ -890,6 +923,7 @@ GenericCosts GenericXLogState GeqoPrivateData GetForeignJoinPaths_function +GetForeignModifyBatchSize_function GetForeignPaths_function GetForeignPlan_function GetForeignRelSize_function @@ -924,12 +958,13 @@ GinStatsData GinTernaryValue GinTupleCollector GinVacuumState -GistBufferingMode +GistBuildMode GistEntryVector GistHstoreOptions GistInetKey GistNSN GistOptBufferingMode +GistSortedBuildPageState GistSplitUnion GistSplitVector GistTsVectorOptions @@ -940,6 +975,7 @@ GrantRoleStmt GrantStmt GrantTargetType Group +GroupClause GroupPath GroupPathExtraData GroupResultPath @@ -980,6 +1016,7 @@ HEntry HIST_ENTRY HKEY HLOCAL +HMAC_CTX HMODULE HOldEntry HRESULT @@ -1041,6 +1078,7 @@ INFIX INT128 INTERFACE_INFO IOFuncSelector +IO_STATUS_BLOCK IPCompareMethod ITEM IV @@ -1073,6 +1111,8 @@ IndexBulkDeleteCallback IndexBulkDeleteResult IndexClause IndexClauseSet +IndexDeleteCounts +IndexDeletePrefetchState IndexElem IndexFetchHeapData IndexFetchTableData @@ -1099,7 +1139,6 @@ InferenceElem InfoItem InhInfo InheritableSocket -InheritanceKind InitSampleScan_function InitializeDSMForeignScan_function InitializeWorkerForeignScan_function @@ -1121,6 +1160,7 @@ IpcMemoryKey IpcMemoryState IpcSemaphoreId IpcSemaphoreKey +IsForeignPathAsyncCapable_function IsForeignRelUpdatable_function IsForeignScanParallelSafe_function IspellDict @@ -1204,6 +1244,7 @@ JsonbParseState JsonbSubWorkspace JsonbTypeCategory JsonbValue +JumbleState JunkFilter KeyArray KeySuffix @@ -1223,7 +1264,6 @@ LLVMJitHandle LLVMMemoryBufferRef LLVMModuleRef LLVMOrcJITStackRef -LLVMOrcLookupStateRef LLVMOrcModuleHandle LLVMOrcTargetAddress LLVMPassManagerBuilderRef @@ -1252,20 +1292,21 @@ LPDWORD LPSECURITY_ATTRIBUTES LPSERVICE_STATUS LPSTR +LPTHREAD_START_ROUTINE LPTSTR LPVOID LPWSTR LSEG LUID LVDeadTuples +LVPagePruneState LVParallelState -LVRelStats +LVRelState LVSavedErrInfo LVShared LVSharedIndStats LWLock LWLockHandle -LWLockMinimallyPadded LWLockMode LWLockPadded LabelProvider @@ -1298,6 +1339,7 @@ LocalBufferLookupEnt LocalPgBackendStatus LocalTransactionId LocationIndex +LocationLen LockAcquireResult LockClauseStrength LockData @@ -1318,24 +1360,25 @@ LockingClause LogOpts LogStmtLevel LogicalDecodeBeginCB +LogicalDecodeBeginPrepareCB LogicalDecodeChangeCB LogicalDecodeCommitCB -LogicalDecodeFilterPrepareCB -LogicalDecodeBeginPrepareCB -LogicalDecodePrepareCB LogicalDecodeCommitPreparedCB -LogicalDecodeRollbackPreparedCB LogicalDecodeFilterByOriginCB +LogicalDecodeFilterPrepareCB LogicalDecodeMessageCB +LogicalDecodePrepareCB +LogicalDecodeRollbackPreparedCB LogicalDecodeShutdownCB -LogicalDecodeStreamStartCB -LogicalDecodeStreamStopCB +LogicalDecodeStartupCB LogicalDecodeStreamAbortCB -LogicalDecodeStreamPrepareCB -LogicalDecodeStreamCommitCB LogicalDecodeStreamChangeCB +LogicalDecodeStreamCommitCB LogicalDecodeStreamMessageCB -LogicalDecodeStartupCB +LogicalDecodeStreamPrepareCB +LogicalDecodeStreamStartCB +LogicalDecodeStreamStopCB +LogicalDecodeStreamTruncateCB LogicalDecodeTruncateCB LogicalDecodingContext LogicalErrorCallbackState @@ -1346,6 +1389,7 @@ LogicalOutputPluginWriterWrite LogicalRepBeginData LogicalRepCommitData LogicalRepCtxStruct +LogicalRepMsgType LogicalRepPartMapEntry LogicalRepRelId LogicalRepRelMapEntry @@ -1353,7 +1397,6 @@ LogicalRepRelation LogicalRepTupleData LogicalRepTyp LogicalRepWorker -LogicalRepWorkerId LogicalRewriteMappingData LogicalTape LogicalTapeSet @@ -1367,6 +1410,7 @@ MEMORY_BASIC_INFORMATION MINIDUMPWRITEDUMP MINIDUMP_TYPE MJEvalResult +MTTargetRelLookup MVDependencies MVDependency MVNDistinct @@ -1394,10 +1438,12 @@ MetaCommand MinMaxAggInfo MinMaxAggPath MinMaxExpr +MinMaxMultiOptions MinMaxOp MinimalTuple MinimalTupleData MinimalTupleTableSlot +MinmaxMultiOpaque MinmaxOpaque ModifyTable ModifyTablePath @@ -1417,6 +1463,7 @@ MultirangeParseState MultirangeType NDBOX NODE +NTSTATUS NUMCacheEntry NUMDesc NUMProc @@ -1486,6 +1533,7 @@ Oid OidOptions OkeysState OldSnapshotControlData +OldSnapshotTimeMapping OldToNewMapping OldToNewMappingData OnCommitAction @@ -1521,6 +1569,7 @@ PATH PBOOL PCtxtHandle PFN +PFN_NTQUERYINFORMATIONFILE PGAlignedBlock PGAlignedXLogBlock PGAsyncStatusType @@ -1556,8 +1605,9 @@ PGQueryClass PGRUsage PGSemaphore PGSemaphoreData -PGSetenvStatusType PGShmemHeader +PGTargetServerType +PGTernaryBool PGTransactionStatusType PGVerbosity PG_Locale_Strategy @@ -1575,12 +1625,12 @@ PGresAttValue PGresParamDesc PGresult PGresult_data -PgArchData PHANDLE +PIO_STATUS_BLOCK PLAINTREE +PLAssignStmt PLUID_AND_ATTRIBUTES PLcword -PLpgSQL_arrayelem PLpgSQL_case_when PLpgSQL_condition PLpgSQL_datum @@ -1725,6 +1775,8 @@ Pairs ParallelAppendState ParallelBitmapHeapState ParallelBlockTableScanDesc +ParallelBlockTableScanWorker +ParallelBlockTableScanWorkerData ParallelCompletionPtr ParallelContext ParallelExecutorInfo @@ -1736,6 +1788,7 @@ ParallelIndexScanDesc ParallelReadyList ParallelSlot ParallelSlotArray +ParallelSlotResultHandler ParallelState ParallelTableScanDesc ParallelTableScanDescData @@ -1792,7 +1845,6 @@ PartitionPruningData PartitionRangeBound PartitionRangeDatum PartitionRangeDatumKind -PartitionRoutingInfo PartitionScheme PartitionSpec PartitionTupleRouting @@ -1807,6 +1859,8 @@ PathHashStack PathKey PathKeysComparison PathTarget +PatternInfo +PatternInfoArray Pattern_Prefix_Status Pattern_Type PendingFsyncEntry @@ -1818,6 +1872,7 @@ PerlInterpreter Perl_check_t Perl_ppaddr_t Permutation +PgArchData PgBackendGSSStatus PgBackendSSLStatus PgBackendStatus @@ -1830,6 +1885,7 @@ PgBenchValue PgBenchValueType PgChecksumMode PgFdwAnalyzeState +PgFdwConnState PgFdwDirectModifyState PgFdwModifyState PgFdwOption @@ -1846,10 +1902,12 @@ PgStat_FunctionEntry PgStat_GlobalStats PgStat_Msg PgStat_MsgAnalyze +PgStat_MsgAnlAncestors PgStat_MsgArchiver PgStat_MsgAutovacStart PgStat_MsgBgWriter PgStat_MsgChecksumFailure +PgStat_MsgConn PgStat_MsgDeadlock PgStat_MsgDropdb PgStat_MsgDummy @@ -1930,7 +1988,6 @@ PredicateLockTargetType PrefetchBufferResult PrepParallelRestorePtrType PrepareStmt -PreparedParamsData PreparedStatement PresortedKeyData PrewarmType @@ -1949,6 +2006,7 @@ ProcSignalHeader ProcSignalReason ProcSignalSlot ProcState +ProcWaitStatus ProcessUtilityContext ProcessUtility_hook_type ProcessingMode @@ -2009,6 +2067,7 @@ QueryRepresentationOperand QuerySource QueueBackendStatus QueuePosition +QuitSignalReason RBTNode RBTOrderControl RBTree @@ -2040,7 +2099,9 @@ RangeTblRef RangeType RangeVar RangeVarGetRelidCallback +Ranges RawColumnDefault +RawParseMode RawStmt ReInitializeDSMForeignScan_function ReScanForeignScan_function @@ -2055,6 +2116,7 @@ RecordCacheEntry RecordCompareData RecordIOData RecoveryLockListsEntry +RecoveryPauseState RecoveryState RecoveryTargetTimeLineGoal RecoveryTargetType @@ -2089,6 +2151,7 @@ RelToCluster RelabelType Relation RelationData +RelationInfo RelationPtr RelationSyncEntry RelcacheCallbackFunction @@ -2107,10 +2170,21 @@ ReorderBufferApplyTruncateCB ReorderBufferBeginCB ReorderBufferChange ReorderBufferCommitCB +ReorderBufferCommitPreparedCB ReorderBufferDiskChange ReorderBufferIterTXNEntry ReorderBufferIterTXNState ReorderBufferMessageCB +ReorderBufferPrepareCB +ReorderBufferRollbackPreparedCB +ReorderBufferStreamAbortCB +ReorderBufferStreamChangeCB +ReorderBufferStreamCommitCB +ReorderBufferStreamMessageCB +ReorderBufferStreamPrepareCB +ReorderBufferStreamStartCB +ReorderBufferStreamStopCB +ReorderBufferStreamTruncateCB ReorderBufferTXN ReorderBufferTXNByIdEnt ReorderBufferToastEnt @@ -2144,9 +2218,17 @@ RestoreOptions RestorePass RestrictInfo Result +ResultCache +ResultCacheEntry +ResultCacheInstrumentation +ResultCacheKey +ResultCachePath +ResultCacheState +ResultCacheTuple ResultRelInfo ResultState ReturnSetInfo +ReturnStmt RevmapContents RewriteMappingDataEntry RewriteMappingFile @@ -2163,6 +2245,7 @@ RollupData RowCompareExpr RowCompareType RowExpr +RowIdentityVarInfo RowMarkClause RowMarkType RowSecurityDesc @@ -2182,9 +2265,6 @@ SERIALIZABLEXIDTAG SERVICE_STATUS SERVICE_STATUS_HANDLE SERVICE_TABLE_ENTRY -SHA1_CTX -SHA256_CTX -SHA512_CTX SHM_QUEUE SID_AND_ATTRIBUTES SID_IDENTIFIER_AUTHORITY @@ -2197,7 +2277,11 @@ SMgrSortArray SOCKADDR SOCKET SPELL +SPICallbackArg +SPIExecuteOptions +SPIParseOpenOptions SPIPlanPtr +SPIPrepareOptions SPITupleTable SPLITCOST SPNode @@ -2207,6 +2291,7 @@ SQLCmd SQLDropObject SQLFunctionCache SQLFunctionCachePtr +SQLFunctionParseInfo SQLFunctionParseInfoPtr SQLValueFunction SQLValueFunctionOp @@ -2215,14 +2300,15 @@ SSLExtensionInfoContext SSL_CTX STARTUPINFO STRLEN -ST_ELEMENT_TYPE -ST_POINTER_TYPE SV +SYNCHRONIZATION_BARRIER SampleScan SampleScanGetSampleSize_function SampleScanState SamplerRandomState ScalarArrayOpExpr +ScalarArrayOpExprHashEntry +ScalarArrayOpExprHashTable ScalarIOData ScalarItem ScalarMCVItem @@ -2254,11 +2340,13 @@ SerCommitSeqNo SerialControl SerializableXactHandle SerializedActiveRelMaps +SerializedRanges SerializedReindexState SerializedSnapshotData SerializedTransactionState Session SessionBackupState +SessionEndType SetConstraintState SetConstraintStateData SetConstraintTriggerData @@ -2272,9 +2360,11 @@ SetOpStatePerGroup SetOpStrategy SetOperation SetOperationStmt +SetQuantifier SetToDefault SetupWorkerPtrType ShDependObjectInfo +SharedAggInfo SharedBitmapState SharedDependencyObjectType SharedDependencyType @@ -2293,6 +2383,7 @@ SharedJitInstrumentation SharedRecordTableEntry SharedRecordTableKey SharedRecordTypmodRegistry +SharedResultCacheInfo SharedSortInfo SharedTuplestore SharedTuplestoreAccessor @@ -2385,6 +2476,7 @@ SpinDelayStatus SplitInterval SplitLR SplitPoint +SplitTextOutputData SplitVar SplitedPageLayout StackElem @@ -2392,7 +2484,6 @@ StartBlobPtrType StartBlobsPtrType StartDataPtrType StartReplicationCmd -StartupPacket StartupStatusEnum StatEntry StatExtEntry @@ -2400,7 +2491,9 @@ StatMsgType StateFileChunk StatisticExtInfo Stats +StatsBuildData StatsData +StatsElem StatsExtInfo StdAnalyzeData StdRdOptions @@ -2422,10 +2515,13 @@ SubXactCallback SubXactCallbackItem SubXactEvent SubXactInfo -SubplanResultRelHashElem SubqueryScan SubqueryScanPath SubqueryScanState +SubscriptExecSetup +SubscriptExecSteps +SubscriptRoutines +SubscriptTransform SubscriptingRef SubscriptingRefState Subscription @@ -2442,6 +2538,7 @@ SyncRepConfigData SyncRepStandbyData SyncRequestHandler SyncRequestType +SysFKRelationship SysScanDesc SyscacheCallbackFunction SystemRowsSamplerData @@ -2457,6 +2554,9 @@ TBMStatus TBlockState TIDBitmap TM_FailureData +TM_IndexDelete +TM_IndexDeleteOp +TM_IndexStatus TM_Result TOKEN_DEFAULT_DACL TOKEN_INFORMATION_CLASS @@ -2502,6 +2602,7 @@ T_WorkerStatus TabStatHashEntry TabStatusArray TableAmRoutine +TableAttachInfo TableDataInfo TableFunc TableFuncRoutine @@ -2539,8 +2640,13 @@ TextPositionState TheLexeme TheSubstitute TidExpr +TidExprType TidHashKey +TidOpExpr TidPath +TidRangePath +TidRangeScan +TidRangeScanState TidScan TidScanState TimeADT @@ -2558,6 +2664,7 @@ TimestampTz TmFromChar TmToChar ToastAttrInfo +ToastCompressionId ToastTupleContext ToastedAttribute TocEntry @@ -2702,6 +2809,7 @@ ViewOptions ViewStmt VirtualTransactionId VirtualTupleTableSlot +VolatileFunctionStatus Vsrt WAIT_ORDER WALAvailability @@ -2716,7 +2824,6 @@ WCHAR WCOKind WFW_WaitOption WIDGET -WIN32_FILE_ATTRIBUTE_DATA WORD WORKSTATE WSABUF @@ -2825,8 +2932,8 @@ XactCallbackItem XactEvent XactLockTableWaitInfo XidBoundsViolation +XidCacheStatus XidCommitStatus -XidHorizonPrefetchState XidStatus XmlExpr XmlExprOp @@ -2844,12 +2951,16 @@ __CreateRestrictedToken __IsProcessInJob __QueryInformationJobObject __SetInformationJobObject +__time64_t +_dev_t +_ino_t _resultmap _stringlist -abs acquireLocksOnSubLinks_context adjust_appendrel_attrs_context +aff_regex_struct allocfunc +amadjustmembers_function ambeginscan_function ambuild_function ambuildempty_function @@ -2894,6 +3005,7 @@ bits32 bits8 bloom_filter brin_column_state +brin_serialize_callback_type bytea cached_re_str cashKEY @@ -2913,6 +3025,7 @@ coercion collation_cache_entry color colormaprange +compare_context config_var_value contain_aggs_of_level_context convert_testexpr_context @@ -2922,6 +3035,7 @@ core_yy_extra_type core_yyscan_t corrupt_items cost_qual_eval_context +cp_hash_func create_upper_paths_hook_type createdb_failure_params crosstab_HashEnt @@ -2990,6 +3104,7 @@ file_action_t file_entry_t file_type_t filehash_hash +filehash_iterator filemap_t fill_string_relopt finalize_primnode_context @@ -3023,7 +3138,6 @@ generate_series_numeric_fctx generate_series_timestamp_fctx generate_series_timestamptz_fctx generate_subscripts_fctx -get_agg_clause_costs_context get_attavgwidth_hook_type get_index_stats_hook_type get_relation_info_hook_type @@ -3097,8 +3211,8 @@ intset_internal_node intset_leaf_node intset_node intvKEY -itemIdSort -itemIdSortData +itemIdCompact +itemIdCompactData iterator jmp_buf join_search_hook_type @@ -3147,11 +3261,11 @@ manifest_wal_range map_variable_attnos_context max_parallel_hazard_context mb2wchar_with_len_converter +mbchar_verifier mbcharacter_incrementer mbdisplaylen_converter mblen_converter -mbverifier -md5_ctxt +mbstr_verifier metastring mix_data_t mixedStruct @@ -3214,6 +3328,7 @@ pg_enc pg_enc2gettext pg_enc2name pg_encname +pg_funcptr_t pg_gssinfo pg_hmac_ctx pg_int64 @@ -3236,9 +3351,11 @@ pg_time_usec_t pg_tz pg_tz_cache pg_tzenum +pg_unicode_decompinfo pg_unicode_decomposition pg_unicode_norminfo pg_unicode_normprops +pg_unicode_recompinfo pg_utf_to_local_combined pg_uuid_t pg_wc_probefunc @@ -3251,8 +3368,6 @@ pgsql_thing_t pgssEntry pgssGlobalStats pgssHashKey -pgssJumbleState -pgssLocationLen pgssSharedState pgssStoreKind pgssVersion @@ -3283,6 +3398,7 @@ pointer polymorphic_actuals pos_trgm post_parse_analyze_hook_type +postprocess_result_function pqbool pqsigfunc printQueryOpt @@ -3301,8 +3417,8 @@ proclist_head proclist_mutable_iter proclist_node promptStatus_t -pthread_attr_t pthread_barrier_t +pthread_cond_t pthread_key_t pthread_mutex_t pthread_once_t @@ -3314,6 +3430,7 @@ pull_varnos_context pull_vars_context pullup_replace_vars_context pushdown_safety_info +qc_hash_func qsort_arg_comparator qsort_comparator query_pathkeys_callback @@ -3353,6 +3470,8 @@ remoteDep rendezvousHashEntry replace_rte_variables_callback replace_rte_variables_context +resultcache_hash +resultcache_iterator ret_type rewind_source rewrite_event @@ -3361,6 +3480,7 @@ rm_detail_t role_auth_extra row_security_policy_hook_type rsv_callback +saophash_hash save_buffer scram_state scram_state_enum @@ -3432,12 +3552,13 @@ substitute_phv_relids_context svtype symbol tablespaceinfo -teReqs teSection temp_tablespaces_extra -test_function +test_re_flags +test_regex_ctx test_shm_mq_header test_spec +test_start_function text timeKEY time_t @@ -3515,7 +3636,6 @@ walrcv_startstreaming_fn wchar2mb_with_len_converter wchar_t win32_deadchild_waitinfo -win32_pthread wint_t worker_state worktable @@ -3538,7 +3658,6 @@ xl_btree_unlink_page xl_btree_update xl_btree_vacuum xl_clog_truncate -xl_commit_ts_set xl_commit_ts_truncate xl_dbase_create_rec xl_dbase_drop_rec |
