PostgreSQL Source Code
git master
|
Go to the source code of this file.
Data Structures | |
struct | xl_standby_lock |
Macros | |
#define | NoLock 0 |
#define | AccessShareLock 1 /* SELECT */ |
#define | RowShareLock 2 /* SELECT FOR UPDATE/FOR SHARE */ |
#define | RowExclusiveLock 3 /* INSERT, UPDATE, DELETE */ |
#define | ShareUpdateExclusiveLock |
#define | ShareLock 5 /* CREATE INDEX (WITHOUT CONCURRENTLY) */ |
#define | ShareRowExclusiveLock |
#define | ExclusiveLock 7 /* blocks ROW SHARE/SELECT...FOR UPDATE */ |
#define | AccessExclusiveLock |
#define | MaxLockMode 8 |
Typedefs | |
typedef int | LOCKMASK |
typedef int | LOCKMODE |
typedef struct xl_standby_lock | xl_standby_lock |
#define AccessExclusiveLock |
Definition at line 45 of file lockdefs.h.
Referenced by _bt_parallel_build_main(), _PG_init(), AcquireDeletionLock(), AlterObjectNamespace_oid(), AlterPolicy(), AlterSubscription(), AlterTableGetLockLevel(), AlterTableGetRelOptionsLockLevel(), AlterTableMoveAll(), AlterTableNamespace(), AlterTableNamespaceInternal(), AlterTypeOwner_oid(), ATExecAttachPartition(), ATExecAttachPartitionIdx(), ATExecDetachPartition(), ATExecDropConstraint(), ATPostAlterTypeCleanup(), BootstrapToastTable(), check_default_partition_contents(), CloneFkReferencing(), cluster(), cluster_rel(), copy_table_data(), count_nondeletable_pages(), create_reloptions_table(), create_toast_table(), CreatePolicy(), dbase_redo(), DefineQueryRewrite(), DefineRelation(), DefineRule(), DefineSequence(), DefineVirtualRelation(), do_autovacuum(), dropdb(), DropRole(), DropSubscription(), ExecAlterObjectDependsStmt(), ExecAlterObjectSchemaStmt(), ExecAlterOwnerStmt(), ExecRefreshMatView(), ExecRenameStmt(), ExecuteTruncate(), ExecuteTruncateGuts(), GetRunningTransactionLocks(), heap_drop_with_catalog(), heap_truncate(), heap_truncate_one_rel(), index_create(), index_drop(), intorel_startup(), lazy_truncate_heap(), lock_twophase_standby_recover(), LockAcquireExtended(), movedb(), NewRelationCreateToastTable(), pg_truncate_visibility_map(), PreCommit_Notify(), ProcSleep(), QueuePartitionConstraintValidation(), RangeVarCallbackForDropRelation(), rebuild_relation(), reindex_index(), ReindexIndex(), ReindexRelationConcurrently(), RelationTruncateIndexes(), ReleaseDeletionLock(), RemoveAttrDefaultById(), RemoveAttributeById(), RemoveConstraintById(), RemoveObjects(), RemovePolicyById(), RemoveRelations(), RemoveRewriteRuleById(), RemoveRoleFromObjectPolicy(), RemoveTriggerById(), rename_constraint_internal(), rename_policy(), renameatt(), renameatt_internal(), RenameConstraint(), RenameDatabase(), RenameRelation(), RenameRelationInternal(), RenameRewriteRule(), renametrig(), ResolveRecoveryConflictWithLock(), SetAttrMissing(), shdepReassignOwned(), StandbyAcquireAccessExclusiveLock(), StandbyReleaseLockList(), swap_relation_files(), transformRuleStmt(), vacuum_rel(), and validatePartitionedIndex().
#define AccessShareLock 1 /* SELECT */ |
Definition at line 36 of file lockdefs.h.
Referenced by acquire_inherited_sample_rows(), AcquireRewriteLocks(), addRangeTableEntry(), addRangeTableEntryForRelation(), AddRelationNewConstraints(), AddSubscriptionRelState(), AfterTriggerSetState(), AlterDatabaseSet(), AlterDomainValidateConstraint(), AlterExtensionNamespace(), AlterPolicy(), AlterSeqNamespaces(), AlterSubscription_refresh(), AlterTableGetLockLevel(), AlterTableMoveAll(), AssignTypeArrayOid(), AssignTypeMultirangeArrayOid(), AssignTypeMultirangeOid(), ATExecAddIndexConstraint(), ATExecAddInherit(), ATExecAddOf(), ATExecAlterColumnGenericOptions(), ATExecAttachPartition(), ATExecAttachPartitionIdx(), ATExecDropInherit(), ATExecDropNotNull(), ATPrepChangePersistence(), AttachPartitionEnsureIndexes(), AttrDefaultFetch(), autoprewarm_database_main(), brin_page_items(), bringetbitmap(), brinvacuumcleanup(), bt_index_check_internal(), bt_metap(), bt_page_items_internal(), bt_page_stats_internal(), BuildEventTriggerCache(), calculate_indexes_size(), calculate_toast_table_size(), CatalogCacheInitializeCache(), change_owner_recurse_to_sequences(), check_db_file_conflict(), check_of_type(), check_selective_binary_conversion(), CheckAttributeType(), CheckConstraintFetch(), CheckIndexCompatible(), checkSharedDependencies(), ChooseConstraintName(), CloneFkReferenced(), collect_corrupt_items(), collect_visibility_data(), ConstraintNameExists(), ConstraintNameIsUsed(), copy_table(), create_estate_for_relation(), createdb(), CreatePolicy(), CreateSubscription(), CreateTrigger(), currtid_byrelname(), currtid_for_view(), database_to_xmlschema_internal(), dblink_build_sql_delete(), dblink_build_sql_insert(), dblink_build_sql_update(), dblink_get_pkey(), DefineRelation(), deparse_context_for(), do_analyze_rel(), do_autovacuum(), DoCopy(), enum_endpoint(), enum_range_internal(), EventTriggerSQLDropAddObject(), exec_object_restorecon(), ExecAlterExtensionStmt(), ExecGetRangeTableRelation(), ExecRefreshMatView(), expand_vacuum_rel(), expandRelation(), expandTableLikeClause(), find_composite_type_dependencies(), find_inheritance_children(), find_typed_table_dependencies(), generate_partition_qual(), get_all_vacuum_rels(), get_database_list(), get_database_oid(), get_db_info(), get_domain_constraint_oid(), get_extension_name(), get_extension_oid(), get_extension_schema(), get_file_fdw_attribute_options(), get_index_constraint(), get_index_ref_constraints(), get_object_address_attrdef(), get_object_address_publication_rel(), get_object_address_relobject(), get_partition_ancestors(), get_partition_parent(), get_partition_qual_relid(), get_pkey_attnames(), get_primary_key_attnos(), get_raw_page_internal(), get_relation_constraint_attnos(), get_relation_constraint_oid(), get_relation_idx_constraint_oid(), get_relation_policy_oid(), get_rels_with_domain(), get_subscription_list(), get_tables_to_cluster(), get_tablespace_name(), get_tablespace_oid(), get_trigger_oid(), GetAllTablesPublicationRelations(), GetAllTablesPublications(), getAutoExtensionsOfObject(), GetComment(), getConstraintTypeDescription(), GetDatabaseTuple(), GetDatabaseTupleByOid(), GetDefaultOpClass(), getExtensionOfObject(), getObjectDescription(), getObjectIdentityParts(), getOwnedSequences_internal(), GetParentedForeignKeyRefs(), GetPublicationRelations(), getRelationsInNamespace(), GetSecurityLabel(), GetSharedSecurityLabel(), GetSubscriptionNotReadyRelations(), GetSubscriptionRelations(), GetTypeCollations(), gist_page_items(), GrantRole(), has_superclass(), hash_bitmap_info(), heap_fetch_toast_slice(), heap_truncate_find_FKs(), indexam_property(), InitCatCachePhase2(), isQueryUsingTempRelation_walker(), LargeObjectExists(), load_critical_index(), load_domaintype_info(), load_enum_cache_data(), load_typcache_tupdesc(), LockTableAclCheck(), lookup_ts_config_cache(), LookupOpclassInfo(), make_ruledef(), make_viewdef(), myLargeObjectExists(), objectsInSchemaToOids(), pg_event_trigger_ddl_commands(), pg_extension_ownercheck(), pg_freespace(), pg_get_constraintdef_worker(), pg_get_object_address(), pg_get_replica_identity_index(), pg_get_serial_sequence(), pg_get_triggerdef_worker(), pg_identify_object(), pg_indexes_size(), pg_largeobject_aclmask_snapshot(), pg_largeobject_ownercheck(), pg_partition_tree(), pg_prewarm(), pg_relation_size(), pg_relpages(), pg_relpages_v1_5(), pg_relpagesbyid(), pg_relpagesbyid_v1_5(), pg_table_size(), pg_total_relation_size(), pg_visibility(), pg_visibility_map(), pg_visibility_map_summary(), pgrowlocks(), pgstat_collect_oids(), pgstat_heap(), pgstat_index(), pgstatginindex_internal(), pgstathashindex(), pgstatindex(), pgstatindex_impl(), pgstatindex_v1_5(), pgstatindexbyid(), pgstatindexbyid_v1_5(), pgstattuple(), pgstattuple_approx_internal(), pgstattuple_v1_5(), pgstattuplebyid(), pgstattuplebyid_v1_5(), plan_cluster_use_sort(), plan_create_index_workers(), process_owned_by(), process_settings(), RangeVarCallbackForAttachIndex(), RangeVarGetAndCheckCreationNamespace(), recordDependencyOnSingleRelExpr(), ReindexMultipleTables(), relation_has_policies(), relation_is_updatable(), relation_open(), RelationBuildPartitionDesc(), RelationBuildRowSecurity(), RelationBuildRuleLock(), RelationBuildTriggers(), RelationBuildTupleDesc(), RelationGetExclusionInfo(), RelationGetFKeyList(), RelationGetIndexAttrBitmap(), RelationGetIndexList(), RelationGetStatExtList(), RelationNameGetTupleDesc(), RelidByRelfilenode(), remove_dbtablespaces(), RemoveRoleFromObjectACL(), RemoveRoleFromObjectPolicy(), RI_Initial_Check(), satisfies_hash_partition(), ScanPgRelation(), schema_to_xmlschema_internal(), SearchCatCacheList(), SearchCatCacheMiss(), sepgsql_attribute_post_create(), sepgsql_database_post_create(), sepgsql_index_modify(), sepgsql_proc_post_create(), sepgsql_proc_setattr(), sepgsql_relation_post_create(), sepgsql_relation_setattr(), sepgsql_schema_post_create(), sequenceIsOwned(), set_relation_column_names(), shdepLockAndCheckObject(), systable_beginscan(), systable_endscan(), table_to_xml_and_xmlschema(), table_to_xmlschema(), test_rls_hooks_permissive(), test_rls_hooks_restrictive(), ThereIsAtLeastOneRole(), toast_fetch_datum(), toast_fetch_datum_slice(), toastid_valueid_exists(), transformAlterTableStmt(), transformIndexConstraint(), transformIndexStmt(), transformPartitionSpec(), transformRuleStmt(), transformTableLikeClause(), try_relation_open(), tuple_data_split_internal(), typeInheritsFrom(), UpdateRangeTableOfViewParse(), UpdateSubscriptionRelState(), vac_truncate_clog(), vac_update_datfrozenxid(), validatePartitionedIndex(), and verify_heapam().
#define ExclusiveLock 7 /* blocks ROW SHARE/SELECT...FOR UPDATE */ |
Definition at line 44 of file lockdefs.h.
Referenced by _bt_getbuf(), AddEnumLabel(), BloomNewBuffer(), brin_getinsertbuffer(), btvacuumscan(), ExecRefreshMatView(), fsm_extend(), GetLockStatusData(), ginInsertCleanup(), GinNewBuffer(), ginvacuumcleanup(), gistNewBuffer(), gistvacuumscan(), pg_advisory_lock_int4(), pg_advisory_lock_int8(), pg_advisory_unlock_int4(), pg_advisory_unlock_int8(), pg_advisory_xact_lock_int4(), pg_advisory_xact_lock_int8(), pg_try_advisory_lock_int4(), pg_try_advisory_lock_int8(), pg_try_advisory_xact_lock_int4(), pg_try_advisory_xact_lock_int8(), pgstat_index(), RelationGetBufferForTuple(), RenameEnumLabel(), replorigin_create(), replorigin_drop(), revmap_physical_extend(), SpeculativeInsertionLockAcquire(), SpeculativeInsertionLockRelease(), SpGistNewBuffer(), spgvacuumscan(), vac_update_datfrozenxid(), VirtualXactLock(), VirtualXactLockTableCleanup(), vm_extend(), XactLockTableDelete(), and XactLockTableInsert().
#define MaxLockMode 8 |
Definition at line 48 of file lockdefs.h.
Referenced by CheckRelationLockedByMe().
#define NoLock 0 |
Definition at line 34 of file lockdefs.h.
Referenced by acquire_inherited_sample_rows(), AcquireRewriteLocks(), addFkRecurseReferenced(), addFkRecurseReferencing(), addRangeTableEntry(), AddRoleMems(), AddSubscriptionRelState(), AlterDatabase(), AlterDatabaseOwner(), AlterDomainNotNull(), AlterFunction(), AlterObjectNamespace_oid(), AlterOperator(), AlterPolicy(), AlterRole(), AlterSeqNamespaces(), AlterSequence(), AlterSetting(), AlterTable(), AlterTableGetRelOptionsLockLevel(), AlterTableNamespace(), AlterTableSpaceOptions(), analyze_rel(), apply_handle_delete(), apply_handle_insert(), apply_handle_truncate(), apply_handle_update(), ATAddCheckConstraint(), ATAddForeignKeyConstraint(), ATCheckPartitionsNotInUse(), ATController(), ATDetachCheckNoForeignKeyRefs(), ATExecAddColumn(), ATExecAddIndex(), ATExecAddIndexConstraint(), ATExecAddInherit(), ATExecAlterColumnType(), ATExecAttachPartition(), ATExecAttachPartitionIdx(), ATExecChangeOwner(), ATExecDetachPartition(), ATExecDropColumn(), ATExecDropConstraint(), ATExecDropInherit(), ATExecReplicaIdentity(), ATExecSetRelOptions(), ATExecSetTableSpace(), ATExecValidateConstraint(), ATPostAlterTypeParse(), ATPrepAlterColumnType(), ATRewriteCatalogs(), ATRewriteTable(), ATRewriteTables(), ATSimpleRecursion(), ATTypedTableRecursion(), boot_openrel(), BootstrapToastTable(), brincostestimate(), build_indices(), build_physical_tlist(), change_owner_recurse_to_sequences(), check_default_partition_contents(), check_index_is_clusterable(), check_of_type(), CheckAndCreateToastTable(), CheckIndexCompatible(), CloneFkReferenced(), CloneFkReferencing(), close_lo_relation(), closerel(), CloseTableList(), cluster(), CollationCreate(), CommentObject(), convert_table_name(), copy_table(), copy_table_data(), CountDBSubscriptions(), create_toast_table(), CreateComments(), createdb(), CreatePolicy(), CreateRole(), CreateSharedComments(), CreateStatistics(), CreateTableSpace(), CreateTrigger(), currval_oid(), database_to_xmlschema_internal(), DefineCompositeType(), DefineIndex(), DefineQueryRewrite(), DefineRelation(), DefineSequence(), DefineVirtualRelation(), DelRoleMems(), deparseColumnRef(), deparseFromExprForRel(), deparseSelectSql(), do_analyze_rel(), do_setval(), DoCopy(), dropdb(), DropRole(), DropSubscription(), DropTableSpace(), ENRMetadataGetTupDesc(), exec_object_restorecon(), ExecAlterExtensionContentsStmt(), ExecAlterObjectDependsStmt(), ExecCleanupTupleRouting(), ExecCloseRangeTableRelations(), ExecCloseResultRelations(), ExecEndBitmapIndexScan(), ExecEndIndexOnlyScan(), ExecEndIndexScan(), ExecGetRangeTableRelation(), ExecGetTriggerResultRel(), ExecRefreshMatView(), ExecSecLabelStmt(), ExecuteTruncate(), ExecuteTruncateGuts(), expand_inherited_rtentry(), expand_partitioned_rtentry(), expand_vacuum_rel(), expandTableLikeClause(), find_inheritance_children(), finish_heap_swap(), fireRIRrules(), free_parsestate(), generate_partition_qual(), get_actual_variable_range(), get_db_info(), get_object_address(), get_partition_qual_relid(), get_relation_constraints(), get_relation_data_width(), get_relation_info(), get_rels_with_domain(), get_row_security_policies(), GetLockStatusData(), GetPublicationRelations(), GetSingleProcBlockerStatusData(), GetTypeCollations(), gincostestimate(), GrantRole(), has_row_triggers(), has_stored_generated_columns(), heap_create_with_catalog(), heap_drop_with_catalog(), heap_truncate(), heap_truncate_one_rel(), heap_vacuum_rel(), index_close(), index_concurrently_build(), index_concurrently_create_copy(), index_concurrently_set_dead(), index_concurrently_swap(), index_create(), index_drop(), infer_arbiter_indexes(), intorel_shutdown(), lastval(), lock_and_open_sequence(), LockTableRecurse(), LockViewRecurse(), logicalrep_rel_open(), LogicalRepSyncTableStart(), LookupTypeNameExtended(), make_new_heap(), MergeAttributes(), movedb(), nextval(), nextval_internal(), objectNamesToOids(), OpenTableList(), owningrel_does_not_exist_skipping(), pg_blocking_pids(), pg_get_serial_sequence(), pg_get_viewdef_name(), pg_get_viewdef_name_ext(), pg_lock_status(), pg_sequence_last_value(), plan_create_index_workers(), plpgsql_parse_cwordrowtype(), plpgsql_parse_cwordtype(), populate_typ_array(), postgresPlanDirectModify(), postgresPlanForeignModify(), preprocess_targetlist(), process_owned_by(), QueuePartitionConstraintValidation(), RangeVarGetAndCheckCreationNamespace(), RangeVarGetRelidExtended(), rebuild_relation(), refresh_by_match_merge(), regclassin(), reindex_index(), reindex_relation(), ReindexRelationConcurrently(), relation_close(), relation_open(), relation_openrv(), relation_openrv_extended(), RelationBuildPartitionDesc(), RelationFindReplTupleByIndex(), RelationTruncateIndexes(), RemoveAttrDefaultById(), RemoveAttributeById(), RemoveConstraintById(), RemoveObjects(), RemovePolicyById(), RemoveRewriteRuleById(), RemoveRoleFromObjectPolicy(), RemoveTriggerById(), rename_constraint_internal(), rename_policy(), renameatt_internal(), RenameConstraint(), RenameDatabase(), RenameRelationInternal(), RenameRewriteRule(), RenameRole(), RenameSchema(), RenameTableSpace(), renametrig(), ResetSequence(), RewriteQuery(), rewriteTargetView(), row_security_active_name(), satisfies_hash_partition(), schema_to_xmlschema_internal(), searchRangeTableForRel(), sepgsql_dml_privileges(), setTargetTable(), shdepReassignOwned(), swap_relation_files(), table_to_xml_and_xmlschema(), table_to_xmlschema(), text_regclass(), to_regclass(), toast_get_valid_index(), transformAlterTableStmt(), transformCreateStmt(), transformIndexConstraint(), transformIndexStmt(), transformRuleStmt(), transformTableLikeClause(), transientrel_shutdown(), transientrel_startup(), try_relation_open(), TryReuseIndex(), UpdateSubscriptionRelState(), vac_open_indexes(), vacuum_open_relation(), vacuum_rel(), validate_index(), and validateDomainConstraint().
#define RowExclusiveLock 3 /* INSERT, UPDATE, DELETE */ |
Definition at line 38 of file lockdefs.h.
Referenced by _bt_parallel_build_main(), AddEnumLabel(), AddNewAttributeTuples(), addRangeTableEntryForRelation(), AddRoleMems(), AddSubscriptionRelState(), AggregateCreate(), AlterConstraintNamespaces(), AlterDatabase(), AlterDatabaseOwner(), AlterDomainAddConstraint(), AlterDomainDefault(), AlterDomainDropConstraint(), AlterDomainNotNull(), AlterDomainValidateConstraint(), AlterEventTrigger(), AlterEventTriggerOwner(), AlterEventTriggerOwner_oid(), AlterExtensionNamespace(), AlterForeignDataWrapper(), AlterForeignDataWrapperOwner(), AlterForeignDataWrapperOwner_oid(), AlterForeignServer(), AlterForeignServerOwner(), AlterForeignServerOwner_oid(), AlterFunction(), AlterObjectNamespace_oid(), AlterOperator(), AlterPolicy(), AlterPublication(), AlterPublicationOwner(), AlterPublicationOwner_oid(), AlterRole(), AlterSchemaOwner(), AlterSchemaOwner_oid(), AlterSequence(), AlterSetting(), AlterStatistics(), AlterSubscription(), AlterSubscriptionOwner(), AlterSubscriptionOwner_oid(), AlterTableNamespaceInternal(), AlterTableSpaceOptions(), AlterTSConfiguration(), AlterTSDictionary(), AlterType(), AlterTypeNamespaceInternal(), AlterTypeOwner(), AlterTypeOwner_oid(), AlterTypeOwnerInternal(), AlterUserMapping(), AppendAttributeTuples(), apply_handle_delete(), apply_handle_insert(), apply_handle_truncate(), apply_handle_update(), ApplyExtensionUpdates(), ATExecAddColumn(), ATExecAddIdentity(), ATExecAddOf(), ATExecAlterColumnGenericOptions(), ATExecAlterColumnType(), ATExecAlterConstraint(), ATExecChangeOwner(), ATExecDetachPartition(), ATExecDisableRowSecurity(), ATExecDropColumn(), ATExecDropConstraint(), ATExecDropExpression(), ATExecDropIdentity(), ATExecDropNotNull(), ATExecDropOf(), ATExecEnableRowSecurity(), ATExecForceNoForceRowSecurity(), ATExecGenericOptions(), ATExecSetIdentity(), ATExecSetNotNull(), ATExecSetOptions(), ATExecSetRelOptions(), ATExecSetStatistics(), ATExecSetStorage(), ATExecSetTableSpace(), ATExecSetTableSpaceNoStorage(), ATExecValidateConstraint(), BuildRelationExtStatistics(), CastCreate(), change_owner_fix_column_acls(), changeDependenciesOf(), changeDependenciesOn(), changeDependencyFor(), changeDependencyOnOwner(), changeDependencyOnTablespace(), ClassifyUtilityCommandAsReadOnly(), CloneRowTriggersToPartition(), ComputeExtStatisticsRows(), ConstraintSetParentConstraint(), ConversionCreate(), copy_table_data(), CopyStatistics(), copyTemplateDependencies(), CountDBSubscriptions(), create_toast_table(), CreateAccessMethod(), CreateComments(), CreateConstraintEntry(), createdb(), CreateForeignDataWrapper(), CreateForeignServer(), CreateForeignTable(), CreateInheritance(), CreateOpFamily(), CreatePolicy(), CreateProceduralLanguage(), CreatePublication(), CreateRole(), CreateSharedComments(), CreateStatistics(), CreateSubscription(), CreateTableSpace(), CreateTransform(), CreateTrigger(), CreateUserMapping(), DefineIndex(), DefineOpClass(), DefineQueryRewrite(), DefineSequence(), DefineTSConfiguration(), DefineTSDictionary(), DefineTSParser(), DefineTSTemplate(), DeleteAttributeTuples(), DeleteComments(), deleteDependencyRecordsFor(), deleteDependencyRecordsForClass(), deleteDependencyRecordsForSpecific(), DeleteInheritsTuple(), DeleteInitPrivs(), deleteOneObject(), DeleteRelationTuple(), DeleteSecurityLabel(), DeleteSequenceTuple(), DeleteSharedComments(), deleteSharedDependencyRecordsFor(), DeleteSharedSecurityLabel(), DeleteSystemAttributeTuples(), DelRoleMems(), DoCopy(), drop_parent_dependency(), DropClonedTriggersFromPartition(), dropDatabaseDependencies(), dropdb(), DropObjectById(), DropRole(), DropSetting(), DropTableSpace(), EnableDisableRule(), EnableDisableTrigger(), EnumValuesCreate(), EnumValuesDelete(), ExecAlterObjectSchemaStmt(), ExecAlterOwnerStmt(), ExecCloseIndices(), ExecGrant_Database(), ExecGrant_Fdw(), ExecGrant_ForeignServer(), ExecGrant_Function(), ExecGrant_Language(), ExecGrant_Largeobject(), ExecGrant_Namespace(), ExecGrant_Relation(), ExecGrant_Tablespace(), ExecGrant_Type(), ExecInitPartitionDispatchInfo(), ExecInitPartitionInfo(), ExecOpenIndices(), ExecRenameStmt(), extension_config_remove(), finish_heap_swap(), gin_clean_pending_list(), heap_create_with_catalog(), heap_drop_with_catalog(), heap_force_common(), heap_vacuum_rel(), index_build(), index_concurrently_build(), index_concurrently_create_copy(), index_concurrently_swap(), index_constraint_create(), index_create(), index_drop(), index_set_state_flags(), index_update_stats(), IndexSetParentIndex(), InitPostgres(), insert_event_trigger_tuple(), InsertExtensionTuple(), InsertRule(), LargeObjectCreate(), LargeObjectDrop(), lock_and_open_sequence(), LockAcquireExtended(), LockTableAclCheck(), LogicalRepSyncTableStart(), mark_index_clustered(), MergeAttributesIntoExisting(), MergeConstraintsIntoExisting(), MergeWithExistingConstraint(), movedb(), NamespaceCreate(), open_lo_relation(), OperatorCreate(), OperatorShellMake(), OperatorUpd(), parallel_vacuum_main(), performDeletion(), performMultipleDeletions(), pg_extension_config_dump(), pg_nextoid(), pg_replication_origin_advance(), ProcedureCreate(), publication_add_relation(), RangeCreate(), RangeDelete(), recordExtensionInitPrivWorker(), recordExtObjInitPriv(), recordMultipleDependencies(), recordSharedDependencyOn(), refresh_by_match_merge(), reindex_index(), relation_mark_replica_identity(), RelationClearMissing(), RelationFindReplTupleByIndex(), RelationRemoveInheritance(), RelationSetNewRelfilenode(), RemoveAttrDefault(), RemoveAttrDefaultById(), RemoveAttributeById(), RemoveConstraintById(), RemoveExtensionById(), RemoveFunctionById(), RemoveInheritance(), RemoveOperatorById(), RemovePartitionKeyByRelId(), RemovePolicyById(), RemovePublicationRelById(), RemoveRewriteRuleById(), RemoveRoleFromObjectPolicy(), RemoveStatistics(), RemoveStatisticsById(), RemoveSubscriptionRel(), RemoveTriggerById(), RemoveTSConfigurationById(), RemoveTypeById(), rename_policy(), renameatt_internal(), RenameConstraint(), RenameConstraintById(), RenameDatabase(), RenameEnumLabel(), RenameRelationInternal(), RenameRewriteRule(), RenameRole(), RenameSchema(), RenameTableSpace(), renametrig(), RenameType(), RenameTypeInternal(), rewriteTargetView(), RI_FKey_cascade_del(), RI_FKey_cascade_upd(), ri_set(), SetAttrMissing(), SetDefaultACL(), SetMatViewPopulatedState(), SetRelationHasSubclass(), SetRelationNumChecks(), SetRelationRuleStatus(), SetSecurityLabel(), SetSharedSecurityLabel(), setTargetTable(), shdepDropOwned(), shdepReassignOwned(), statext_store(), StoreAttrDefault(), StoreCatalogInheritance(), storeOperators(), StorePartitionBound(), StorePartitionKey(), storeProcedures(), StoreSingleInheritance(), swap_relation_files(), toast_delete_datum(), toast_save_datum(), toastrel_valueid_exists(), transformOnConflictClause(), tryAttachPartitionForeignKey(), TypeCreate(), TypeShellMake(), unique_key_recheck(), update_attstats(), update_default_partition_oid(), update_relispartition(), updateAclDependencies(), UpdateIndexRelation(), UpdateStatisticsForTypeChange(), UpdateSubscriptionRelState(), vac_update_datfrozenxid(), vac_update_relstats(), validate_index(), validatePartitionedIndex(), and visitDependenciesOf().
#define RowShareLock 2 /* SELECT FOR UPDATE/FOR SHARE */ |
Definition at line 37 of file lockdefs.h.
Referenced by AcquireRewriteLocks(), addRangeTableEntry(), addRangeTableEntryForRelation(), ATRewriteTables(), CloneFkReferenced(), RI_FKey_check(), and ri_restrict().
#define ShareLock 5 /* CREATE INDEX (WITHOUT CONCURRENTLY) */ |
Definition at line 41 of file lockdefs.h.
Referenced by _bt_parallel_build_main(), AlterDomainNotNull(), ATDetachCheckNoForeignKeyRefs(), ATExecReplicaIdentity(), brin_page_cleanup(), bt_index_check_internal(), ConditionalXactLockTableWait(), create_toast_table(), createdb(), createdb_failure_callback(), DefineIndex(), pg_advisory_lock_shared_int4(), pg_advisory_lock_shared_int8(), pg_advisory_unlock_shared_int4(), pg_advisory_unlock_shared_int8(), pg_advisory_xact_lock_shared_int4(), pg_advisory_xact_lock_shared_int8(), pg_try_advisory_lock_shared_int4(), pg_try_advisory_lock_shared_int8(), pg_try_advisory_xact_lock_shared_int4(), pg_try_advisory_xact_lock_shared_int8(), ProcessUtilitySlow(), RangeVarCallbackForReindexIndex(), reindex_index(), reindex_relation(), ReindexPartitions(), ReindexRelationConcurrently(), ReindexTable(), SpeculativeInsertionWait(), validateDomainConstraint(), VirtualXactLock(), and XactLockTableWait().
#define ShareRowExclusiveLock |
Definition at line 42 of file lockdefs.h.
Referenced by addFkRecurseReferenced(), AlterSequence(), AlterTableGetLockLevel(), ATAddForeignKeyConstraint(), CloneFkReferencing(), CollationCreate(), and CreateTrigger().
#define ShareUpdateExclusiveLock |
Definition at line 39 of file lockdefs.h.
Referenced by _bt_parallel_build_main(), AcquireDeletionLock(), AlterPublicationTables(), AlterTableGetLockLevel(), analyze_rel(), ATExecAddInherit(), ATExecDetachPartition(), brin_desummarize_range(), brin_summarize_range(), CommentObject(), CreateStatistics(), DefineIndex(), DefineRelation(), ExecAlterExtensionContentsStmt(), ExecSecLabelStmt(), index_concurrently_build(), index_concurrently_set_dead(), index_concurrently_swap(), index_drop(), OpenTableList(), parallel_vacuum_main(), ProcessUtilitySlow(), RangeVarCallbackForDropRelation(), RangeVarCallbackForReindexIndex(), ReindexIndex(), ReindexRelationConcurrently(), ReindexTable(), RemoveRelations(), RenameRelation(), RenameRelationInternal(), vacuum_rel(), and validate_index().
typedef int LOCKMASK |
Definition at line 25 of file lockdefs.h.
typedef int LOCKMODE |
Definition at line 26 of file lockdefs.h.
typedef struct xl_standby_lock xl_standby_lock |