PostgreSQL Source Code  git master
postgres.h File Reference
#include "c.h"
#include "utils/elog.h"
#include "utils/palloc.h"
Include dependency graph for postgres.h:

Go to the source code of this file.

Data Structures

struct  NullableDatum
 

Macros

#define FIELDNO_NULLABLE_DATUM_DATUM   0
 
#define FIELDNO_NULLABLE_DATUM_ISNULL   1
 
#define SIZEOF_DATUM   SIZEOF_VOID_P
 
#define Int64GetDatumFast(X)    (AssertVariableIsOfTypeMacro(X, int64), PointerGetDatum(&(X)))
 
#define Float8GetDatumFast(X)    (AssertVariableIsOfTypeMacro(X, double), PointerGetDatum(&(X)))
 
#define NON_EXEC_STATIC   static
 

Typedefs

typedef uintptr_t Datum
 
typedef struct NullableDatum NullableDatum
 

Functions

static bool DatumGetBool (Datum X)
 
static Datum BoolGetDatum (bool X)
 
static char DatumGetChar (Datum X)
 
static Datum CharGetDatum (char X)
 
static Datum Int8GetDatum (int8 X)
 
static uint8 DatumGetUInt8 (Datum X)
 
static Datum UInt8GetDatum (uint8 X)
 
static int16 DatumGetInt16 (Datum X)
 
static Datum Int16GetDatum (int16 X)
 
static uint16 DatumGetUInt16 (Datum X)
 
static Datum UInt16GetDatum (uint16 X)
 
static int32 DatumGetInt32 (Datum X)
 
static Datum Int32GetDatum (int32 X)
 
static uint32 DatumGetUInt32 (Datum X)
 
static Datum UInt32GetDatum (uint32 X)
 
static Oid DatumGetObjectId (Datum X)
 
static Datum ObjectIdGetDatum (Oid X)
 
static TransactionId DatumGetTransactionId (Datum X)
 
static Datum TransactionIdGetDatum (TransactionId X)
 
static Datum MultiXactIdGetDatum (MultiXactId X)
 
static CommandId DatumGetCommandId (Datum X)
 
static Datum CommandIdGetDatum (CommandId X)
 
static Pointer DatumGetPointer (Datum X)
 
static Datum PointerGetDatum (const void *X)
 
static char * DatumGetCString (Datum X)
 
static Datum CStringGetDatum (const char *X)
 
static Name DatumGetName (Datum X)
 
static Datum NameGetDatum (const NameData *X)
 
static int64 DatumGetInt64 (Datum X)
 
Datum Int64GetDatum (int64 X)
 
static uint64 DatumGetUInt64 (Datum X)
 
static Datum UInt64GetDatum (uint64 X)
 
static float4 DatumGetFloat4 (Datum X)
 
static Datum Float4GetDatum (float4 X)
 
static float8 DatumGetFloat8 (Datum X)
 
Datum Float8GetDatum (float8 X)
 

Macro Definition Documentation

◆ FIELDNO_NULLABLE_DATUM_DATUM

#define FIELDNO_NULLABLE_DATUM_DATUM   0

Definition at line 74 of file postgres.h.

◆ FIELDNO_NULLABLE_DATUM_ISNULL

#define FIELDNO_NULLABLE_DATUM_ISNULL   1

Definition at line 76 of file postgres.h.

◆ Float8GetDatumFast

#define Float8GetDatumFast (   X)     (AssertVariableIsOfTypeMacro(X, double), PointerGetDatum(&(X)))

Definition at line 556 of file postgres.h.

◆ Int64GetDatumFast

#define Int64GetDatumFast (   X)     (AssertVariableIsOfTypeMacro(X, int64), PointerGetDatum(&(X)))

Definition at line 554 of file postgres.h.

◆ NON_EXEC_STATIC

#define NON_EXEC_STATIC   static

Definition at line 576 of file postgres.h.

◆ SIZEOF_DATUM

#define SIZEOF_DATUM   SIZEOF_VOID_P

Definition at line 81 of file postgres.h.

Typedef Documentation

◆ Datum

typedef uintptr_t Datum

Definition at line 64 of file postgres.h.

◆ NullableDatum

typedef struct NullableDatum NullableDatum

Function Documentation

◆ BoolGetDatum()

static Datum BoolGetDatum ( bool  X)
inlinestatic

Definition at line 102 of file postgres.h.

103 {
104  return (Datum) (X ? 1 : 0);
105 }
uintptr_t Datum
Definition: postgres.h:64

Referenced by aclexplode(), add_security_quals(), add_with_check_options(), AddRoleMems(), AggregateCreate(), AlterDatabase(), AlterOperator(), AlterPublicationOptions(), AlterRole(), AlterSubscription(), ApplyExtensionUpdates(), boolvarsel(), brin_inclusion_add_value(), brin_inclusion_union(), brin_page_items(), brincostestimate(), bt_page_print_tuples(), btcostestimate(), build_coercion_expression(), CollationCreate(), ConversionCreate(), CreateConstraintEntry(), CreateConversionCommand(), createdb(), CreatePolicy(), CreateProceduralLanguage(), CreatePublication(), CreateRole(), CreateSubscription(), CreateTriggerFiringOn(), DefineOpClass(), DefineSequence(), DelRoleMems(), DisableSubscription(), eval_const_expressions_mutator(), examine_simple_variable(), examine_variable(), exec_set_found(), ExecEvalHashedScalarArrayOp(), ExecEvalJsonIsPredicate(), ExecEvalRowNullInt(), ExecEvalScalarArrayOp(), ExecEvalXmlExpr(), ExecHashBuildSkewHash(), ExecHashSubPlan(), ExecInterpExpr(), ExecScanSubPlan(), ExecSetParamPlan(), gbt_num_fetch(), get_attavgwidth(), get_available_versions_for_extension(), get_relation_statistics_worker(), get_tables_to_cluster(), GetAllTablesPublications(), gist_page_items(), gist_page_items_bytea(), hash_bitmap_info(), in_range_date_interval(), InsertExtensionTuple(), InsertPgAttributeTuples(), InsertPgClassTuple(), InsertRule(), jsonb_populate_record_valid(), JsonbHashScalarValueExtended(), leftmostvalue_bool(), make_const(), makeBoolConst(), OperatorCreate(), OperatorShellMake(), perform_base_backup(), perform_default_encoding_conversion(), pg_buffercache_pages(), pg_control_checkpoint(), pg_control_init(), pg_control_recovery(), pg_cursor(), pg_do_encoding_conversion(), pg_do_encoding_conversion_buf(), pg_event_trigger_ddl_commands(), pg_event_trigger_dropped_objects(), pg_get_catalog_foreign_keys(), pg_get_replication_slots(), pg_lock_status(), pg_partition_tree(), pg_prepared_statement(), pg_sequence_parameters(), pg_stat_file(), pg_stat_get_activity(), pg_stat_get_backend_subxact(), pg_stat_statements_internal(), pg_stats_ext_mcvlist_items(), pg_timezone_abbrevs(), pg_unicode_to_server(), pg_unicode_to_server_noerror(), pg_visibility(), pg_visibility_map(), pg_visibility_map_rel(), pg_visibility_rel(), pg_wal_summary_contents(), PLyObject_ToBool(), postgres_fdw_get_connections(), ProcedureCreate(), RelationClearMissing(), RemoveStatisticsDataById(), ri_AttributesEqual(), serialize_expr_stats(), SetAttrMissing(), show_all_file_settings(), ssl_extension_info(), statext_dependencies_load(), statext_expressions_load(), statext_mcv_load(), statext_ndistinct_load(), statext_store(), StoreSingleInheritance(), test_predtest(), TypeCreate(), TypeShellMake(), update_attstats(), update_frameheadpos(), update_frametailpos(), and UpdateIndexRelation().

◆ CharGetDatum()

◆ CommandIdGetDatum()

static Datum CommandIdGetDatum ( CommandId  X)
inlinestatic

Definition at line 302 of file postgres.h.

303 {
304  return (Datum) X;
305 }

Referenced by heap_getsysattr().

◆ CStringGetDatum()

static Datum CStringGetDatum ( const char *  X)
inlinestatic

Definition at line 350 of file postgres.h.

351 {
352  return PointerGetDatum(X);
353 }
static Datum PointerGetDatum(const void *X)
Definition: postgres.h:322

References PointerGetDatum().

Referenced by AddEnumLabel(), AfterTriggerSetState(), AlterDatabase(), AlterDatabaseOwner(), AlterDatabaseRefreshColl(), AlterDomainDropConstraint(), AlterDomainValidateConstraint(), AlterEventTrigger(), AlterEventTriggerOwner(), AlterForeignDataWrapper(), AlterForeignDataWrapperOwner(), AlterForeignServer(), AlterForeignServerOwner(), AlterObjectRename_internal(), AlterOpFamily(), AlterPolicy(), AlterPublication(), AlterPublicationOwner(), AlterRole(), AlterSchemaOwner(), AlterSubscription(), AlterSubscriptionOwner(), AlterTableSpaceOptions(), ATExecAlterConstraint(), ATExecAttachPartition(), ATExecDropConstraint(), ATExecValidateConstraint(), check_timezone(), ChooseConstraintName(), ConstraintNameExists(), ConstraintNameIsUsed(), convert_column_name(), convert_function_name(), convert_requires_to_datum(), convert_type_name(), CreateAccessMethod(), CreateConversionCommand(), createdb(), CreateEventTrigger(), CreateForeignDataWrapper(), CreateForeignServer(), CreateOpFamily(), CreatePolicy(), CreatePublication(), CreateRole(), CreateStatistics(), CreateSubscription(), CreateTableSpace(), CreateTriggerFiringOn(), current_schema(), current_schemas(), current_user(), datum_to_jsonb_internal(), defGetInt64(), defGetObjectId(), DefineCompositeType(), DefineDomain(), DefineEnum(), DefineOpClass(), DefineRange(), DefineType(), DirectInputFunctionCallSafe(), dropconstraint_internal(), DropSubscription(), DropTableSpace(), EnableDisableTrigger(), enum_in(), enum_recv(), ExecAlterExtensionStmt(), executeItemOptUnwrapTarget(), extract_date(), flatten_set_variable_args(), FuncnameGetCandidates(), get_am_type_oid(), get_available_versions_for_extension(), get_database_oid(), get_db_info(), get_domain_constraint_oid(), get_event_trigger_oid(), get_extension_oid(), get_foreign_data_wrapper_oid(), get_foreign_server_oid(), get_language_oid(), get_namespace_oid(), get_object_address_defacl(), get_object_address_usermapping(), get_publication_oid(), get_relation_constraint_attnos(), get_relation_constraint_oid(), get_relation_policy_oid(), get_role_oid(), get_rolespec_tuple(), get_subscription_oid(), get_tablespace_oid(), get_trigger_oid(), getdatabaseencoding(), GetDatabaseTuple(), heap_create_with_catalog(), hstore_to_jsonb_loose(), inet_client_port(), inet_server_port(), InputFunctionCall(), InputFunctionCallSafe(), InsertExtensionTuple(), interval_part_common(), IsThereCollationInNamespace(), IsThereFunctionInNamespace(), IsThereOpClassInNamespace(), IsThereOpFamilyInNamespace(), jsonb_set_lax(), leftmostvalue_bit(), leftmostvalue_inet(), leftmostvalue_varbit(), libpqrcv_create_slot(), make_const(), make_tuple_from_result_row(), makeArrayTypeName(), makeMultirangeTypeName(), MergeWithExistingConstraint(), moddatetime(), movedb(), NameGetDatum(), numeric_float4(), numeric_float8(), numeric_to_number(), OpernameGetCandidates(), OpernameGetOprid(), parse_subscription_options(), perform_default_encoding_conversion(), pg_available_extensions(), pg_client_encoding(), pg_convert_from(), pg_convert_to(), pg_do_encoding_conversion(), pg_do_encoding_conversion_buf(), PG_encoding_to_char(), pg_get_catalog_foreign_keys(), pg_get_viewdef_worker(), pg_lsn_mi(), pg_lsn_mii(), pg_lsn_pli(), pg_size_bytes(), pg_split_walfile_name(), pg_stat_get_activity(), pg_stat_get_backend_client_addr(), pg_stat_get_backend_client_port(), pg_stat_get_wal(), pg_stat_statements_internal(), pg_unicode_to_server(), pg_unicode_to_server_noerror(), pgarch_readyXlog(), plperl_sv_to_literal(), plpgsql_fulfill_promise(), PLyNumber_ToJsonbValue(), rename_policy(), RenameRole(), RenameSchema(), RenameTableSpace(), RenameTypeInternal(), SearchSysCacheAttName(), session_user(), SetAttrMissing(), ssl_client_serial(), string_to_datum(), SV_to_JsonbValue(), test_resowner_forget_between_phases(), test_resowner_leak(), test_resowner_priorities(), test_resowner_remember_between_phases(), timestamp_part_common(), timestamptz_part_common(), TypeCreate(), typenameTypeMod(), uuid_generate_internal(), and validateRecoveryParameters().

◆ DatumGetBool()

static bool DatumGetBool ( Datum  X)
inlinestatic

Definition at line 90 of file postgres.h.

91 {
92  return (X != 0);
93 }

Referenced by _bt_allequalimage(), _bt_checkkeys(), _bt_compare_scankey_args(), _bt_find_extreme_element(), _hash_checkqual(), _int_different(), abs_interval(), add_values_to_range(), advance_windowaggregate(), advance_windowaggregate_base(), apply_child_basequals(), array_contain_compare(), array_eq(), array_iterator(), array_ne(), array_position_common(), array_positions(), array_replace_internal(), AssertCheckExpandedRanges(), AssertCheckRanges(), booltestsel(), brin_inclusion_add_value(), brin_inclusion_consistent(), brin_inclusion_union(), brin_minmax_add_value(), brin_minmax_consistent(), brin_minmax_multi_consistent(), brin_minmax_multi_distance_numeric(), brin_minmax_multi_distance_uuid(), bringetbitmap(), check_constant_qual(), clause_selectivity_ext(), compare_expanded_ranges(), compare_values(), CompareOpclassOptions(), compute_distinct_stats(), convert_numeric_to_scalar(), datum_to_json_internal(), datum_to_jsonb_internal(), directBoolConsistentFn(), do_pg_abort_backup(), do_pg_backup_start(), eqjoinsel_inner(), eqjoinsel_semi(), equalsJsonbScalarValue(), eval_const_expressions_mutator(), examine_attribute(), examine_expression(), exec_eval_boolean(), ExecCheck(), ExecEvalConstraintCheck(), ExecEvalPreOrderedDistinctSingle(), ExecEvalScalarArrayOp(), ExecEvalXmlExpr(), ExecInterpExpr(), ExecQual(), ExecScanSubPlan(), execTuplesUnequal(), fetch_remote_table_info(), find_duplicate_ors(), gbt_biteq(), gbt_bitge(), gbt_bitgt(), gbt_bitle(), gbt_bitlt(), gbt_bpchareq(), gbt_bpcharge(), gbt_bpchargt(), gbt_bpcharle(), gbt_bpcharlt(), gbt_byteaeq(), gbt_byteage(), gbt_byteagt(), gbt_byteale(), gbt_bytealt(), gbt_dateeq(), gbt_datege(), gbt_dategt(), gbt_datele(), gbt_datelt(), gbt_enumge(), gbt_enumgt(), gbt_enumle(), gbt_enumlt(), gbt_intveq(), gbt_intvge(), gbt_intvgt(), gbt_intvle(), gbt_intvlt(), gbt_macad8eq(), gbt_macad8ge(), gbt_macad8gt(), gbt_macad8le(), gbt_macad8lt(), gbt_macadeq(), gbt_macadge(), gbt_macadgt(), gbt_macadle(), gbt_macadlt(), gbt_num_compress(), gbt_numeric_eq(), gbt_numeric_ge(), gbt_numeric_gt(), gbt_numeric_le(), gbt_numeric_lt(), gbt_texteq(), gbt_textge(), gbt_textgt(), gbt_textle(), gbt_textlt(), gbt_timeeq(), gbt_timege(), gbt_timegt(), gbt_timele(), gbt_timelt(), gbt_tseq(), gbt_tsge(), gbt_tsgt(), gbt_tsle(), gbt_tslt(), gen_partprune_steps_internal(), get_qual_for_range(), get_rule_expr(), get_stats_slot_range(), get_with_clause(), gist_box_leaf_consistent(), gist_point_consistent(), gistindex_keytest(), gseg_internal_consistent(), has_matching_range(), HeapKeyTest(), histogram_selectivity(), index_recheck_constraint(), ineq_histogram_selectivity(), inet_mcv_join_sel(), inet_semi_join_sel(), interpt_pp(), isCurrentGroup(), lt_q_regex(), ltree_consistent(), make_ands_implicit(), make_greater_string(), make_ruledef(), make_viewdef(), map_sql_value_to_xml_value(), mcv_get_match_bitmap(), mcv_selectivity(), merge_overlapping_ranges(), mode_final(), negate_clause(), numeric_half_rounded(), numeric_is_less(), oidvectoreqfast(), operator_predicate_proof(), pgoutput_row_filter_exec_expr(), PLyBool_FromBool(), predicate_implied_by_simple_clause(), process_implied_equality(), process_ordered_aggregate_single(), range_contains_value(), range_union_internal(), record_eq(), record_image_ne(), record_ne(), register_persistent_abort_backup_handler(), relation_excluded_by_constraints(), restriction_is_constant_false(), ri_AttributesEqual(), rinfo_is_constant_true(), rtree_internal_consistent(), saop_hash_element_match(), simplify_and_arguments(), simplify_boolean_equality(), simplify_or_arguments(), spg_box_quad_leaf_consistent(), spg_quad_inner_consistent(), spg_text_leaf_consistent(), spgLeafTest(), synchronize_slots(), test_predtest(), text_isequal(), texteqfast(), ts_match_tq(), ts_match_tt(), tuples_equal(), update_frameheadpos(), update_frametailpos(), validate_remote_info(), validateDomainConstraint(), and var_eq_const().

◆ DatumGetChar()

static char DatumGetChar ( Datum  X)
inlinestatic

◆ DatumGetCommandId()

static CommandId DatumGetCommandId ( Datum  X)
inlinestatic

Definition at line 292 of file postgres.h.

293 {
294  return (CommandId) X;
295 }
uint32 CommandId
Definition: c.h:653

◆ DatumGetCString()

◆ DatumGetFloat4()

static float4 DatumGetFloat4 ( Datum  X)
inlinestatic

Definition at line 458 of file postgres.h.

459 {
460  union
461  {
462  int32 value;
463  float4 retval;
464  } myunion;
465 
466  myunion.value = DatumGetInt32(X);
467  return myunion.retval;
468 }
signed int int32
Definition: c.h:481
float float4
Definition: c.h:616
static struct @150 value
static int32 DatumGetInt32(Datum X)
Definition: postgres.h:202

References DatumGetInt32(), and value.

Referenced by bernoulli_beginsamplescan(), bernoulli_samplescangetsamplesize(), btfloat4fastcmp(), convert_numeric_to_scalar(), gbt_num_compress(), PLyFloat_FromFloat4(), similarity_dist(), similarity_op(), system_beginsamplescan(), and system_samplescangetsamplesize().

◆ DatumGetFloat8()

static float8 DatumGetFloat8 ( Datum  X)
inlinestatic

◆ DatumGetInt16()

◆ DatumGetInt32()

static int32 DatumGetInt32 ( Datum  X)
inlinestatic

Definition at line 202 of file postgres.h.

203 {
204  return (int32) X;
205 }

Referenced by _bt_check_rowcompare(), _bt_compare(), _bt_compare_array_elements(), _bt_keep_natts(), ApplyInt32SortComparator(), ApplyWorkerMain(), array_cmp(), array_subscript_check_subscripts(), autoinc(), AuxiliaryProcKill(), c_overpaid(), check_new_partition_bound(), check_toast_tuple(), cmpEntries(), collectMatchBitmap(), compare_val_int4(), compareDatetime(), compareJsonbScalarValue(), compareNumeric(), convert_numeric_to_scalar(), create_range_bounds(), CreateConversionCommand(), date_dist(), DatumGetDateADT(), DatumGetFloat4(), element_compare(), exec_eval_integer(), exec_stmt_fori(), ExecEvalMinMax(), ExecEvalXmlExpr(), ExecInterpExpr(), ExecMergeAppend(), executeItemOptUnwrapTarget(), exprIsLengthCoercion(), fetch_tuple_flag(), gather_merge_getnext(), gbt_bitcmp(), gbt_bpcharcmp(), gbt_byteacmp(), gbt_date_penalty(), gbt_datekey_cmp(), gbt_enumkey_cmp(), gbt_intvkey_cmp(), gbt_macad8key_cmp(), gbt_macadkey_cmp(), gbt_num_compress(), gbt_numeric_cmp(), gbt_textcmp(), gbt_timekey_cmp(), gbt_tskey_cmp(), gdb_date_dist(), generate_series_int4_support(), get_partition_for_tuple(), get_rule_expr(), get_windowclause_startup_tuples(), gin_btree_compare_prefix(), gin_enum_cmp(), gin_numeric_cmp(), ginCompareEntries(), heap_compare_slots(), heap_fetch_toast_slice(), hlparsetext(), hstore_eq(), hstore_ge(), hstore_gt(), hstore_le(), hstore_lt(), hstore_ne(), hypothetical_dense_rank_final(), hypothetical_rank_common(), int4eqfast(), int4hashfast(), int4range_canonical(), int8_to_char(), interval_support(), IpcMemoryDelete(), leadlag_common(), match_kind(), matchPartialInPendingList(), merge_list_bounds(), multirange_elem_bsearch_comparison(), numeric_support(), numeric_to_char(), oidvectoreq(), oidvectorge(), oidvectorgt(), oidvectorhashfast(), oidvectorle(), oidvectorlt(), oidvectorne(), overpaid(), ParallelApplyWorkerMain(), parsetext(), partition_hash_bsearch(), partition_list_bsearch(), partition_rbound_cmp(), partition_rbound_datum_cmp(), pg_do_encoding_conversion_buf(), pg_get_constraintdef_worker(), pg_unicode_to_server_noerror(), PLyLong_FromInt32(), printsimple(), prs_setup_firstcall(), qsort_partition_list_value_cmp(), range_cmp_bound_values(), range_cmp_bounds(), range_contains_elem_internal(), record_cmp(), ReorderBufferIterCompare(), ReorderBufferIterTXNNext(), ReorderBufferToastAppendChunk(), ResOwnerPrintBufferIO(), ResOwnerPrintBufferPin(), ResOwnerPrintFile(), ResOwnerReleaseBufferIO(), ResOwnerReleaseBufferPin(), ResOwnerReleaseFile(), seg_different(), seg_ge(), seg_gt(), seg_le(), seg_lt(), seg_same(), signValue(), ssup_datum_int32_cmp(), store_att_byval(), TablesyncWorkerMain(), TemporalSimplify(), test_shm_mq_main(), test_support_func(), text_format(), texthashfast(), typenameTypeMod(), varbit_support(), varchar_support(), width_bucket_array_fixed(), width_bucket_array_variable(), window_nth_value(), window_ntile(), and worker_spi_main().

◆ DatumGetInt64()

◆ DatumGetName()

◆ DatumGetObjectId()

◆ DatumGetPointer()

static Pointer DatumGetPointer ( Datum  X)
inlinestatic

Definition at line 312 of file postgres.h.

313 {
314  return (Pointer) X;
315 }
char * Pointer
Definition: c.h:470

Referenced by _bt_check_rowcompare(), _bt_end_vacuum_callback(), _bt_first(), _bt_fix_scankey_strategy(), _bt_mark_scankey_required(), _ltree_compress(), _ltree_consistent(), _ltree_penalty(), accumArrayResultArr(), add_function_cost(), advance_transition_function(), advance_windowaggregate(), advance_windowaggregate_base(), AlterForeignDataWrapper(), AlterForeignServer(), AlterUserMapping(), apply_returning_filter(), array_get_element(), array_get_slice(), array_set_element(), array_set_element_expanded(), ArrayCastAndSet(), assign_simple_var(), ATExecAlterColumnGenericOptions(), ATExecGenericOptions(), brin_build_desc(), brin_form_tuple(), brin_inclusion_add_value(), brin_inclusion_union(), brin_minmax_add_value(), brin_minmax_multi_add_value(), brin_minmax_multi_serialize(), brin_minmax_union(), brin_range_serialize(), bt_normalize_tuple(), BufferSync(), build_replindex_scan_key(), CatCacheFreeKeys(), check_domain_for_new_field(), check_toast_tuple(), check_tuple_attribute(), CheckIndexCompatible(), cleanup_background_workers(), CleanupInvalidationState(), coerce_function_result_tuple(), collectMatchBitmap(), compileTheLexeme(), compileTheSubstitute(), compute_distinct_stats(), compute_range_stats(), compute_scalar_stats(), compute_trivial_stats(), compute_tsvector_stats(), convert_saop_to_hashed_saop_walker(), convert_string_datum(), CopyArrayEls(), CopyIndexAttOptions(), createdb_failure_callback(), CreateForeignDataWrapper(), CreateForeignServer(), CreateForeignTable(), CreateTriggerFiringOn(), CreateUserMapping(), datum_compute_size(), datum_image_eq(), datum_image_hash(), datum_write(), datumCopy(), datumEstimateSpace(), DatumGetAnyArrayP(), DatumGetBoxP(), DatumGetCircleP(), DatumGetCString(), DatumGetEOHP(), DatumGetExpandedArray(), DatumGetExpandedArrayX(), DatumGetExpandedRecord(), DatumGetFloat8(), DatumGetInt64(), DatumGetIntervalP(), DatumGetItemPointer(), DatumGetLineP(), DatumGetLsegP(), DatumGetMacaddr8P(), DatumGetMacaddrP(), DatumGetName(), DatumGetPointP(), datumGetSize(), DatumGetTimeTzADTP(), DatumGetTSQuery(), DatumGetUInt64(), DatumGetUUIDP(), datumIsEqual(), datumSerialize(), datumTransfer(), DeconstructFkConstraintRow(), DeleteExpandedObject(), do_text_output_multiline(), dsa_on_dsm_detach_release_in_place(), dsa_on_shmem_exit_release_in_place(), dsm_postmaster_shutdown(), ER_get_flat_size(), eval_windowaggregates(), EvalPlanQualFetchRowMark(), exec_assign_value(), exec_move_row_from_datum(), exec_stmt_foreach_a(), ExecAggCopyTransValue(), ExecAggPlainTransByRef(), ExecCallTriggerFunc(), execCurrentOf(), ExecEvalFieldSelect(), ExecEvalPreOrderedDistinctSingle(), ExecEvalXmlExpr(), ExecInitCteScan(), ExecInitInterpreter(), ExecLockRows(), ExecModifyTable(), ExecSetParamPlan(), execute_foreign_modify(), ExecWorkTableScan(), expand_array(), expanded_record_set_field_internal(), expanded_record_set_fields(), expanded_record_set_tuple(), extractNotNullColumn(), fill_val(), finalize_aggregates(), find_window_run_conditions(), FreeTupleDesc(), function_selectivity(), g_int_compress(), g_int_consistent(), g_int_decompress(), g_int_penalty(), g_intbig_compress(), g_intbig_consistent(), g_intbig_penalty(), gbt_bit_consistent(), gbt_bool_consistent(), gbt_bool_penalty(), gbt_bpchar_consistent(), gbt_bytea_consistent(), gbt_cash_consistent(), gbt_cash_distance(), gbt_cash_penalty(), gbt_date_consistent(), gbt_date_distance(), gbt_date_penalty(), gbt_enum_consistent(), gbt_enum_penalty(), gbt_float4_consistent(), gbt_float4_distance(), gbt_float4_penalty(), gbt_float8_consistent(), gbt_float8_distance(), gbt_float8_penalty(), gbt_inet_consistent(), gbt_inet_penalty(), gbt_int2_consistent(), gbt_int2_distance(), gbt_int2_penalty(), gbt_int4_consistent(), gbt_int4_distance(), gbt_int4_penalty(), gbt_int8_consistent(), gbt_int8_distance(), gbt_int8_penalty(), gbt_intv_compress(), gbt_intv_consistent(), gbt_intv_decompress(), gbt_intv_distance(), gbt_intv_penalty(), gbt_macad8_consistent(), gbt_macad8_penalty(), gbt_macad_consistent(), gbt_macad_penalty(), gbt_num_bin_union(), gbt_num_compress(), gbt_num_picksplit(), gbt_num_union(), gbt_numeric_consistent(), gbt_numeric_penalty(), gbt_oid_consistent(), gbt_oid_distance(), gbt_oid_penalty(), gbt_text_consistent(), gbt_time_consistent(), gbt_time_distance(), gbt_time_penalty(), gbt_timetz_consistent(), gbt_ts_consistent(), gbt_ts_distance(), gbt_ts_penalty(), gbt_tstz_consistent(), gbt_tstz_distance(), gbt_uuid_consistent(), gbt_uuid_penalty(), gbt_var_bin_union(), gbt_var_decompress(), gbt_var_penalty(), gbt_var_picksplit(), gbt_var_same(), gbt_var_union(), generateClonedIndexStmt(), get_function_rows(), get_index_clause_from_support(), get_index_column_opclass(), getDatumCopy(), GetFdwRoutine(), GetIndexAmRoutine(), getSubscriptingRoutines(), GetTableAmRoutine(), getTokenTypes(), GetTsmRoutine(), ghstore_compress(), ghstore_consistent(), ghstore_penalty(), gin_extract_hstore_query(), gin_extract_jsonb_query(), gin_extract_jsonb_query_path(), ginExtractEntries(), gistCompressValues(), gistdentryinit(), gistFetchAtt(), gtrgm_compress(), gtrgm_consistent(), gtrgm_decompress(), gtrgm_distance(), gtrgm_penalty(), gtsvector_compress(), gtsvector_consistent(), gtsvector_decompress(), gtsvector_penalty(), heap_compute_data_size(), heap_fetch_toast_slice(), HeapDetermineColumnsInfo(), hlparsetext(), hstore_slice_to_array(), hstoreUpgrade(), index_concurrently_create_copy(), index_form_tuple_context(), index_opclass_options(), index_reloptions(), index_store_float8_orderby_distances(), inet_gist_compress(), int2vectorrecv(), InvalidateTSCacheCallBack(), IpcMemoryDetach(), LexizeExec(), like_fixed_prefix(), lookup_ts_dictionary_cache(), ltree_addtext(), ltree_consistent(), ltree_penalty(), ltree_textadd(), make_array_ref(), make_greater_string(), make_tuple_from_result_row(), make_tuple_indirect(), MakeExpandedObjectReadOnlyInternal(), mcelem_tsquery_selec(), memcpyInnerDatum(), missing_match(), mode_final(), movedb_failure_callback(), numeric_abbrev_convert(), numeric_fast_cmp(), object_aclmask_ext(), oidvectorrecv(), optimize_window_clauses(), ordered_set_shutdown(), outDatum(), pa_shutdown(), ParallelWorkerShutdown(), parseRelOptions(), parseRelOptionsInternal(), parsetext(), patternsel_common(), pg_attribute_aclcheck_all_ext(), pg_attribute_aclmask_ext(), pg_class_aclmask_ext(), pg_column_compression(), pg_column_toast_chunk_id(), pg_get_indexdef_worker(), pg_get_partkeydef_worker(), pg_largeobject_aclmask_snapshot(), pg_namespace_aclmask_ext(), pg_parameter_acl_aclmask(), pg_parameter_aclmask(), pg_replication_origin_create(), pg_replication_origin_drop(), pg_replication_origin_oid(), pg_replication_origin_progress(), pg_replication_origin_session_setup(), pg_stats_ext_mcvlist_items(), pg_type_aclmask_ext(), pgwin32_SharedMemoryDelete(), plperl_call_perl_func(), plperl_hash_from_tuple(), plpgsql_exec_function(), plpgsql_exec_trigger(), plpgsql_inline_handler(), plpython3_inline_handler(), PLy_cursor_plan(), PLy_spi_execute_plan(), PLyObject_FromTransform(), populate_record_field(), PrintManyTest(), PrintString(), printtup(), ProcedureCreate(), process_ordered_aggregate_single(), prs_setup_firstcall(), prune_element_hashtable(), pushval_morph(), record_image_cmp(), refresh_by_match_merge(), RelationBuildPartitionKey(), RelationGetIndexAttOptions(), RelationInitIndexAccessInfo(), ReleaseManyTestResource(), ReleaseString(), ReorderBufferToastAppendChunk(), ReorderBufferToastReplace(), reorderqueue_pop(), ResourceOwnerForget(), ResourceOwnerReleaseAll(), ResOwnerPrintCatCache(), ResOwnerPrintCatCacheList(), ResOwnerPrintDSM(), ResOwnerPrintRelCache(), ResOwnerPrintTupleDesc(), ResOwnerReleaseCachedPlan(), ResOwnerReleaseCatCache(), ResOwnerReleaseCatCacheList(), ResOwnerReleaseCryptoHash(), ResOwnerReleaseDSM(), ResOwnerReleaseHMAC(), ResOwnerReleaseJitContext(), ResOwnerReleaseOSSLCipher(), ResOwnerReleaseOSSLDigest(), ResOwnerReleaseRelation(), ResOwnerReleaseSnapshot(), ResOwnerReleaseTupleDesc(), ResOwnerReleaseWaitEventSet(), scalarineqsel(), sepgsql_fmgr_hook(), SharedFileSetOnDetach(), shm_mq_detach_callback(), show_trgm(), ShowAllGUCConfig(), shutdown_MultiFuncCall(), ShutdownSetExpr(), ShutdownSQLFunction(), simplify_function(), slotsync_failure_callback(), spg_text_inner_consistent(), spg_text_leaf_consistent(), spgFreeSearchItem(), spgist_name_inner_consistent(), spgist_name_leaf_consistent(), statext_mcv_serialize(), StoreAttrDefault(), test_indoption(), text2ltree(), text_substring(), thesaurus_lexize(), TidListEval(), TidRangeEval(), toast_build_flattened_tuple(), toast_compress_datum(), toast_datum_size(), toast_delete_datum(), toast_flatten_tuple(), toast_flatten_tuple_to_datum(), toast_raw_datum_size(), toast_save_datum(), toast_tuple_cleanup(), toast_tuple_externalize(), toast_tuple_find_biggest_attribute(), toast_tuple_init(), toast_tuple_try_compression(), TransferExpandedObject(), transformFkeyCheckAttrs(), transformFkeyGetPrimaryKey(), transformGenericOptions(), transformIndexConstraint(), transformRelOptions(), ts_accum(), ts_lexize(), tsquery_rewrite_query(), tstoreReceiveSlot_detoast(), tsvector_update_trigger(), tt_setup_firstcall(), tts_virtual_materialize(), tuplesort_putdatum(), unaccent_dict(), untransformRelOptions(), and WalRcvDie().

◆ DatumGetTransactionId()

static TransactionId DatumGetTransactionId ( Datum  X)
inlinestatic

Definition at line 262 of file postgres.h.

263 {
264  return (TransactionId) X;
265 }
uint32 TransactionId
Definition: c.h:639

Referenced by ExecCheckTupleVisible(), ExecOnConflictUpdate(), RI_FKey_fk_upd_check_required(), and synchronize_slots().

◆ DatumGetUInt16()

static uint16 DatumGetUInt16 ( Datum  X)
inlinestatic

Definition at line 182 of file postgres.h.

183 {
184  return (uint16) X;
185 }
unsigned short uint16
Definition: c.h:492

Referenced by gintuple_get_attrnum(), and GistTranslateStratnum().

◆ DatumGetUInt32()

◆ DatumGetUInt64()

static uint64 DatumGetUInt64 ( Datum  X)
inlinestatic

◆ DatumGetUInt8()

static uint8 DatumGetUInt8 ( Datum  X)
inlinestatic

Definition at line 142 of file postgres.h.

143 {
144  return (uint8) X;
145 }
unsigned char uint8
Definition: c.h:491

◆ Float4GetDatum()

static Datum Float4GetDatum ( float4  X)
inlinestatic

Definition at line 475 of file postgres.h.

476 {
477  union
478  {
479  float4 value;
480  int32 retval;
481  } myunion;
482 
483  myunion.value = X;
484  return Int32GetDatum(myunion.retval);
485 }
static Datum Int32GetDatum(int32 X)
Definition: postgres.h:212

References Int32GetDatum(), and value.

Referenced by AddEnumLabel(), EnumValuesCreate(), gbt_num_fetch(), index_store_float8_orderby_distances(), InsertPgClassTuple(), leftmostvalue_float4(), ProcedureCreate(), serialize_expr_stats(), set_limit(), and update_attstats().

◆ Float8GetDatum()

◆ Int16GetDatum()

static Datum Int16GetDatum ( int16  X)
inlinestatic

Definition at line 172 of file postgres.h.

173 {
174  return (Datum) X;
175 }

Referenced by AggregateCreate(), AlterStatistics(), brincostestimate(), btcostestimate(), CreateConstraintEntry(), CreateTriggerFiringOn(), DeleteSystemAttributeTuples(), dropOperators(), dropProcedures(), examine_attribute(), examine_simple_variable(), examine_variable(), ExecEvalNextValueExpr(), ExecGrant_Attribute(), ExecHashBuildSkewHash(), expand_all_col_privileges(), fetch_att(), fixup_whole_row_references(), gbt_num_fetch(), get_attavgwidth(), get_attgenerated(), get_attname(), get_attoptions(), get_attribute_options(), get_atttype(), get_atttypetypmodcoll(), get_object_address_opf_member(), get_opfamily_member(), get_opfamily_proc(), get_rte_attribute_is_dropped(), GetAttrDefaultOid(), GetForeignColumnOptions(), GetWALBlockInfo(), gist_point_consistent(), gistindex_keytest(), gistproperty(), inclusion_get_strategy_procinfo(), index_check_primary_key(), index_concurrently_create_copy(), InsertPgAttributeTuples(), InsertPgClassTuple(), join_selectivity(), leftmostvalue_int2(), minmax_get_strategy_procinfo(), minmax_multi_get_strategy_procinfo(), neqjoinsel(), pg_attribute_aclcheck_all_ext(), pg_attribute_aclmask_ext(), pg_buffercache_pages(), pg_lock_status(), pg_wal_summary_contents(), plpgsql_fulfill_promise(), recordExtObjInitPriv(), RelationBuildTupleDesc(), RelationClearMissing(), RemoveAttrDefault(), RemoveAttrDefaultById(), RemoveAttributeById(), removeExtObjInitPriv(), RemoveStatistics(), scalararraysel(), scanRTEForColumn(), SearchSysCacheAttNum(), sepgsql_attribute_post_create(), serialize_expr_stats(), spg_text_choose(), spg_text_picksplit(), spgist_name_choose(), StoreAttrDefault(), storeOperators(), StorePartitionKey(), storeProcedures(), tsvector_unnest(), TypeCreate(), TypeShellMake(), update_attstats(), and UpdateIndexRelation().

◆ Int32GetDatum()

static Datum Int32GetDatum ( int32  X)
inlinestatic

Definition at line 212 of file postgres.h.

213 {
214  return (Datum) X;
215 }

Referenced by _PG_init(), AggregateCreate(), AlterDatabase(), AlterRole(), array_positions(), array_subscript_transform(), ATExecAlterColumnType(), autoinc(), bitshiftleft(), bitshiftright(), brin_metapage_info(), bringetbitmap(), bt_page_print_tuples(), build_coercion_expression(), build_regexp_match_result(), build_regexp_split_result(), build_test_match_result(), cash_numeric(), check_timezone(), CollationCreate(), compileTheLexeme(), compileTheSubstitute(), ConversionCreate(), create_hash_bounds(), CreateComments(), CreateConversionCommand(), createdb(), CreateRole(), DateADTGetDatum(), datum_to_jsonb_internal(), dblink_get_notify(), DeleteComments(), DeleteInitPrivs(), deleteOneObject(), DeleteSecurityLabel(), DirectInputFunctionCallSafe(), drop_parent_dependency(), DropConfigurationMapping(), eval_const_expressions_mutator(), exec_stmt_fori(), ExecEvalGroupingFunc(), ExecEvalNextValueExpr(), ExecInitExprRec(), ExecMergeAppend(), executeItemOptUnwrapTarget(), extract_date(), fetch_att(), fill_hba_line(), fill_ident_line(), FindDefaultConversion(), findDependentObjects(), flatten_set_variable_args(), Float4GetDatum(), gather_merge_getnext(), gather_merge_init(), gbt_num_fetch(), generate_series_step_int4(), generate_setop_tlist(), generate_subscripts(), get_index_constraint(), get_index_ref_constraints(), get_partition_parent_worker(), get_qual_for_hash(), getArrayIndex(), GetComment(), getOwnedSequences_internal(), GetSecurityLabel(), gin_extract_query_trgm(), gin_extract_value_trgm(), gin_metapage_info(), gin_page_opaque_info(), ginint4_queryextract(), gist_page_items(), gist_page_items_bytea(), gist_page_opaque_info(), hash_bitmap_info(), hash_metapage_info(), hash_page_items(), hash_page_stats(), heap_fetch_toast_slice(), hlparsetext(), hstore_to_jsonb_loose(), hypothetical_dense_rank_final(), hypothetical_rank_common(), in_range_int2_int2(), in_range_int2_int8(), in_range_int4_int2(), index_concurrently_swap(), IndexSetParentIndex(), InitAuxiliaryProcess(), InputFunctionCall(), InputFunctionCallSafe(), InsertPgAttributeTuples(), InsertPgClassTuple(), int2vectorrecv(), int4_to_char(), int4range_canonical(), InternalIpcMemoryCreate(), interval_part_common(), inv_read(), inv_truncate(), inv_write(), IsThereCollationInNamespace(), leftmostvalue_bit(), leftmostvalue_int4(), leftmostvalue_varbit(), LexizeExec(), logicalrep_worker_launch(), lookup_collation(), make_const(), MakeConfigurationMapping(), moddatetime(), network_scan_last(), numeric_to_char(), numeric_to_number(), oidvectorrecv(), ordered_set_transition_multi(), page_header(), parsetext(), perform_default_encoding_conversion(), pg_blocking_pids(), pg_buffercache_pages(), pg_buffercache_summary(), pg_control_checkpoint(), pg_control_init(), pg_control_recovery(), pg_control_system(), pg_do_encoding_conversion(), pg_do_encoding_conversion_buf(), pg_event_trigger_ddl_commands(), pg_event_trigger_dropped_objects(), pg_get_catalog_foreign_keys(), pg_get_object_address(), pg_get_replication_slots(), pg_get_serial_sequence(), pg_get_wal_summarizer_state(), pg_lock_status(), pg_lsn_mi(), pg_lsn_mii(), pg_lsn_pli(), pg_partition_tree(), pg_safe_snapshot_blocking_pids(), pg_size_bytes(), pg_split_walfile_name(), pg_stat_get_activity(), pg_stat_get_backend_idset(), pg_stat_get_backend_subxact(), pg_stat_get_progress_info(), pg_stat_get_recovery_prefetch(), pg_stat_get_subscription(), pg_stat_get_wal(), pg_stat_get_wal_receiver(), pg_stat_get_wal_senders(), pg_stat_statements_internal(), pg_stats_ext_mcvlist_items(), pg_unicode_to_server(), pg_unicode_to_server_noerror(), pgstat_reset_entries_of_kind(), pgstatginindex_internal(), pgstathashindex(), PLyNumber_ToJsonbValue(), printTypmod(), prs_setup_firstcall(), PutMemoryContextsStatsTupleStore(), ReceiveFunctionCall(), recordExtensionInitPrivWorker(), recordMultipleDependencies(), regexp_substr(), RememberAllDependentForRebuilding(), ReorderBufferIterTXNInit(), ReorderBufferIterTXNNext(), report_corruption_internal(), ResourceOwnerForgetBuffer(), ResourceOwnerForgetBufferIO(), ResourceOwnerForgetFile(), ResourceOwnerRememberBuffer(), ResourceOwnerRememberBufferIO(), ResourceOwnerRememberFile(), restriction_selectivity(), ri_AttributesEqual(), scalararraysel(), serialize_expr_stats(), SetAttrMissing(), SetSecurityLabel(), shdepAddDependency(), shdepChangeDep(), shdepDropDependency(), show_all_file_settings(), ssl_client_serial(), StoreSingleInheritance(), SV_to_JsonbValue(), test_enc_conversion(), textregexsubstr(), tfuncLoadRows(), timestamp_part_common(), timestamptz_part_common(), toast_save_datum(), ts_lexize(), tsquery_phrase(), ttdummy(), TypeCreate(), TypeShellMake(), unaccent_dict(), update_attstats(), validateRecoveryParameters(), and worker_spi_launch().

◆ Int64GetDatum()

Datum Int64GetDatum ( int64  X)

Definition at line 1807 of file fmgr.c.

1808 {
1809  int64 *retval = (int64 *) palloc(sizeof(int64));
1810 
1811  *retval = X;
1812  return PointerGetDatum(retval);
1813 }

References palloc(), and PointerGetDatum().

Referenced by brin_metapage_info(), brin_page_items(), brin_summarize_new_values(), build_minmax_path(), CashGetDatum(), create_final_distinct_paths(), create_partial_distinct_paths(), DefineSequence(), delay_execution_planner(), ExecEvalNextValueExpr(), executeItemOptUnwrapTarget(), FillXLogStatsRow(), gbt_num_fetch(), generate_series_step_int8(), GetWALBlockInfo(), gin_metapage_info(), gin_page_opaque_info(), gist_page_opaque_info(), hash_array_extended(), hash_bitmap_info(), hash_metapage_info(), hash_page_items(), hash_page_stats(), hash_record_extended(), IdentifySystem(), int4_cash(), int8_cash(), int8_to_char(), int8range_canonical(), leftmostvalue_int8(), leftmostvalue_money(), LSNGetDatum(), make_const(), perform_work_item(), pg_available_wal_summaries(), pg_buffercache_pages(), pg_control_system(), pg_get_replication_slots(), pg_get_shmem_allocations(), pg_get_wal_summarizer_state(), pg_ls_dir_files(), pg_sequence_parameters(), pg_split_walfile_name(), pg_stat_file(), pg_stat_get_archiver(), pg_stat_get_io(), pg_stat_get_progress_info(), pg_stat_get_recovery_prefetch(), pg_stat_get_replication_slot(), pg_stat_get_slru(), pg_stat_get_subscription_stats(), pg_stat_get_wal(), pg_stat_statements_info(), pg_visibility_map_rel(), pg_visibility_map_summary(), pg_visibility_rel(), pg_wal_summary_contents(), pgstatginindex_internal(), pgstathashindex(), pgstattuple_approx_internal(), PutMemoryContextsStatsTupleStore(), ReadReplicationSlot(), report_corruption_internal(), rewriteSearchAndCycle(), SendTablespaceList(), SendXlogRecPtrResult(), StartReplication(), TimeADTGetDatum(), TimestampGetDatum(), TimestampTzGetDatum(), TSQuerySignGetDatum(), UInt64GetDatum(), and validate_index_callback().

◆ Int8GetDatum()

static Datum Int8GetDatum ( int8  X)
inlinestatic

Definition at line 132 of file postgres.h.

133 {
134  return (Datum) X;
135 }

◆ MultiXactIdGetDatum()

static Datum MultiXactIdGetDatum ( MultiXactId  X)
inlinestatic

Definition at line 282 of file postgres.h.

283 {
284  return (Datum) X;
285 }

Referenced by InsertPgClassTuple().

◆ NameGetDatum()

◆ ObjectIdGetDatum()

static Datum ObjectIdGetDatum ( Oid  X)
inlinestatic

Definition at line 252 of file postgres.h.

253 {
254  return (Datum) X;
255 }

Referenced by _bt_allequalimage(), _int_contained_joinsel(), _int_contained_sel(), _int_contains_joinsel(), _int_contains_sel(), _int_overlap_joinsel(), _int_overlap_sel(), aclexplode(), aclitemout(), add_cast_to(), add_function_cost(), AddEnumLabel(), AddRoleMems(), AddSubscriptionRelState(), AfterTriggerSetState(), agg_args_support_sendreceive(), AggregateCreate(), AlterCollation(), AlterConstraintNamespaces(), AlterDatabaseOwner(), AlterDomainAddConstraint(), AlterDomainDefault(), AlterDomainDropConstraint(), AlterDomainNotNull(), AlterDomainValidateConstraint(), AlterEnum(), AlterEventTriggerOwner_oid(), AlterExtensionNamespace(), AlterForeignDataWrapper(), AlterForeignDataWrapperOwner_internal(), AlterForeignDataWrapperOwner_oid(), AlterForeignServerOwner_internal(), AlterForeignServerOwner_oid(), AlterFunction(), AlterObjectNamespace_internal(), AlterObjectOwner_internal(), AlterObjectRename_internal(), AlterOperator(), AlterPolicy(), AlterPublication(), AlterPublicationOptions(), AlterPublicationOwner_oid(), AlterPublicationSchemas(), AlterPublicationTables(), AlterRelationNamespaceInternal(), AlterRole(), AlterSchemaOwner_internal(), AlterSchemaOwner_oid(), AlterSeqNamespaces(), AlterSequence(), AlterSetting(), AlterStatistics(), AlterSubscriptionOwner_oid(), AlterTableMoveAll(), AlterTSDictionary(), AlterTypeNamespaceInternal(), AlterTypeOwner_oid(), AlterTypeOwnerInternal(), AlterTypeRecurse(), AlterUserMapping(), amvalidate(), appendFunctionName(), appendOrderBySuffix(), ApplyExtensionUpdates(), ApplySetting(), assignOperTypes(), assignProcTypes(), ATAddForeignKeyConstraint(), ATDetachCheckNoForeignKeyRefs(), ATExecAddColumn(), ATExecAddOf(), ATExecAlterColumnGenericOptions(), ATExecAlterColumnType(), ATExecAlterConstraint(), ATExecAlterConstrRecurse(), ATExecAttachPartition(), ATExecChangeOwner(), ATExecDropConstraint(), ATExecDropOf(), ATExecForceNoForceRowSecurity(), ATExecGenericOptions(), ATExecSetNotNull(), ATExecSetRelOptions(), ATExecSetRowSecurity(), ATExecValidateConstraint(), ATPostAlterTypeCleanup(), ATPrepChangePersistence(), AttrDefaultFetch(), blvalidate(), brincostestimate(), brinvalidate(), btcostestimate(), btvalidate(), build_coercion_expression(), build_regtype_array(), CacheInvalidateRelcacheByRelid(), call_pltcl_start_proc(), CallStmtResultDesc(), CastCreate(), change_owner_fix_column_acls(), change_owner_recurse_to_sequences(), changeDependenciesOf(), changeDependenciesOn(), changeDependencyFor(), check_amop_signature(), check_amproc_signature(), check_default_text_search_config(), check_enable_rls(), check_for_column_name_collision(), check_hash_func_signature(), check_object_ownership(), check_rel_can_be_partition(), check_timezone(), check_toasted_attribute(), CheckConstraintFetch(), CheckFunctionValidatorAccess(), CheckIndexCompatible(), CheckMyDatabase(), checkSharedDependencies(), ChooseConstraintName(), ChooseExtendedStatisticName(), clear_subscription_skip_lsn(), CloneFkReferenced(), CloneFkReferencing(), CloneRowTriggersToPartition(), cluster_rel(), CollationCreate(), CollationIsVisibleExt(), comparison_ops_are_compatible(), compile_plperl_function(), compile_pltcl_function(), ComputeIndexAttrs(), ConstraintNameExists(), ConstraintNameIsUsed(), ConstraintSetParentConstraint(), ConstructTupleDescriptor(), ConversionCreate(), ConversionGetConid(), ConversionIsVisibleExt(), convert_column_name(), copy_table_data(), CopyStatistics(), copyTemplateDependencies(), CountDBSubscriptions(), create_toast_table(), CreateAccessMethod(), CreateCast(), CreateComments(), CreateConstraintEntry(), createdb(), CreateForeignDataWrapper(), CreateForeignServer(), CreateForeignTable(), CreateFunction(), CreateInheritance(), CreateOpFamily(), CreatePolicy(), CreateProceduralLanguage(), CreatePublication(), CreateRole(), CreateSchemaCommand(), CreateSharedComments(), CreateStatistics(), CreateSubscription(), CreateTableSpace(), CreateTransform(), CreateTriggerFiringOn(), CreateUserMapping(), database_is_invalid_oid(), datum_to_jsonb_internal(), decompile_conbin(), DefineCollation(), DefineCompositeType(), DefineDomain(), DefineEnum(), DefineIndex(), DefineOpClass(), DefineRange(), DefineSequence(), DefineTSConfiguration(), DefineTSDictionary(), DefineTSParser(), DefineTSTemplate(), DefineType(), DeleteAttributeTuples(), DeleteComments(), deleteDependencyRecordsFor(), deleteDependencyRecordsForClass(), deleteDependencyRecordsForSpecific(), DeleteInheritsTuple(), DeleteInitPrivs(), deleteOneObject(), DeleteRelationTuple(), DeleteSecurityLabel(), DeleteSequenceTuple(), DeleteSharedComments(), DeleteSharedSecurityLabel(), DeleteSystemAttributeTuples(), DelRoleMems(), deparseOpExpr(), deparseScalarArrayOpExpr(), DetachPartitionFinalize(), DirectInputFunctionCallSafe(), DisableSubscription(), do_autovacuum(), do_compile(), do_setval(), drop_parent_dependency(), DropClonedTriggersFromPartition(), DropConfigurationMapping(), dropconstraint_internal(), dropDatabaseDependencies(), dropdb(), DropObjectById(), dropOperators(), dropProcedures(), DropRole(), DropSetting(), EnableDisableRule(), EnableDisableTrigger(), enum_cmp_internal(), enum_endpoint(), enum_in(), enum_out(), enum_range_internal(), enum_recv(), enum_send(), EnumValuesCreate(), EnumValuesDelete(), equality_ops_are_compatible(), errdatatype(), eval_const_expressions_mutator(), EventTriggerOnLogin(), examine_attribute(), examine_expression(), examine_simple_variable(), examine_variable(), exec_stmt_getdiag(), ExecGrant_Attribute(), ExecGrant_common(), ExecGrant_Largeobject(), ExecGrant_Parameter(), ExecGrant_Relation(), ExecHashBuildSkewHash(), ExecInitAgg(), ExecInitExprRec(), ExecuteCallStmt(), expand_all_col_privileges(), expand_vacuum_rel(), extension_config_remove(), extract_date(), fetch_agg_sort_op(), fetch_fp_info(), fetch_statentries_for_relation(), fillTypeDesc(), find_coercion_pathway(), find_composite_type_dependencies(), find_expr_references_walker(), find_inheritance_children_extended(), find_typed_table_dependencies(), find_typmod_coercion_function(), FindDefaultConversion(), findDependentObjects(), findNotNullConstraintAttnum(), finish_heap_swap(), fixup_whole_row_references(), flatten_reloptions(), flatten_set_variable_args(), fmgr_c_validator(), fmgr_info_cxt_security(), fmgr_info_other_lang(), fmgr_internal_validator(), fmgr_security_definer(), fmgr_sql_validator(), fmgr_symbol(), ForceTransactionIdLimitUpdate(), format_operator_extended(), format_operator_parts(), format_procedure_extended(), format_procedure_parts(), format_type_extended(), func_get_detail(), func_parallel(), func_strict(), func_volatile(), FunctionIsVisibleExt(), gbt_enumge(), gbt_enumgt(), gbt_enumkey_cmp(), gbt_enumle(), gbt_enumlt(), gbt_num_fetch(), generate_collation_name(), generate_function_name(), generate_operator_clause(), generate_operator_name(), generate_partition_qual(), generate_qualified_relation_name(), generate_qualified_type_name(), generate_relation_name(), generateClonedExtStatsStmt(), generateClonedIndexStmt(), get_am_name(), get_array_type(), get_attavgwidth(), get_attgenerated(), get_attname(), get_attoptions(), get_attribute_options(), get_attstatsslot(), get_atttype(), get_atttypetypmodcoll(), get_base_element_type(), get_cast_oid(), get_catalog_object_by_oid(), get_collation(), get_collation_isdeterministic(), get_collation_name(), get_commutator(), get_compatible_hash_operators(), get_constraint_index(), get_constraint_name(), get_conversion_oid(), get_database_name(), get_db_info(), get_default_acl_internal(), get_default_partition_oid(), get_domain_constraint_oid(), get_element_type(), get_extension_name(), get_extension_schema(), get_func_leakproof(), get_func_name(), get_func_namespace(), get_func_nargs(), get_func_prokind(), get_func_result_name(), get_func_retset(), get_func_rettype(), get_func_signature(), get_func_support(), get_func_variadictype(), get_function_rows(), get_index_column_opclass(), get_index_constraint(), get_index_isclustered(), get_index_isreplident(), get_index_isvalid(), get_index_ref_constraints(), get_language_name(), get_mergejoin_opfamilies(), get_multirange_range(), get_namespace_name(), get_negator(), get_object_address_defacl(), get_object_address_opf_member(), get_object_address_publication_rel(), get_object_address_publication_schema(), get_object_address_usermapping(), get_object_namespace(), get_op_btree_interpretation(), get_op_hash_functions(), get_op_opfamily_properties(), get_op_opfamily_sortfamily(), get_op_opfamily_strategy(), get_op_rettype(), get_opclass(), get_opclass_family(), get_opclass_input_type(), get_opclass_method(), get_opclass_name(), get_opclass_opfamily_and_input_type(), get_opcode(), get_opfamily_member(), get_opfamily_proc(), get_opname(), get_oprjoin(), get_oprrest(), get_ordering_op_for_equality_op(), get_ordering_op_properties(), get_partition_parent_worker(), get_pkey_attnames(), get_primary_key_attnos(), get_publication_name(), get_qual_for_hash(), get_qual_for_range(), get_range_collation(), get_range_multirange(), get_range_subtype(), get_rel_name(), get_rel_namespace(), get_rel_persistence(), get_rel_relispartition(), get_rel_relkind(), get_rel_tablespace(), get_rel_type_id(), get_relation_constraint_attnos(), get_relation_constraint_oid(), get_relation_idx_constraint_oid(), get_relation_policy_oid(), get_relation_statistics(), get_relation_statistics_worker(), get_relname_relid(), get_rels_with_domain(), get_rewrite_oid(), get_ri_constraint_root(), get_rolespec_tuple(), get_rte_attribute_is_dropped(), get_statistics_object_oid(), get_subscription_name(), get_tablespace(), get_tablespace_name(), get_transform_fromsql(), get_transform_oid(), get_transform_tosql(), get_trigger_oid(), get_ts_config_oid(), get_ts_dict_oid(), get_ts_parser_func(), get_ts_parser_oid(), get_ts_template_func(), get_ts_template_oid(), get_typ_typrelid(), get_typbyval(), get_typcollation(), get_typdefault(), get_type_category_preferred(), get_type_io_data(), get_typisdefined(), get_typlen(), get_typlenbyval(), get_typlenbyvalalign(), get_typmodin(), get_typstorage(), get_typsubscript(), get_typtype(), GetAttrDefaultColumnAddress(), GetAttrDefaultOid(), getAutoExtensionsOfObject(), getBaseTypeAndTypmod(), GetComment(), GetDatabaseTupleByOid(), GetDefaultOpClass(), getExtensionOfObject(), GetFdwRoutineByServerId(), GetForeignColumnOptions(), GetForeignDataWrapperExtended(), GetForeignKeyActionTriggers(), GetForeignKeyCheckTriggers(), GetForeignServerExtended(), GetForeignServerIdByRelId(), GetForeignTable(), GetIndexAmRoutineByAmId(), GetNewOidWithIndex(), getObjectDescription(), getObjectIdentityParts(), GetOperatorFromWellKnownStrategy(), getOpFamilyDescription(), getOpFamilyIdentity(), getOwnedSequences_internal(), GetParentedForeignKeyRefs(), getProcedureTypeDescription(), GetPublication(), GetPublicationRelations(), getPublicationSchemaInfo(), GetPublicationSchemas(), getRelationDescription(), getRelationIdentity(), GetRelationPublications(), getRelationsInNamespace(), getRelationTypeDescription(), GetSchemaPublications(), GetSecurityLabel(), GetSharedSecurityLabel(), GetSubscription(), GetSubscriptionRelations(), GetSubscriptionRelState(), GetTSConfigTuple(), getTypeBinaryInputInfo(), getTypeBinaryOutputInfo(), getTypeInputInfo(), getTypeOutputInfo(), GetUserMapping(), GetUserNameFromId(), GetWALBlockInfo(), gin_enum_cmp(), ginvalidate(), gistindex_keytest(), gistproperty(), gistvalidate(), has_bypassrls_privilege(), has_createrole_privilege(), has_rolreplication(), has_subclass(), has_superclass(), hash_metapage_info(), hash_ok_operator(), hashvalidate(), HasSubscriptionRelations(), have_createdb_privilege(), heap_create_with_catalog(), heap_drop_with_catalog(), heap_fetch_toast_slice(), heap_getsysattr(), heap_truncate_find_FKs(), hstore_to_jsonb_loose(), inclusion_get_strategy_procinfo(), index_build(), index_check_primary_key(), index_concurrently_create_copy(), index_concurrently_swap(), index_constraint_create(), index_create(), index_drop(), index_get_partition(), index_set_state_flags(), index_update_stats(), indexam_property(), IndexGetRelation(), IndexSetParentIndex(), IndexSupportsBackwardScan(), init_sql_fcache(), initialize_acl(), initialize_peragg(), InitializeSessionUserId(), inline_set_returning_function(), InputFunctionCall(), InputFunctionCallSafe(), insert_event_trigger_tuple(), InsertExtensionTuple(), InsertPgAttributeTuples(), InsertPgClassTuple(), InsertRule(), int2vectorrecv(), internal_get_result_type(), interpret_function_parameter_list(), interval_part_common(), inv_getsize(), inv_read(), inv_truncate(), inv_write(), is_schema_publication(), IsBinaryCoercibleWithCast(), IsDefinedRewriteRule(), IsThereCollationInNamespace(), IsThereFunctionInNamespace(), IsThereOpClassInNamespace(), IsThereOpFamilyInNamespace(), join_selectivity(), LargeObjectCreate(), LargeObjectDrop(), LargeObjectExists(), lastval(), left_oper(), leftmostvalue_bit(), leftmostvalue_enum(), leftmostvalue_oid(), leftmostvalue_varbit(), lo_manage(), load_domaintype_info(), load_enum_cache_data(), load_rangetype_info(), LockSchemaList(), LockTableRecurse(), logicalrep_write_tuple(), logicalrep_write_typ(), lookup_collation(), lookup_collation_cache(), lookup_ts_config_cache(), lookup_ts_dictionary_cache(), lookup_ts_parser_cache(), lookup_type_cache(), LookupOpclassInfo(), LookupTypeNameExtended(), make_callstmt_target(), make_const(), make_new_connection(), make_new_heap(), makeArrayTypeName(), makeConfigurationDependencies(), MakeConfigurationMapping(), makeMultirangeConstructors(), makeMultirangeTypeName(), map_sql_table_to_xmlschema(), map_sql_type_to_xml_name(), mark_index_clustered(), MarkInheritDetached(), MergeConstraintsIntoExisting(), MergeWithExistingConstraint(), minmax_get_strategy_procinfo(), minmax_multi_get_strategy_procinfo(), moddatetime(), movedb(), myLargeObjectExists(), NamespaceCreate(), neqjoinsel(), nextval_internal(), numeric_to_number(), object_aclmask_ext(), object_ownercheck(), objectsInSchemaToOids(), oidvectorrecv(), op_hashjoinable(), op_in_opfamily(), op_input_types(), op_mergejoinable(), opclass_for_family_datatype(), OpClassCacheLookup(), OpclassIsVisibleExt(), OpclassnameGetOpcid(), oper(), OperatorCreate(), OperatorGet(), OperatorIsVisibleExt(), OperatorShellMake(), OperatorUpd(), OpernameGetOprid(), OpFamilyCacheLookup(), OpfamilyIsVisibleExt(), OpfamilynameGetOpfid(), ParameterAclCreate(), ParseFuncOrColumn(), PartitionHasPendingDetach(), perform_work_item(), pg_attribute_aclcheck_all_ext(), pg_attribute_aclmask_ext(), pg_buffercache_pages(), pg_class_aclmask_ext(), pg_collation_actual_version(), pg_control_checkpoint(), pg_database_collation_actual_version(), pg_event_trigger_ddl_commands(), pg_event_trigger_dropped_objects(), pg_extension_config_dump(), pg_get_catalog_foreign_keys(), pg_get_constraintdef_worker(), pg_get_function_arg_default(), pg_get_function_arguments(), pg_get_function_identity_arguments(), pg_get_function_result(), pg_get_function_sqlbody(), pg_get_functiondef(), pg_get_indexdef_worker(), pg_get_object_address(), pg_get_partkeydef_worker(), pg_get_publication_tables(), pg_get_replication_slots(), pg_get_ruledef_worker(), pg_get_serial_sequence(), pg_get_statisticsobj_worker(), pg_get_statisticsobjdef_expressions(), pg_get_triggerdef_worker(), pg_get_userbyid(), pg_get_viewdef_worker(), pg_import_system_collations(), pg_largeobject_aclmask_snapshot(), pg_last_committed_xact(), pg_lock_status(), pg_ls_tmpdir(), pg_lsn_mi(), pg_lsn_mii(), pg_lsn_pli(), pg_namespace_aclmask_ext(), pg_newlocale_from_collation(), pg_parameter_acl_aclmask(), pg_partition_ancestors(), pg_partition_tree(), pg_prepared_xact(), pg_relation_filenode(), pg_relation_filepath(), pg_relation_is_publishable(), pg_sequence_parameters(), pg_show_replication_origin_status(), pg_size_bytes(), pg_split_walfile_name(), pg_stat_get_activity(), pg_stat_get_progress_info(), pg_stat_get_subscription(), pg_stat_get_subscription_stats(), pg_stat_get_wal(), pg_stat_statements_internal(), pg_tablespace_databases(), pg_type_aclmask_ext(), pg_wal_summary_contents(), pg_xact_commit_timestamp_origin(), pgoutput_column_list_init(), pgoutput_row_filter_init(), pgstat_init_function_usage(), pgstat_release_db_entry_refs(), pgstat_reset_counters(), phraseto_tsquery(), plainto_tsquery(), plperl_trigger_build_args(), plperl_validator(), plpgsql_build_datatype(), plpgsql_compile(), plpgsql_fulfill_promise(), plpgsql_parse_cwordtype(), plpgsql_validator(), plpython3_validator(), plsample_func_handler(), plsample_trigger_handler(), pltcl_trigger_handler(), PLy_procedure_create(), PLy_procedure_get(), PLy_trigger_build_args(), PLyNumber_ToJsonbValue(), policy_role_list_to_array(), prepare_column_cache(), preprocess_aggref(), preprocessNamespacePath(), print_function_arguments(), printsimple(), ProcedureCreate(), pub_collist_contains_invalid_column(), pub_rf_contains_invalid_column(), publication_add_relation(), publication_add_schema(), PublicationDropSchemas(), PublicationDropTables(), RangeCreate(), RangeDelete(), RangeVarCallbackForAlterRelation(), RangeVarCallbackForAttachIndex(), RangeVarCallbackForDropRelation(), RangeVarCallbackForPolicy(), RangeVarCallbackForRenameAttribute(), RangeVarCallbackForRenameRule(), RangeVarCallbackForRenameTrigger(), RangeVarCallbackForTruncate(), RangeVarCallbackOwnsRelation(), ReceiveFunctionCall(), record_plan_function_dependency(), record_plan_type_dependency(), recordExtensionInitPrivWorker(), recordExtObjInitPriv(), recordMultipleDependencies(), refresh_by_match_merge(), regclassout(), regcollationout(), regconfigout(), regdictionaryout(), regoperout(), regprocout(), regtypeout(), reindex_index(), ReindexMultipleInternal(), ReindexMultipleTables(), relation_has_policies(), relation_mark_replica_identity(), RelationBuildPartitionDesc(), RelationBuildPartitionKey(), RelationBuildPublicationDesc(), RelationBuildRowSecurity(), RelationBuildRuleLock(), RelationBuildTriggers(), RelationBuildTupleDesc(), RelationCacheInitializePhase3(), RelationClearMissing(), RelationGetExclusionInfo(), RelationGetFKeyList(), RelationGetIndexList(), RelationGetNotNullConstraints(), RelationGetStatExtList(), relationHasPrimaryKey(), RelationInitIndexAccessInfo(), RelationInitTableAccessMethod(), RelationIsVisibleExt(), RelationReloadIndexInfo(), RelationRemoveInheritance(), RelationSetNewRelfilenumber(), RelidByRelfilenumber(), RememberAllDependentForRebuilding(), RemoveAttrDefault(), RemoveAttrDefaultById(), RemoveAttributeById(), RemoveConstraintById(), RemoveExtensionById(), removeExtObjInitPriv(), RemoveFunctionById(), RemoveInheritance(), RemoveOperatorById(), RemovePartitionKeyByRelId(), RemovePolicyById(), RemovePublicationById(), RemovePublicationRelById(), RemovePublicationSchemaById(), RemoveRewriteRuleById(), RemoveRoleFromObjectACL(), RemoveRoleFromObjectPolicy(), RemoveStatistics(), RemoveStatisticsById(), RemoveStatisticsDataById(), RemoveSubscriptionRel(), RemoveTriggerById(), RemoveTSConfigurationById(), RemoveTypeById(), RemoveUserMapping(), rename_constraint_internal(), rename_policy(), RenameConstraint(), RenameConstraintById(), RenameDatabase(), RenameEnumLabel(), RenameRelationInternal(), RenameRewriteRule(), renametrig(), renametrig_internal(), renametrig_partition(), RenameType(), RenameTypeInternal(), replorigin_by_oid(), replorigin_create(), replorigin_drop_by_name(), ResetRelRewrite(), ResetSequence(), ResolveOpClass(), restriction_selectivity(), ri_GenerateQualCollation(), ri_LoadConstraintInfo(), roles_is_member_of(), scalararraysel(), ScanPgRelation(), scanRTEForColumn(), SearchSysCacheAttName(), SearchSysCacheAttNum(), SendTablespaceList(), sepgsql_attribute_post_create(), sepgsql_database_post_create(), sepgsql_proc_post_create(), sepgsql_proc_setattr(), sepgsql_relation_drop(), sepgsql_relation_post_create(), sepgsql_relation_setattr(), sepgsql_relation_setattr_extra(), sepgsql_schema_post_create(), sequence_options(), sequenceIsOwned(), serialize_expr_stats(), SetAttrMissing(), SetDatatabaseHasLoginEventTriggers(), SetDefaultACL(), SetMatViewPopulatedState(), SetRelationHasSubclass(), SetRelationNumChecks(), SetRelationRuleStatus(), SetRelationTableSpace(), SetSecurityLabel(), SetSharedSecurityLabel(), shdepAddDependency(), shdepChangeDep(), shdepDropDependency(), shdepDropOwned(), shdepLockAndCheckObject(), shdepReassignOwned(), simplify_function(), slot_getsysattr(), spgproperty(), spgvalidate(), SPI_gettype(), ssl_client_serial(), statext_dependencies_load(), statext_expressions_load(), statext_mcv_load(), statext_ndistinct_load(), statext_store(), StatisticsGetRelation(), StatisticsObjIsVisibleExt(), StoreAttrDefault(), storeOperators(), StorePartitionBound(), StorePartitionKey(), storeProcedures(), StoreSingleInheritance(), superuser_arg(), SV_to_JsonbValue(), swap_relation_files(), table_recheck_autovac(), table_to_xml_internal(), test_rls_hooks_permissive(), test_rls_hooks_restrictive(), timestamp_part_common(), timestamptz_part_common(), to_tsquery(), to_tsvector(), toast_delete_datum(), toast_save_datum(), toastrel_valueid_exists(), transformCallStmt(), transformFkeyCheckAttrs(), transformFkeyGetPrimaryKey(), transformFrameOffset(), transformGenericOptions(), triggered_change_notification(), TriggerSetParentTrigger(), try_relation_open(), tryAttachPartitionForeignKey(), TryReuseForeignKey(), ts_headline(), ts_headline_json(), ts_headline_json_opt(), ts_headline_jsonb(), ts_headline_jsonb_opt(), ts_headline_opt(), TSConfigIsVisibleExt(), TSDictionaryIsVisibleExt(), TSParserIsVisibleExt(), TSTemplateIsVisibleExt(), TupleDescInitEntry(), TypeCreate(), typeidType(), typeidTypeRelid(), typeInheritsFrom(), typeIsOfTypedTable(), TypeIsVisibleExt(), TypenameGetTypidExtended(), typeOrDomainTypeRelid(), TypeShellMake(), unaccent_dict(), update_attstats(), update_default_partition_oid(), update_relispartition(), UpdateIndexRelation(), UpdateSubscriptionRelState(), UpdateTwoPhaseState(), vac_update_datfrozenxid(), vac_update_relstats(), validatePartitionedIndex(), validateRecoveryParameters(), verify_dictoptions(), and websearch_to_tsquery().

◆ PointerGetDatum()

static Datum PointerGetDatum ( const void *  X)
inlinestatic

Definition at line 322 of file postgres.h.

323 {
324  return (Datum) X;
325 }

Referenced by _int_different(), _ltree_compress(), _ltree_picksplit(), accumArrayResult(), add_function_cost(), add_values_to_range(), AggregateCreate(), AlterDatabaseOwner(), AlterForeignDataWrapper(), AlterForeignDataWrapperOwner_internal(), AlterForeignServer(), AlterForeignServerOwner_internal(), AlterFunction(), AlterObjectOwner_internal(), AlterPolicy(), AlterSchemaOwner_internal(), AlterSetting(), AlterTSDictionary(), AlterTypeOwnerInternal(), AlterUserMapping(), array_fill_internal(), array_get_slice(), array_in(), array_iterate(), array_iterator(), array_map(), array_ref(), array_replace_internal(), array_set(), array_set_element(), array_set_slice(), array_subscript_assign(), array_subscript_assign_slice(), assign_simple_var(), ATExecAlterColumnGenericOptions(), ATExecAlterColumnType(), ATExecChangeOwner(), ATExecGenericOptions(), autoinc(), binary_upgrade_create_empty_extension(), bool_to_plperl(), BoxPGetDatum(), bpcharfastcmp_c(), brin_bloom_add_value(), brin_deform_tuple(), brin_form_tuple(), brin_memtuple_initialize(), brin_minmax_multi_add_value(), brin_minmax_multi_serialize(), brin_minmax_multi_summary_out(), brin_minmax_multi_union(), brin_range_deserialize(), brin_revmap_data(), bringetbitmap(), bt_normalize_tuple(), bt_page_print_tuples(), btbulkdelete(), BufferSync(), build_function_result_tupdesc_d(), build_function_result_tupdesc_t(), build_regexp_match_result(), build_regexp_split_result(), build_regtype_array(), build_sorted_items(), build_test_info_result(), build_test_match_result(), bytea_overlay(), calc_arraycontsel(), change_owner_fix_column_acls(), check_for_column_name_collision(), check_foreign_key(), check_primary_key(), check_role(), check_session_authorization(), CheckIndexCompatible(), ChooseExtendedStatisticName(), CirclePGetDatum(), coerce_function_result_tuple(), coerce_type(), CollationCreate(), collectMatchBitmap(), compareJsonbScalarValue(), comparetup_datum_tiebreak(), compileTheLexeme(), compileTheSubstitute(), compute_array_stats(), compute_distinct_stats(), compute_range_stats(), compute_scalar_stats(), compute_tsvector_stats(), construct_empty_expanded_array(), construct_md_array(), ConversionCreate(), ConversionGetConid(), convert_prep_stmt_params(), convert_requires_to_datum(), CopyIndexAttOptions(), CreateConstraintEntry(), createdb(), CreateExtensionInternal(), CreateForeignDataWrapper(), CreateForeignServer(), CreateForeignTable(), CreateFunction(), CreatePolicy(), CreateProceduralLanguage(), CreateStatistics(), CreateTriggerFiringOn(), CreateUserMapping(), CStringGetDatum(), daitch_mokotoff_coding(), date_mi_interval(), date_pl_interval(), datum_to_json(), datumCopy(), datumRestore(), DefineAggregate(), DefineIndex(), DefineOpClass(), DefineTSDictionary(), detoast_external_attr(), directBoolConsistentFn(), directTriConsistentFn(), do_text_output_multiline(), doPickSplit(), DropRole(), dsa_attach(), dsa_attach_in_place(), dsa_create(), dsa_create_in_place(), dsm_postmaster_startup(), each_object_field_end(), each_worker_jsonb(), elements_array_element_end(), elements_worker_jsonb(), EnableDisableRule(), end_MultiFuncCall(), EOHPGetRODatum(), EOHPGetRWDatum(), equalsJsonbScalarValue(), evaluate_expr(), examine_attribute(), examine_expression(), exec_assign_c_string(), ExecBuildAggTrans(), ExecEvalArrayCoerce(), ExecEvalArrayExpr(), ExecEvalCoerceViaIOSafe(), ExecEvalMergeSupportFunc(), ExecEvalWholeRowVar(), ExecEvalXmlExpr(), ExecGrant_Attribute(), ExecGrant_common(), ExecGrant_Largeobject(), ExecGrant_Parameter(), ExecGrant_Relation(), ExecIndexBuildScanKeys(), ExecIndexEvalRuntimeKeys(), ExecInitCteScan(), ExecInitRecursiveUnion(), ExecInitSubPlan(), ExecInterpExpr(), ExecMakeFunctionResultSet(), ExecPrepareTuplestoreResult(), ExecSetParamPlan(), ExecuteDoStmt(), executeItemOptUnwrapTarget(), expanded_record_set_field_internal(), expanded_record_set_fields(), extension_config_remove(), fetch_att(), fill_hba_line(), filter_list_to_array(), find_or_create_child_node(), find_window_run_conditions(), FinishSortSupportFunction(), Float8GetDatum(), fmgr_sql(), ForgetManyTestResources(), formTextDatum(), function_selectivity(), g_cube_decompress(), g_cube_distance(), g_cube_picksplit(), g_int_compress(), g_int_consistent(), g_int_decompress(), g_int_picksplit(), g_intbig_compress(), g_intbig_picksplit(), gbt_bitcmp(), gbt_biteq(), gbt_bitge(), gbt_bitgt(), gbt_bitle(), gbt_bitlt(), gbt_bpcharcmp(), gbt_bpchareq(), gbt_bpcharge(), gbt_bpchargt(), gbt_bpcharle(), gbt_bpcharlt(), gbt_byteacmp(), gbt_byteaeq(), gbt_byteage(), gbt_byteagt(), gbt_byteale(), gbt_bytealt(), gbt_inet_compress(), gbt_intv_compress(), gbt_intv_decompress(), gbt_macad8eq(), gbt_macad8ge(), gbt_macad8gt(), gbt_macad8le(), gbt_macad8lt(), gbt_macadeq(), gbt_macadge(), gbt_macadgt(), gbt_macadle(), gbt_macadlt(), gbt_num_bin_union(), gbt_num_compress(), gbt_num_picksplit(), gbt_numeric_cmp(), gbt_numeric_eq(), gbt_numeric_ge(), gbt_numeric_gt(), gbt_numeric_le(), gbt_numeric_lt(), gbt_numeric_penalty(), gbt_textcmp(), gbt_texteq(), gbt_textge(), gbt_textgt(), gbt_textle(), gbt_textlt(), gbt_timetz_compress(), gbt_tstz_compress(), gbt_uuid_compress(), gbt_var_bin_union(), gbt_var_compress(), gbt_var_decompress(), gbt_var_fetch(), gbt_var_penalty(), gbt_var_picksplit(), gbt_var_union(), generate_series_timestamp(), Generic_Text_IC_like(), genericPickSplit(), get_conversion_oid(), get_func_input_arg_names(), get_function_rows(), get_index_clause_from_support(), get_relname_relid(), get_rewrite_oid(), get_role_password(), get_statistics_object_oid(), get_text_array_contents(), get_ts_config_oid(), get_ts_dict_oid(), get_ts_parser_oid(), get_ts_template_oid(), getmissingattr(), GetTsmRoutine(), GetWALBlockInfo(), ghstore_compress(), ghstore_picksplit(), gin_btree_extract_query(), gin_btree_extract_value(), gin_extract_hstore(), gin_extract_hstore_query(), gin_extract_jsonb_query(), gin_extract_jsonb_query_path(), gin_extract_tsquery(), gin_extract_tsvector(), gin_leafpage_items(), gin_page_opaque_info(), gincost_pattern(), ginExtractEntries(), gist_box_leaf_consistent(), gist_box_picksplit(), gist_circle_compress(), gist_page_items_bytea(), gist_page_opaque_info(), gist_point_consistent(), gist_point_fetch(), gist_poly_compress(), gistCompressValues(), gistdentryinit(), gistFetchAtt(), gistindex_keytest(), gistKeyIsEQ(), gistMakeUnionItVec(), gistMakeUnionKey(), gistpenalty(), gistUserPicksplit(), gseg_picksplit(), gtrgm_compress(), gtrgm_decompress(), gtrgm_picksplit(), gtsvector_compress(), gtsvector_decompress(), gtsvector_picksplit(), hash_metapage_info(), hash_page_items(), headline_json_value(), heap_copy_tuple_as_datum(), heap_create_with_catalog(), heap_fill_tuple(), heap_getsysattr(), heap_page_items(), heap_tuple_infomask_flags(), HeapTupleHeaderGetDatum(), hlparsetext(), hstore_akeys(), hstore_avals(), hstore_each(), hstore_skeys(), hstore_slice_to_array(), hstore_subscript_assign(), hstore_subscript_fetch(), hstore_svals(), hstore_to_array_internal(), hstore_to_plperl(), hstore_to_plpython(), index_form_tuple_context(), index_opclass_options(), inet_gist_compress(), inet_gist_picksplit(), InetPGetDatum(), init_MultiFuncCall(), init_ts_config_cache(), InitializeSessionUserId(), insert_username(), InsertExtensionTuple(), InsertOneNull(), InsertRule(), int2vectorrecv(), Int64GetDatum(), InternalIpcMemoryCreate(), interpret_function_parameter_list(), IntervalPGetDatum(), inv_truncate(), inv_write(), IsDefinedRewriteRule(), IsThereFunctionInNamespace(), ItemPointerGetDatum(), join_selectivity(), json_build_array_worker(), json_build_object_worker(), jsonb_get_element(), jsonb_ops__add_path_item(), jsonb_put_escaped_value(), jsonb_to_plperl(), jsonb_to_plpython(), JsonbPGetDatum(), JsonbValueAsText(), leftmostvalue_numeric(), leftmostvalue_text(), LexizeExec(), LinePGetDatum(), lo_manage(), LogicalOutputWrite(), lookup_collation(), lookup_ts_dictionary_cache(), lookup_ts_parser_cache(), LookupTypeNameExtended(), LsegPGetDatum(), lt_q_regex(), ltree_addtext(), ltree_compress(), ltree_consistent(), ltree_decompress(), ltree_picksplit(), ltree_textadd(), ltree_to_plpython(), Macaddr8PGetDatum(), MacaddrPGetDatum(), make_greater_string(), make_text_key(), make_tuple_indirect(), makeArrayResultArr(), makeConst(), makeMdArrayResult(), makeMultirangeConstructors(), makeRangeConstructors(), matchPartialInPendingList(), MJExamineQuals(), moddatetime(), movedb(), multirange_send(), MultirangeTypePGetDatum(), NamespaceCreate(), neqjoinsel(), NumericGetDatum(), oidvectorrecv(), OpClassCacheLookup(), OpclassnameGetOpcid(), OperatorGet(), OpFamilyCacheLookup(), OpfamilynameGetOpfid(), optimize_window_clauses(), optionListToArray(), ordered_set_startup(), ParallelApplyWorkerMain(), ParallelWorkerMain(), ParameterAclCreate(), ParameterAclLookup(), parse_ident(), parsetext(), PathPGetDatum(), pg_check_frozen(), pg_check_visible(), pg_event_trigger_ddl_commands(), pg_event_trigger_dropped_objects(), pg_extension_config_dump(), pg_get_publication_tables(), pg_get_statisticsobjdef_expressions(), pg_identify_object_as_address(), pg_parameter_aclmask(), pg_stat_get_slru(), pg_stats_ext_mcvlist_items(), pgrowlocks(), PGSharedMemoryCreate(), phraseto_tsquery(), phraseto_tsquery_byid(), plainto_tsquery(), plainto_tsquery_byid(), plperl_array_to_datum(), plperl_sv_to_datum(), plperl_trigger_handler(), plpgsql_call_handler(), plpgsql_fulfill_promise(), plpython3_call_handler(), plsample_call_handler(), pltcl_handler(), PLy_cursor_plan(), PLy_spi_execute_plan(), PLyObject_ToBytea(), PLyObject_ToTransform(), PLySequence_ToArray(), PointPGetDatum(), PolygonPGetDatum(), populate_array_element(), populate_domain(), populate_scalar(), prepare_sql_fn_parse_info(), PrepareSortSupportFromGistIndexRel(), ProcedureCreate(), proclock_hash(), ProcLockHashCode(), prs_setup_firstcall(), publication_add_relation(), publicationListToArray(), quote_ident_cstr(), range_gist_double_sorting_split(), range_send(), range_serialize(), RangeTypePGetDatum(), ReadArrayBinary(), readDatum(), readtup_datum(), ReceiveFunctionCall(), recordExtensionInitPrivWorker(), regexp_match(), regexp_matches(), regexp_substr(), RememberManyTestResources(), removeabbrev_datum(), RemoveRoleFromObjectPolicy(), RenameRewriteRule(), renametrig(), renametrig_internal(), ReorderBufferToastReplace(), ReplSlotSyncWorkerMain(), ResolveOpClass(), ResourceOwnerForgetCatCacheListRef(), ResourceOwnerForgetCatCacheRef(), ResourceOwnerForgetCryptoHash(), ResourceOwnerForgetDSM(), ResourceOwnerForgetHMAC(), ResourceOwnerForgetJIT(), ResourceOwnerForgetOSSLCipher(), ResourceOwnerForgetOSSLDigest(), ResourceOwnerForgetPlanCacheRef(), ResourceOwnerForgetRelationRef(), ResourceOwnerForgetSnapshot(), ResourceOwnerForgetTupleDesc(), ResourceOwnerForgetWaitEventSet(), ResourceOwnerRememberCatCacheListRef(), ResourceOwnerRememberCatCacheRef(), ResourceOwnerRememberCryptoHash(), ResourceOwnerRememberDSM(), ResourceOwnerRememberHMAC(), ResourceOwnerRememberJIT(), ResourceOwnerRememberOSSLCipher(), ResourceOwnerRememberOSSLDigest(), ResourceOwnerRememberPlanCacheRef(), ResourceOwnerRememberRelationRef(), ResourceOwnerRememberSnapshot(), ResourceOwnerRememberTupleDesc(), ResourceOwnerRememberWaitEventSet(), restriction_selectivity(), RI_FKey_cascade_del(), RI_FKey_cascade_upd(), RI_FKey_check(), ri_restrict(), ri_set(), rtree_internal_consistent(), scalararraysel(), sepgsql_fmgr_hook(), serialize_expr_stats(), set_fn_opclass_options(), SetDefaultACL(), setup_background_workers(), SharedFileSetAttach(), SharedFileSetInit(), SharedInvalBackendInit(), SharedRecordTypmodRegistryAttach(), shimBoolConsistentFn(), shm_mq_attach(), shm_mq_detach(), show_all_file_settings(), show_trgm(), ShowAllGUCConfig(), simplify_function(), slot_getsysattr(), spg_quad_inner_consistent(), spg_range_quad_picksplit(), spg_text_inner_consistent(), spg_text_leaf_consistent(), spgdoinsert(), spgGetCache(), spgInnerTest(), spgist_name_inner_consistent(), spgist_name_leaf_consistent(), spgLeafTest(), spgvalidate(), split_text_accum_result(), ssl_extension_info(), statext_mcv_deserialize(), statext_mcv_serialize(), statext_store(), StatisticsObjIsVisibleExt(), StoreAttrDefault(), StorePartitionKey(), string_to_bytea_const(), suppress_redundant_updates_trigger(), SyncReplicationSlots(), test_enc_conversion(), test_regex(), test_shm_mq_setup(), text2ltree(), text_isequal(), text_overlay(), textoverlay_no_len(), textregexsubstr(), thesaurus_lexize(), timestamp_izone(), timestamp_mi_interval(), timestamptz_izone(), timetz_at_local(), timetz_izone(), TimeTzADTPGetDatum(), to_tsquery(), to_tsquery_byid(), to_tsvector(), toast_build_flattened_tuple(), toast_compress_datum(), toast_datum_size(), toast_flatten_tuple(), toast_flatten_tuple_to_datum(), toast_raw_datum_size(), toast_save_datum(), toast_tuple_init(), transformGenericOptions(), transformRelOptions(), trigger_return_old(), triggered_change_notification(), trim_array(), ts_headline_byid_opt(), ts_headline_json_byid_opt(), ts_headline_jsonb_byid_opt(), ts_lexize(), TSConfigIsVisibleExt(), TSDictionaryIsVisibleExt(), TSParserIsVisibleExt(), TSQueryGetDatum(), tsqueryin(), TSTemplateIsVisibleExt(), tstoreReceiveSlot_detoast(), tsvector_to_array(), tsvector_unnest(), tsvector_update_trigger(), TSVectorGetDatum(), ttdummy(), tts_virtual_materialize(), tuple_data_split_internal(), tuple_to_stringinfo(), tuplesort_getdatum(), TypeCreate(), TypeIsVisibleExt(), TypenameGetTypidExtended(), typenameTypeMod(), unaccent_dict(), union_tuples(), update_attstats(), UpdateIndexRelation(), UUIDPGetDatum(), VarBitPGetDatum(), varlenafastcmp_locale(), varstr_abbrev_convert(), varstrfastcmp_c(), verify_dictoptions(), WalReceiverMain(), websearch_to_tsquery(), websearch_to_tsquery_byid(), writetup_datum(), xmlconcat(), and XmlPGetDatum().

◆ TransactionIdGetDatum()

◆ UInt16GetDatum()

◆ UInt32GetDatum()

◆ UInt64GetDatum()

static Datum UInt64GetDatum ( uint64  X)
inlinestatic

Definition at line 436 of file postgres.h.

437 {
438 #ifdef USE_FLOAT8_BYVAL
439  return (Datum) X;
440 #else
441  return Int64GetDatum((int64) X);
442 #endif
443 }
Datum Int64GetDatum(int64 X)
Definition: fmgr.c:1807

References Int64GetDatum().

Referenced by compute_partition_hash_value(), exec_stmt_getdiag(), FullTransactionIdGetDatum(), hash_aclitem_extended(), hash_any_extended(), hash_numeric_extended(), hash_uint32_extended(), JsonbHashScalarValueExtended(), pg_stat_get_activity(), and satisfies_hash_partition().

◆ UInt8GetDatum()

static Datum UInt8GetDatum ( uint8  X)
inlinestatic

Definition at line 152 of file postgres.h.

153 {
154  return (Datum) X;
155 }

Referenced by heap_page_items().