PostgreSQL Source Code: RelationData Struct Reference (original) (raw)

#include <[rel.h](rel%5F8h%5Fsource.html)>

Data Fields
RelFileLocator rd_locator
SMgrRelation rd_smgr
int rd_refcnt
ProcNumber rd_backend
bool rd_islocaltemp
bool rd_isnailed
bool rd_isvalid
bool rd_indexvalid
bool rd_statvalid
SubTransactionId rd_createSubid
SubTransactionId rd_newRelfilelocatorSubid
SubTransactionId rd_firstRelfilelocatorSubid
SubTransactionId rd_droppedSubid
Form_pg_class rd_rel
TupleDesc rd_att
Oid rd_id
LockInfoData rd_lockInfo
RuleLock * rd_rules
MemoryContext rd_rulescxt
TriggerDesc * trigdesc
struct RowSecurityDesc * rd_rsdesc
List * rd_fkeylist
bool rd_fkeyvalid
PartitionKey rd_partkey
MemoryContext rd_partkeycxt
PartitionDesc rd_partdesc
MemoryContext rd_pdcxt
PartitionDesc rd_partdesc_nodetached
MemoryContext rd_pddcxt
TransactionId rd_partdesc_nodetached_xmin
List * rd_partcheck
bool rd_partcheckvalid
MemoryContext rd_partcheckcxt
List * rd_indexlist
Oid rd_pkindex
bool rd_ispkdeferrable
Oid rd_replidindex
List * rd_statlist
bool rd_attrsvalid
Bitmapset * rd_keyattr
Bitmapset * rd_pkattr
Bitmapset * rd_idattr
Bitmapset * rd_hotblockingattr
Bitmapset * rd_summarizedattr
PublicationDesc * rd_pubdesc
bytea * rd_options
Oid rd_amhandler
const struct TableAmRoutine * rd_tableam
Form_pg_index rd_index
struct HeapTupleData * rd_indextuple
MemoryContext rd_indexcxt
struct IndexAmRoutine * rd_indam
Oid * rd_opfamily
Oid * rd_opcintype
RegProcedure * rd_support
struct FmgrInfo * rd_supportinfo
int16 * rd_indoption
List * rd_indexprs
List * rd_indpred
Oid * rd_exclops
Oid * rd_exclprocs
uint16 * rd_exclstrats
Oid * rd_indcollation
bytea ** rd_opcoptions
void * rd_amcache
struct FdwRoutine * rd_fdwroutine
Oid rd_toastoid
bool pgstat_enabled
struct PgStat_TableStatus * pgstat_info

Definition at line 55 of file rel.h.

pgstat_enabled

bool RelationData::pgstat_enabled

pgstat_info

Definition at line 255 of file rel.h.

Referenced by load_relcache_init_file(), pgstat_assoc_relation(), pgstat_count_heap_delete(), pgstat_count_heap_insert(), pgstat_count_heap_update(), pgstat_count_truncate(), pgstat_drop_relation(), pgstat_init_relation(), pgstat_report_analyze(), pgstat_unlink_relation(), and pgstat_update_heap_dead_tuples().

rd_amcache

void* RelationData::rd_amcache

rd_amhandler

Oid RelationData::rd_amhandler

rd_att

Definition at line 112 of file rel.h.

Referenced by AddNewRelationTuple(), addRangeTableEntry(), addRangeTableEntryForRelation(), AddRelationNewConstraints(), afterTriggerInvokeEvents(), AggregateCreate(), AllocateRelationDesc(), AppendAttributeTuples(), ATExecReplicaIdentity(), ATExecSetExpression(), attnameAttNum(), attnumAttName(), attnumCollationId(), attnumTypeId(), AttrDefaultFetch(), boot_openrel(), btestimateparallelscan(), build_column_default(), build_index_tlist(), build_physical_tlist(), BuildOnConflictExcludedTargetlist(), check_foreign_key(), check_primary_key(), check_toast_tuple(), CheckIndexCompatible(), checkInsertTargets(), CheckNNConstraintFetch(), CloneRowTriggersToPartition(), ConversionCreate(), CopyFrom(), CreateForeignDataWrapper(), CreateForeignServer(), CreateForeignTable(), CreateOpFamily(), CreateStatistics(), CreateTableSpace(), CreateTriggerFiringOn(), CreateUserMapping(), database_to_xmlschema_internal(), DefineOpClass(), DefineTSConfiguration(), DefineTSDictionary(), DefineTSParser(), DefineTSTemplate(), DefineVirtualRelation(), DetachPartitionFinalize(), do_analyze_rel(), ENRMetadataGetTupDesc(), examine_attribute(), ExecInitIndexOnlyScan(), ExecInitModifyTable(), ExecInsert(), ExecRelCheck(), ExecSimpleRelationInsert(), ExecSimpleRelationUpdate(), ExecUpdateAct(), ExecUpdatePrepareSlot(), expand_insert_targetlist(), expandRelation(), formrdesc(), gbt_var_penalty(), get_pkey_attnames(), get_rel_data_width(), get_relation_constraints(), get_relation_info(), get_rels_with_domain(), get_sql_delete(), get_sql_insert(), get_sql_update(), get_tuple_of_interest(), gistCompressValues(), gistFetchTuple(), heap_create_with_catalog(), heap_fetch_toast_slice(), heap_toast_delete(), heap_toast_insert_or_update(), heapam_relation_needs_toast_table(), infer_collation_opclass_match(), insert_event_trigger_tuple(), InsertExtensionTuple(), InsertOneNull(), InsertOneValue(), InsertRule(), inv_truncate(), inv_write(), IsIndexUsableForReplicaIdentityFull(), lo_manage(), load_domaintype_info(), load_relcache_init_file(), MergeConstraintsIntoExisting(), MergeWithExistingConstraint(), NamespaceCreate(), OperatorShellMake(), PartConstraintImpliedByRelConstraint(), pg_get_triggerdef_worker(), plperl_modify_tuple(), plperl_trigger_build_args(), pub_contains_invalid_column(), refresh_by_match_merge(), RelationBuildLocalRelation(), RelationBuildPartitionKey(), RelationBuildTriggers(), RelationBuildTupleDesc(), RelationCacheInitializePhase3(), RelationDestroyRelation(), RelationGetExclusionInfo(), RelationRebuildRelation(), rewriteTargetListIU(), rewriteValuesRTE(), ri_ReportViolation(), schema_to_xmlschema_internal(), shdepAddDependency(), SPI_modifytuple(), StoreAttrDefault(), storeOperators(), storeProcedures(), table_to_xml_and_xmlschema(), table_to_xmlschema(), toast_delete_external(), toast_save_datum(), toast_tuple_cleanup(), toast_tuple_find_biggest_attribute(), toast_tuple_init(), transformAssignedExpr(), transformIndexConstraint(), triggered_change_notification(), tsvector_update_trigger(), TypeShellMake(), validate_pkattnums(), and write_relcache_init_file().

rd_attrsvalid

bool RelationData::rd_attrsvalid

rd_backend

Definition at line 60 of file rel.h.

Referenced by calculate_indexes_size(), calculate_table_size(), calculate_toast_table_size(), CreateFakeRelcacheEntry(), formrdesc(), pg_relation_size(), RelationBuildDesc(), RelationBuildLocalRelation(), RelationDropStorage(), RelationGetSmgr(), and RelationSetNewRelfilenumber().

rd_createSubid

Definition at line 103 of file rel.h.

Referenced by AtEOSubXact_cleanup(), AtEOXact_cleanup(), ATExecAddIndex(), CopyFrom(), ExecuteTruncateGuts(), formrdesc(), load_relcache_init_file(), RelationBuildDesc(), RelationBuildLocalRelation(), RelationCacheInvalidate(), RelationClearRelation(), RelationCloseCleanup(), RelationFlushRelation(), RelationForgetRelation(), swap_relation_files(), and TryReuseIndex().

rd_droppedSubid

Definition at line 109 of file rel.h.

Referenced by AtEOSubXact_cleanup(), AtEOXact_cleanup(), formrdesc(), load_relcache_init_file(), RelationBuildDesc(), RelationBuildLocalRelation(), RelationClearRelation(), RelationFlushRelation(), RelationForgetRelation(), RelationIdGetRelation(), RelationRebuildRelation(), and RelationReloadIndexInfo().

rd_exclops

Oid* RelationData::rd_exclops

rd_exclprocs

Oid* RelationData::rd_exclprocs

rd_exclstrats

uint16* RelationData::rd_exclstrats

rd_fdwroutine

rd_firstRelfilelocatorSubid

Definition at line 106 of file rel.h.

Referenced by AtEOSubXact_cleanup(), AtEOXact_cleanup(), ATExecAddIndex(), CopyFrom(), formrdesc(), load_relcache_init_file(), RelationAssumeNewRelfilelocator(), RelationBuildDesc(), RelationBuildLocalRelation(), RelationCacheInvalidate(), RelationClearRelation(), RelationCloseCleanup(), RelationFlushRelation(), RelationForgetRelation(), RelationInitPhysicalAddr(), swap_relation_files(), and TryReuseIndex().

rd_fkeylist

List* RelationData::rd_fkeylist

rd_fkeyvalid

bool RelationData::rd_fkeyvalid

rd_hotblockingattr

rd_id

Definition at line 113 of file rel.h.

Referenced by ATExecAlterColumnGenericOptions(), ATExecGenericOptions(), BitmapHeapScanNextBlock(), CheckForSerializableConflictIn(), CheckTableForSerializableConflictIn(), compute_expr_stats(), CreateTriggerFiringOn(), do_analyze_rel(), DropAllPredicateLocksFromTable(), heapam_scan_bitmap_next_tuple(), PageIsPredicateLocked(), plperl_trigger_build_args(), plpgsql_fulfill_promise(), pltcl_trigger_handler(), PLy_trigger_build_args(), PredicateLockingNeededForRelation(), PredicateLockPage(), PredicateLockPageSplit(), PredicateLockRelation(), PredicateLockTID(), RelationInitPhysicalAddr(), ri_ReportViolation(), and SPI_register_trigger_data().

rd_idattr

rd_indam

Definition at line 206 of file rel.h.

Referenced by ATExecReplicaIdentity(), ATExecSetRelOptions(), check_index_is_clusterable(), generateClonedIndexStmt(), get_relation_info(), index_beginscan_internal(), index_build(), index_bulk_delete(), index_can_return(), index_concurrently_create_copy(), index_endscan(), index_getbitmap(), index_getnext_tid(), index_getprocid(), index_getprocinfo(), index_insert(), index_insert_cleanup(), index_markpos(), index_opclass_options(), index_parallelrescan(), index_parallelscan_estimate(), index_parallelscan_initialize(), index_rescan(), index_restrpos(), index_vacuum_cleanup(), InitIndexAmRoutine(), load_relcache_init_file(), parallel_vacuum_compute_workers(), parallel_vacuum_index_is_parallel_safe(), parallel_vacuum_init(), PrepareSortSupportFromIndexRel(), RelationGetIndexAttrBitmap(), RelationInitIndexAccessInfo(), RelationParseRelOptions(), and write_relcache_init_file().

rd_indcollation

Oid* RelationData::rd_indcollation

Definition at line 217 of file rel.h.

Referenced by _bt_allequalimage(), _bt_mkscankey(), _hash_datum2hashkey(), _hash_datum2hashkey_type(), add_values_to_range(), ATExecAttachPartitionIdx(), AttachPartitionEnsureIndexes(), build_replindex_scan_key(), DefineIndex(), examine_attribute(), get_relation_info(), index_concurrently_create_copy(), infer_collation_opclass_match(), load_relcache_init_file(), RelationInitIndexAccessInfo(), spgbeginscan(), transformIndexConstraint(), tuplesort_begin_index_gin(), tuplesort_begin_index_gist(), union_tuples(), and write_relcache_init_file().

rd_index

Definition at line 192 of file rel.h.

Referenced by _bt_mkscankey(), ATExecAttachPartitionIdx(), ATExecReplicaIdentity(), ATExecSetStatistics(), AttachPartitionEnsureIndexes(), brin_desummarize_range(), brin_summarize_range(), bt_check_every_level(), build_replindex_scan_key(), BuildIndexValueDescription(), check_index_is_clusterable(), CheckTableForSerializableConflictIn(), DefineIndex(), DefineRelation(), DropAllPredicateLocksFromTable(), dropconstraint_internal(), ExecCheckIndexConstraints(), ExecInitIndexOnlyScan(), ExecInsertIndexTuples(), ExecOpenIndices(), get_attr_expr(), get_relation_info(), gin_clean_pending_list(), index_checkable(), index_create(), IndexSetParentIndex(), infer_arbiter_indexes(), infer_collation_opclass_match(), InitCatCachePhase2(), InitConflictIndexes(), is_usable_unique_index(), IsIndexUsableForReplicaIdentityFull(), load_relcache_init_file(), pgstat_relation(), pgstatginindex_internal(), pgstathashindex(), pgstatindex_impl(), PredicateLockTID(), refresh_by_match_merge(), ReindexRelationConcurrently(), RelationGetExclusionInfo(), RelationGetIdentityKeyBitmap(), RelationGetIndexAttrBitmap(), RelationInitIndexAccessInfo(), RelationReloadIndexInfo(), SetIndexStorageProperties(), systable_beginscan(), systable_beginscan_ordered(), toast_open_indexes(), toast_save_datum(), transformIndexConstraint(), vac_open_indexes(), and validatePartitionedIndex().

rd_indexcxt

Definition at line 204 of file rel.h.

Referenced by _bt_getroot(), _bt_getrootheight(), _bt_metaversion(), _hash_getcachedmetap(), index_create(), index_getprocinfo(), InitIndexAmRoutine(), load_relcache_init_file(), RelationDestroyRelation(), RelationGetExclusionInfo(), RelationGetIndexAttOptions(), RelationGetIndexExpressions(), RelationGetIndexPredicate(), RelationInitIndexAccessInfo(), and RelationRebuildRelation().

rd_indexlist

List* RelationData::rd_indexlist

rd_indexprs

List* RelationData::rd_indexprs

rd_indextuple

Definition at line 194 of file rel.h.

Referenced by bt_check_every_level(), build_replindex_scan_key(), check_index_is_clusterable(), generateClonedIndexStmt(), get_relation_info(), index_opclass_options(), IsIndexUsableForReplicaIdentityFull(), load_relcache_init_file(), refresh_by_match_merge(), RelationDestroyRelation(), RelationGetDummyIndexExpressions(), RelationGetIndexAttrBitmap(), RelationGetIndexExpressions(), RelationGetIndexPredicate(), RelationInitIndexAccessInfo(), RelationReloadIndexInfo(), transformIndexConstraint(), and write_relcache_init_file().

rd_indexvalid

bool RelationData::rd_indexvalid

rd_indoption

int16* RelationData::rd_indoption

rd_indpred

List* RelationData::rd_indpred

rd_islocaltemp

bool RelationData::rd_islocaltemp

rd_isnailed

bool RelationData::rd_isnailed

Definition at line 62 of file rel.h.

Referenced by AtEOXact_cleanup(), CheckTableNotInUse(), formrdesc(), load_critical_index(), load_relcache_init_file(), RelationBuildDesc(), RelationBuildLocalRelation(), RelationCacheInvalidate(), RelationClearRelation(), RelationFlushRelation(), RelationIdGetRelation(), RelationRebuildRelation(), RelationReloadNailed(), and write_relcache_init_file().

rd_ispkdeferrable

bool RelationData::rd_ispkdeferrable

rd_isvalid

bool RelationData::rd_isvalid

rd_keyattr

rd_locator

Definition at line 57 of file rel.h.

Referenced by _bt_allocbuf(), _hash_alloc_buckets(), _hash_init(), ATExecAddIndex(), ATExecSetTableSpace(), calculate_indexes_size(), calculate_table_size(), calculate_toast_table_size(), CheckForSerializableConflictIn(), CheckTableForSerializableConflictIn(), CreateFakeRelcacheEntry(), do_setval(), DropAllPredicateLocksFromTable(), EvictRelUnpinnedBuffers(), fill_seq_fork_with_data(), fill_seq_with_data(), FlushRelationBuffers(), ginPlaceToPage(), gistXLogPageReuse(), heap_create(), index_beginscan_parallel(), index_build(), index_parallelscan_initialize(), invalidate_rel_block(), log_heap_new_cid(), nextval_internal(), PageIsPredicateLocked(), pg_relation_size(), pg_truncate_visibility_map(), PredicateLockPage(), PredicateLockPageSplit(), PredicateLockRelation(), PredicateLockTID(), RelationDropStorage(), RelationGetSmgr(), RelationInitPhysicalAddr(), RelationSetNewRelfilenumber(), RelationTruncate(), ReleaseAndReadBuffer(), ss_get_location(), ss_report_location(), table_beginscan_parallel(), table_block_parallelscan_initialize(), and TryReuseIndex().

rd_lockInfo

Definition at line 114 of file rel.h.

Referenced by _bt_end_vacuum(), _bt_start_vacuum(), _bt_vacuum_cycleid(), CheckRelationLockedByMe(), ConditionalLockPage(), ConditionalLockRelation(), ConditionalLockRelationForExtension(), ConditionalLockTuple(), CreateFakeRelcacheEntry(), DefineIndex(), index_close(), index_drop(), LockHasWaitersRelation(), LockPage(), LockRelation(), LockRelationForExtension(), LockTuple(), ReindexRelationConcurrently(), relation_close(), RelationExtensionLockWaiterCount(), RelationInitLockInfo(), UnlockPage(), UnlockRelation(), UnlockRelationForExtension(), UnlockTuple(), and vacuum_rel().

rd_newRelfilelocatorSubid

rd_opcintype

Oid* RelationData::rd_opcintype

Definition at line 208 of file rel.h.

Referenced by _bt_allequalimage(), _bt_compare_scankey_args(), _bt_first(), _bt_num_array_keys(), _bt_saoparray_shrink(), _bt_setup_array_cmp(), _bt_skiparray_strat_decrement(), _bt_skiparray_strat_increment(), _hash_first(), BuildIndexValueDescription(), ExecInitIndexOnlyScan(), get_relation_info(), gistrescan(), infer_collation_opclass_match(), load_relcache_init_file(), PrepareSortSupportFromGistIndexRel(), PrepareSortSupportFromIndexRel(), RelationInitIndexAccessInfo(), and write_relcache_init_file().

rd_opcoptions

bytea** RelationData::rd_opcoptions

rd_opfamily

Oid* RelationData::rd_opfamily

Definition at line 207 of file rel.h.

Referenced by _bt_allequalimage(), _bt_compare_scankey_args(), _bt_find_extreme_element(), _bt_first(), _bt_merge_arrays(), _bt_num_array_keys(), _bt_saoparray_shrink(), _bt_skiparray_strat_decrement(), _bt_skiparray_strat_increment(), _hash_datum2hashkey_type(), ATExecAttachPartitionIdx(), AttachPartitionEnsureIndexes(), bt_index_check_callback(), DefineIndex(), get_relation_info(), inclusion_get_strategy_procinfo(), infer_collation_opclass_match(), load_relcache_init_file(), minmax_get_strategy_procinfo(), minmax_multi_get_strategy_procinfo(), PrepareSortSupportFromGistIndexRel(), PrepareSortSupportFromIndexRel(), RelationGetExclusionInfo(), RelationInitIndexAccessInfo(), and write_relcache_init_file().

rd_options

bytea* RelationData::rd_options

rd_partcheck

List* RelationData::rd_partcheck

rd_partcheckcxt

rd_partcheckvalid

bool RelationData::rd_partcheckvalid

rd_partdesc

rd_partdesc_nodetached

rd_partdesc_nodetached_xmin

rd_partkey

rd_partkeycxt

rd_pdcxt

rd_pddcxt

rd_pkattr

rd_pkindex

Oid RelationData::rd_pkindex

rd_pubdesc

rd_refcnt

int RelationData::rd_refcnt

Definition at line 59 of file rel.h.

Referenced by AtEOXact_cleanup(), CheckTableNotInUse(), formrdesc(), load_critical_index(), load_relcache_init_file(), RelationBuildDesc(), RelationBuildLocalRelation(), RelationCacheInvalidate(), RelationDecrementReferenceCount(), RelationFlushRelation(), RelationIncrementReferenceCount(), and ResOwnerReleaseRelation().

rd_rel

Definition at line 111 of file rel.h.

Referenced by acquire_inherited_sample_rows(), AcquireRewriteLocks(), add_row_identity_columns(), addFkConstraint(), addFkRecurseReferenced(), addFkRecurseReferencing(), AddNewRelationTuple(), addRangeTableEntry(), addRangeTableEntryForRelation(), afterTriggerInvokeEvents(), AfterTriggerSaveEvent(), AllocateRelationDesc(), AlterSequence(), AlterTableNamespace(), AlterTableNamespaceInternal(), amcheck_index_mainfork_expected(), amcheck_lock_relation_and_check(), analyze_rel(), apply_handle_delete(), apply_handle_delete_internal(), apply_handle_insert(), apply_handle_insert_internal(), apply_handle_truncate(), apply_handle_tuple_routing(), apply_handle_update(), ATAddForeignKeyConstraint(), ATCheckPartitionsNotInUse(), ATExecAddColumn(), ATExecAddIdentity(), ATExecAddIndexConstraint(), ATExecAddInherit(), ATExecAddOf(), ATExecAlterConstraint(), ATExecAlterConstrDeferrability(), ATExecAlterConstrEnforceability(), ATExecAttachPartition(), ATExecAttachPartitionIdx(), ATExecClusterOn(), ATExecCmd(), ATExecDropColumn(), ATExecDropIdentity(), ATExecDropInherit(), ATExecDropNotNull(), ATExecDropOf(), ATExecReplicaIdentity(), ATExecSetAccessMethodNoStorage(), ATExecSetIdentity(), ATExecSetNotNull(), ATExecSetRelOptions(), ATExecSetStatistics(), ATExecSetTableSpace(), ATExecSetTableSpaceNoStorage(), ATGetQueueEntry(), ATPrepAddColumn(), ATPrepAddInherit(), ATPrepAlterColumnType(), ATPrepChangePersistence(), ATPrepCmd(), ATPrepDropColumn(), ATPrepSetAccessMethod(), ATRewriteTables(), ATSimplePermissions(), ATSimpleRecursion(), AttachPartitionEnsureIndexes(), ATTypedTableRecursion(), BeginCopyTo(), BootstrapToastTable(), brin_desummarize_range(), brin_summarize_range(), build_replindex_scan_key(), BuildOnConflictExcludedTargetlist(), BuildRelationExtStatistics(), CacheInvalidateRelcache(), calculate_indexes_size(), calculate_table_size(), check_default_partition_contents(), check_of_type(), check_publication_add_relation(), check_relation_relkind(), check_relation_updatable(), check_tuple_attribute(), CheckCmdReplicaIdentity(), checkFkeyPermissions(), CheckNNConstraintFetch(), CheckPubRelationColumnList(), CheckRelationTableSpaceMove(), CheckTableNotInUse(), CheckValidResultRel(), CheckValidRowMarkRel(), CloneFkReferencing(), CloneForeignKeyConstraints(), cluster(), cluster_rel(), CommentObject(), copy_table_data(), CopyFrom(), CopyMultiInsertInfoInit(), create_edata_for_relation(), create_estate_for_relation(), create_toast_table(), CreateFakeRelcacheEntry(), CreateInheritance(), CreateStatistics(), CreateTriggerFiringOn(), currtid_internal(), DefineIndex(), DefineQueryRewrite(), DefineRelation(), DefineVirtualRelation(), DetachPartitionFinalize(), do_analyze_rel(), dropconstraint_internal(), EnableDisableTrigger(), estimate_rel_size(), EvalPlanQualFetchRowMark(), ExecConstraints(), ExecFindPartition(), ExecGetAncestorResultRels(), ExecGetRootToChildMap(), ExecInitMerge(), ExecInitModifyTable(), ExecInsert(), ExecLockRows(), ExecModifyTable(), ExecRelCheck(), ExecSecLabelStmt(), ExecSimpleRelationInsert(), ExecSimpleRelationUpdate(), ExecUpdateAct(), ExecUpdatePrologue(), ExecuteTruncate(), ExecuteTruncateGuts(), expand_inherited_rtentry(), expand_partitioned_rtentry(), expand_single_inheritance_child(), expandTableLikeClause(), ExtendBufferedRelBy(), ExtendBufferedRelTo(), ExtractReplicaIdentity(), fill_seq_with_data(), find_composite_type_dependencies(), FindLogicalRepLocalIndex(), finish_heap_swap(), formrdesc(), generate_partition_qual(), generate_relation_name(), generateSerialExtraStmts(), get_attr_expr(), get_raw_page_internal(), get_rel_from_relname(), get_relation_by_qualified_name(), get_relation_constraints(), get_relation_info(), get_rels_with_domain(), get_view_query(), GetStrictOldestNonRemovableTransactionId(), gin_clean_pending_list(), gistGetFakeLSN(), GlobalVisHorizonKindForRel(), has_partition_attrs(), heap_abort_speculative(), heap_create(), heap_create_with_catalog(), heap_delete(), heap_drop_with_catalog(), heap_force_common(), heap_index_delete_tuples(), heap_prepare_insert(), heap_toast_delete(), heap_toast_insert_or_update(), heap_truncate_check_FKs(), heap_truncate_one_rel(), heap_update(), heap_vacuum_rel(), heapam_index_build_range_scan(), heapam_index_validate_scan(), heapam_relation_copy_data(), heapam_relation_set_new_filelocator(), heapam_relation_toast_am(), index_build(), index_check_primary_key(), index_checkable(), index_concurrently_build(), index_concurrently_create_copy(), index_copy_data(), index_create(), index_drop(), index_update_stats(), IndexSetParentIndex(), init_sequence(), InitResultRelInfo(), InsertPgClassTuple(), is_publishable_relation(), IsIndexUsableForReplicaIdentityFull(), isQueryUsingTempRelation_walker(), IsSystemRelation(), lazy_vacuum_all_indexes(), load_relcache_init_file(), load_typcache_tupdesc(), LockViewRecurse(), log_heap_update(), logicalrep_rel_open(), logicalrep_write_attrs(), logicalrep_write_delete(), logicalrep_write_rel(), logicalrep_write_update(), LogicalRepSyncTableStart(), make_append_rel_info(), make_new_heap(), mark_index_clustered(), MarkInheritDetached(), MergeAttributes(), MergeAttributesIntoExisting(), MergeConstraintsIntoExisting(), MergeWithExistingConstraint(), needs_toast_table(), OpenTableList(), pg_freespace(), pg_prewarm(), pg_relpages_impl(), pgoutput_change(), pgoutput_truncate(), pgstat_assoc_relation(), pgstat_copy_relation_stats(), pgstat_create_relation(), pgstat_drop_relation(), pgstat_heap(), pgstat_init_relation(), pgstat_relation(), pgstat_report_analyze(), pgstattuple_approx_internal(), plan_create_index_workers(), postgresAcquireSampleRowsFunc(), postgresAnalyzeForeignTable(), postgresGetAnalyzeInfoForForeignTable(), PrepareSortSupportFromGistIndexRel(), PrepareSortSupportFromIndexRel(), process_owned_by(), pub_contains_invalid_column(), pub_rf_contains_invalid_column(), PublicationAddTables(), QueueFKConstraintValidation(), QueuePartitionConstraintValidation(), read_stream_begin_relation(), ReadBuffer_common(), rebuild_relation(), RefreshMatViewByOid(), reindex_index(), reindex_relation(), ReindexRelationConcurrently(), relation_is_updatable(), RelationBuildDesc(), RelationBuildLocalRelation(), RelationBuildPublicationDesc(), RelationBuildRuleLock(), RelationBuildTupleDesc(), RelationCacheInitializePhase3(), RelationDestroyRelation(), RelationGetIndexList(), RelationGetNumberOfBlocksInFork(), RelationGetPartitionDesc(), RelationGetPartitionKey(), RelationGetPartitionQual(), RelationInitIndexAccessInfo(), RelationInitLockInfo(), RelationInitPhysicalAddr(), RelationInitTableAccessMethod(), RelationParseRelOptions(), RelationRebuildRelation(), RelationReloadIndexInfo(), RelationReloadNailed(), RelationSetNewRelfilenumber(), removable_cutoff(), RemoveInheritance(), RemovePolicyById(), RemoveTriggerById(), renameatt_internal(), RenameRelationInternal(), renametrig(), renametrig_partition(), ReorderBufferProcessTXN(), ReorderBufferToastReplace(), replorigin_create(), ResetSequence(), RewriteQuery(), rewriteTargetView(), rewriteValuesRTE(), ri_Check_Pk_Match(), RI_FKey_check(), RI_FKey_fk_upd_check_required(), RI_Initial_Check(), RI_PartitionRemove_Check(), ri_restrict(), ri_set(), SetAttrMissing(), SetMatViewPopulatedState(), SetRelationTableSpace(), StoreAttrMissingVal(), StorePartitionBound(), StorePartitionKey(), StoreRelCheck(), table_block_relation_estimate_size(), table_slot_callbacks(), TargetPrivilegesCheck(), toast_save_datum(), transformAlterTableStmt(), transformIndexConstraint(), transformMergeStmt(), transformPartitionCmd(), TransformPubWhereClauses(), transformRuleStmt(), transformTableLikeClause(), TryReuseIndex(), tuple_data_split_internal(), tuplesort_begin_cluster(), vac_estimate_reltuples(), vacuum_get_cutoffs(), vacuum_rel(), validate_index(), validate_relation_kind(), validatePartitionedIndex(), and write_relcache_init_file().

rd_replidindex

Oid RelationData::rd_replidindex

rd_rsdesc

rd_rules

Definition at line 115 of file rel.h.

Referenced by currtid_for_view(), DefineQueryRewrite(), fireRIRrules(), get_view_query(), load_relcache_init_file(), matchLocks(), RefreshMatViewByOid(), relation_is_updatable(), RelationBuildDesc(), RelationBuildRuleLock(), RelationCacheInitializePhase3(), RelationRebuildRelation(), and vac_update_relstats().

rd_rulescxt

rd_smgr

rd_statlist

List* RelationData::rd_statlist

rd_statvalid

bool RelationData::rd_statvalid

rd_summarizedattr

rd_support

rd_supportinfo

struct FmgrInfo* RelationData::rd_supportinfo

rd_tableam

Definition at line 189 of file rel.h.

Referenced by formrdesc(), get_relation_info(), heap_getnext(), InitTableAmRoutine(), RelationCacheInitializePhase3(), table_beginscan(), table_beginscan_analyze(), table_beginscan_bm(), table_beginscan_catalog(), table_beginscan_parallel(), table_beginscan_sampling(), table_beginscan_strat(), table_beginscan_tid(), table_beginscan_tidrange(), table_endscan(), table_finish_bulk_insert(), table_index_build_range_scan(), table_index_build_scan(), table_index_delete_tuples(), table_index_fetch_begin(), table_index_fetch_end(), table_index_fetch_reset(), table_index_fetch_tuple(), table_index_validate_scan(), table_multi_insert(), table_parallelscan_estimate(), table_parallelscan_initialize(), table_parallelscan_reinitialize(), table_relation_copy_data(), table_relation_copy_for_cluster(), table_relation_estimate_size(), table_relation_fetch_toast_slice(), table_relation_needs_toast_table(), table_relation_nontransactional_truncate(), table_relation_set_new_filelocator(), table_relation_size(), table_relation_toast_am(), table_relation_vacuum(), table_rescan(), table_rescan_set_params(), table_rescan_tidrange(), table_scan_analyze_next_block(), table_scan_analyze_next_tuple(), table_scan_bitmap_next_tuple(), table_scan_getnextslot(), table_scan_getnextslot_tidrange(), table_scan_sample_next_block(), table_scan_sample_next_tuple(), table_slot_callbacks(), table_tuple_complete_speculative(), table_tuple_delete(), table_tuple_fetch_row_version(), table_tuple_get_latest_tid(), table_tuple_insert(), table_tuple_insert_speculative(), table_tuple_lock(), table_tuple_satisfies_snapshot(), table_tuple_tid_valid(), and table_tuple_update().

rd_toastoid

Oid RelationData::rd_toastoid

trigdesc

Definition at line 117 of file rel.h.

Referenced by add_row_identity_columns(), ATExecAddInherit(), ATExecAttachPartition(), CopyFrom(), DefineRelation(), deparseDeleteSql(), deparseInsertSql(), deparseUpdateSql(), error_view_not_updatable(), ExecInitGenerated(), has_row_triggers(), InitResultRelInfo(), load_relcache_init_file(), postgresPlanForeignModify(), relation_is_updatable(), RelationBuildDesc(), RelationBuildTriggers(), RelationCacheInitializePhase3(), RelationDestroyRelation(), vac_update_relstats(), and view_has_instead_trigger().


The documentation for this struct was generated from the following file: