PostgreSQL Source Code
git master
|
Go to the source code of this file.
Data Structures | |
struct | varatt_external |
struct | varatt_indirect |
struct | varatt_expanded |
union | varattrib_4b |
struct | varattrib_1b |
struct | varattrib_1b_e |
struct | NullableDatum |
Macros | |
#define | VARTAG_IS_EXPANDED(tag) (((tag) & ~1) == VARTAG_EXPANDED_RO) |
#define | VARTAG_SIZE(tag) |
#define | VARATT_IS_4B(PTR) ((((varattrib_1b *) (PTR))->va_header & 0x01) == 0x00) |
#define | VARATT_IS_4B_U(PTR) ((((varattrib_1b *) (PTR))->va_header & 0x03) == 0x00) |
#define | VARATT_IS_4B_C(PTR) ((((varattrib_1b *) (PTR))->va_header & 0x03) == 0x02) |
#define | VARATT_IS_1B(PTR) ((((varattrib_1b *) (PTR))->va_header & 0x01) == 0x01) |
#define | VARATT_IS_1B_E(PTR) ((((varattrib_1b *) (PTR))->va_header) == 0x01) |
#define | VARATT_NOT_PAD_BYTE(PTR) (*((uint8 *) (PTR)) != 0) |
#define | VARSIZE_4B(PTR) ((((varattrib_4b *) (PTR))->va_4byte.va_header >> 2) & 0x3FFFFFFF) |
#define | VARSIZE_1B(PTR) ((((varattrib_1b *) (PTR))->va_header >> 1) & 0x7F) |
#define | VARTAG_1B_E(PTR) (((varattrib_1b_e *) (PTR))->va_tag) |
#define | SET_VARSIZE_4B(PTR, len) (((varattrib_4b *) (PTR))->va_4byte.va_header = (((uint32) (len)) << 2)) |
#define | SET_VARSIZE_4B_C(PTR, len) (((varattrib_4b *) (PTR))->va_4byte.va_header = (((uint32) (len)) << 2) | 0x02) |
#define | SET_VARSIZE_1B(PTR, len) (((varattrib_1b *) (PTR))->va_header = (((uint8) (len)) << 1) | 0x01) |
#define | SET_VARTAG_1B_E(PTR, tag) |
#define | VARHDRSZ_SHORT offsetof(varattrib_1b, va_data) |
#define | VARATT_SHORT_MAX 0x7F |
#define | VARATT_CAN_MAKE_SHORT(PTR) |
#define | VARATT_CONVERTED_SHORT_SIZE(PTR) (VARSIZE(PTR) - VARHDRSZ + VARHDRSZ_SHORT) |
#define | VARHDRSZ_EXTERNAL offsetof(varattrib_1b_e, va_data) |
#define | VARDATA_4B(PTR) (((varattrib_4b *) (PTR))->va_4byte.va_data) |
#define | VARDATA_4B_C(PTR) (((varattrib_4b *) (PTR))->va_compressed.va_data) |
#define | VARDATA_1B(PTR) (((varattrib_1b *) (PTR))->va_data) |
#define | VARDATA_1B_E(PTR) (((varattrib_1b_e *) (PTR))->va_data) |
#define | VARRAWSIZE_4B_C(PTR) (((varattrib_4b *) (PTR))->va_compressed.va_rawsize) |
#define | VARDATA(PTR) VARDATA_4B(PTR) |
#define | VARSIZE(PTR) VARSIZE_4B(PTR) |
#define | VARSIZE_SHORT(PTR) VARSIZE_1B(PTR) |
#define | VARDATA_SHORT(PTR) VARDATA_1B(PTR) |
#define | VARTAG_EXTERNAL(PTR) VARTAG_1B_E(PTR) |
#define | VARSIZE_EXTERNAL(PTR) (VARHDRSZ_EXTERNAL + VARTAG_SIZE(VARTAG_EXTERNAL(PTR))) |
#define | VARDATA_EXTERNAL(PTR) VARDATA_1B_E(PTR) |
#define | VARATT_IS_COMPRESSED(PTR) VARATT_IS_4B_C(PTR) |
#define | VARATT_IS_EXTERNAL(PTR) VARATT_IS_1B_E(PTR) |
#define | VARATT_IS_EXTERNAL_ONDISK(PTR) (VARATT_IS_EXTERNAL(PTR) && VARTAG_EXTERNAL(PTR) == VARTAG_ONDISK) |
#define | VARATT_IS_EXTERNAL_INDIRECT(PTR) (VARATT_IS_EXTERNAL(PTR) && VARTAG_EXTERNAL(PTR) == VARTAG_INDIRECT) |
#define | VARATT_IS_EXTERNAL_EXPANDED_RO(PTR) (VARATT_IS_EXTERNAL(PTR) && VARTAG_EXTERNAL(PTR) == VARTAG_EXPANDED_RO) |
#define | VARATT_IS_EXTERNAL_EXPANDED_RW(PTR) (VARATT_IS_EXTERNAL(PTR) && VARTAG_EXTERNAL(PTR) == VARTAG_EXPANDED_RW) |
#define | VARATT_IS_EXTERNAL_EXPANDED(PTR) (VARATT_IS_EXTERNAL(PTR) && VARTAG_IS_EXPANDED(VARTAG_EXTERNAL(PTR))) |
#define | VARATT_IS_EXTERNAL_NON_EXPANDED(PTR) (VARATT_IS_EXTERNAL(PTR) && !VARTAG_IS_EXPANDED(VARTAG_EXTERNAL(PTR))) |
#define | VARATT_IS_SHORT(PTR) VARATT_IS_1B(PTR) |
#define | VARATT_IS_EXTENDED(PTR) (!VARATT_IS_4B_U(PTR)) |
#define | SET_VARSIZE(PTR, len) SET_VARSIZE_4B(PTR, len) |
#define | SET_VARSIZE_SHORT(PTR, len) SET_VARSIZE_1B(PTR, len) |
#define | SET_VARSIZE_COMPRESSED(PTR, len) SET_VARSIZE_4B_C(PTR, len) |
#define | SET_VARTAG_EXTERNAL(PTR, tag) SET_VARTAG_1B_E(PTR, tag) |
#define | VARSIZE_ANY(PTR) |
#define | VARSIZE_ANY_EXHDR(PTR) |
#define | VARDATA_ANY(PTR) (VARATT_IS_1B(PTR) ? VARDATA_1B(PTR) : VARDATA_4B(PTR)) |
#define | FIELDNO_NULLABLE_DATUM_DATUM 0 |
#define | FIELDNO_NULLABLE_DATUM_ISNULL 1 |
#define | SIZEOF_DATUM SIZEOF_VOID_P |
#define | DatumGetBool(X) ((bool) ((X) != 0)) |
#define | BoolGetDatum(X) ((Datum) ((X) ? 1 : 0)) |
#define | DatumGetChar(X) ((char) (X)) |
#define | CharGetDatum(X) ((Datum) (X)) |
#define | Int8GetDatum(X) ((Datum) (X)) |
#define | DatumGetUInt8(X) ((uint8) (X)) |
#define | UInt8GetDatum(X) ((Datum) (X)) |
#define | DatumGetInt16(X) ((int16) (X)) |
#define | Int16GetDatum(X) ((Datum) (X)) |
#define | DatumGetUInt16(X) ((uint16) (X)) |
#define | UInt16GetDatum(X) ((Datum) (X)) |
#define | DatumGetInt32(X) ((int32) (X)) |
#define | Int32GetDatum(X) ((Datum) (X)) |
#define | DatumGetUInt32(X) ((uint32) (X)) |
#define | UInt32GetDatum(X) ((Datum) (X)) |
#define | DatumGetObjectId(X) ((Oid) (X)) |
#define | ObjectIdGetDatum(X) ((Datum) (X)) |
#define | DatumGetTransactionId(X) ((TransactionId) (X)) |
#define | TransactionIdGetDatum(X) ((Datum) (X)) |
#define | MultiXactIdGetDatum(X) ((Datum) (X)) |
#define | DatumGetCommandId(X) ((CommandId) (X)) |
#define | CommandIdGetDatum(X) ((Datum) (X)) |
#define | DatumGetPointer(X) ((Pointer) (X)) |
#define | PointerGetDatum(X) ((Datum) (X)) |
#define | DatumGetCString(X) ((char *) DatumGetPointer(X)) |
#define | CStringGetDatum(X) PointerGetDatum(X) |
#define | DatumGetName(X) ((Name) DatumGetPointer(X)) |
#define | NameGetDatum(X) CStringGetDatum(NameStr(*(X))) |
#define | DatumGetInt64(X) (* ((int64 *) DatumGetPointer(X))) |
#define | DatumGetUInt64(X) (* ((uint64 *) DatumGetPointer(X))) |
#define | UInt64GetDatum(X) Int64GetDatum((int64) (X)) |
#define | DatumGetFloat8(X) (* ((float8 *) DatumGetPointer(X))) |
#define | Int64GetDatumFast(X) PointerGetDatum(&(X)) |
#define | Float8GetDatumFast(X) PointerGetDatum(&(X)) |
Typedefs | |
typedef struct varatt_external | varatt_external |
typedef struct varatt_indirect | varatt_indirect |
typedef struct ExpandedObjectHeader | ExpandedObjectHeader |
typedef struct varatt_expanded | varatt_expanded |
typedef enum vartag_external | vartag_external |
typedef uintptr_t | Datum |
typedef struct NullableDatum | NullableDatum |
Enumerations | |
enum | vartag_external { VARTAG_INDIRECT = 1, VARTAG_EXPANDED_RO = 2, VARTAG_EXPANDED_RW = 3, VARTAG_ONDISK = 18 } |
Functions | |
Datum | Int64GetDatum (int64 X) |
static float4 | DatumGetFloat4 (Datum X) |
static Datum | Float4GetDatum (float4 X) |
Datum | Float8GetDatum (float8 X) |
#define BoolGetDatum | ( | X | ) | ((Datum) ((X) ? 1 : 0)) |
Definition at line 402 of file postgres.h.
Referenced by aclexplode(), add_security_quals(), add_with_check_options(), AddRoleMems(), AggregateCreate(), AlterDatabase(), AlterPublicationOptions(), AlterRole(), AlterSubscription(), ApplyExtensionUpdates(), boolvarsel(), brin_inclusion_add_value(), brin_inclusion_union(), brin_page_items(), brincostestimate(), btcostestimate(), build_coercion_expression(), CollationCreate(), ConversionCreate(), create_proc_lang(), CreateConstraintEntry(), createdb(), CreatePolicy(), CreatePublication(), CreateRole(), CreateSubscription(), CreateTrigger(), DefineOpClass(), DefineSequence(), DelRoleMems(), do_pg_start_backup(), do_pg_stop_backup(), eval_const_expressions_mutator(), examine_simple_variable(), examine_variable(), exec_set_found(), ExecEvalRowNullInt(), ExecEvalScalarArrayOp(), ExecEvalXmlExpr(), ExecHashBuildSkewHash(), ExecHashSubPlan(), ExecInterpExpr(), ExecScanSubPlan(), ExecSetParamPlan(), get_attavgwidth(), get_available_versions_for_extension(), get_tables_to_cluster(), GetAllTablesPublications(), hash_bitmap_info(), in_range_date_interval(), InsertExtensionTuple(), InsertPgAttributeTuple(), InsertPgClassTuple(), InsertRule(), JsonbHashScalarValueExtended(), leftmostvalue_bool(), makeBoolConst(), OperatorCreate(), OperatorShellMake(), pg_buffercache_pages(), pg_control_checkpoint(), pg_control_init(), pg_control_recovery(), pg_cursor(), pg_event_trigger_ddl_commands(), pg_event_trigger_dropped_objects(), pg_get_replication_slots(), pg_lock_status(), pg_partition_tree(), pg_prepared_statement(), pg_sequence_parameters(), pg_stat_file(), pg_stat_get_activity(), pg_stats_ext_mcvlist_items(), pg_timezone_abbrevs(), pg_timezone_names(), pg_visibility(), pg_visibility_map(), pg_visibility_map_rel(), pg_visibility_rel(), PLyObject_ToBool(), ProcedureCreate(), RelationClearMissing(), RemoveAttributeById(), ri_AttributesEqual(), SetAttrMissing(), show_all_file_settings(), SPI_sql_row_to_xmlelement(), ssl_extension_info(), test_predtest(), TypeCreate(), TypeShellMake(), update_attstats(), update_frameheadpos(), update_frametailpos(), and UpdateIndexRelation().
#define CharGetDatum | ( | X | ) | ((Datum) (X)) |
Definition at line 416 of file postgres.h.
Referenced by AddSubscriptionRelState(), AggregateCreate(), CloneFkReferenced(), CollationCreate(), CreateAccessMethod(), CreateCast(), CreateConstraintEntry(), CreatePolicy(), CreateStatistics(), CreateTrigger(), do_autovacuum(), EnableDisableRule(), get_default_acl_internal(), get_object_address_defacl(), get_op_opfamily_properties(), get_op_opfamily_sortfamily(), get_op_opfamily_strategy(), GetAllTablesPublicationRelations(), GetParentedForeignKeyRefs(), getRelationsInNamespace(), GetSubscriptionNotReadyRelations(), insert_event_trigger_tuple(), InsertPgAttributeTuple(), InsertPgClassTuple(), InsertRule(), interpret_function_parameter_list(), leftmostvalue_char(), objectsInSchemaToOids(), op_in_opfamily(), OperatorCreate(), OperatorShellMake(), ProcedureCreate(), recordExtensionInitPrivWorker(), recordMultipleDependencies(), SetDefaultACL(), shdepAddDependency(), shdepChangeDep(), storeOperators(), StorePartitionKey(), TypeCreate(), TypeShellMake(), and UpdateSubscriptionRelState().
#define CommandIdGetDatum | ( | X | ) | ((Datum) (X)) |
Definition at line 542 of file postgres.h.
Referenced by heap_getsysattr().
#define CStringGetDatum | ( | X | ) | PointerGetDatum(X) |
Definition at line 578 of file postgres.h.
Referenced by AddEnumLabel(), AfterTriggerSetState(), AlterDatabase(), AlterDatabaseOwner(), 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(), CreateTrigger(), current_schema(), current_schemas(), current_user(), datum_to_jsonb(), defGetInt64(), DefineCompositeType(), DefineDomain(), DefineEnum(), DefineOpClass(), DefineRange(), DefineType(), DropSubscription(), DropTableSpace(), EnableDisableTrigger(), enum_in(), enum_recv(), ExecAlterExtensionStmt(), find_language_template(), 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(), GetPublicationByName(), heap_create_with_catalog(), hstore_to_jsonb_loose(), inet_client_port(), inet_server_port(), InputFunctionCall(), InsertExtensionTuple(), IsThereCollationInNamespace(), IsThereFunctionInNamespace(), IsThereOpClassInNamespace(), IsThereOpFamilyInNamespace(), jsonb_in_scalar(), leftmostvalue_bit(), leftmostvalue_inet(), leftmostvalue_varbit(), libpqrcv_create_slot(), make_const(), make_tuple_from_result_row(), makeArrayTypeName(), MergeWithExistingConstraint(), moddatetime(), movedb(), numeric_float4(), numeric_float8(), numeric_to_number(), OpernameGetCandidates(), OpernameGetOprid(), perform_default_encoding_conversion(), pg_available_extensions(), pg_backup_start_time(), pg_client_encoding(), pg_convert_from(), pg_convert_to(), pg_do_encoding_conversion(), PG_encoding_to_char(), pg_get_viewdef_worker(), pg_lsn_mi(), pg_size_bytes(), pg_stat_get_activity(), pg_stat_get_backend_client_addr(), pg_stat_get_backend_client_port(), plperl_sv_to_literal(), plpgsql_fulfill_promise(), PLyNumber_ToJsonbValue(), regclassin(), regconfigin(), regdictionaryin(), regnamespacein(), regoperatorin(), regoperin(), regprocedurein(), regprocin(), regrolein(), regtypein(), rename_policy(), RenameRole(), RenameSchema(), RenameTableSpace(), RenameTypeInternal(), SearchSysCacheAttName(), session_user(), SetAttrMissing(), SPI_sql_row_to_xmlelement(), ssl_client_serial(), string_to_datum(), SV_to_JsonbValue(), TypeCreate(), typenameTypeMod(), uuid_generate_internal(), and validateRecoveryParameters().
#define DatumGetBool | ( | X | ) | ((bool) ((X) != 0)) |
Definition at line 393 of file postgres.h.
Referenced by _bt_checkkeys(), _bt_compare_scankey_args(), _bt_find_extreme_element(), _hash_checkqual(), _int_different(), abs_interval(), 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(), booltestsel(), brin_inclusion_add_value(), brin_inclusion_consistent(), brin_inclusion_union(), brin_minmax_add_value(), brin_minmax_consistent(), bringetbitmap(), brininsert(), check_constant_qual(), clause_selectivity(), compute_distinct_stats(), convert_numeric_to_scalar(), datum_to_json(), datum_to_jsonb(), directBoolConsistentFn(), eqjoinsel_inner(), eqjoinsel_semi(), equalsJsonbScalarValue(), eval_const_expressions_mutator(), examine_attribute(), exec_eval_boolean(), ExecCheck(), ExecEvalConstraintCheck(), ExecEvalScalarArrayOp(), ExecEvalXmlExpr(), ExecInterpExpr(), ExecQual(), ExecScanSubPlan(), execTuplesUnequal(), fetch_remote_table_info(), find_duplicate_ors(), gbt_biteq(), gbt_bitge(), gbt_bitgt(), gbt_bitle(), gbt_bitlt(), 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_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_variable_range(), gist_box_leaf_consistent(), gist_point_consistent(), gistindex_keytest(), gseg_internal_consistent(), histogram_selectivity(), index_recheck_constraint(), ineq_histogram_selectivity(), inet_mcv_join_sel(), inet_semi_join_sel(), interpt_pp(), 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(), mode_final(), negate_clause(), numeric_half_rounded(), numeric_is_less(), oidvectoreqfast(), operator_predicate_proof(), pg_start_backup_callback(), pg_stop_backup_callback(), PLyBool_FromBool(), process_implied_equality(), process_ordered_aggregate_single(), range_intersect(), range_union_internal(), record_eq(), record_image_ne(), record_ne(), relation_excluded_by_constraints(), RelationBuildRowSecurity(), restriction_is_constant_false(), ri_AttributesEqual(), rtree_internal_consistent(), simplify_and_arguments(), simplify_boolean_equality(), simplify_or_arguments(), spg_box_quad_leaf_consistent(), spg_quad_inner_consistent(), spg_text_leaf_consistent(), spgLeafTest(), test_predtest(), text_isequal(), texteqfast(), ts_match_tq(), ts_match_tt(), tuples_equal(), update_frameheadpos(), update_frametailpos(), validateDomainConstraint(), and var_eq_const().
#define DatumGetChar | ( | X | ) | ((char) (X)) |
Definition at line 409 of file postgres.h.
Referenced by AlterPolicy(), chareqfast(), charhashfast(), convert_string_datum(), EnableDisableRule(), fetch_remote_table_info(), GetSubscriptionRelState(), make_ruledef(), make_viewdef(), RelationBuildRowSecurity(), and tsvector_filter().
#define DatumGetCommandId | ( | X | ) | ((CommandId) (X)) |
Definition at line 535 of file postgres.h.
#define DatumGetCString | ( | X | ) | ((char *) DatumGetPointer(X)) |
Definition at line 566 of file postgres.h.
Referenced by ArrayGetIntegerTypmods(), CatCacheCopyKeys(), coerce_type(), compute_distinct_stats(), compute_scalar_stats(), compute_trivial_stats(), datum_image_eq(), datum_write(), exec_eval_using_params(), ExecInterpExpr(), executeItemOptUnwrapTarget(), fill_val(), flatten_set_variable_args(), int4_to_char(), int8_to_char(), iterate_jsonb_values(), jsonb_put_escaped_value(), JsonbValue_to_SV(), JsonbValueAsText(), make_greater_string(), numeric_float4(), numeric_float8(), numeric_to_char(), numeric_to_cstring(), numeric_to_double_no_overflow(), OutputFunctionCall(), pg_column_size(), plperl_trigger_build_args(), pltcl_trigger_handler(), PLy_trigger_build_args(), PLyDecimal_FromNumeric(), PLyObject_FromJsonbValue(), populate_scalar(), printJsonPathItem(), printTypmod(), RelationBuildTriggers(), statext_mcv_serialize(), table_to_xml_internal(), timestamp_izone(), timestamptz_izone(), and timetz_izone().
#define DatumGetFloat8 | ( | X | ) | (* ((float8 *) DatumGetPointer(X))) |
Definition at line 714 of file postgres.h.
Referenced by btfloat8fastcmp(), calc_length_hist_frac(), call_subtype_diff(), compute_range_stats(), convert_numeric_to_scalar(), Float4GetDatum(), float8_lerp(), g_cube_distance(), gbt_num_compress(), gbt_numeric_penalty(), get_distance(), get_position(), gistindex_keytest(), join_selectivity(), length_hist_bsearch(), neqjoinsel(), numrange_subdiff(), PLyFloat_FromFloat8(), pt_in_widget(), restriction_selectivity(), scalararraysel(), setup_pct_info(), spg_kd_choose(), spg_kd_inner_consistent(), system_time_beginsamplescan(), system_time_samplescangetsamplesize(), and width_bucket_array_float8().
#define DatumGetInt16 | ( | X | ) | ((int16) (X)) |
Definition at line 444 of file postgres.h.
Referenced by btint2fastcmp(), convert_numeric_to_scalar(), decompile_column_index_array(), gbt_num_compress(), int2eqfast(), int2hashfast(), pg_get_constraintdef_worker(), PLyInt_FromInt16(), searchChar(), spg_text_inner_consistent(), and text_format().
#define DatumGetInt32 | ( | X | ) | ((int32) (X)) |
Definition at line 472 of file postgres.h.
Referenced by _bt_check_rowcompare(), _bt_compare(), _bt_compare_array_elements(), _bt_keep_natts(), ApplyWorkerMain(), array_cmp(), autoinc(), AuxiliaryProcKill(), btint4fastcmp(), c_overpaid(), check_new_partition_bound(), CleanupProcSignalState(), cmpEntries(), collectMatchBitmap(), compare_val_int4(), compareDatetime(), compareJsonbScalarValue(), compareNumeric(), convert_numeric_to_scalar(), create_range_bounds(), date_dist(), DatumGetFloat4(), element_compare(), exec_eval_integer(), exec_stmt_fori(), ExecEvalMinMax(), ExecEvalSubscriptingRef(), ExecEvalXmlExpr(), ExecInterpExpr(), ExecMergeAppend(), exprIsLengthCoercion(), fetch_tuple_flag(), gather_merge_getnext(), gbt_bitcmp(), 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_hash_partition_greatest_modulus(), get_rule_expr(), gin_btree_compare_prefix(), gin_enum_cmp(), gin_numeric_cmp(), ginCompareEntries(), heap_compare_slots(), hlparsetext(), hstore_eq(), hstore_ge(), hstore_gt(), hstore_le(), hstore_lt(), hstore_ne(), hypothetical_dense_rank_final(), hypothetical_rank_common(), initialize_worker_spi(), int4eqfast(), int4hashfast(), int8_to_char(), interval_support(), IpcMemoryDelete(), leadlag_common(), matchPartialInPendingList(), numeric_support(), numeric_to_char(), oidvectoreq(), oidvectorge(), oidvectorgt(), oidvectorhashfast(), oidvectorle(), oidvectorlt(), oidvectorne(), overpaid(), parsetext(), partition_hash_bsearch(), partition_list_bsearch(), partition_rbound_cmp(), partition_rbound_datum_cmp(), pg_get_constraintdef_worker(), PLyInt_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(), seg_different(), seg_ge(), seg_gt(), seg_le(), seg_lt(), seg_same(), signValue(), TemporalSimplify(), test_shm_mq_main(), test_support_func(), text_format(), texthashfast(), toast_fetch_datum(), toast_fetch_datum_slice(), typenameTypeMod(), varbit_support(), varchar_support(), width_bucket_array_fixed(), width_bucket_array_variable(), window_nth_value(), and window_ntile().
#define DatumGetInt64 | ( | X | ) | (* ((int64 *) DatumGetPointer(X))) |
Definition at line 607 of file postgres.h.
Referenced by autoinc(), btint8fastcmp(), convert_numeric_to_scalar(), defGetInt64(), ExecWindowAgg(), Float4GetDatum(), gbt_num_compress(), generate_series_int8_support(), hash_range_extended(), heapam_index_validate_scan(), initialize_worker_spi(), int4_cash(), int8_cash(), int8_to_char(), limit_needed(), numeric_cash(), pg_size_bytes(), PLyLong_FromInt64(), preprocess_limit(), printsimple(), recompute_limits(), row_is_in_frame(), simplify_EXISTS_query(), system_rows_beginsamplescan(), system_rows_samplescangetsamplesize(), timetz_hash_extended(), ttdummy(), update_frameheadpos(), and update_frametailpos().
#define DatumGetName | ( | X | ) | ((Name) DatumGetPointer(X)) |
Definition at line 585 of file postgres.h.
Referenced by AlterObjectNamespace_internal(), AlterObjectOwner_internal(), AlterObjectRename_internal(), DropSubscription(), EventTriggerSQLDropAddObject(), GetSubscription(), make_ruledef(), nameeqfast(), namefastcmp_c(), namefastcmp_locale(), namehashfast(), pg_get_triggerdef_worker(), pg_identify_object(), and RelationBuildRowSecurity().
#define DatumGetObjectId | ( | X | ) | ((Oid) (X)) |
Definition at line 500 of file postgres.h.
Referenced by AlterObjectNamespace_internal(), AlterObjectOwner_internal(), AlterObjectRename_internal(), AlterPolicy(), btoidfastcmp(), convert_function_name(), convert_numeric_to_scalar(), convert_type_name(), CreatePolicy(), DefineTSParser(), DefineTSTemplate(), EvalPlanQualFetchRowMark(), EventTriggerSQLDropAddObject(), execCurrentOf(), ExecLockRows(), fetch_remote_table_info(), find_expr_references_walker(), fix_expr_common(), gbt_num_compress(), generateClonedIndexStmt(), get_object_namespace(), heap_tuple_attr_equals(), inclusion_get_strategy_procinfo(), LexizeExec(), make_ruledef(), make_viewdef(), minmax_get_strategy_procinfo(), pg_get_constraintdef_worker(), PLyLong_FromOid(), query_to_oid_list(), regclassin(), regconfigin(), regdictionaryin(), regnamespacein(), regoperatorin(), regoperin(), regprocedurein(), regprocin(), regrolein(), regtypein(), RemoveRoleFromObjectPolicy(), ReorderBufferToastAppendChunk(), sepgsql_relation_setattr_extra(), and tsvector_update_trigger().
#define DatumGetPointer | ( | X | ) | ((Pointer) (X)) |
Definition at line 549 of file postgres.h.
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_inclusion_add_value(), brin_inclusion_union(), brin_minmax_add_value(), brin_minmax_union(), bt_normalize_tuple(), BufferSync(), build_replindex_scan_key(), CatCacheFreeKeys(), check_domain_for_new_field(), 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_string_datum(), CopyArrayEls(), createdb_failure_callback(), CreateForeignDataWrapper(), CreateForeignServer(), CreateForeignTable(), CreateTrigger(), CreateUserMapping(), datum_compute_size(), datum_image_eq(), datum_write(), datumCopy(), datumEstimateSpace(), DatumGetAnyArrayP(), DatumGetEOHP(), DatumGetExpandedArray(), DatumGetExpandedArrayX(), DatumGetExpandedRecord(), datumGetSize(), 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(), eval_windowfunction(), EvalPlanQualFetchRowMark(), exec_assign_value(), exec_move_row_from_datum(), exec_stmt_foreach_a(), ExecAggTransReparent(), ExecCallTriggerFunc(), execCurrentOf(), ExecEvalFieldSelect(), ExecEvalXmlExpr(), ExecInitCteScan(), ExecInitInterpreter(), ExecInterpExpr(), ExecLockRows(), ExecModifyTable(), ExecSetParamPlan(), execute_foreign_modify(), ExecWorkTableScan(), expand_array(), expanded_record_set_field_internal(), expanded_record_set_fields(), expanded_record_set_tuple(), fill_val(), finalize_aggregate(), finalize_partialaggregate(), finalize_windowaggregate(), 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_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(), GetTableAmRoutine(), getTokenTypes(), GetTsmRoutine(), ghstore_compress(), ghstore_consistent(), ghstore_penalty(), gin_extract_hstore_query(), gin_extract_jsonb_query(), gin_extract_jsonb_query_path(), ginExtractEntries(), ginNewScanKey(), gistdentryinit(), gistFetchAtt(), gistFormTuple(), gtrgm_compress(), gtrgm_consistent(), gtrgm_decompress(), gtrgm_distance(), gtrgm_penalty(), gtsvector_compress(), gtsvector_consistent(), gtsvector_decompress(), gtsvector_penalty(), heap_compute_data_size(), heapam_index_validate_scan(), hlparsetext(), hstore_slice_to_array(), hstoreUpgrade(), index_concurrently_create_copy(), index_form_tuple(), 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(), memcpyDatum(), mode_final(), movedb_failure_callback(), numeric_abbrev_convert(), numeric_fast_cmp(), oidvectorrecv(), ordered_set_shutdown(), outDatum(), parseRelOptions(), parsetext(), patternsel_common(), pg_attribute_aclmask(), pg_class_aclmask(), pg_database_aclmask(), pg_foreign_data_wrapper_aclmask(), pg_foreign_server_aclmask(), pg_get_indexdef_worker(), pg_get_partkeydef_worker(), pg_language_aclmask(), pg_largeobject_aclmask_snapshot(), pg_namespace_aclmask(), pg_proc_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_tablespace_aclmask(), pg_type_aclmask(), pgwin32_SharedMemoryDelete(), plperl_call_perl_func(), plperl_hash_from_tuple(), plpgsql_exec_function(), plpgsql_exec_trigger(), plpgsql_inline_handler(), plpython_inline_handler(), PLy_cursor_plan(), PLy_spi_execute_plan(), PLyObject_FromTransform(), populate_record_field(), printtup(), ProcedureCreate(), process_ordered_aggregate_single(), prs_setup_firstcall(), prune_element_hashtable(), pushval_morph(), record_image_cmp(), refresh_by_match_merge(), RelationBuildPartitionKey(), RelationInitIndexAccessInfo(), ReorderBufferToastAppendChunk(), ReorderBufferToastReplace(), reorderqueue_pop(), ResourceOwnerForgetJIT(), ResourceOwnerReleaseInternal(), scalarineqsel(), sepgsql_fmgr_hook(), SharedFileSetOnDetach(), shm_mq_detach_callback(), show_trgm(), ShowAllGUCConfig(), shutdown_MultiFuncCall(), ShutdownSetExpr(), ShutdownSQLFunction(), ShutdownTupleDescRef(), simplify_function(), spg_text_inner_consistent(), spg_text_leaf_consistent(), spgFreeSearchItem(), statext_mcv_serialize(), StoreAttrDefault(), test_indoption(), text2ltree(), text_substring(), thesaurus_lexize(), TidListEval(), toast_build_flattened_tuple(), toast_compress_datum(), toast_datum_size(), toast_delete_datum(), toast_fetch_datum(), toast_fetch_datum_slice(), 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(), and untransformRelOptions().
#define DatumGetTransactionId | ( | X | ) | ((TransactionId) (X)) |
Definition at line 514 of file postgres.h.
Referenced by ExecCheckTupleVisible(), ExecOnConflictUpdate(), and RI_FKey_fk_upd_check_required().
#define DatumGetUInt16 | ( | X | ) | ((uint16) (X)) |
Definition at line 458 of file postgres.h.
Referenced by gintuple_get_attrnum().
#define DatumGetUInt32 | ( | X | ) | ((uint32) (X)) |
Definition at line 486 of file postgres.h.
Referenced by _hash_datum2hashkey(), _hash_datum2hashkey_type(), bernoulli_nextsampletuple(), bms_hash_value(), comparetup_index_hash(), element_hash(), ExecHashBuildSkewHash(), ExecHashGetHashValue(), hash_array(), hash_range(), JsonbHashScalarValue(), lexeme_hash(), macaddr_abbrev_convert(), make_text_key(), network_abbrev_convert(), notification_hash(), numeric_cmp_abbrev(), ParallelWorkerMain(), ResourceArrayAdd(), ResourceArrayRemove(), string_hash(), system_nextsampleblock(), tablesample_init(), tag_hash(), timetz_hash(), TupleHashTableHash(), uint32_hash(), uuid_abbrev_convert(), and varstr_abbrev_convert().
#define DatumGetUInt64 | ( | X | ) | (* ((uint64 *) DatumGetPointer(X))) |
Definition at line 634 of file postgres.h.
Referenced by AppendJumble(), compute_partition_hash_value(), hash_array_extended(), hash_numeric_extended(), hash_range_extended(), JsonbHashScalarValueExtended(), k_hashes(), pgss_hash_string(), pgss_post_parse_analyze(), satisfies_hash_partition(), and timetz_hash_extended().
#define DatumGetUInt8 | ( | X | ) | ((uint8) (X)) |
Definition at line 430 of file postgres.h.
#define FIELDNO_NULLABLE_DATUM_DATUM 0 |
Definition at line 377 of file postgres.h.
#define FIELDNO_NULLABLE_DATUM_ISNULL 1 |
Definition at line 379 of file postgres.h.
Referenced by llvm_compile_expr().
#define Float8GetDatumFast | ( | X | ) | PointerGetDatum(&(X)) |
Definition at line 761 of file postgres.h.
Referenced by float4_accum(), float8_accum(), float8_combine(), float8_regr_accum(), float8_regr_combine(), interval_lerp(), and pg_stat_statements_internal().
#define Int16GetDatum | ( | X | ) | ((Datum) (X)) |
Definition at line 451 of file postgres.h.
Referenced by AggregateCreate(), brincostestimate(), btcostestimate(), column_privilege_check(), CreateConstraintEntry(), CreateTrigger(), DeleteSystemAttributeTuples(), dropOperators(), dropProcedures(), examine_simple_variable(), examine_variable(), ExecEvalNextValueExpr(), ExecGrant_Attribute(), ExecHashBuildSkewHash(), expand_all_col_privileges(), fixup_whole_row_references(), gbt_num_fetch(), get_attavgwidth(), get_attgenerated(), get_attname(), get_attribute_options(), get_atttype(), get_atttypetypmodcoll(), get_object_address_attrdef(), get_object_address_opf_member(), get_opfamily_member(), get_opfamily_proc(), get_rte_attribute_is_dropped(), get_rte_attribute_type(), GetForeignColumnOptions(), gist_point_consistent(), gistindex_keytest(), gistproperty(), inclusion_get_strategy_procinfo(), index_check_primary_key(), InsertPgAttributeTuple(), InsertPgClassTuple(), join_selectivity(), leftmostvalue_int2(), minmax_get_strategy_procinfo(), neqjoinsel(), pg_attribute_aclcheck_all(), pg_attribute_aclmask(), pg_buffercache_pages(), pg_lock_status(), plpgsql_fulfill_promise(), recordExtObjInitPriv(), RelationBuildTupleDesc(), RelationClearMissing(), RemoveAttrDefault(), RemoveAttrDefaultById(), RemoveAttributeById(), removeExtObjInitPriv(), RemoveStatistics(), scalararraysel(), scanRTEForColumn(), SearchSysCacheAttNum(), sepgsql_attribute_post_create(), spg_text_choose(), spg_text_picksplit(), StoreAttrDefault(), storeOperators(), StorePartitionKey(), storeProcedures(), tsvector_unnest(), TypeCreate(), TypeShellMake(), update_attstats(), and UpdateIndexRelation().
#define Int32GetDatum | ( | X | ) | ((Datum) (X)) |
Definition at line 479 of file postgres.h.
Referenced by _PG_init(), AggregateCreate(), AlterDatabase(), AlterRole(), AlterStatistics(), array_positions(), ATExecAlterColumnType(), autoinc(), bitshiftleft(), bitshiftright(), brin_metapage_info(), build_coercion_expression(), build_regexp_match_result(), build_regexp_split_result(), cash_numeric(), check_timezone(), CollationCreate(), compileTheLexeme(), compileTheSubstitute(), ConversionCreate(), create_hash_bounds(), CreateComments(), CreateConstraintEntry(), CreateConversionCommand(), createdb(), CreateRole(), CreateStatistics(), daterange_canonical(), datum_to_jsonb(), dblink_get_notify(), DeleteComments(), DeleteInitPrivs(), deleteOneObject(), DeleteSecurityLabel(), drop_parent_dependency(), DropConfigurationMapping(), eval_const_expressions_mutator(), exec_stmt_fori(), ExecEvalGroupingFunc(), ExecEvalNextValueExpr(), ExecInitExprRec(), ExecMergeAppend(), executeItemOptUnwrapTarget(), fill_hba_line(), FindDefaultConversion(), findDependentObjects(), flatten_set_variable_args(), Float4GetDatum(), gather_merge_getnext(), gather_merge_init(), gbt_num_fetch(), gbt_numeric_penalty(), generate_series_step_int4(), generate_setop_tlist(), generate_subscripts(), get_constraint_index(), 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(), hash_bitmap_info(), hash_metapage_info(), hash_page_items(), hash_page_stats(), hlparsetext(), hstore_to_jsonb_loose(), hypothetical_dense_rank_final(), hypothetical_rank_common(), IdentifySystem(), in_range_int2_int2(), in_range_int2_int8(), in_range_int4_int2(), index_concurrently_swap(), IndexSetParentIndex(), InitAuxiliaryProcess(), InputFunctionCall(), InsertPgAttributeTuple(), InsertPgClassTuple(), int2vectorrecv(), int4_to_char(), int4range_canonical(), int8_avg_deserialize(), InternalIpcMemoryCreate(), inv_read(), inv_truncate(), inv_write(), IsThereCollationInNamespace(), jsonb_in_scalar(), leftmostvalue_bit(), leftmostvalue_int4(), leftmostvalue_varbit(), LexizeExec(), logicalrep_worker_launch(), lookup_collation(), make_const(), MakeConfigurationMapping(), moddatetime(), network_scan_last(), numeric_avg_deserialize(), numeric_deserialize(), numeric_poly_deserialize(), numeric_to_char(), numeric_to_number(), oidvectorrecv(), ordered_set_transition_multi(), parsetext(), perform_default_encoding_conversion(), pg_backup_start_time(), pg_blocking_pids(), pg_buffercache_pages(), pg_control_checkpoint(), pg_control_init(), pg_control_recovery(), pg_control_system(), pg_do_encoding_conversion(), pg_event_trigger_ddl_commands(), pg_event_trigger_dropped_objects(), pg_get_object_address(), pg_get_replication_slots(), pg_get_serial_sequence(), pg_lock_status(), pg_lsn_mi(), pg_partition_tree(), pg_safe_snapshot_blocking_pids(), pg_size_bytes(), pg_stat_get_activity(), pg_stat_get_backend_idset(), pg_stat_get_progress_info(), pg_stat_get_subscription(), pg_stat_get_wal_receiver(), pg_stat_get_wal_senders(), pg_stats_ext_mcvlist_items(), pgstatginindex_internal(), pgstathashindex(), PLyNumber_ToJsonbValue(), printTypmod(), ProcSignalInit(), prs_setup_firstcall(), ReceiveFunctionCall(), recordExtensionInitPrivWorker(), recordMultipleDependencies(), ReorderBufferIterTXNInit(), ReorderBufferIterTXNNext(), restriction_selectivity(), ri_AttributesEqual(), scalararraysel(), SetAttrMissing(), SetSecurityLabel(), shdepAddDependency(), shdepChangeDep(), shdepDropDependency(), show_all_file_settings(), ssl_client_serial(), StoreSingleInheritance(), SV_to_JsonbValue(), textregexsubstr(), tfuncLoadRows(), toast_fetch_datum_slice(), toast_save_datum(), transformContainerSubscripts(), ts_lexize(), tsquery_phrase(), ttdummy(), TypeCreate(), TypeShellMake(), unaccent_dict(), update_attstats(), validateRecoveryParameters(), and worker_spi_launch().
#define Int64GetDatumFast | ( | X | ) | PointerGetDatum(&(X)) |
Definition at line 760 of file postgres.h.
Referenced by DefineSequence(), FunctionNext(), int2int4_sum(), int8_avg(), interval_hash(), interval_hash_extended(), numeric_poly_avg(), pg_stat_statements_internal(), timetz_hash(), and timetz_hash_extended().
#define Int8GetDatum | ( | X | ) | ((Datum) (X)) |
Definition at line 423 of file postgres.h.
#define MultiXactIdGetDatum | ( | X | ) | ((Datum) (X)) |
Definition at line 528 of file postgres.h.
Referenced by InsertPgClassTuple().
#define NameGetDatum | ( | X | ) | CStringGetDatum(NameStr(*(X))) |
Definition at line 595 of file postgres.h.
Referenced by AddEnumLabel(), AlterObjectRename_internal(), AlterTypeNamespaceInternal(), CatCacheCopyKeys(), CollationCreate(), ConversionCreate(), copy_replication_slot(), create_proc_lang(), CreateConstraintEntry(), CreateOpFamily(), CreateStatistics(), DefineOpClass(), DefineTSConfiguration(), DefineTSDictionary(), DefineTSParser(), DefineTSTemplate(), EnumValuesCreate(), insert_event_trigger_tuple(), InsertPgAttributeTuple(), InsertPgClassTuple(), InsertRule(), leftmostvalue_name(), nameiclike(), nameicnlike(), NamespaceCreate(), OperatorCreate(), OperatorShellMake(), pg_create_logical_replication_slot(), pg_create_physical_replication_slot(), pg_get_replication_slots(), pg_replication_slot_advance(), ProcedureCreate(), RelationBuildTriggers(), TypeCreate(), and TypeShellMake().
#define ObjectIdGetDatum | ( | X | ) | ((Datum) (X)) |
Definition at line 507 of file postgres.h.
Referenced by _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(), 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(), AlterPublicationOwner_oid(), AlterRelationNamespaceInternal(), AlterRole(), AlterSchemaOwner_internal(), AlterSchemaOwner_oid(), AlterSeqNamespaces(), AlterSequence(), AlterSetting(), AlterStatistics(), AlterSubscriptionOwner_oid(), AlterTableMoveAll(), AlterTSDictionary(), AlterTypeNamespaceInternal(), AlterTypeOwner_oid(), AlterTypeOwnerInternal(), AlterUserMapping(), amvalidate(), appendAggOrderBy(), appendFunctionName(), ApplyExtensionUpdates(), ApplySetting(), assignOperTypes(), assignProcTypes(), ATAddForeignKeyConstraint(), ATDetachCheckNoForeignKeyRefs(), ATExecAddColumn(), ATExecAddOf(), ATExecAlterColumnType(), ATExecAlterConstraint(), ATExecAttachPartition(), ATExecChangeOwner(), ATExecDetachPartition(), ATExecDisableRowSecurity(), ATExecDropConstraint(), ATExecDropNotNull(), ATExecDropOf(), ATExecEnableRowSecurity(), ATExecForceNoForceRowSecurity(), ATExecSetRelOptions(), ATExecSetTableSpace(), ATExecSetTableSpaceNoStorage(), ATExecValidateConstraint(), ATPostAlterTypeCleanup(), ATPrepChangePersistence(), AttrDefaultFetch(), blvalidate(), brincostestimate(), brinvalidate(), btcostestimate(), btvalidate(), build_coercion_expression(), build_regtype_array(), CacheInvalidateRelcacheByRelid(), call_pltcl_start_proc(), CallStmtResultDesc(), change_owner_fix_column_acls(), change_owner_recurse_to_sequences(), changeDependenciesOf(), changeDependenciesOn(), changeDependencyFor(), check_amop_signature(), check_amproc_signature(), check_enable_rls(), check_for_column_name_collision(), check_hash_func_signature(), check_object_ownership(), check_rel_can_be_partition(), check_sql_fn_statements(), check_timezone(), check_TSCurrentConfig(), CheckConstraintFetch(), CheckFunctionValidatorAccess(), CheckIndexCompatible(), CheckMyDatabase(), checkSharedDependencies(), ChooseConstraintName(), ChooseExtendedStatisticName(), CloneFkReferenced(), CloneRowTriggersToPartition(), cluster(), cluster_rel(), CollationCreate(), CollationIsVisible(), column_privilege_check(), compile_plperl_function(), compile_pltcl_function(), ComputeIndexAttrs(), ConstraintNameExists(), ConstraintNameIsUsed(), ConstraintSetParentConstraint(), ConstructTupleDescriptor(), ConversionCreate(), ConversionGetConid(), ConversionIsVisible(), convert_column_name(), copy_table_data(), copyTemplateDependencies(), CountDBSubscriptions(), create_proc_lang(), create_toast_table(), CreateAccessMethod(), CreateCast(), CreateComments(), CreateConstraintEntry(), createdb(), CreateForeignDataWrapper(), CreateForeignServer(), CreateForeignTable(), CreateFunction(), CreateInheritance(), CreateOpFamily(), CreatePolicy(), CreatePublication(), CreateRole(), CreateSchemaCommand(), CreateSharedComments(), CreateStatistics(), CreateSubscription(), CreateTableSpace(), CreateTransform(), CreateTrigger(), CreateUserMapping(), currtid_for_view(), datum_to_jsonb(), decompile_conbin(), DefineCollation(), DefineCompositeType(), DefineDomain(), DefineEnum(), DefineIndex(), DefineOpClass(), DefineQueryRewrite(), DefineRange(), DefineSequence(), DefineTSConfiguration(), DefineTSDictionary(), DefineTSParser(), DefineTSTemplate(), DefineType(), DeleteAttributeTuples(), DeleteComments(), deleteDependencyRecordsFor(), deleteDependencyRecordsForClass(), DeleteInheritsTuple(), DeleteInitPrivs(), deleteOneObject(), DeleteRelationTuple(), DeleteSecurityLabel(), DeleteSequenceTuple(), DeleteSharedComments(), DeleteSharedSecurityLabel(), DeleteSystemAttributeTuples(), DelRoleMems(), deparseOpExpr(), deparseScalarArrayOpExpr(), do_autovacuum(), do_compile(), do_setval(), drop_parent_dependency(), DropCastById(), DropConfigurationMapping(), dropDatabaseDependencies(), dropdb(), dropOperators(), DropProceduralLanguageById(), dropProcedures(), DropRole(), DropSetting(), DropTransformById(), 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(), examine_attribute(), examine_simple_variable(), examine_variable(), exec_stmt_call(), ExecGrant_Attribute(), ExecGrant_Database(), ExecGrant_Fdw(), ExecGrant_ForeignServer(), ExecGrant_Function(), ExecGrant_Language(), ExecGrant_Largeobject(), ExecGrant_Namespace(), ExecGrant_Relation(), ExecGrant_Tablespace(), ExecGrant_Type(), ExecHashBuildSkewHash(), ExecInitAgg(), ExecInitExprRec(), ExecuteCallStmt(), expand_all_col_privileges(), expand_vacuum_rel(), extension_config_remove(), fetch_agg_sort_op(), fetch_fp_info(), fetch_statentries_for_relation(), find_coercion_pathway(), find_composite_type_dependencies(), find_expr_references_walker(), find_inheritance_children(), find_typed_table_dependencies(), find_typmod_coercion_function(), FindDefaultConversion(), findDependentObjects(), 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_internal(), format_operator_parts(), format_procedure_internal(), format_procedure_parts(), format_type_extended(), func_get_detail(), func_parallel(), func_strict(), func_volatile(), FunctionIsVisible(), 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_qualified_relation_name(), generate_qualified_type_name(), generate_relation_name(), generateClonedExtStatsStmt(), generateClonedIndexStmt(), get_agg_clause_costs_walker(), get_am_name(), get_array_type(), get_attavgwidth(), get_attgenerated(), get_attname(), 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_ref_constraints(), get_language_name(), get_mergejoin_opfamilies(), get_namespace_name(), get_negator(), get_object_address_attrdef(), get_object_address_defacl(), get_object_address_opf_member(), get_object_address_publication_rel(), 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_name(), get_opclass_opfamily_and_input_type(), get_opcode(), get_oper_expr(), 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_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_relname_relid(), get_rels_with_domain(), get_rewrite_oid(), get_rte_attribute_is_dropped(), get_rte_attribute_type(), get_statistics_object_oid(), get_subscription_name(), get_tablespace(), get_tablespace_name(), get_transform_oid(), 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_typtype(), getBaseTypeAndTypmod(), GetComment(), GetConnection(), GetDatabaseTupleByOid(), GetDefaultOpClass(), getExtensionOfObject(), GetFdwRoutineByServerId(), GetForeignColumnOptions(), GetForeignDataWrapperExtended(), GetForeignServerExtended(), GetForeignServerIdByRelId(), GetForeignTable(), GetIndexAmRoutineByAmId(), GetNewOidWithIndex(), getObjectDescription(), getObjectIdentityParts(), getOpFamilyDescription(), getOpFamilyIdentity(), getOwnedSequences_internal(), GetParentedForeignKeyRefs(), getProcedureTypeDescription(), GetPublication(), GetPublicationRelations(), getRelationDescription(), getRelationIdentity(), GetRelationPublicationActions(), GetRelationPublications(), getRelationsInNamespace(), getRelationTypeDescription(), GetSecurityLabel(), GetSharedSecurityLabel(), GetSubscription(), GetSubscriptionNotReadyRelations(), GetSubscriptionRelations(), GetSubscriptionRelState(), GetTSConfigTuple(), getTypeBinaryInputInfo(), getTypeBinaryOutputInfo(), getTypeInputInfo(), getTypeOutputInfo(), GetUserMapping(), GetUserNameFromId(), gin_enum_cmp(), ginvalidate(), gistindex_keytest(), gistproperty(), gistvalidate(), has_any_column_privilege_id(), has_any_column_privilege_id_id(), has_any_column_privilege_name_id(), has_bypassrls_privilege(), has_createrole_privilege(), has_database_privilege_id(), has_database_privilege_id_id(), has_database_privilege_name_id(), has_foreign_data_wrapper_privilege_id(), has_foreign_data_wrapper_privilege_id_id(), has_foreign_data_wrapper_privilege_name_id(), has_function_privilege_id(), has_function_privilege_id_id(), has_function_privilege_name_id(), has_language_privilege_id(), has_language_privilege_id_id(), has_language_privilege_name_id(), has_rolinherit(), has_rolreplication(), has_schema_privilege_id(), has_schema_privilege_id_id(), has_schema_privilege_name_id(), has_server_privilege_id(), has_server_privilege_id_id(), has_server_privilege_name_id(), has_subclass(), has_superclass(), has_table_privilege_id(), has_table_privilege_id_id(), has_table_privilege_name_id(), has_tablespace_privilege_id(), has_tablespace_privilege_id_id(), has_tablespace_privilege_name_id(), has_type_privilege_id(), has_type_privilege_id_id(), has_type_privilege_name_id(), hash_metapage_info(), hash_ok_operator(), hashvalidate(), have_createdb_privilege(), heap_create_with_catalog(), heap_drop_with_catalog(), heap_getsysattr(), 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_peragg(), InitializeSessionUserId(), inline_set_returning_function(), InputFunctionCall(), insert_event_trigger_tuple(), InsertExtensionTuple(), InsertPgAttributeTuple(), InsertPgClassTuple(), InsertRule(), int2vectorrecv(), int8_avg_deserialize(), internal_get_result_type(), interpret_function_parameter_list(), inv_getsize(), inv_read(), inv_truncate(), inv_write(), is_admin_of_role(), IsBinaryCoercible(), IsDefinedRewriteRule(), isObjectPinned(), isSharedObjectPinned(), IsThereCollationInNamespace(), IsThereFunctionInNamespace(), IsThereOpClassInNamespace(), IsThereOpFamilyInNamespace(), join_selectivity(), jsonb_in_scalar(), 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(), 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_const(), make_new_heap(), makeArrayTypeName(), makeConfigurationDependencies(), MakeConfigurationMapping(), map_sql_table_to_xmlschema(), map_sql_type_to_xml_name(), mark_index_clustered(), MergeConstraintsIntoExisting(), MergeWithExistingConstraint(), minmax_get_strategy_procinfo(), moddatetime(), movedb(), myLargeObjectExists(), NamespaceCreate(), neqjoinsel(), nextval_internal(), numeric_avg_deserialize(), numeric_deserialize(), numeric_poly_deserialize(), numeric_to_number(), objectsInSchemaToOids(), oidvectorrecv(), op_hashjoinable(), op_in_opfamily(), op_input_types(), op_mergejoinable(), OpClassCacheLookup(), OpclassIsVisible(), OpclassnameGetOpcid(), oper(), OperatorCreate(), OperatorGet(), OperatorIsVisible(), OperatorShellMake(), OperatorUpd(), OpernameGetOprid(), opfamily_can_sort_type(), OpFamilyCacheLookup(), OpfamilyIsVisible(), OpfamilynameGetOpfid(), ParseFuncOrColumn(), perform_work_item(), pg_attribute_aclcheck_all(), pg_attribute_aclmask(), pg_backup_start_time(), pg_buffercache_pages(), pg_class_aclmask(), pg_class_ownercheck(), pg_collation_actual_version(), pg_collation_is_visible(), pg_collation_ownercheck(), pg_control_checkpoint(), pg_conversion_is_visible(), pg_conversion_ownercheck(), pg_database_aclmask(), pg_database_ownercheck(), pg_event_trigger_ddl_commands(), pg_event_trigger_dropped_objects(), pg_event_trigger_ownercheck(), pg_extension_config_dump(), pg_extension_ownercheck(), pg_foreign_data_wrapper_aclmask(), pg_foreign_data_wrapper_ownercheck(), pg_foreign_server_aclmask(), pg_foreign_server_ownercheck(), pg_function_is_visible(), pg_get_constraintdef_worker(), pg_get_function_arg_default(), pg_get_function_arguments(), pg_get_function_identity_arguments(), pg_get_function_result(), pg_get_functiondef(), pg_get_indexdef_worker(), pg_get_object_address(), pg_get_partkeydef_worker(), pg_get_publication_tables(), pg_get_ruledef_worker(), pg_get_serial_sequence(), pg_get_statisticsobj_worker(), pg_get_triggerdef_worker(), pg_get_userbyid(), pg_get_viewdef_worker(), pg_language_aclmask(), pg_language_ownercheck(), pg_largeobject_aclmask_snapshot(), pg_largeobject_ownercheck(), pg_lock_status(), pg_ls_tmpdir(), pg_lsn_mi(), pg_namespace_aclmask(), pg_namespace_ownercheck(), pg_newlocale_from_collation(), pg_opclass_is_visible(), pg_opclass_ownercheck(), pg_oper_ownercheck(), pg_operator_is_visible(), pg_opfamily_is_visible(), pg_opfamily_ownercheck(), pg_partition_ancestors(), pg_partition_tree(), pg_prepared_xact(), pg_proc_aclmask(), pg_proc_ownercheck(), pg_publication_ownercheck(), pg_relation_filenode(), pg_relation_filepath(), pg_relation_is_publishable(), pg_sequence_parameters(), pg_show_replication_origin_status(), pg_size_bytes(), pg_stat_get_activity(), pg_stat_get_progress_info(), pg_stat_get_subscription(), pg_stat_statements_internal(), pg_statistics_obj_is_visible(), pg_statistics_object_ownercheck(), pg_subscription_ownercheck(), pg_table_is_visible(), pg_tablespace_aclmask(), pg_tablespace_databases(), pg_tablespace_ownercheck(), pg_ts_config_is_visible(), pg_ts_config_ownercheck(), pg_ts_dict_is_visible(), pg_ts_dict_ownercheck(), pg_ts_parser_is_visible(), pg_ts_template_is_visible(), pg_type_aclmask(), pg_type_is_visible(), pg_type_ownercheck(), pgfdw_reject_incomplete_xact_state_change(), phraseto_tsquery(), plainto_tsquery(), plperl_trigger_build_args(), plperl_validator(), plpgsql_build_datatype(), plpgsql_compile(), plpgsql_fulfill_promise(), plpgsql_parse_cwordtype(), plpgsql_validator(), plpython_validator(), pltcl_trigger_handler(), PLy_procedure_create(), PLy_procedure_get(), PLy_trigger_build_args(), PLyNumber_ToJsonbValue(), policy_role_list_to_array(), prepare_column_cache(), ProcedureCreate(), publication_add_relation(), PublicationDropTables(), RangeCreate(), RangeDelete(), RangeVarCallbackForAlterRelation(), RangeVarCallbackForAttachIndex(), RangeVarCallbackForDropRelation(), RangeVarCallbackForPolicy(), RangeVarCallbackForRenameAttribute(), RangeVarCallbackForRenameRule(), RangeVarCallbackForRenameTrigger(), RangeVarCallbackForTruncate(), RangeVarCallbackOwnsRelation(), ReceiveFunctionCall(), recomputeNamespacePath(), record_plan_function_dependency(), record_plan_type_dependency(), recordExtensionInitPrivWorker(), recordExtObjInitPriv(), recordMultipleDependencies(), refresh_by_match_merge(), regclassout(), regconfigout(), regdictionaryout(), regoperout(), regprocout(), regtypeout(), reindex_index(), ReindexMultipleTables(), relation_has_policies(), relation_mark_replica_identity(), RelationBuildPartitionDesc(), RelationBuildPartitionKey(), RelationBuildRowSecurity(), RelationBuildRuleLock(), RelationBuildTriggers(), RelationBuildTupleDesc(), RelationCacheInitializePhase3(), RelationClearMissing(), RelationGetExclusionInfo(), RelationGetFKeyList(), RelationGetIndexList(), RelationGetStatExtList(), relationHasPrimaryKey(), RelationInitIndexAccessInfo(), RelationInitTableAccessMethod(), RelationIsVisible(), RelationReloadIndexInfo(), RelationRemoveInheritance(), RelationSetNewRelfilenode(), RelidByRelfilenode(), RemoveAccessMethodById(), RemoveAmOpEntryById(), RemoveAmProcEntryById(), RemoveAttrDefault(), RemoveAttrDefaultById(), RemoveAttributeById(), RemoveCollationById(), RemoveConstraintById(), RemoveConversionById(), RemoveDefaultACLById(), RemoveEventTriggerById(), RemoveExtensionById(), removeExtObjInitPriv(), RemoveForeignDataWrapperById(), RemoveForeignServerById(), RemoveFunctionById(), RemoveInheritance(), RemoveOpClassById(), RemoveOperatorById(), RemoveOpFamilyById(), RemovePartitionKeyByRelId(), RemovePolicyById(), RemovePublicationById(), RemovePublicationRelById(), RemoveRewriteRuleById(), RemoveRoleFromObjectACL(), RemoveRoleFromObjectPolicy(), RemoveSchemaById(), RemoveStatistics(), RemoveStatisticsById(), RemoveSubscriptionRel(), RemoveTriggerById(), RemoveTSConfigurationById(), RemoveTSDictionaryById(), RemoveTSParserById(), RemoveTSTemplateById(), RemoveTypeById(), RemoveUserMapping(), RemoveUserMappingById(), rename_constraint_internal(), rename_policy(), RenameConstraint(), RenameConstraintById(), RenameDatabase(), RenameEnumLabel(), RenameRelationInternal(), RenameRewriteRule(), renametrig(), RenameType(), RenameTypeInternal(), replorigin_by_oid(), replorigin_create(), replorigin_drop(), ResetSequence(), ResolveOpClass(), restriction_selectivity(), ri_GenerateQualCollation(), ri_LoadConstraintInfo(), right_oper(), roles_has_privs_of(), roles_is_member_of(), scalararraysel(), ScanPgRelation(), scanRTEForColumn(), SearchSysCacheAttName(), SearchSysCacheAttNum(), 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(), sequenceIsOwned(), SetAttrMissing(), SetDefaultACL(), SetFunctionArgType(), SetFunctionReturnType(), SetMatViewPopulatedState(), SetRelationHasSubclass(), SetRelationNumChecks(), SetRelationRuleStatus(), SetSecurityLabel(), SetSharedSecurityLabel(), shdepAddDependency(), shdepChangeDep(), shdepDropDependency(), shdepDropOwned(), shdepLockAndCheckObject(), shdepReassignOwned(), simplify_function(), slot_getsysattr(), spgproperty(), spgvalidate(), SPI_gettype(), ssl_client_serial(), statext_dependencies_load(), statext_mcv_load(), statext_ndistinct_load(), statext_store(), StatisticsObjIsVisible(), 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(), to_tsquery(), to_tsvector(), toast_delete_datum(), toast_fetch_datum(), toast_fetch_datum_slice(), toast_save_datum(), toastrel_valueid_exists(), transformContainerType(), transformFkeyCheckAttrs(), transformFkeyGetPrimaryKey(), transformFrameOffset(), transformGenericOptions(), triggered_change_notification(), try_relation_open(), tryAttachPartitionForeignKey(), TryReuseForeignKey(), ts_headline(), ts_headline_json(), ts_headline_json_opt(), ts_headline_jsonb(), ts_headline_jsonb_opt(), ts_headline_opt(), TSConfigIsVisible(), TSDictionaryIsVisible(), TSParserIsVisible(), TSTemplateIsVisible(), TupleDescInitEntry(), TypeCreate(), typeidType(), typeidTypeRelid(), typeInheritsFrom(), typeIsOfTypedTable(), TypeIsVisible(), TypenameGetTypidExtended(), typeOrDomainTypeRelid(), TypeShellMake(), unaccent_dict(), update_attstats(), update_default_partition_oid(), update_relispartition(), UpdateIndexRelation(), UpdateStatisticsForTypeChange(), UpdateSubscriptionRelState(), vac_update_datfrozenxid(), vac_update_relstats(), validatePartitionedIndex(), validateRecoveryParameters(), verify_dictoptions(), and websearch_to_tsquery().
#define PointerGetDatum | ( | X | ) | ((Datum) (X)) |
Definition at line 556 of file postgres.h.
Referenced by _int_different(), _ltree_compress(), _ltree_picksplit(), accumArrayResult(), add_function_cost(), 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_iterate(), array_iterator(), array_map(), array_ref(), array_replace_internal(), array_set(), array_set_element(), array_set_slice(), assign_simple_var(), ATExecAlterColumnGenericOptions(), ATExecAlterColumnType(), ATExecChangeOwner(), ATExecGenericOptions(), autoinc(), binary_upgrade_create_empty_extension(), bpcharfastcmp_c(), brin_revmap_data(), brinbuildCallback(), bringetbitmap(), brininsert(), bt_normalize_tuple(), 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(), 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(), coerce_function_result_tuple(), coerce_type(), CollationCreate(), collectMatchBitmap(), compareJsonbScalarValue(), comparetup_datum(), 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(), create_proc_lang(), CreateConstraintEntry(), createdb(), CreateExtensionInternal(), CreateForeignDataWrapper(), CreateForeignServer(), CreateForeignTable(), CreateFunction(), CreatePolicy(), CreateProceduralLanguage(), CreateSchemaCommand(), CreateStatistics(), CreateTrigger(), CreateUserMapping(), currtid_for_view(), date_mi_interval(), date_pl_interval(), 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(), equalsJsonbScalarValue(), evaluate_expr(), examine_attribute(), exec_assign_c_string(), exec_assign_value(), ExecBuildAggTrans(), ExecEvalArrayCoerce(), ExecEvalArrayExpr(), ExecEvalSubscriptingRefAssign(), ExecEvalWholeRowVar(), ExecEvalXmlExpr(), ExecGrant_Attribute(), ExecGrant_Database(), ExecGrant_Fdw(), ExecGrant_ForeignServer(), ExecGrant_Function(), ExecGrant_Language(), ExecGrant_Largeobject(), ExecGrant_Namespace(), ExecGrant_Relation(), ExecGrant_Tablespace(), ExecGrant_Type(), ExecIndexBuildScanKeys(), ExecIndexEvalRuntimeKeys(), ExecInitCteScan(), ExecInitRecursiveUnion(), ExecInitSubPlan(), ExecInterpExpr(), ExecMakeFunctionResultSet(), ExecPrepareTuplestoreResult(), ExecSetParamPlan(), ExecuteDoStmt(), expanded_record_set_field_internal(), expanded_record_set_fields(), extension_config_remove(), fill_hba_line(), filter_list_to_array(), FinishSortSupportFunction(), Float8GetDatum(), fmgr_sql(), 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_bpchar_consistent(), 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_fetch(), 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(), generate_series_timestamptz(), Generic_Text_IC_like(), genericPickSplit(), get_cached_rowtype(), 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(), 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(), ginNewScanKey(), gist_box_leaf_consistent(), gist_box_picksplit(), gist_circle_compress(), gist_point_consistent(), gist_point_fetch(), gist_poly_compress(), gistdentryinit(), gistFetchAtt(), gistFormTuple(), 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_svals(), hstore_to_array_internal(), hstore_to_plperl(), hstore_to_plpython(), index_form_tuple(), inet_gist_compress(), inet_gist_picksplit(), init_MultiFuncCall(), init_ts_config_cache(), InitializeSessionUserId(), insert_username(), InsertExtensionTuple(), InsertOneNull(), InsertRule(), int2vectorrecv(), Int64GetDatum(), int8_avg_deserialize(), InternalIpcMemoryCreate(), interpret_function_parameter_list(), inv_truncate(), inv_write(), IsDefinedRewriteRule(), IsThereFunctionInNamespace(), jit_release_context(), join_selectivity(), jsonb_ops__add_path_item(), jsonb_put_escaped_value(), jsonb_to_plperl(), jsonb_to_plpython(), JsonbValueAsText(), leftmostvalue_numeric(), leftmostvalue_text(), LexizeExec(), llvm_create_context(), lo_manage(), LogicalOutputWrite(), lookup_collation(), lookup_ts_dictionary_cache(), lookup_ts_parser_cache(), LookupTypeNameExtended(), lt_q_regex(), ltree_addtext(), ltree_compress(), ltree_consistent(), ltree_decompress(), ltree_picksplit(), ltree_textadd(), ltree_to_plpython(), make_greater_string(), make_text_key(), make_tuple_indirect(), makeArrayResultArr(), makeConst(), makeMdArrayResult(), makeRangeConstructors(), matchPartialInPendingList(), MJExamineQuals(), moddatetime(), movedb(), NamespaceCreate(), neqjoinsel(), numeric_avg_deserialize(), numeric_deserialize(), numeric_poly_deserialize(), oidvectorrecv(), OpClassCacheLookup(), OpclassnameGetOpcid(), OperatorGet(), OpFamilyCacheLookup(), OpfamilynameGetOpfid(), optionListToArray(), ordered_set_startup(), parse_ident(), parsetext(), pg_check_frozen(), pg_check_visible(), pg_event_trigger_ddl_commands(), pg_event_trigger_dropped_objects(), pg_extension_config_dump(), pg_identify_object_as_address(), pg_stats_ext_mcvlist_items(), pgrowlocks(), PGSharedMemoryCreate(), phraseto_tsquery(), phraseto_tsquery_byid(), plainto_tsquery(), plainto_tsquery_byid(), plperl_call_handler(), plperl_sv_to_datum(), plperl_trigger_handler(), plpgsql_call_handler(), plpgsql_fulfill_promise(), plpython_call_handler(), pltcl_handler(), PLy_cursor_plan(), PLy_spi_execute_plan(), PLyObject_ToBytea(), PLyObject_ToTransform(), PLySequence_ToArray(), populate_array_element(), populate_domain(), populate_scalar(), prepare_sql_fn_parse_info(), ProcedureCreate(), proclock_hash(), ProcLockHashCode(), prs_setup_firstcall(), publicationListToArray(), quote_ident_cstr(), range_gist_double_sorting_split(), range_send(), range_serialize(), ReadArrayBinary(), ReadArrayStr(), readDatum(), readtup_datum(), ReceiveFunctionCall(), recordExtensionInitPrivWorker(), regexp_match(), regexp_matches(), RemoveRoleFromObjectPolicy(), RenameRewriteRule(), renametrig(), ReorderBufferToastReplace(), ResolveOpClass(), ResourceOwnerCreate(), ResourceOwnerForgetCatCacheListRef(), ResourceOwnerForgetCatCacheRef(), ResourceOwnerForgetDSM(), ResourceOwnerForgetPlanCacheRef(), ResourceOwnerForgetRelationRef(), ResourceOwnerForgetSnapshot(), ResourceOwnerForgetTupleDesc(), ResourceOwnerReleaseInternal(), ResourceOwnerRememberCatCacheListRef(), ResourceOwnerRememberCatCacheRef(), ResourceOwnerRememberDSM(), ResourceOwnerRememberPlanCacheRef(), ResourceOwnerRememberRelationRef(), ResourceOwnerRememberSnapshot(), ResourceOwnerRememberTupleDesc(), restriction_selectivity(), RI_FKey_cascade_del(), RI_FKey_cascade_upd(), RI_FKey_check(), ri_restrict(), ri_set(), rtree_internal_consistent(), scalararraysel(), sepgsql_fmgr_hook(), 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(), spgLeafTest(), spgvalidate(), SPI_sql_row_to_xmlelement(), ssl_extension_info(), statext_mcv_deserialize(), statext_mcv_serialize(), statext_store(), StatisticsObjIsVisible(), StoreAttrDefault(), StorePartitionKey(), string_to_bytea_const(), suppress_redundant_updates_trigger(), test_shm_mq_setup(), text2ltree(), text_isequal(), text_overlay(), text_to_array_internal(), textoverlay_no_len(), textregexsubstr(), thesaurus_lexize(), timestamp_izone(), timestamp_mi_interval(), timestamptz_izone(), timestamptz_mi_interval(), timetz_izone(), to_tsquery(), to_tsquery_byid(), to_tsvector(), toast_build_flattened_tuple(), toast_compress_datum(), toast_datum_size(), toast_delete_external(), 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(), ts_headline_byid_opt(), ts_headline_json_byid_opt(), ts_headline_jsonb_byid_opt(), ts_lexize(), TSConfigIsVisible(), TSDictionaryIsVisible(), TSParserIsVisible(), tsqueryin(), TSTemplateIsVisible(), tstoreReceiveSlot_detoast(), tsvector_to_array(), tsvector_unnest(), tsvector_update_trigger(), ttdummy(), tts_virtual_materialize(), tuple_data_split_internal(), tuple_to_stringinfo(), tuplesort_getdatum(), tuplesort_putdatum(), TypeCreate(), TypeIsVisible(), TypenameGetTypidExtended(), typenameTypeMod(), unaccent_dict(), union_tuples(), unique_key_recheck(), update_attstats(), UpdateIndexRelation(), varlenafastcmp_locale(), varstr_abbrev_convert(), varstrfastcmp_c(), verify_dictoptions(), websearch_to_tsquery(), websearch_to_tsquery_byid(), writetup_datum(), and xmlconcat().
#define SET_VARSIZE | ( | PTR, | |
len | |||
) | SET_VARSIZE_4B(PTR, len) |
Definition at line 329 of file postgres.h.
Referenced by _ltree_compress(), _ltree_picksplit(), _ltree_union(), aclnewowner(), aclupdate(), allocacl(), array_cat(), array_get_slice(), array_in(), array_map(), array_recv(), array_replace_internal(), array_set_element(), array_set_slice(), array_to_tsvector(), be_loread(), binary_decode(), binary_encode(), bit(), bit_and(), bit_catenate(), bit_in(), bit_or(), bit_recv(), bitfromint4(), bitfromint8(), bitnot(), bitsetbit(), bitshiftleft(), bitshiftright(), bitsubstring(), bitxor(), box_poly(), bpchar(), bpchar_input(), bqarr_in(), buf_finalize(), buildint2vector(), buildoidvector(), bytea_catenate(), bytea_string_agg_finalfn(), byteain(), bytearecv(), byteatrim(), catenate_stringinfo_string(), char_bpchar(), char_text(), chr(), circle_poly(), cleanup_tsquery_stopwords(), concat_text(), construct_empty_array(), construct_md_array(), convertToJsonb(), copytext(), create_array_envelope(), cstring_to_text_with_len(), cube_a_f8(), cube_a_f8_f8(), cube_c_f8(), cube_c_f8_f8(), cube_enlarge(), cube_f8(), cube_f8_f8(), cube_inter(), cube_subset(), cube_union_v0(), decrypt_internal(), detoast_attr(), detoast_attr_slice(), EA_flatten_into(), encrypt_internal(), ExecEvalArrayExpr(), expandColorTrigrams(), fillRelOptions(), formTextDatum(), g_intbig_compress(), g_intbig_picksplit(), g_intbig_union(), gbt_bit_xfrm(), gbt_var_key_copy(), gbt_var_key_from_datum(), gbt_var_node_truncate(), generate_trgm(), generate_wildcard_trgm(), generateHeadline(), get_raw_page_internal(), ghstore_compress(), ghstore_picksplit(), ghstore_union(), gtrgm_compress(), gtrgm_picksplit(), gtrgm_union(), gtsvector_compress(), gtsvector_picksplit(), gtsvector_union(), heap_page_items(), hstore_concat(), hstore_delete(), hstore_delete_array(), hstore_delete_hstore(), hstorePairs(), inner_subltree(), int2vectorin(), inv_truncate(), inv_write(), JsonbValueToJsonb(), jsonPathFromCstring(), lca_inner(), lo_get_fragment_internal(), lpad(), lquery_in(), ltree2text(), ltree_compress(), ltree_concat(), ltree_in(), ltree_picksplit(), ltree_union(), make_greater_string(), make_result_opt_error(), make_text_key(), make_tsvector(), makeArrayResultArr(), makeDefaultBloomOptions(), makeitem(), MatchText(), new_intArrayType(), numeric_abbrev_convert(), oidvectorin(), optionListToArray(), parse_tsquery(), path_add(), path_in(), path_poly(), path_recv(), pg_armor(), pg_convert(), pg_dearmor(), pg_decrypt(), pg_decrypt_iv(), pg_digest(), pg_encrypt(), pg_encrypt_iv(), pg_hmac(), pg_random_bytes(), pgp_key_id_w(), PLyObject_ToBytea(), poly_in(), poly_path(), poly_recv(), pq_endtypsend(), QTN2QT(), queryin(), quote_literal(), range_serialize(), read_binary_file(), ReorderBufferToastReplace(), repeat(), resize_intArrayType(), rpad(), sha224_bytea(), sha256_bytea(), sha384_bytea(), sha512_bytea(), show_trgm(), similar_escape_internal(), spg_text_inner_consistent(), spg_text_leaf_consistent(), statext_dependencies_serialize(), statext_mcv_deserialize(), statext_mcv_serialize(), statext_ndistinct_serialize(), string_to_bytea_const(), text_catenate(), text_reverse(), text_substring(), toast_decompress_datum(), toast_decompress_datum_slice(), toast_fetch_datum(), toast_fetch_datum_slice(), toast_save_datum(), transformRelOptions(), translate(), tsquery_rewrite(), tsquery_rewrite_query(), tsqueryrecv(), tsquerytree(), tsvector_concat(), tsvector_delete_by_indices(), tsvector_filter(), tsvector_strip(), tsvectorin(), tsvectorrecv(), tuple_data_split_internal(), txid_current_snapshot(), txid_snapshot_recv(), varbit(), varbit_in(), varbit_recv(), and xml_recv().
#define SET_VARSIZE_1B | ( | PTR, | |
len | |||
) | (((varattrib_1b *) (PTR))->va_header = (((uint8) (len)) << 1) | 0x01) |
Definition at line 261 of file postgres.h.
#define SET_VARSIZE_4B | ( | PTR, | |
len | |||
) | (((varattrib_4b *) (PTR))->va_4byte.va_header = (((uint32) (len)) << 2)) |
Definition at line 257 of file postgres.h.
#define SET_VARSIZE_4B_C | ( | PTR, | |
len | |||
) | (((varattrib_4b *) (PTR))->va_4byte.va_header = (((uint32) (len)) << 2) | 0x02) |
Definition at line 259 of file postgres.h.
#define SET_VARSIZE_COMPRESSED | ( | PTR, | |
len | |||
) | SET_VARSIZE_4B_C(PTR, len) |
Definition at line 331 of file postgres.h.
Referenced by ReorderBufferToastReplace(), toast_compress_datum(), toast_fetch_datum(), and toast_fetch_datum_slice().
#define SET_VARSIZE_SHORT | ( | PTR, | |
len | |||
) | SET_VARSIZE_1B(PTR, len) |
Definition at line 330 of file postgres.h.
Referenced by datum_write(), fill_val(), and formTextDatum().
#define SET_VARTAG_1B_E | ( | PTR, | |
tag | |||
) |
Definition at line 263 of file postgres.h.
#define SET_VARTAG_EXTERNAL | ( | PTR, | |
tag | |||
) | SET_VARTAG_1B_E(PTR, tag) |
Definition at line 333 of file postgres.h.
Referenced by EOH_init_header(), make_tuple_indirect(), ReorderBufferToastReplace(), and toast_save_datum().
#define SIZEOF_DATUM SIZEOF_VOID_P |
Definition at line 384 of file postgres.h.
Referenced by macaddr_abbrev_convert(), and network_abbrev_convert().
#define TransactionIdGetDatum | ( | X | ) | ((Datum) (X)) |
Definition at line 521 of file postgres.h.
Referenced by createdb(), heap_getsysattr(), InsertPgClassTuple(), LogicalOutputWrite(), page_header(), pg_control_checkpoint(), pg_get_replication_slots(), pg_last_committed_xact(), pg_lock_status(), pg_prepared_xact(), and pg_stat_get_activity().
#define UInt16GetDatum | ( | X | ) | ((Datum) (X)) |
Definition at line 465 of file postgres.h.
Referenced by brin_page_items(), collectMatchBitmap(), directBoolConsistentFn(), directTriConsistentFn(), gin_leafpage_items(), gincost_pattern(), GinFormTuple(), ginNewScanKey(), heap_page_items(), matchPartialInPendingList(), page_header(), pg_lock_status(), ProcedureCreate(), and shimBoolConsistentFn().
#define UInt32GetDatum | ( | X | ) | ((Datum) (X)) |
Definition at line 493 of file postgres.h.
Referenced by _hash_convert_tuple(), brin_page_items(), directBoolConsistentFn(), directTriConsistentFn(), gin_extract_jsonb_path(), hash_any(), hash_uint32(), heap_page_items(), jsonb_path_ops__extract_nodes(), LaunchParallelWorkers(), pg_lock_status(), pg_walfile_name_offset(), pgstatginindex_internal(), setup_background_workers(), and shimBoolConsistentFn().
#define UInt64GetDatum | ( | X | ) | Int64GetDatum((int64) (X)) |
Definition at line 648 of file postgres.h.
Referenced by compute_partition_hash_value(), exec_stmt_getdiag(), hash_aclitem_extended(), hash_numeric_extended(), JsonbHashScalarValueExtended(), and satisfies_hash_partition().
#define UInt8GetDatum | ( | X | ) | ((Datum) (X)) |
Definition at line 437 of file postgres.h.
Referenced by heap_page_items().
#define VARATT_CAN_MAKE_SHORT | ( | PTR | ) |
Definition at line 270 of file postgres.h.
Referenced by datum_compute_size(), datum_write(), fill_val(), and heap_compute_data_size().
#define VARATT_CONVERTED_SHORT_SIZE | ( | PTR | ) | (VARSIZE(PTR) - VARHDRSZ + VARHDRSZ_SHORT) |
Definition at line 273 of file postgres.h.
Referenced by datum_compute_size(), datum_write(), fill_val(), and heap_compute_data_size().
#define VARATT_IS_1B | ( | PTR | ) | ((((varattrib_1b *) (PTR))->va_header & 0x01) == 0x01) |
Definition at line 242 of file postgres.h.
#define VARATT_IS_1B_E | ( | PTR | ) | ((((varattrib_1b *) (PTR))->va_header) == 0x01) |
Definition at line 244 of file postgres.h.
#define VARATT_IS_4B | ( | PTR | ) | ((((varattrib_1b *) (PTR))->va_header & 0x01) == 0x00) |
Definition at line 236 of file postgres.h.
#define VARATT_IS_4B_C | ( | PTR | ) | ((((varattrib_1b *) (PTR))->va_header & 0x03) == 0x02) |
Definition at line 240 of file postgres.h.
#define VARATT_IS_4B_U | ( | PTR | ) | ((((varattrib_1b *) (PTR))->va_header & 0x03) == 0x00) |
Definition at line 238 of file postgres.h.
#define VARATT_IS_COMPRESSED | ( | PTR | ) | VARATT_IS_4B_C(PTR) |
Definition at line 312 of file postgres.h.
Referenced by bt_normalize_tuple(), detoast_attr(), detoast_attr_slice(), mcelem_tsquery_selec(), pg_detoast_datum_packed(), text_substring(), toast_compress_datum(), toast_decompress_datum(), toast_decompress_datum_slice(), toast_flatten_tuple_to_datum(), toast_raw_datum_size(), toast_save_datum(), and toast_tuple_find_biggest_attribute().
#define VARATT_IS_EXTENDED | ( | PTR | ) | (!VARATT_IS_4B_U(PTR)) |
Definition at line 327 of file postgres.h.
Referenced by detoast_attr(), getdatafield(), index_form_tuple(), pg_detoast_datum(), pg_detoast_datum_copy(), ReorderBufferToastAppendChunk(), toast_fetch_datum(), and toast_fetch_datum_slice().
#define VARATT_IS_EXTERNAL | ( | PTR | ) | VARATT_IS_1B_E(PTR) |
Definition at line 313 of file postgres.h.
Referenced by bt_normalize_tuple(), check_domain_for_new_field(), datum_write(), detoast_attr_slice(), detoast_external_attr(), ER_get_flat_size(), expanded_record_set_field_internal(), expanded_record_set_fields(), fill_val(), index_form_tuple(), mcelem_tsquery_selec(), pg_detoast_datum_packed(), ReorderBufferToastReplace(), text_substring(), toast_build_flattened_tuple(), toast_compress_datum(), toast_flatten_tuple(), toast_flatten_tuple_to_datum(), toast_save_datum(), toast_tuple_find_biggest_attribute(), toast_tuple_init(), tstoreReceiveSlot_detoast(), and tuple_data_split_internal().
#define VARATT_IS_EXTERNAL_EXPANDED | ( | PTR | ) | (VARATT_IS_EXTERNAL(PTR) && VARTAG_IS_EXPANDED(VARTAG_EXTERNAL(PTR))) |
Definition at line 322 of file postgres.h.
Referenced by array_get_element(), array_set_element(), coerce_function_result_tuple(), datumCopy(), datumEstimateSpace(), DatumGetAnyArrayP(), DatumGetEOHP(), datumSerialize(), detoast_attr(), detoast_attr_slice(), detoast_external_attr(), exec_move_row_from_datum(), ExecEvalFieldSelect(), expand_array(), fill_val(), heap_compute_data_size(), plpgsql_exec_trigger(), toast_datum_size(), toast_raw_datum_size(), and tts_virtual_materialize().
#define VARATT_IS_EXTERNAL_EXPANDED_RO | ( | PTR | ) | (VARATT_IS_EXTERNAL(PTR) && VARTAG_EXTERNAL(PTR) == VARTAG_EXPANDED_RO) |
Definition at line 318 of file postgres.h.
Referenced by plpgsql_exec_function().
#define VARATT_IS_EXTERNAL_EXPANDED_RW | ( | PTR | ) | (VARATT_IS_EXTERNAL(PTR) && VARTAG_EXTERNAL(PTR) == VARTAG_EXPANDED_RW) |
Definition at line 320 of file postgres.h.
Referenced by DatumGetExpandedArray(), DatumGetExpandedArrayX(), DatumGetExpandedRecord(), datumTransfer(), DeleteExpandedObject(), exec_assign_value(), exec_move_row_from_datum(), MakeExpandedObjectReadOnlyInternal(), plpgsql_exec_function(), and TransferExpandedObject().
#define VARATT_IS_EXTERNAL_INDIRECT | ( | PTR | ) | (VARATT_IS_EXTERNAL(PTR) && VARTAG_EXTERNAL(PTR) == VARTAG_INDIRECT) |
Definition at line 316 of file postgres.h.
Referenced by detoast_attr(), detoast_attr_slice(), detoast_external_attr(), make_tuple_indirect(), toast_datum_size(), toast_raw_datum_size(), and tuple_data_split_internal().
#define VARATT_IS_EXTERNAL_NON_EXPANDED | ( | PTR | ) | (VARATT_IS_EXTERNAL(PTR) && !VARTAG_IS_EXPANDED(VARTAG_EXTERNAL(PTR))) |
Definition at line 324 of file postgres.h.
Referenced by assign_simple_var().
#define VARATT_IS_EXTERNAL_ONDISK | ( | PTR | ) | (VARATT_IS_EXTERNAL(PTR) && VARTAG_EXTERNAL(PTR) == VARTAG_ONDISK) |
Definition at line 314 of file postgres.h.
Referenced by detoast_attr(), detoast_attr_slice(), detoast_external_attr(), logicalrep_write_tuple(), make_tuple_indirect(), toast_datum_size(), toast_delete_datum(), toast_delete_external(), toast_fetch_datum(), toast_fetch_datum_slice(), toast_raw_datum_size(), toast_save_datum(), toast_tuple_init(), tuple_data_split_internal(), and tuple_to_stringinfo().
#define VARATT_IS_SHORT | ( | PTR | ) | VARATT_IS_1B(PTR) |
Definition at line 326 of file postgres.h.
Referenced by datum_write(), detoast_attr(), detoast_attr_slice(), fill_val(), numeric_abbrev_convert(), ReorderBufferToastAppendChunk(), ReorderBufferToastReplace(), toast_datum_size(), toast_fetch_datum(), toast_fetch_datum_slice(), toast_raw_datum_size(), and toast_save_datum().
#define VARATT_NOT_PAD_BYTE | ( | PTR | ) | (*((uint8 *) (PTR)) != 0) |
Definition at line 246 of file postgres.h.
#define VARATT_SHORT_MAX 0x7F |
Definition at line 269 of file postgres.h.
Referenced by formTextDatum(), numeric_abbrev_convert(), and numeric_sortsupport().
#define VARDATA | ( | PTR | ) | VARDATA_4B(PTR) |
Definition at line 302 of file postgres.h.
Referenced by array_send(), array_to_tsvector(), be_loread(), binary_decode(), binary_encode(), bpchar(), bpchar_input(), brin_page_type(), bt_page_items_bytea(), bytea_catenate(), bytea_string_agg_finalfn(), byteain(), bytearecv(), byteaSetBit(), byteaSetByte(), byteatrim(), catenate_stringinfo_string(), char_bpchar(), char_text(), chr(), concat_text(), CopyOneRowTo(), copytext(), cstring_to_text_with_len(), datum_write(), detoast_attr(), detoast_attr_slice(), encode_to_ascii(), fill_val(), fsm_page_contents(), gbt_bit_xfrm(), gbt_bytea_pf_match(), gbt_var_key_copy(), gbt_var_key_from_datum(), gbt_var_node_cp_len(), gbt_var_node_truncate(), gbt_var_penalty(), get_jsonb_path_all(), get_raw_page_internal(), ghstore_consistent(), gin_extract_hstore_query(), gin_extract_jsonb_query(), gtrgm_consistent(), gtrgm_distance(), heap_page_items(), hstore_from_array(), hstore_from_arrays(), hstore_hash(), hstore_hash_extended(), hstore_slice_to_array(), hstoreArrayToPairs(), inv_read(), inv_truncate(), inv_write(), jsonb_exists_all(), jsonb_exists_any(), JsonbValueToJsonb(), lo_get_fragment_internal(), lpad(), ltree2text(), make_greater_string(), make_text_key(), makeitem(), MatchText(), numeric_abbrev_convert(), optionListToArray(), page_checksum(), page_header(), parseRelOptions(), pg_armor(), pg_convert(), pg_dearmor(), pg_decrypt(), pg_decrypt_iv(), pg_digest(), pg_encrypt(), pg_encrypt_iv(), pg_hmac(), pg_random_bytes(), pgp_key_id_w(), PLyObject_ToBytea(), printtup(), printtup_internal_20(), quote_literal(), range_send(), read_binary_file(), read_text_file(), record_send(), ReorderBufferToastReplace(), repeat(), rpad(), SendFunctionResult(), sha224_bytea(), sha256_bytea(), sha384_bytea(), sha512_bytea(), show_trgm(), similar_escape_internal(), spg_text_inner_consistent(), spg_text_leaf_consistent(), SPI_sql_row_to_xmlelement(), statext_dependencies_serialize(), statext_mcv_deserialize(), statext_mcv_serialize(), statext_ndistinct_serialize(), string_to_bytea_const(), text_catenate(), text_reverse(), text_substring(), toast_decompress_datum(), toast_decompress_datum_slice(), toast_fetch_datum(), toast_fetch_datum_slice(), toast_save_datum(), transformRelOptions(), translate(), tsvector_delete_arr(), tsvector_setweight_by_filter(), tuple_data_split_internal(), verify_brin_page(), and xml_recv().
#define VARDATA_1B | ( | PTR | ) | (((varattrib_1b *) (PTR))->va_data) |
Definition at line 280 of file postgres.h.
#define VARDATA_1B_E | ( | PTR | ) | (((varattrib_1b_e *) (PTR))->va_data) |
Definition at line 281 of file postgres.h.
#define VARDATA_4B | ( | PTR | ) | (((varattrib_4b *) (PTR))->va_4byte.va_data) |
Definition at line 278 of file postgres.h.
#define VARDATA_4B_C | ( | PTR | ) | (((varattrib_4b *) (PTR))->va_compressed.va_data) |
Definition at line 279 of file postgres.h.
#define VARDATA_ANY | ( | PTR | ) | (VARATT_IS_1B(PTR) ? VARDATA_1B(PTR) : VARDATA_4B(PTR)) |
Definition at line 348 of file postgres.h.
Referenced by appendStringInfoRegexpSubstr(), appendStringInfoText(), ascii(), bcTruelen(), be_lo_from_bytea(), be_lo_put(), be_lowrite(), binary_decode(), binary_encode(), bpchar(), bpchar_larger(), bpchar_name(), bpchar_smaller(), bpcharcmp(), bpchareq(), bpcharfastcmp_c(), bpcharge(), bpchargt(), bpcharle(), bpcharlen(), bpcharlt(), bpcharne(), btnametextcmp(), btrim(), btrim1(), bttextnamecmp(), bytea_catenate(), bytea_string_agg_transfn(), byteacmp(), byteaeq(), byteage(), byteaGetBit(), byteaGetByte(), byteagt(), byteale(), bytealike(), bytealt(), byteane(), byteanlike(), byteaout(), byteapos(), byteatrim(), check_replace_text_has_escape_char(), citext_eq(), citext_hash(), citext_hash_extended(), citext_ne(), citextcmp(), CloneRowTriggersToPartition(), compare_lexeme_textfreq(), compare_text_lexemes(), concat_text(), convert_bytea_to_scalar(), convert_charset(), copytext(), create_mbuf_from_vardata(), datum_image_eq(), decrypt_internal(), deserialize_deflist(), encrypt_internal(), find_provider(), Generic_Text_IC_like(), get_page_from_raw(), ghstore_consistent(), gin_cmp_prefix(), gin_cmp_tslexeme(), gin_compare_jsonb(), gin_extract_hstore_query(), gin_extract_jsonb_query(), gin_extract_query_trgm(), gin_extract_value_trgm(), gtrgm_compress(), hashbpchar(), hashbpcharextended(), hashinet(), hashinetextended(), hashtext(), hashtextextended(), hashvarlena(), hashvarlenaextended(), hstore_defined(), hstore_delete(), hstore_exists(), hstore_fetchval(), hstore_from_text(), init_work(), initcap(), int8_avg_deserialize(), int8_avg_serialize(), internal_bpchar_pattern_compare(), internal_citext_pattern_cmp(), internal_text_pattern_compare(), interval_part(), interval_trunc(), json_send(), jsonb_delete(), jsonb_delete_array(), jsonb_exists(), jsonb_object_field(), jsonb_object_field_text(), length_in_encoding(), levenshtein(), levenshtein_less_equal(), levenshtein_less_equal_with_costs(), levenshtein_with_costs(), like_fixed_prefix(), lower(), lpad(), ltrim(), ltrim1(), make_greater_string(), makeJsonLexContext(), map_sql_value_to_xml_value(), MatchText(), md5_bytea(), md5_text(), nameeqtext(), namelike(), namenetext(), namenlike(), numeric_avg_deserialize(), numeric_avg_serialize(), numeric_deserialize(), numeric_poly_deserialize(), numeric_poly_serialize(), numeric_serialize(), numeric_to_number(), parse_re_flags(), pg_armor(), pg_convert(), pg_dearmor(), pg_decrypt(), pg_decrypt_iv(), pg_digest(), pg_encrypt(), pg_encrypt_iv(), pg_file_write_internal(), pg_get_triggerdef_worker(), pg_hmac(), pg_logical_emit_message_bytea(), pgp_armor_headers(), pgxml_xpath(), PLyBytes_FromBytea(), populate_record_worker(), printsimple(), prs_setup_firstcall(), quote_literal(), RE_compile(), RE_compile_and_cache(), record_image_cmp(), RelationBuildTriggers(), repeat(), replace_text(), replace_text_regexp(), rpad(), rtrim(), rtrim1(), setPathObject(), setup_regexp_matches(), sha224_bytea(), sha256_bytea(), sha384_bytea(), sha512_bytea(), show_trgm(), similar_escape_internal(), similarity(), sort(), spg_text_choose(), spg_text_inner_consistent(), spg_text_leaf_consistent(), spg_text_picksplit(), SPI_sql_row_to_xmlelement(), split_text(), statext_dependencies_deserialize(), statext_mcv_deserialize(), statext_mcv_serialize(), statext_ndistinct_deserialize(), strict_word_similarity(), strict_word_similarity_commutator_op(), strict_word_similarity_dist_commutator_op(), strict_word_similarity_dist_op(), strict_word_similarity_op(), test_shm_mq(), test_shm_mq_pipelined(), text_catenate(), text_char(), text_cmp(), text_format(), text_left(), text_length(), text_name(), text_position_setup(), text_reverse(), text_right(), text_starts_with(), text_substring(), text_to_array_internal(), text_to_cstring(), text_to_cstring_buffer(), texteq(), texteqname(), texticregexeq(), texticregexne(), textlike(), textne(), textnename(), textnlike(), textregexeq(), textregexne(), textregexsubstr(), textsend(), time_part(), timestamp_part(), timestamp_trunc(), timestamptz_part(), timestamptz_trunc_internal(), timetz_part(), to_tsvector_byid(), toast_compress_datum(), transform_jsonb_string_values(), translate(), ts_headline_byid_opt(), ts_lexize(), ts_stat_sql(), tsquery_opr_selec(), tsvector_delete_str(), tsvector_update_trigger(), unaccent_dict(), upper(), uuid_generate_v3(), uuid_generate_v5(), varchar(), varlenafastcmp_locale(), varstr_abbrev_convert(), varstrfastcmp_c(), word_similarity(), word_similarity_commutator_op(), word_similarity_dist_commutator_op(), word_similarity_dist_op(), word_similarity_op(), xml_is_well_formed(), xml_send(), xmlcomment(), xpath_string(), and xslt_process().
#define VARDATA_EXTERNAL | ( | PTR | ) | VARDATA_1B_E(PTR) |
Definition at line 310 of file postgres.h.
Referenced by DatumGetEOHP(), EOH_init_header(), make_tuple_indirect(), ReorderBufferToastReplace(), and toast_save_datum().
#define VARDATA_SHORT | ( | PTR | ) | VARDATA_1B(PTR) |
Definition at line 306 of file postgres.h.
Referenced by detoast_attr(), detoast_attr_slice(), numeric_abbrev_convert(), toast_fetch_datum(), toast_fetch_datum_slice(), and toast_save_datum().
#define VARHDRSZ_EXTERNAL offsetof(varattrib_1b_e, va_data) |
Definition at line 276 of file postgres.h.
#define VARHDRSZ_SHORT offsetof(varattrib_1b, va_data) |
Definition at line 268 of file postgres.h.
Referenced by detoast_attr(), detoast_attr_slice(), formTextDatum(), numeric_abbrev_convert(), ReorderBufferToastAppendChunk(), toast_fetch_datum(), toast_fetch_datum_slice(), toast_raw_datum_size(), and toast_save_datum().
#define VARRAWSIZE_4B_C | ( | PTR | ) | (((varattrib_4b *) (PTR))->va_compressed.va_rawsize) |
Definition at line 283 of file postgres.h.
Referenced by toast_raw_datum_size(), and toast_save_datum().
#define VARSIZE | ( | PTR | ) | VARSIZE_4B(PTR) |
Definition at line 303 of file postgres.h.
Referenced by _ltq_extract_regex(), _ltree_extract_isparent(), _ltree_extract_risparent(), _ltxtq_extract_exec(), array_send(), array_to_tsvector(), bit_and(), bit_or(), bitnot(), bitsetbit(), bitshiftleft(), bitshiftright(), bitxor(), brin_page_type(), bt_page_items_bytea(), byteaSetBit(), byteaSetByte(), CompareTSQ(), copy_ltree(), CopyOneRowTo(), datum_write(), detoast_attr_slice(), encode_to_ascii(), fill_val(), flattenJsonPathParseItem(), g_cube_binary_union(), g_cube_union(), g_int_union(), gbt_bytea_pf_match(), gbt_var_key_copy(), gbt_var_key_from_datum(), gbt_var_key_readable(), gbt_var_node_cp_len(), gbt_var_node_truncate(), gbt_var_penalty(), get_attribute_options(), get_jsonb_path_all(), get_tablespace(), getdatafield(), ghstore_consistent(), gin_extract_hstore_query(), gin_extract_jsonb_query(), gtrgm_consistent(), gtrgm_distance(), gtrgm_penalty(), gtsvector_compress(), heap_page_items(), hstore_concat(), hstore_delete(), hstore_delete_array(), hstore_delete_hstore(), hstore_from_array(), hstore_from_arrays(), hstore_hash(), hstore_hash_extended(), hstore_slice_to_array(), hstoreArrayToPairs(), hstoreUpgrade(), hstoreValidNewFormat(), hstoreValidOldFormat(), index_form_tuple(), jsonb_exists_all(), jsonb_exists_any(), jsonb_out(), jsonb_pretty(), jsonb_send(), jsonpath_out(), jsonpath_send(), load_relcache_init_file(), ltree2text(), ltree_compress(), ltree_concat(), ltree_out(), ltree_picksplit(), ltree_union(), numeric(), numeric_abs(), numeric_uminus(), numeric_uplus(), page_checksum(), page_header(), parseRelOptions(), pg_detoast_datum_copy(), populate_record_worker(), populate_scalar(), printtup(), printtup_internal_20(), range_deserialize(), range_get_flags(), range_send(), range_set_contain_empty(), read_text_file(), record_send(), RelationParseRelOptions(), ReorderBufferToastAppendChunk(), ReorderBufferToastReplace(), SendFunctionResult(), setup_firstcall(), silly_cmp_tsvector(), SPI_sql_row_to_xmlelement(), toast_datum_size(), toast_decompress_datum_slice(), toast_fetch_datum(), toast_fetch_datum_slice(), toast_raw_datum_size(), toast_save_datum(), toast_tuple_try_compression(), transformRelOptions(), tsvector_concat(), tsvector_delete_arr(), tsvector_delete_by_indices(), tsvector_filter(), tsvector_setweight(), tsvector_setweight_by_filter(), tuple_data_split(), txid_snapshot_xip(), verify_brin_page(), write_relcache_init_file(), xmlconcat(), and xmlroot().
#define VARSIZE_1B | ( | PTR | ) | ((((varattrib_1b *) (PTR))->va_header >> 1) & 0x7F) |
Definition at line 252 of file postgres.h.
#define VARSIZE_4B | ( | PTR | ) | ((((varattrib_4b *) (PTR))->va_4byte.va_header >> 2) & 0x3FFFFFFF) |
Definition at line 250 of file postgres.h.
#define VARSIZE_ANY | ( | PTR | ) |
Definition at line 335 of file postgres.h.
Referenced by clear_and_pfree(), compute_distinct_stats(), compute_range_stats(), compute_scalar_stats(), compute_trivial_stats(), compute_tsvector_stats(), convertJsonbScalar(), datumCopy(), datumGetSize(), decrypt_internal(), detoast_attr(), detoast_external_attr(), encrypt_internal(), inet_set_masklen(), make_tuple_indirect(), MatchText(), memcpyDatum(), printtup(), replace_text(), replace_text_regexp(), SpGistGetTypeSize(), statext_dependencies_deserialize(), statext_mcv_deserialize(), statext_ndistinct_deserialize(), text_to_array_internal(), toast_tuple_init(), tuple_data_split_internal(), and varsize_any().
#define VARSIZE_ANY_EXHDR | ( | PTR | ) |
Definition at line 341 of file postgres.h.
Referenced by appendStringInfoRegexpSubstr(), appendStringInfoText(), ascii(), bcTruelen(), be_lo_from_bytea(), be_lo_put(), be_lowrite(), binary_decode(), binary_encode(), bpchar(), bpchar_name(), bpcharfastcmp_c(), btnametextcmp(), btrim(), btrim1(), bttextnamecmp(), bytea_catenate(), bytea_string_agg_transfn(), byteacmp(), byteage(), byteaGetBit(), byteaGetByte(), byteagt(), byteale(), bytealike(), bytealt(), byteanlike(), byteaout(), byteaoverlay_no_len(), byteapos(), byteatrim(), check_replace_text_has_escape_char(), citext_eq(), citext_hash(), citext_hash_extended(), citext_ne(), citextcmp(), compare_lexeme_textfreq(), compare_text_lexemes(), concat_text(), convert_bytea_to_scalar(), convert_charset(), copytext(), create_mbuf_from_vardata(), decrypt_internal(), deserialize_deflist(), do_to_timestamp(), encrypt_internal(), find_provider(), Generic_Text_IC_like(), get_page_from_raw(), ghstore_consistent(), gin_cmp_prefix(), gin_cmp_tslexeme(), gin_compare_jsonb(), gin_extract_hstore_query(), gin_extract_jsonb_query(), gin_extract_query_trgm(), gin_extract_value_trgm(), gtrgm_compress(), hashbpcharextended(), hashtext(), hashtextextended(), hashvarlena(), hashvarlenaextended(), hstore_defined(), hstore_delete(), hstore_exists(), hstore_fetchval(), hstore_from_text(), init_work(), initcap(), int8_avg_deserialize(), int8_avg_serialize(), internal_citext_pattern_cmp(), internal_text_pattern_compare(), interval_part(), interval_to_char(), interval_trunc(), json_send(), jsonb_delete(), jsonb_delete_array(), jsonb_exists(), jsonb_object_field(), jsonb_object_field_text(), JsonbInitBinary(), length_in_encoding(), levenshtein(), levenshtein_less_equal(), levenshtein_less_equal_with_costs(), levenshtein_with_costs(), like_fixed_prefix(), lower(), lpad(), ltrim(), ltrim1(), make_greater_string(), makeJsonLexContext(), map_sql_value_to_xml_value(), MatchText(), md5_bytea(), md5_text(), nameeqtext(), namelike(), namenetext(), namenlike(), numeric_avg_deserialize(), numeric_avg_serialize(), numeric_deserialize(), numeric_poly_deserialize(), numeric_poly_serialize(), numeric_serialize(), numeric_to_number(), parse_re_flags(), pg_armor(), pg_convert(), pg_dearmor(), pg_decrypt(), pg_decrypt_iv(), pg_digest(), pg_encrypt(), pg_encrypt_iv(), pg_file_write_internal(), pg_hmac(), pg_logical_emit_message_bytea(), pg_size_bytes(), pgp_armor_headers(), pgxml_xpath(), PLyBytes_FromBytea(), populate_record_worker(), printsimple(), prs_setup_firstcall(), quote_literal(), RE_compile(), RE_compile_and_cache(), repeat(), replace_text(), replace_text_regexp(), rpad(), rtrim(), rtrim1(), setPathObject(), setup_regexp_matches(), sha224_bytea(), sha256_bytea(), sha384_bytea(), sha512_bytea(), show_trgm(), similar_escape_internal(), similarity(), sort(), spg_text_choose(), spg_text_inner_consistent(), spg_text_leaf_consistent(), spg_text_picksplit(), SPI_sql_row_to_xmlelement(), split_text(), statext_dependencies_deserialize(), statext_mcv_serialize(), statext_ndistinct_deserialize(), strict_word_similarity(), strict_word_similarity_commutator_op(), strict_word_similarity_dist_commutator_op(), strict_word_similarity_dist_op(), strict_word_similarity_op(), test_shm_mq(), test_shm_mq_pipelined(), text_catenate(), text_char(), text_cmp(), text_format(), text_left(), text_length(), text_name(), text_position(), text_position_setup(), text_reverse(), text_right(), text_starts_with(), text_substring(), text_to_array_internal(), text_to_cstring(), text_to_cstring_buffer(), texteqname(), texticregexeq(), texticregexne(), textlike(), textnename(), textnlike(), textregexeq(), textregexne(), textregexsubstr(), textsend(), time_part(), timestamp_part(), timestamp_to_char(), timestamp_trunc(), timestamptz_part(), timestamptz_to_char(), timestamptz_trunc_internal(), timetz_part(), to_tsvector_byid(), toast_compress_datum(), transform_jsonb_string_values(), translate(), ts_headline_byid_opt(), ts_lexize(), ts_stat_sql(), tsquery_opr_selec(), tsvector_delete_str(), tsvector_update_trigger(), unaccent_dict(), upper(), uuid_generate_v3(), uuid_generate_v5(), varchar(), varlenafastcmp_locale(), varstr_abbrev_convert(), varstrfastcmp_c(), word_similarity(), word_similarity_commutator_op(), word_similarity_dist_commutator_op(), word_similarity_dist_op(), word_similarity_op(), xml_is_document(), xml_is_well_formed(), xml_send(), xmlcomment(), xpath_string(), and xslt_process().
#define VARSIZE_EXTERNAL | ( | PTR | ) | (VARHDRSZ_EXTERNAL + VARTAG_SIZE(VARTAG_EXTERNAL(PTR))) |
Definition at line 309 of file postgres.h.
Referenced by fill_val(), and toast_tuple_init().
#define VARSIZE_SHORT | ( | PTR | ) | VARSIZE_1B(PTR) |
Definition at line 305 of file postgres.h.
Referenced by datum_write(), detoast_attr(), detoast_attr_slice(), fill_val(), numeric_abbrev_convert(), ReorderBufferToastAppendChunk(), toast_datum_size(), toast_fetch_datum(), toast_fetch_datum_slice(), toast_raw_datum_size(), and toast_save_datum().
#define VARTAG_1B_E | ( | PTR | ) | (((varattrib_1b_e *) (PTR))->va_tag) |
Definition at line 254 of file postgres.h.
#define VARTAG_EXTERNAL | ( | PTR | ) | VARTAG_1B_E(PTR) |
Definition at line 308 of file postgres.h.
#define VARTAG_IS_EXPANDED | ( | tag | ) | (((tag) & ~1) == VARTAG_EXPANDED_RO) |
Definition at line 120 of file postgres.h.
#define VARTAG_SIZE | ( | tag | ) |
Definition at line 123 of file postgres.h.
typedef uintptr_t Datum |
Definition at line 367 of file postgres.h.
typedef struct ExpandedObjectHeader ExpandedObjectHeader |
Definition at line 99 of file postgres.h.
typedef struct NullableDatum NullableDatum |
typedef struct varatt_expanded varatt_expanded |
typedef struct varatt_external varatt_external |
typedef struct varatt_indirect varatt_indirect |
typedef enum vartag_external vartag_external |
enum vartag_external |
Enumerator | |
---|---|
VARTAG_INDIRECT | |
VARTAG_EXPANDED_RO | |
VARTAG_EXPANDED_RW | |
VARTAG_ONDISK |
Definition at line 111 of file postgres.h.
Definition at line 664 of file postgres.h.
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().
Definition at line 681 of file postgres.h.
References DatumGetFloat8, DatumGetInt64, Int32GetDatum, and value.
Referenced by AddEnumLabel(), EnumValuesCreate(), gbt_num_fetch(), index_store_float8_orderby_distances(), InsertPgClassTuple(), leftmostvalue_float4(), ProcedureCreate(), set_limit(), and update_attstats().
Definition at line 1708 of file fmgr.c.
References palloc(), and PointerGetDatum.
Referenced by assign_random_seed(), compute_range_stats(), executeItemOptUnwrapTarget(), float8_lerp(), gbt_num_fetch(), hash_metapage_info(), index_store_float8_orderby_distances(), int8_to_char(), interval_avg(), leftmostvalue_float8(), normal_rand(), pg_stats_ext_mcvlist_items(), pgstathashindex(), pgstattuple_approx_internal(), spg_kd_picksplit(), SPI_sql_row_to_xmlelement(), and SV_to_JsonbValue().
Datum Int64GetDatum | ( | int64 | X | ) |
Definition at line 1699 of file fmgr.c.
References palloc(), and PointerGetDatum.
Referenced by brin_metapage_info(), brin_summarize_new_values(), build_minmax_path(), cash_numeric(), DefineSequence(), ExecEvalNextValueExpr(), executeKeyValueMethod(), gbt_num_fetch(), generate_series_step_int8(), gin_metapage_info(), gin_page_opaque_info(), hash_array_extended(), hash_bitmap_info(), hash_metapage_info(), hash_page_items(), hash_page_stats(), int4_cash(), int64_to_numeric(), int8_cash(), int8_to_char(), int8range_canonical(), leftmostvalue_int8(), leftmostvalue_money(), make_const(), numeric_avg(), numeric_cash(), numeric_half_rounded(), numeric_shift_right(), perform_work_item(), pg_buffercache_pages(), pg_control_system(), pg_ls_dir_files(), pg_sequence_parameters(), pg_size_bytes(), pg_stat_file(), pg_stat_get_archiver(), pg_stat_get_progress_info(), pg_stat_get_wal_senders(), pg_visibility_map_rel(), pg_visibility_map_summary(), pg_visibility_rel(), pgstatginindex_internal(), pgstathashindex(), pgstattuple_approx_internal(), StartReplication(), SV_to_JsonbValue(), txid_snapshot_xip(), and validate_index_callback().