|
PostgreSQL Source Code git master
|
#include "postgres.h"#include "access/hash.h"#include "access/htup_details.h"#include "bootstrap/bootstrap.h"#include "catalog/namespace.h"#include "catalog/pg_am.h"#include "catalog/pg_amop.h"#include "catalog/pg_amproc.h"#include "catalog/pg_cast.h"#include "catalog/pg_class.h"#include "catalog/pg_collation.h"#include "catalog/pg_constraint.h"#include "catalog/pg_database.h"#include "catalog/pg_index.h"#include "catalog/pg_language.h"#include "catalog/pg_namespace.h"#include "catalog/pg_opclass.h"#include "catalog/pg_opfamily.h"#include "catalog/pg_operator.h"#include "catalog/pg_proc.h"#include "catalog/pg_publication.h"#include "catalog/pg_range.h"#include "catalog/pg_statistic.h"#include "catalog/pg_subscription.h"#include "catalog/pg_transform.h"#include "catalog/pg_type.h"#include "miscadmin.h"#include "nodes/makefuncs.h"#include "utils/array.h"#include "utils/builtins.h"#include "utils/catcache.h"#include "utils/datum.h"#include "utils/fmgroids.h"#include "utils/lsyscache.h"#include "utils/syscache.h"#include "utils/typcache.h"
Go to the source code of this file.
Variables | |
| get_attavgwidth_hook_type | get_attavgwidth_hook = NULL |
Definition at line 834 of file lsyscache.c.
References IndexAmRoutine::amconsistentordering, GetIndexAmRoutineByAmId(), GETSTRUCT(), i, catclist::members, catclist::n_members, ObjectIdGetDatum(), op_in_opfamily(), ReleaseSysCacheList, SearchSysCacheList1, and catctup::tuple.
Referenced by ineq_histogram_selectivity().
Definition at line 778 of file lsyscache.c.
References IndexAmRoutine::amconsistentequality, GetIndexAmRoutineByAmId(), GETSTRUCT(), i, catclist::members, catclist::n_members, ObjectIdGetDatum(), op_in_opfamily(), ReleaseSysCacheList, SearchSysCacheList1, and catctup::tuple.
Referenced by query_is_distinct_for().
| void free_attstatsslot | ( | AttStatsSlot * | sslot | ) |
Definition at line 3509 of file lsyscache.c.
References AttStatsSlot::numbers_arr, pfree(), AttStatsSlot::values, and AttStatsSlot::values_arr.
Referenced by _int_matchsel(), booltestsel(), brincostestimate(), btcost_correlation(), calc_arraycontsel(), calc_hist_selectivity(), calc_multirangesel(), calc_rangesel(), eqjoinsel(), estimate_array_length(), estimate_hash_bucket_stats(), ExecHashBuildSkewHash(), get_variable_range(), histogram_selectivity(), ineq_histogram_selectivity(), mcv_selectivity(), networkjoinsel_inner(), networkjoinsel_semi(), networksel(), scalararraysel_containment(), tsquerysel(), var_eq_const(), and var_eq_non_const().
| char func_parallel | ( | Oid | funcid | ) |
Definition at line 1964 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by max_parallel_hazard_checker(), and set_rel_consider_parallel().
| bool func_strict | ( | Oid | funcid | ) |
Definition at line 1926 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by AggregateCreate(), check_and_push_window_quals(), clause_is_strict_for(), contain_nonstrict_functions_checker(), find_nonnullable_rels_walker(), find_nonnullable_vars_walker(), hash_ok_operator(), is_strict_saop(), op_strict(), and process_equivalence().
| char func_volatile | ( | Oid | funcid | ) |
Definition at line 1945 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by contain_mutable_functions_checker(), contain_mutable_or_user_functions_checker(), contain_volatile_functions_checker(), contain_volatile_functions_not_nextval_checker(), ece_function_is_safe(), findRangeCanonicalFunction(), findRangeSubtypeDiffFunction(), findTypeInputFunction(), findTypeOutputFunction(), findTypeReceiveFunction(), findTypeSendFunction(), findTypeTypmodinFunction(), findTypeTypmodoutFunction(), op_volatile(), to_json_is_immutable(), and to_jsonb_is_immutable().
Definition at line 2952 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by AlterTypeNamespace_oid(), enforce_generic_type_consistency(), ExecAlterExtensionContentsRecurse(), get_promoted_array_type(), initArrayResultAny(), LookupTypeNameExtended(), make_partition_op_expr(), make_SAOP_expr(), make_scalar_array_op(), match_orclause_to_indexcol(), moveArrayTypeName(), ParseFuncOrColumn(), plpgsql_build_datatype_arrayof(), resolve_anyarray_from_others(), transformAExprIn(), and transformArrayExpr().
| int32 get_attavgwidth | ( | Oid | relid, |
| AttrNumber | attnum | ||
| ) |
Definition at line 3323 of file lsyscache.c.
References attnum, BoolGetDatum(), get_attavgwidth_hook, GETSTRUCT(), HeapTupleIsValid, Int16GetDatum(), ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache3().
Referenced by get_rel_data_width(), and set_rel_width().
| char get_attgenerated | ( | Oid | relid, |
| AttrNumber | attnum | ||
| ) |
Definition at line 979 of file lsyscache.c.
References attnum, elog, ERROR, GETSTRUCT(), HeapTupleIsValid, Int16GetDatum(), ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache2().
Referenced by check_nested_generated_walker(), and CreateStatistics().
| char * get_attname | ( | Oid | relid, |
| AttrNumber | attnum, | ||
| bool | missing_ok | ||
| ) |
Definition at line 918 of file lsyscache.c.
References attnum, elog, ERROR, GETSTRUCT(), HeapTupleIsValid, Int16GetDatum(), NameStr, ObjectIdGetDatum(), pstrdup(), ReleaseSysCache(), and SearchSysCache2().
Referenced by AddRelationNewConstraints(), AddRelationNotNullConstraints(), ATExecAlterConstrInheritability(), attribute_statistics_update(), check_nested_generated_walker(), ComputePartitionAttrs(), contain_invalid_rfcolumn_walker(), CreateStatistics(), decompile_column_index_array(), deparseColumnRef(), DoCopy(), dropconstraint_internal(), errtablecol(), fixup_inherited_columns(), generateClonedExtStatsStmt(), generateClonedIndexStmt(), get_insert_query_def(), get_merge_query_def(), get_rte_attribute_name(), get_update_query_targetlist_def(), getIdentitySequence(), getObjectDescription(), getObjectIdentityParts(), MergeConstraintsIntoExisting(), pg_get_constraintdef_worker(), pg_get_indexdef_worker(), pg_get_partkeydef_worker(), pg_get_statisticsobj_worker(), pg_get_triggerdef_worker(), processIndirection(), pub_contains_invalid_column(), QueueNNConstraintValidation(), RelationGetNotNullConstraints(), RememberAllDependentForRebuilding(), transformPartitionBound(), and transformPartitionRangeBounds().
| AttrNumber get_attnum | ( | Oid | relid, |
| const char * | attname | ||
| ) |
Definition at line 949 of file lsyscache.c.
References attname, GETSTRUCT(), HeapTupleIsValid, InvalidAttrNumber, ReleaseSysCache(), and SearchSysCacheAttName().
Referenced by AddRelationNewConstraints(), AddRelationNotNullConstraints(), ATExecColumnDefault(), ATExecDropNotNull(), ATExecSetNotNull(), attribute_statistics_update(), contain_invalid_rfcolumn_walker(), expand_col_privileges(), findNotNullConstraint(), fixup_inherited_columns(), get_object_address_attrdef(), get_object_address_attribute(), getIdentitySequence(), LookupTypeNameExtended(), pg_clear_attribute_stats(), pg_get_serial_sequence(), process_owned_by(), pub_collist_validate(), pub_contains_invalid_column(), transformAlterTableStmt(), and transformAssignmentIndirection().
Definition at line 1061 of file lsyscache.c.
References attnum, datumCopy(), elog, ERROR, HeapTupleIsValid, Int16GetDatum(), ObjectIdGetDatum(), ReleaseSysCache(), SearchSysCache2(), and SysCacheGetAttr().
Referenced by CheckIndexCompatible(), generateClonedIndexStmt(), index_concurrently_create_copy(), pg_get_indexdef_worker(), RelationGetIndexAttOptions(), and transformIndexConstraint().
| bool get_attstatsslot | ( | AttStatsSlot * | sslot, |
| HeapTuple | statstuple, | ||
| int | reqkind, | ||
| Oid | reqop, | ||
| int | flags | ||
| ) |
Definition at line 3399 of file lsyscache.c.
References ARR_DATA_PTR, ARR_DIMS, ARR_ELEMTYPE, ARR_HASNULL, ARR_NDIM, ATTSTATSSLOT_NUMBERS, ATTSTATSSLOT_VALUES, DatumGetArrayTypePCopy, deconstruct_array(), elog, ERROR, GETSTRUCT(), HeapTupleIsValid, i, InvalidOid, AttStatsSlot::nnumbers, AttStatsSlot::numbers, AttStatsSlot::numbers_arr, AttStatsSlot::nvalues, ObjectIdGetDatum(), pfree(), ReleaseSysCache(), SearchSysCache1(), AttStatsSlot::stacoll, AttStatsSlot::staop, STATISTIC_NUM_SLOTS, SysCacheGetAttrNotNull(), val, AttStatsSlot::values, AttStatsSlot::values_arr, and AttStatsSlot::valuetype.
Referenced by _int_matchsel(), booltestsel(), brincostestimate(), btcost_correlation(), calc_arraycontsel(), calc_hist_selectivity(), calc_multirangesel(), calc_rangesel(), eqjoinsel(), estimate_array_length(), estimate_hash_bucket_stats(), ExecHashBuildSkewHash(), get_variable_range(), histogram_selectivity(), ineq_histogram_selectivity(), mcv_selectivity(), networkjoinsel_inner(), networkjoinsel_semi(), networksel(), scalararraysel_containment(), tsquerysel(), var_eq_const(), and var_eq_non_const().
| Oid get_atttype | ( | Oid | relid, |
| AttrNumber | attnum | ||
| ) |
Definition at line 1004 of file lsyscache.c.
References attnum, GETSTRUCT(), HeapTupleIsValid, Int16GetDatum(), InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache2().
Referenced by generateClonedIndexStmt(), GetIndexInputType(), LookupTypeNameExtended(), and transformAlterTableStmt().
| void get_atttypetypmodcoll | ( | Oid | relid, |
| AttrNumber | attnum, | ||
| Oid * | typid, | ||
| int32 * | typmod, | ||
| Oid * | collid | ||
| ) |
Definition at line 1034 of file lsyscache.c.
References attnum, collid, elog, ERROR, GETSTRUCT(), HeapTupleIsValid, Int16GetDatum(), ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache2().
Referenced by pg_get_indexdef_worker(), pg_get_partkeydef_worker(), and transformAssignmentIndirection().
Definition at line 2997 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by array_typanalyze(), arraycontsel(), build_datatype(), cache_array_element_properties(), concat_internal(), ConstructTupleDescriptor(), count_nulls(), CreateFunction(), get_call_expr_argtype(), get_elem_stat_type(), get_rule_expr(), make_scalar_array_op(), ParseFuncOrColumn(), plperl_hash_from_tuple(), scalararraysel(), and text_format().
Definition at line 1098 of file lsyscache.c.
References ereport, errcode(), errmsg(), ERROR, format_type_be(), GetSysCacheOid2, ObjectIdGetDatum(), and OidIsValid.
Referenced by get_object_address().
| bool get_collation_isdeterministic | ( | Oid | colloid | ) |
Definition at line 1145 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by ATAddForeignKeyConstraint(), index_create(), and match_pattern_prefix().
| char * get_collation_name | ( | Oid | colloid | ) |
Definition at line 1126 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, NameStr, ObjectIdGetDatum(), pstrdup(), ReleaseSysCache(), and SearchSysCache1().
Referenced by analyzeCTE(), assign_collations_walker(), assign_hypothetical_collations(), ATAddForeignKeyConstraint(), ATExecAddColumn(), checkViewColumns(), merge_collation_state(), MergeChildAttribute(), MergeInheritedAttribute(), select_common_collation(), show_sortorder_options(), and transformJsonBehavior().
Definition at line 1674 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by CommuteOpExpr(), compute_semijoin_info(), ComputeIndexAttrs(), convert_EXISTS_to_ANY(), expand_indexqual_rowcompare(), group_similar_or_args(), hash_inner_and_outer(), match_clause_to_ordering_op(), match_clause_to_partition_key(), match_foreign_keys_to_quals(), match_opclause_to_indexcol(), match_orclause_to_indexcol(), match_rowcompare_to_indexcol(), multirangesel(), networkjoinsel(), operator_predicate_proof(), rangesel(), scalarineqsel_wrapper(), select_mergejoin_clauses(), and targetIsInSortList().
Definition at line 482 of file lsyscache.c.
References get_opfamily_member(), GETSTRUCT(), HTEqualStrategyNumber, i, InvalidOid, catclist::members, catclist::n_members, ObjectIdGetDatum(), OidIsValid, ReleaseSysCacheList, SearchSysCacheList1, and catctup::tuple.
Referenced by create_unique_paths(), and ExecInitSubPlan().
Definition at line 1204 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by ATPostAlterTypeParse(), infer_arbiter_indexes(), and RememberConstraintForRebuilding().
| char * get_constraint_name | ( | Oid | conoid | ) |
Definition at line 1172 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, NameStr, ObjectIdGetDatum(), pstrdup(), ReleaseSysCache(), and SearchSysCache1().
Referenced by addFkRecurseReferencing(), CloneFkReferencing(), get_insert_query_def(), and report_triggers().
| char get_constraint_type | ( | Oid | conoid | ) |
Definition at line 1234 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by AttachPartitionEnsureIndexes(), and RememberConstraintForRebuilding().
| char * get_database_name | ( | Oid | dbid | ) |
Definition at line 1257 of file lsyscache.c.
References datname, GETSTRUCT(), HeapTupleIsValid, NameStr, ObjectIdGetDatum(), pstrdup(), ReleaseSysCache(), and SearchSysCache1().
Referenced by AfterTriggerSetState(), AlterObjectRename_internal(), AlterPublicationOwner_internal(), AlterSchemaOwner_internal(), AlterSubscriptionOwner_internal(), calculate_database_size(), createdb(), CreatePublication(), CreateSchemaCommand(), CreateSubscription(), current_database(), database_to_xml_internal(), DeconstructQualifiedName(), do_analyze_rel(), do_autovacuum(), exec_object_restorecon(), ExpandColumnRefStar(), GetNewMultiXactId(), GetNewTransactionId(), getObjectDescription(), getObjectIdentityParts(), heap_vacuum_rel(), IdentifySystem(), InitTempTableNamespace(), map_sql_catalog_to_xmlschema_types(), map_sql_schema_to_xmlschema_types(), map_sql_table_to_xmlschema(), map_sql_type_to_xml_name(), perform_work_item(), RangeVarGetAndCheckCreationNamespace(), RangeVarGetCreationNamespace(), RangeVarGetRelidExtended(), regdatabaseout(), ReindexMultipleTables(), RenameSchema(), SetMultiXactIdLimit(), SetTransactionIdLimit(), shdepLockAndCheckObject(), TerminateOtherDBBackends(), and transformColumnRef().
Definition at line 2924 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by aclcheck_error_type(), AlterTypeNamespace_oid(), build_coercion_expression(), check_generic_type_consistency(), CheckAttributeType(), CreateCast(), enforce_generic_type_consistency(), exec_stmt_foreach_a(), ExecInitExprRec(), fetch_array_arg_replace_nulls(), find_coercion_pathway(), get_promoted_array_type(), initArrayResultArr(), interpret_function_parameter_list(), is_complex_array(), json_categorize_type(), moveArrayTypeName(), plperl_array_to_datum(), ProcedureCreate(), resolve_anyelement_from_others(), transformArrayExpr(), and transformTypeCast().
Definition at line 331 of file lsyscache.c.
References COMPARE_EQ, COMPARE_GT, get_opfamily_member_for_cmptype(), get_ordering_op_properties(), and InvalidOid.
Referenced by addTargetToSortList(), create_unique_paths(), preparePresortedCols(), preprocess_minmax_aggregates(), and show_sortorder_options().
| bool get_func_leakproof | ( | Oid | funcid | ) |
Definition at line 2002 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by contain_leaked_vars_checker(), contain_leaked_vars_walker(), create_agg_clause_infos(), select_equality_operator(), statext_is_compatible_clause_internal(), and statistic_proc_security_check().
| char * get_func_name | ( | Oid | funcid | ) |
Definition at line 1773 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, NameStr, ObjectIdGetDatum(), pstrdup(), ReleaseSysCache(), and SearchSysCache1().
Referenced by AlterFunction(), AlterOpFamilyAdd(), DefineOpClass(), ExecBuildGroupingEqual(), ExecBuildParamSetEqual(), ExecInitAgg(), ExecInitExprRec(), ExecInitFunc(), ExecInitWindowAgg(), ExecuteCallStmt(), ExplainTargetRel(), findRangeCanonicalFunction(), findRangeSubtypeDiffFunction(), HandleFunctionRequest(), init_sexpr(), initialize_peragg(), lookup_agg_function(), lookup_am_handler_func(), print_expr(), show_tablesample(), statistic_proc_security_check(), and WinCheckAndInitializeNullTreatment().
Definition at line 1797 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by ExplainTargetRel(), sepgsql_proc_drop(), and unaccent_dict().
| int get_func_nargs | ( | Oid | funcid | ) |
Definition at line 1839 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), pronargs, ReleaseSysCache(), and SearchSysCache1().
| char get_func_prokind | ( | Oid | funcid | ) |
Definition at line 1983 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by LookupFuncNameInternal(), LookupFuncWithArgs(), and RemoveObjects().
| bool get_func_retset | ( | Oid | funcid | ) |
Definition at line 1907 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by make_op(), and make_scalar_array_op().
Definition at line 1820 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by CreateConversionCommand(), CreateEventTrigger(), CreateProceduralLanguage(), CreateTriggerFiringOn(), DefineOperator(), findRangeCanonicalFunction(), findRangeSubtypeDiffFunction(), findTypeAnalyzeFunction(), findTypeInputFunction(), findTypeOutputFunction(), findTypeReceiveFunction(), findTypeSendFunction(), findTypeSubscriptingFunction(), findTypeTypmodinFunction(), findTypeTypmodoutFunction(), get_ts_parser_func(), get_ts_template_func(), gistrescan(), interpret_func_support(), lookup_am_handler_func(), lookup_fdw_handler_func(), OperatorCreate(), spgrescan(), transformRangeTableSample(), ValidateJoinEstimator(), and ValidateRestrictionEstimator().
Definition at line 1861 of file lsyscache.c.
References Assert(), elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), palloc(), ReleaseSysCache(), and SearchSysCache1().
Referenced by plperl_call_perl_func(), resolve_aggregate_transtype(), and typeDepNeeded().
| RegProcedure get_func_support | ( | Oid | funcid | ) |
Definition at line 2023 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by exec_check_rw_parameter(), find_window_run_conditions(), function_selectivity(), get_index_clause_from_support(), optimize_window_clauses(), and simplify_aggref().
Definition at line 1888 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by assign_hypothetical_collations(), and assign_ordered_set_collations().
Definition at line 3677 of file lsyscache.c.
References Assert(), DatumGetPointer(), GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), SearchSysCache1(), SysCacheGetAttrNotNull(), and oidvector::values.
Referenced by gistproperty(), ri_LoadConstraintInfo(), and spgproperty().
| bool get_index_isclustered | ( | Oid | index_oid | ) |
Definition at line 3766 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by cluster(), cluster_rel(), mark_index_clustered(), and RememberClusterOnForRebuilding().
| bool get_index_isreplident | ( | Oid | index_oid | ) |
Definition at line 3720 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by RememberReplicaIdentityForRebuilding().
| bool get_index_isvalid | ( | Oid | index_oid | ) |
Definition at line 3743 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by DefineIndex(), reindex_index(), reindex_relation(), and ReindexRelationConcurrently().
| char * get_language_name | ( | Oid | langoid, |
| bool | missing_ok | ||
| ) |
Definition at line 1278 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, NameStr, ObjectIdGetDatum(), pstrdup(), ReleaseSysCache(), and SearchSysCache1().
Referenced by get_transform_oid(), getObjectDescription(), getObjectIdentityParts(), and pg_get_functiondef().
Definition at line 435 of file lsyscache.c.
References COMPARE_EQ, get_opmethod_canorder(), GETSTRUCT(), i, IndexAmTranslateStrategy(), lappend_oid(), catclist::members, catclist::n_members, NIL, ObjectIdGetDatum(), ReleaseSysCacheList, SearchSysCacheList1, and catctup::tuple.
Referenced by check_mergejoinable(), compute_semijoin_info(), get_eclass_for_sortgroupclause(), have_partkey_equi_join(), make_pathkey_from_sortinfo(), and match_eclasses_to_foreign_key_col().
Definition at line 3648 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by AlterTypeOwner(), check_generic_type_consistency(), enforce_generic_type_consistency(), get_attr_stat_type(), load_multirangetype_info(), pg_type_aclmask_ext(), resolve_anyelement_from_others(), and resolve_anyrange_from_others().
| char * get_namespace_name | ( | Oid | nspid | ) |
Definition at line 3531 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, NameStr, nspid, ObjectIdGetDatum(), pstrdup(), ReleaseSysCache(), and SearchSysCache1().
Referenced by acquire_inherited_sample_rows(), AlterExtensionNamespace(), AlterObjectNamespace_internal(), AlterObjectOwner_internal(), AlterObjectRename_internal(), AlterRelationNamespaceInternal(), AlterSubscription_refresh(), AlterSubscription_refresh_seq(), AlterTableMoveAll(), AlterTypeNamespaceInternal(), AlterTypeOwner(), appendFunctionName(), apply_handle_tuple_routing(), ApplyExtensionUpdates(), ATExecChangeOwner(), ATParseTransformCmd(), BuildRelationExtStatistics(), check_and_init_gencol(), check_default_text_search_config(), check_publication_add_schema(), check_publications_origin_sequences(), check_publications_origin_tables(), CheckPubRelationColumnList(), compute_return_type(), copy_table(), copy_table_data(), create_pg_locale(), CreateConversionCommand(), CreateExtensionInternal(), CreateFunction(), CreateStatistics(), current_schema(), current_schemas(), currtid_internal(), DefineAggregate(), DefineCollation(), DefineDomain(), DefineEnum(), DefineIndex(), DefineOpClass(), DefineOperator(), DefineOpFamily(), DefineRange(), DefineTSConfiguration(), DefineTSDictionary(), DefineType(), deparseOperatorName(), deparseRelation(), do_analyze_rel(), do_autovacuum(), DoCopy(), errdatatype(), errtable(), EventTriggerSQLDropAddObject(), exec_object_restorecon(), ExecAlterExtensionContentsRecurse(), ExecBRInsertTriggers(), execute_extension_script(), fetch_statentries_for_relation(), format_operator_extended(), format_procedure_extended(), generate_operator_clause(), generate_relation_name(), generateClonedIndexStmt(), generateSerialExtraStmts(), get_and_validate_seq_info(), get_collation(), get_namespace_name_or_temp(), get_opclass(), get_other_operator(), getObjectDescription(), getOpFamilyDescription(), getPublicationSchemaInfo(), getRelationDescription(), GetTempNamespaceProcNumber(), HandleFunctionRequest(), heap_create(), heap_vacuum_rel(), isAnyTempNamespace(), IsThereCollationInNamespace(), IsThereFunctionInNamespace(), IsThereOpClassInNamespace(), IsThereOpFamilyInNamespace(), logicalrep_write_namespace(), LogicalRepSyncSequences(), map_sql_catalog_to_xmlschema_types(), map_sql_schema_to_xmlschema_types(), map_sql_table_to_xmlschema(), map_sql_type_to_xml_name(), MarkInheritDetached(), obtain_object_name_namespace(), parallel_vacuum_main(), perform_work_item(), pg_decode_change(), pg_decode_truncate(), pg_identify_object(), pgoutput_column_list_init(), pgoutput_row_filter(), plpgsql_fulfill_promise(), publication_add_schema(), PublicationDropSchemas(), quoteRelationName(), RangeVarCallbackForAlterRelation(), RangeVarGetAndCheckCreationNamespace(), RebuildConstraintComment(), refresh_by_match_merge(), RefreshMatViewByOid(), regclassout(), regcollationout(), regconfigout(), regdictionaryout(), regnamespaceout(), regoperout(), regprocout(), reindex_index(), reindex_relation(), ReindexMultipleInternal(), ReindexPartitions(), ReindexRelationConcurrently(), report_namespace_conflict(), ReportApplyConflict(), ri_GenerateQualCollation(), schema_to_xml_internal(), sepgsql_proc_post_create(), sepgsql_relation_post_create(), SPI_getnspname(), swap_relation_files(), transformAlterTableStmt(), transformCreateStmt(), and unaccent_dict().
| char * get_namespace_name_or_temp | ( | Oid | nspid | ) |
Definition at line 3555 of file lsyscache.c.
References get_namespace_name(), isTempNamespace(), nspid, and pstrdup().
Referenced by add_cast_to(), ExplainTargetRel(), format_operator_parts(), format_procedure_parts(), format_type_extended(), generate_collation_name(), generate_function_name(), generate_operator_name(), generate_qualified_relation_name(), generate_qualified_type_name(), generate_relation_name(), get_opclass_name(), getObjectIdentityParts(), getOpFamilyIdentity(), getRelationIdentity(), overexplain_range_table(), pg_event_trigger_ddl_commands(), pg_get_functiondef(), pg_get_statisticsobj_worker(), and postgresExplainForeignScan().
Definition at line 1698 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by analyzeCTE(), convert_saop_to_hashed_saop_walker(), eqsel_internal(), get_op_index_interpretation(), lookup_proof_cache(), match_clause_to_partition_key(), negate_clause(), neqjoinsel(), operator_same_subexprs_proof(), patternsel(), and scalararraysel().
| bool get_op_hash_functions | ( | Oid | opno, |
| RegProcedure * | lhs_procno, | ||
| RegProcedure * | rhs_procno | ||
| ) |
Definition at line 582 of file lsyscache.c.
References get_opfamily_proc(), GETSTRUCT(), HASHSTANDARD_PROC, HTEqualStrategyNumber, i, InvalidOid, catclist::members, catclist::n_members, ObjectIdGetDatum(), OidIsValid, ReleaseSysCacheList, SearchSysCacheList1, and catctup::tuple.
Referenced by convert_saop_to_hashed_saop_walker(), eqjoinsel(), ExecInitHashJoin(), ExecInitMemoize(), ExecInitSubPlan(), and execTuplesHashPrepare().
Definition at line 673 of file lsyscache.c.
References IndexAmRoutine::amcanorder, OpIndexInterpretation::cmptype, COMPARE_EQ, COMPARE_INVALID, COMPARE_NE, get_negator(), get_opmethod_canorder(), GetIndexAmRoutineByAmId(), GETSTRUCT(), i, IndexAmTranslateStrategy(), lappend(), catclist::members, catclist::n_members, NIL, ObjectIdGetDatum(), OidIsValid, OpIndexInterpretation::opfamily_id, OpIndexInterpretation::oplefttype, OpIndexInterpretation::oprighttype, palloc_object, ReleaseSysCacheList, SearchSysCacheList1, and catctup::tuple.
Referenced by find_window_run_conditions(), lookup_proof_cache(), and make_row_comparison_op().
| void get_op_opfamily_properties | ( | Oid | opno, |
| Oid | opfamily, | ||
| bool | ordering_op, | ||
| int * | strategy, | ||
| Oid * | lefttype, | ||
| Oid * | righttype | ||
| ) |
Definition at line 138 of file lsyscache.c.
References CharGetDatum(), elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache3().
Referenced by ExecIndexBuildScanKeys(), ExecInitExprRec(), expand_indexqual_rowcompare(), gen_prune_steps_from_opexps(), gincost_pattern(), match_clause_to_partition_key(), mergejoinscansel(), and MJExamineQuals().
Definition at line 110 of file lsyscache.c.
References CharGetDatum(), GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache3().
Referenced by match_clause_to_ordering_op().
Definition at line 85 of file lsyscache.c.
References CharGetDatum(), GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache3().
Referenced by btcostestimate(), ComputeIndexAttrs(), expand_indexqual_rowcompare(), get_actual_variable_range(), match_rowcompare_to_indexcol(), and RelationGetExclusionInfo().
Definition at line 1498 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by gistvalidate(), spgproperty(), and spgvalidate().
Definition at line 1307 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by build_replindex_scan_key(), ComputeIndexAttrs(), infer_collation_opclass_match(), IsIndexUsableForReplicaIdentityFull(), load_rangetype_info(), and lookup_type_cache().
Definition at line 1329 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by btadjustmembers(), build_replindex_scan_key(), CheckIndexCompatible(), findRangeSubOpclass(), get_rule_expr(), hashadjustmembers(), infer_collation_opclass_match(), load_rangetype_info(), and lookup_type_cache().
Definition at line 1377 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by GetOperatorFromCompareType().
Definition at line 1352 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by DefineIndex(), FindFKPeriodOpers(), GetOperatorFromCompareType(), gistproperty(), and spgproperty().
| RegProcedure get_opcode | ( | Oid | opno | ) |
Definition at line 1450 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by _bt_compare_scankey_args(), _bt_find_extreme_element(), _bt_preprocess_array_keys(), _bt_skiparray_strat_decrement(), _bt_skiparray_strat_increment(), AlterOpFamilyAdd(), build_pertrans_for_aggref(), build_replindex_scan_key(), BuildSpeculativeIndexInfo(), check_functions_in_node(), ComputeIndexAttrs(), contain_leaked_vars_walker(), convert_saop_to_hashed_saop_walker(), cost_qual_eval_walker(), DefineOpClass(), eqjoinsel(), ExecInitMemoize(), ExecInitSubPlan(), execTuplesHashPrepare(), execTuplesMatchPrepare(), generic_restriction_selectivity(), get_expr_result_type(), get_variable_range(), inclusion_get_strategy_procinfo(), inet_mcv_join_sel(), lookup_type_cache(), make_partition_op_expr(), make_SAOP_expr(), match_pattern_prefix(), mcv_get_match_bitmap(), minmax_get_strategy_procinfo(), minmax_multi_get_strategy_procinfo(), mode_final(), networkjoinsel_semi(), networksel(), op_strict(), op_volatile(), OperatorLookup(), patternsel_common(), prefix_selectivity(), preparePresortedCols(), RelationGetExclusionInfo(), ri_HashCompareOp(), scalarineqsel(), select_equality_operator(), set_opfuncid(), set_sa_opfuncid(), statext_is_compatible_clause_internal(), std_typanalyze(), and var_eq_const().
Definition at line 168 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, Int16GetDatum(), InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache4().
Referenced by _bt_compare_scankey_args(), _bt_find_extreme_element(), _bt_num_array_keys(), _bt_skiparray_strat_decrement(), _bt_skiparray_strat_increment(), ATAddForeignKeyConstraint(), btcost_correlation(), build_bound_expr(), build_replindex_scan_key(), BuildSpeculativeIndexInfo(), DefineIndex(), expand_indexqual_rowcompare(), get_compatible_hash_operators(), get_opfamily_member_for_cmptype(), get_partition_operator(), GetOperatorFromCompareType(), have_partkey_equi_join(), lookup_type_cache(), and mergejoinscansel().
| Oid get_opfamily_member_for_cmptype | ( | Oid | opfamily, |
| Oid | lefttype, | ||
| Oid | righttype, | ||
| CompareType | cmptype | ||
| ) |
Definition at line 197 of file lsyscache.c.
References get_opfamily_member(), get_opfamily_method(), IndexAmTranslateCompareType(), and InvalidOid.
Referenced by appendOrderByClause(), create_indexscan_plan(), DefineIndex(), find_window_run_conditions(), get_eclass_for_sortgroupclause(), get_equality_op_for_ordering_op(), get_ordering_op_for_equality_op(), get_relation_info(), lookup_proof_cache(), make_pathkey_from_sortinfo(), make_unique_from_pathkeys(), match_network_subset(), prepare_sort_from_pathkeys(), refresh_by_match_merge(), and select_equality_operator().
Definition at line 1401 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by DefineIndex(), get_opfamily_member_for_cmptype(), mergejoinscansel(), and MJExamineQuals().
| char * get_opfamily_name | ( | Oid | opfid, |
| bool | missing_ok | ||
| ) |
Definition at line 1418 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, NameStr, ObjectIdGetDatum(), pstrdup(), ReleaseSysCache(), and SearchSysCache1().
Referenced by ATAddForeignKeyConstraint(), blvalidate(), brinvalidate(), btvalidate(), ComputeIndexAttrs(), DefineIndex(), GetOperatorFromCompareType(), ginvalidate(), gistvalidate(), hashvalidate(), and spgvalidate().
Definition at line 887 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, Int16GetDatum(), InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache4().
Referenced by _bt_allequalimage(), _bt_first(), _bt_merge_arrays(), _bt_saoparray_shrink(), _bt_setup_array_cmp(), _hash_datum2hashkey_type(), create_grouping_expr_infos(), ExecIndexBuildScanKeys(), ExecInitExprRec(), FinishSortSupportFunction(), get_op_hash_functions(), gincost_pattern(), gisttranslatecmptype(), gistvalidate(), init_grouping_targets(), load_rangetype_info(), lookup_type_cache(), match_clause_to_partition_key(), MJExamineQuals(), PrepareSkipSupportFromOpclass(), PrepareSortSupportFromGistIndexRel(), and RelationBuildPartitionKey().
|
static |
Definition at line 221 of file lsyscache.c.
References IndexAmRoutine::amcanorder, GetIndexAmRoutineByAmId(), and pfree().
Referenced by get_mergejoin_opfamilies(), get_op_index_interpretation(), get_ordering_op_for_equality_op(), and get_ordering_op_properties().
| char * get_opname | ( | Oid | opno | ) |
Definition at line 1475 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, NameStr, ObjectIdGetDatum(), pstrdup(), ReleaseSysCache(), and SearchSysCache1().
Referenced by AlterOpFamilyAdd(), DefineIndex(), DefineOpClass(), OperatorUpd(), print_expr(), and show_sortorder_options().
| RegProcedure get_oprjoin | ( | Oid | opno | ) |
Definition at line 1746 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by join_selectivity(), and scalararraysel().
| RegProcedure get_oprrest | ( | Oid | opno | ) |
Definition at line 1722 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by clauselist_selectivity_ext(), dependency_is_compatible_clause(), dependency_is_compatible_expression(), restriction_selectivity(), scalararraysel(), and statext_is_compatible_clause_internal().
Definition at line 369 of file lsyscache.c.
References COMPARE_EQ, COMPARE_LT, get_opfamily_member_for_cmptype(), get_opmethod_canorder(), GETSTRUCT(), i, IndexAmTranslateStrategy(), InvalidOid, catclist::members, catclist::n_members, ObjectIdGetDatum(), OidIsValid, ReleaseSysCacheList, SearchSysCacheList1, and catctup::tuple.
Referenced by create_unique_paths().
| bool get_ordering_op_properties | ( | Oid | opno, |
| Oid * | opfamily, | ||
| Oid * | opcintype, | ||
| CompareType * | cmptype | ||
| ) |
Definition at line 266 of file lsyscache.c.
References COMPARE_GT, COMPARE_INVALID, COMPARE_LT, get_opmethod_canorder(), GETSTRUCT(), i, IndexAmTranslateStrategy(), InvalidOid, catclist::members, catclist::n_members, ObjectIdGetDatum(), ReleaseSysCacheList, SearchSysCacheList1, and catctup::tuple.
Referenced by build_expression_pathkey(), get_eclass_for_sortgroupclause(), get_equality_op_for_ordering_op(), get_relation_info(), make_pathkey_from_sortop(), PrepareSortSupportFromOrderingOp(), and transformWindowDefinitions().
Definition at line 2976 of file lsyscache.c.
References get_array_type(), get_element_type(), InvalidOid, and OidIsValid.
Referenced by build_subplan(), and exprType().
| char * get_publication_name | ( | Oid | pubid, |
| bool | missing_ok | ||
| ) |
Definition at line 3810 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, NameStr, ObjectIdGetDatum(), pstrdup(), ReleaseSysCache(), and SearchSysCache1().
Referenced by getObjectDescription(), getObjectIdentityParts(), and getPublicationSchemaInfo().
| Oid get_publication_oid | ( | const char * | pubname, |
| bool | missing_ok | ||
| ) |
Definition at line 3790 of file lsyscache.c.
References CStringGetDatum(), ereport, errcode(), errmsg(), ERROR, GetSysCacheOid1, and OidIsValid.
Referenced by get_object_address_unqualified(), and GetPublicationByName().
Definition at line 3598 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by CheckAttributeType().
Definition at line 3623 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by AlterTypeOwnerInternal(), enforce_generic_type_consistency(), ExecAlterExtensionContentsRecurse(), and resolve_anymultirange_from_others().
Definition at line 3572 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by check_generic_type_consistency(), CheckAttributeType(), enforce_generic_type_consistency(), and resolve_anyelement_from_others().
| char * get_rel_name | ( | Oid | relid | ) |
Definition at line 2093 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, NameStr, ObjectIdGetDatum(), pstrdup(), ReleaseSysCache(), and SearchSysCache1().
Referenced by adjust_appendrel_attrs_mutator(), adjust_inherited_attnums(), AdjustNotNullInheritance(), AlterPublicationOptions(), AlterSubscription_refresh(), AlterSubscription_refresh_seq(), AlterTableNamespace(), ATExecAlterConstraint(), ATExecChangeOwner(), ATPrepAddPrimaryKey(), BeginCopyTo(), check_enable_rls(), check_new_partition_bound(), check_publications_origin_sequences(), check_publications_origin_tables(), cluster_is_permitted_for_relation(), convert_column_name(), CreateTriggerFiringOn(), DefineRelation(), do_autovacuum(), EnableDisableRule(), errdetail_apply_conflict(), exec_object_restorecon(), ExecCheckPermissions(), execCurrentOf(), expand_col_privileges(), explain_get_index_name(), ExplainTargetRel(), FinishSyncWorker(), get_relation_constraint_attnos(), get_relation_constraint_oid(), get_relation_name(), get_relation_policy_oid(), get_rewrite_oid(), get_trigger_oid(), gincost_pattern(), has_sequence_privilege_id(), has_sequence_privilege_id_id(), has_sequence_privilege_name_id(), heap_truncate_check_FKs(), InitializeLogRepWorker(), InsertRule(), LockTableRecurse(), LockViewRecurse_walker(), make_modifytable(), makeWholeRowVar(), map_sql_schema_to_xmlschema_types(), MarkInheritDetached(), overexplain_range_table(), perform_work_item(), pg_clear_attribute_stats(), pg_decode_change(), pg_extension_config_dump(), pg_prewarm(), pg_sequence_parameters(), postgresExplainForeignScan(), process_owned_by(), QueueNNConstraintValidation(), refuseDupeIndexAttach(), reindex_index(), reindex_relation(), ReindexMultipleInternal(), ReindexPartitions(), ReindexRelationConcurrently(), RememberClusterOnForRebuilding(), RememberReplicaIdentityForRebuilding(), RemoveSubscriptionRel(), RenameConstraintById(), renametrig(), satisfies_hash_partition(), set_rtable_names(), show_modifytable_info(), subquery_planner(), swap_relation_files(), SysCacheGetAttrNotNull(), table_to_xml_internal(), TargetPrivilegesCheck(), transformAlterTableStmt(), and verifyNotNullPKCompatible().
Definition at line 2117 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by AlterSubscription_refresh(), AlterSubscription_refresh_seq(), check_publications_origin_sequences(), check_publications_origin_tables(), do_autovacuum(), exec_object_restorecon(), ExecCheckXactReadOnly(), ExplainTargetRel(), get_rel_sync_entry(), GetTopMostAncestorInPublication(), overexplain_range_table(), perform_work_item(), pg_decode_change(), pg_get_publication_tables(), pgoutput_row_filter_init(), postgresExplainForeignScan(), reindex_relation(), ReindexMultipleInternal(), ReindexPartitions(), ReindexRelationConcurrently(), RelationBuildPublicationDesc(), sepgsql_relation_drop(), swap_relation_files(), and transformAlterTableStmt().
| char get_rel_persistence | ( | Oid | relid | ) |
Definition at line 2243 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by DefineIndex(), index_drop(), RangeVarCallbackForLockTable(), ReindexIndex(), ReindexMultipleInternal(), ReindexTable(), and set_rel_consider_parallel().
Definition at line 2265 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by DefineRelation().
| bool get_rel_relispartition | ( | Oid | relid | ) |
Definition at line 2192 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by check_rel_can_be_partition(), filter_partitions(), get_partition_qual_relid(), get_rel_sync_entry(), and index_concurrently_swap().
| char get_rel_relkind | ( | Oid | relid | ) |
Definition at line 2168 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by AlterPublicationOptions(), AlterSubscription_refresh(), AlterTableMoveAll(), AlterTypeNamespaceInternal(), AlterTypeOwner(), ATExecAlterConstrDeferrability(), ATExecAlterConstrEnforceability(), ATExecChangeOwner(), AttachPartitionForeignKey(), BeginCopyTo(), check_rel_can_be_partition(), check_relation_privileges(), CreateSubscription(), CreateTriggerFiringOn(), doDeletion(), EnableDisableRule(), exec_object_restorecon(), ExecCheckPermissions(), FetchRelationStates(), get_object_type(), get_rel_sync_entry(), get_tables_to_cluster_partitioned(), getOwnedSequences_internal(), GetPubPartitionOptionRelations(), GetSchemaPublicationRelations(), GetSubscriptionRelations(), has_sequence_privilege_id(), has_sequence_privilege_id_id(), has_sequence_privilege_id_name(), has_sequence_privilege_name(), has_sequence_privilege_name_id(), has_sequence_privilege_name_name(), HasSubscriptionTables(), LockTableCommand(), pg_get_serial_sequence(), pg_get_triggerdef_worker(), pg_partition_tree(), pg_prewarm(), ProcessSyncingTablesForApply(), ProcessUtilitySlow(), QueueFKConstraintValidation(), RangeVarCallbackForAlterRelation(), RangeVarCallbackForDblink(), RangeVarCallbackForLockTable(), RangeVarCallbackForPolicy(), RangeVarCallbackForReindexIndex(), RangeVarCallbackForRenameRule(), RangeVarCallbackForRenameTrigger(), RangeVarCallbackForStats(), RangeVarCallbackMaintainsTable(), RangeVarCallbackOwnsRelation(), RangeVarGetAndCheckCreationNamespace(), ReindexIndex(), ReindexMultipleInternal(), ReindexPartitions(), ReindexRelationConcurrently(), ReindexTable(), RelationBuildPartitionDesc(), RememberAllDependentForRebuilding(), RemoveSubscriptionRel(), renameatt_check(), RenameRelation(), RenameType(), sepgsql_attribute_drop(), sepgsql_attribute_post_create(), sepgsql_attribute_relabel(), sepgsql_attribute_setattr(), sepgsql_relation_drop(), sepgsql_relation_relabel(), sepgsql_relation_setattr(), and sepgsql_relation_truncate().
Definition at line 2219 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by DefineRelation(), pg_get_constraintdef_worker(), and pg_get_indexdef_worker().
Definition at line 2144 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by ExecAlterExtensionContentsRecurse(), get_tupdesc_for_join_scan_tuples(), makeWholeRowVar(), plpgsql_parse_cwordrowtype(), plpgsql_parse_wordrowtype(), and serialize_expr_stats().
Definition at line 2050 of file lsyscache.c.
References GetSysCacheOid2, ObjectIdGetDatum(), PointerGetDatum(), and relname.
Referenced by AlterRelationNamespaceInternal(), ATExecClusterOn(), ATExecReplicaIdentity(), cluster(), CreateTableAsRelExists(), heap_create_with_catalog(), index_create(), RangeVarGetAndCheckCreationNamespace(), RangeVarGetRelidExtended(), refnameNamespaceItem(), RelationIsVisibleExt(), RelnameGetRelid(), RenameRelationInternal(), and transformIndexConstraint().
| char * get_subscription_name | ( | Oid | subid, |
| bool | missing_ok | ||
| ) |
Definition at line 3860 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, NameStr, ObjectIdGetDatum(), pstrdup(), ReleaseSysCache(), SearchSysCache1(), and subname.
Referenced by getObjectDescription(), getObjectIdentityParts(), and RemoveSubscriptionRel().
| Oid get_subscription_oid | ( | const char * | subname, |
| bool | missing_ok | ||
| ) |
Definition at line 3840 of file lsyscache.c.
References CStringGetDatum(), ereport, errcode(), errmsg(), ERROR, GetSysCacheOid2, MyDatabaseId, ObjectIdGetDatum(), OidIsValid, and subname.
Referenced by binary_upgrade_add_sub_rel_state(), binary_upgrade_replorigin_advance(), and get_object_address_unqualified().
Definition at line 2285 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, list_member_oid(), ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache2().
Referenced by plperl_call_perl_func(), plperl_hash_from_tuple(), plperl_ref_from_pg_array(), and PLy_input_setup_func().
Definition at line 2307 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, list_member_oid(), ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache2().
Referenced by plperl_sv_to_datum(), and PLy_output_setup_func().
Definition at line 2896 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by ATPostAlterTypeCleanup(), CheckAttributeType(), find_expr_references_walker(), process_function_rte_ref(), and processIndirection().
Definition at line 2743 of file lsyscache.c.
References get_typlen(), and type_maximum_size().
Referenced by add_row_identity_var(), create_one_window_path(), find_placeholder_info(), get_agg_clause_costs(), get_expr_width(), get_rel_data_width(), set_append_rel_size(), and set_rel_width().
| bool get_typbyval | ( | Oid | typid | ) |
Definition at line 2387 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by brin_range_deserialize(), and brin_range_serialize().
Definition at line 3221 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by assign_collations_walker(), ATExecAddColumn(), DefineRange(), domainAddCheckConstraint(), fixed_paramref_hook(), get_cast_hashentry(), get_collation(), get_const_collation(), get_from_clause_coldeflist(), GetColumnDefCollation(), paramlist_param_ref(), resolve_polymorphic_tupdesc(), show_sortorder_options(), sql_fn_make_param(), transformAssignmentSubscripts(), transformJsonBehavior(), transformJsonFuncExpr(), transformRangeTableFunc(), type_is_collatable(), variable_coerce_param_hook(), and variable_paramref_hook().
Definition at line 2613 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), getTypeIOParam(), HeapTupleIsValid, makeConst(), ObjectIdGetDatum(), OidInputFunctionCall(), pfree(), ReleaseSysCache(), SearchSysCache1(), stringToNode(), SysCacheGetAttr(), TextDatumGetCString, and type.
Referenced by build_column_default().
| void get_type_category_preferred | ( | Oid | typid, |
| char * | typcategory, | ||
| bool * | typispreferred | ||
| ) |
Definition at line 2875 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by checkJsonOutputFormat(), func_select_candidate(), get_json_table_columns(), IsPreferredType(), select_common_type(), select_common_type_from_oids(), transformJsonParseArg(), transformJsonSerializeExpr(), transformJsonValueExpr(), TypeCategory(), and XmlTableGetValue().
| void get_type_io_data | ( | Oid | typid, |
| IOFuncSelector | which_func, | ||
| int16 * | typlen, | ||
| bool * | typbyval, | ||
| char * | typalign, | ||
| char * | typdelim, | ||
| Oid * | typioparam, | ||
| Oid * | func | ||
| ) |
Definition at line 2490 of file lsyscache.c.
References boot_get_type_io_data(), elog, ERROR, GETSTRUCT(), getTypeIOParam(), HeapTupleIsValid, IOFunc_input, IOFunc_output, IOFunc_receive, IOFunc_send, IsBootstrapProcessingMode, ObjectIdGetDatum(), ReleaseSysCache(), SearchSysCache1(), and typalign.
Referenced by array_in(), array_out(), array_recv(), array_send(), array_to_text_internal(), get_multirange_io_data(), get_range_io_data(), and plperl_ref_from_pg_array().
| bool get_typisdefined | ( | Oid | typid | ) |
Definition at line 2338 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by DefineRange(), DefineType(), moveArrayTypeName(), and RenameTypeInternal().
Definition at line 2362 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by array_exec_setup(), brin_range_deserialize(), brin_range_serialize(), build_sorted_items(), DefineType(), ExecBuildProjectionInfo(), ExecInitCoerceToDomain(), ExecInitExprRec(), get_typavgwidth(), pg_column_compression(), pg_column_size(), pg_column_toast_chunk_id(), and sql_compile_callback().
Definition at line 2416 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by build_pertrans_for_aggref(), calculate_frame_offsets(), copyParamList(), eqjoinsel_find_matches(), EstimateParamExecSpace(), EstimateParamListSpace(), eval_const_expressions_mutator(), evaluate_expr(), exec_eval_using_params(), exec_stmt_block(), ExecInitAgg(), ExecInitIndexScan(), ExecInitWindowAgg(), get_actual_variable_range(), get_variable_range(), initialize_peragg(), makeNullConst(), preprocess_aggref(), ReplaceVarFromTargetList(), scalararraysel(), SerializeParamExecParams(), SerializeParamList(), sql_compile_callback(), and tuplesort_begin_datum().
Definition at line 2436 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), SearchSysCache1(), and typalign.
Referenced by _bt_preprocess_array_keys(), array_create_iterator(), array_exec_setup(), array_fill_internal(), array_map(), array_position_common(), array_positions(), array_to_json_internal(), array_to_jsonb_internal(), array_unnest(), arrayconst_startup_fn(), CreateCast(), DefineRange(), ExecEvalHashedScalarArrayOp(), ExecEvalScalarArrayOp(), ExecIndexEvalArrayKeys(), ExecInitExprRec(), expand_array(), extract_variadic_args(), get_text_array_contents(), ginarrayextract(), gincost_scalararrayopexpr(), ginqueryarrayextract(), initArrayResultWithSize(), make_SAOP_expr(), map_sql_value_to_xml_value(), match_clause_to_partition_key(), mcv_get_match_bitmap(), ordered_set_startup(), RelationBuildPartitionKey(), satisfies_hash_partition(), scalararraysel(), text_format(), and trim_array().
Definition at line 3171 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
| char get_typstorage | ( | Oid | typid | ) |
Definition at line 2584 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by GetAttributeStorage().
| RegProcedure get_typsubscript | ( | Oid | typid, |
| Oid * | typelemp | ||
| ) |
Definition at line 3262 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, InvalidOid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by exec_check_rw_parameter(), and getSubscriptingRoutines().
| char get_typtype | ( | Oid | typid | ) |
Definition at line 2794 of file lsyscache.c.
References GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by AlterTypeNamespace(), check_sql_stmt_retval(), CheckAttributeType(), CreateCast(), CreateTransform(), DefineAggregate(), DefineRange(), DefineType(), ExecInitJsonExpr(), fmgr_sql_validator(), get_rels_with_domain(), get_type_func_class(), isCompositeType(), map_sql_type_to_xmlschema_type(), plperl_validator(), plpgsql_validator(), prepare_column_cache(), transformJsonFuncExpr(), transformJsonOutput(), type_is_enum(), type_is_multirange(), type_is_range(), and type_is_rowtype().
Definition at line 2686 of file lsyscache.c.
References getBaseTypeAndTypmod().
Referenced by ATAddForeignKeyConstraint(), ATPostAlterTypeCleanup(), binary_oper_exact(), check_generic_type_consistency(), CheckAttributeType(), coerce_type(), enforce_generic_type_consistency(), ExecInitJsonCoercion(), find_coercion_pathway(), find_expr_references_walker(), func_select_candidate(), get_type_func_class(), GetDefaultOpClass(), GetIndexInputType(), IsBinaryCoercibleWithCast(), isCompositeType(), json_categorize_type(), logicalrep_write_typ(), map_sql_typecoll_to_xmlschema_types(), map_sql_value_to_xml_value(), multirange_typanalyze(), PLy_output_setup_func(), range_typanalyze(), resolve_anyelement_from_others(), resolve_anymultirange_from_others(), resolve_anyrange_from_others(), select_common_type(), select_common_type_from_oids(), transformJsonBehavior(), and type_is_rowtype().
Definition at line 2703 of file lsyscache.c.
References Assert(), elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by ATExecAddColumn(), build_coercion_expression(), cache_record_field_properties(), coerce_null_to_domain(), coerce_record_to_complex(), coerce_type(), expand_insert_targetlist(), getBaseType(), lookup_type_cache(), map_sql_type_to_xmlschema_type(), prepare_column_cache(), SendRowDescriptionMessage(), transformAssignmentIndirection(), transformContainerType(), and transformTypeCast().
| const struct SubscriptRoutines * getSubscriptingRoutines | ( | Oid | typid, |
| Oid * | typelemp | ||
| ) |
Definition at line 3295 of file lsyscache.c.
References DatumGetPointer(), get_typsubscript(), OidFunctionCall0, and OidIsValid.
Referenced by contain_leaked_vars_walker(), contain_nonstrict_functions_walker(), ExecInitSubscriptingRef(), and transformContainerSubscripts().
Definition at line 3105 of file lsyscache.c.
References elog, ereport, errcode(), errmsg(), ERROR, format_type_be(), GETSTRUCT(), getTypeIOParam(), HeapTupleIsValid, ObjectIdGetDatum(), OidIsValid, ReleaseSysCache(), SearchSysCache1(), and type.
Referenced by array_agg_deserialize(), CopyFromBinaryInFunc(), domain_state_setup(), exec_bind_message(), parse_fcall_arguments(), record_recv(), slot_modify_data(), and slot_store_data().
Definition at line 3138 of file lsyscache.c.
References elog, ereport, errcode(), errmsg(), ERROR, format_type_be(), GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), OidIsValid, ReleaseSysCache(), SearchSysCache1(), and type.
Referenced by array_agg_serialize(), CopyToBinaryOutFunc(), printtup_prepare_info(), record_send(), SendFunctionResult(), and serialize_prepare_info().
Definition at line 3039 of file lsyscache.c.
References elog, ereport, errcode(), errmsg(), ERROR, format_type_be(), GETSTRUCT(), getTypeIOParam(), HeapTupleIsValid, ObjectIdGetDatum(), OidIsValid, ReleaseSysCache(), SearchSysCache1(), and type.
Referenced by _sv_to_datum_finfo(), check_functions_in_node(), CopyFromTextLikeInFunc(), cost_qual_eval_walker(), DefineAggregate(), domain_state_setup(), eval_const_expressions_mutator(), exec_bind_message(), ExecInitExprRec(), ExecInitJsonExpr(), ExecInitTableFuncScan(), GetAggInitVal(), hstore_populate_record(), parse_fcall_arguments(), pg_input_is_valid_common(), plperl_spi_prepare(), pltcl_SPI_prepare(), PLy_output_setup_func(), prepare_column_cache(), record_in(), slot_modify_data(), slot_store_data(), and TupleDescGetAttInMetadata().
Definition at line 2468 of file lsyscache.c.
References GETSTRUCT(), and OidIsValid.
Referenced by compile_plperl_function(), compile_pltcl_function(), get_typdefault(), get_type_io_data(), getTypeBinaryInputInfo(), getTypeInputInfo(), plsample_func_handler(), and stringTypeDatum().
Definition at line 3072 of file lsyscache.c.
References elog, ereport, errcode(), errmsg(), ERROR, format_type_be(), GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), OidIsValid, ReleaseSysCache(), SearchSysCache1(), and type.
Referenced by brin_minmax_multi_summary_out(), brin_page_items(), build_concat_foutcache(), BuildIndexValueDescription(), BuildParamLogString(), check_functions_in_node(), convert_value_to_string(), CopyToTextLikeOutFunc(), cost_qual_eval_walker(), create_foreign_modify(), debugtup(), deparseConst(), eval_const_expressions_mutator(), ExecBuildSlotPartitionKeyDescription(), ExecBuildSlotValueDescription(), ExecInitExprRec(), get_const_expr(), gist_page_items(), hstore_from_record(), json_categorize_type(), map_sql_value_to_xml_value(), pg_stats_ext_mcvlist_items(), plperl_hash_from_tuple(), plperl_sv_to_literal(), pltcl_build_tuple_argument(), pltcl_set_tuple_values(), PLy_input_setup_func(), prepare_query_params(), print_expr(), printtup_prepare_info(), record_out(), ri_ReportViolation(), SendFunctionResult(), serialize_prepare_info(), set_limit(), SPI_getvalue(), text_format(), and tuple_to_stringinfo().
Definition at line 1602 of file lsyscache.c.
References GETSTRUCT(), TypeCacheEntry::hash_proc, HeapTupleIsValid, lookup_type_cache(), ObjectIdGetDatum(), ReleaseSysCache(), SearchSysCache1(), and TYPECACHE_HASH_PROC.
Referenced by addTargetToSortList(), check_hashjoinable(), compute_semijoin_info(), generate_join_implied_equalities_normal(), and hash_ok_operator().
Definition at line 68 of file lsyscache.c.
References CharGetDatum(), ObjectIdGetDatum(), and SearchSysCacheExists3.
Referenced by comparison_ops_are_compatible(), equality_ops_are_compatible(), have_partkey_equi_join(), IsBooleanOpfamily(), match_clause_to_partition_key(), match_opclause_to_indexcol(), match_orclause_to_indexcol(), match_pattern_prefix(), and match_saopclause_to_indexcol().
Definition at line 1523 of file lsyscache.c.
References elog, ERROR, GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), and SearchSysCache1().
Referenced by CheckIndexCompatible(), initialize_mergeclause_eclasses(), process_equivalence(), reconsider_full_join_clause(), reconsider_outer_join_clause(), ri_HashCompareOp(), and typeDepNeeded().
Definition at line 1551 of file lsyscache.c.
References TypeCacheEntry::cmp_proc, GETSTRUCT(), HeapTupleIsValid, lookup_type_cache(), ObjectIdGetDatum(), ReleaseSysCache(), SearchSysCache1(), and TYPECACHE_CMP_PROC.
Referenced by check_mergejoinable(), and compute_semijoin_info().
| bool op_strict | ( | Oid | opno | ) |
Definition at line 1642 of file lsyscache.c.
References elog, ERROR, func_strict(), get_opcode(), and InvalidOid.
Referenced by clause_is_strict_for(), ExecInitHashJoin(), have_partkey_equi_join(), match_clause_to_partition_key(), and operator_predicate_proof().
| char op_volatile | ( | Oid | opno | ) |
Definition at line 1658 of file lsyscache.c.
References elog, ERROR, func_volatile(), get_opcode(), and InvalidOid.
Referenced by lookup_proof_cache(), and match_clause_to_partition_key().
| bool type_is_collatable | ( | Oid | typid | ) |
Definition at line 3246 of file lsyscache.c.
References get_typcollation(), and OidIsValid.
Referenced by CheckAttributeType(), coerce_to_target_type(), coerce_type(), ComputeIndexAttrs(), ComputePartitionAttrs(), create_ctas_nodata(), DefineRange(), DefineVirtualRelation(), intorel_startup(), pg_collation_for(), and transformCollateClause().
| bool type_is_enum | ( | Oid | typid | ) |
Definition at line 2843 of file lsyscache.c.
References get_typtype().
Referenced by check_generic_type_consistency(), enforce_generic_type_consistency(), and IsBinaryCoercibleWithCast().
| bool type_is_multirange | ( | Oid | typid | ) |
Definition at line 2863 of file lsyscache.c.
References get_typtype().
Referenced by get_attr_stat_type(), IsBinaryCoercibleWithCast(), multirange_agg_transfn(), multirange_intersect_agg_transfn(), and transformIndexConstraint().
| bool type_is_range | ( | Oid | typid | ) |
Definition at line 2853 of file lsyscache.c.
References get_typtype().
Referenced by ExecAlterExtensionContentsRecurse(), IsBinaryCoercibleWithCast(), range_agg_transfn(), range_intersect_agg_transfn(), and transformIndexConstraint().
| bool type_is_rowtype | ( | Oid | typid | ) |
Definition at line 2820 of file lsyscache.c.
References get_typtype(), and getBaseType().
Referenced by build_datatype(), can_minmax_aggs(), coerce_function_result_tuple(), compile_plperl_function(), compile_pltcl_function(), deparseNullTest(), exec_assign_value(), exec_stmt_return(), exec_stmt_return_next(), ExecMakeTableFunctionResult(), get_rule_expr(), hstore_populate_record(), init_execution_state(), json_categorize_type(), makeWholeRowVar(), plperl_hash_from_tuple(), plperl_ref_from_pg_array(), plperl_sv_to_datum(), plpgsql_compile_callback(), plpgsql_exec_trigger(), and transformExprRecurse().
| get_attavgwidth_hook_type get_attavgwidth_hook = NULL |
Definition at line 55 of file lsyscache.c.
Referenced by get_attavgwidth().