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 |
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 Datum * | DatumPtr |
Enumerations | |
enum | vartag_external { VARTAG_INDIRECT = 1, VARTAG_EXPANDED_RO = 2, VARTAG_EXPANDED_RW = 3, VARTAG_ONDISK = 18 } |
Functions | |
Datum | Int64GetDatum (int64 X) |
Datum | Float4GetDatum (float4 X) |
Datum | Float8GetDatum (float8 X) |
void | ExceptionalCondition (const char *conditionName, const char *errorType, const char *fileName, int lineNumber) pg_attribute_noreturn() |
#define BoolGetDatum | ( | X | ) | ((Datum) ((X) ? 1 : 0)) |
Definition at line 410 of file postgres.h.
Referenced by aclexplode(), add_security_quals(), add_with_check_options(), AddRoleMems(), AggregateCreate(), AlterDatabase(), AlterRole(), ApplyExtensionUpdates(), boolvarsel(), brin_inclusion_add_value(), brin_inclusion_union(), brin_page_items(), btcostestimate(), build_coercion_expression(), ConversionCreate(), create_proc_lang(), CreateConstraintEntry(), createdb(), CreateRole(), CreateTrigger(), DefineOpClass(), DefineSequence(), DelRoleMems(), do_pg_start_backup(), eval_const_expressions_mutator(), examine_simple_variable(), examine_variable(), exec_set_found(), ExecEvalAnd(), ExecEvalArrayCoerceExpr(), ExecEvalBooleanTest(), ExecEvalDistinct(), ExecEvalNot(), ExecEvalNullTest(), ExecEvalOr(), ExecEvalRowCompare(), ExecEvalScalarArrayOp(), ExecEvalXml(), ExecHashBuildSkewHash(), ExecHashSubPlan(), ExecScanSubPlan(), ExecSetParamPlan(), get_attavgwidth(), get_available_versions_for_extension(), get_tables_to_cluster(), InsertExtensionTuple(), InsertPgAttributeTuple(), InsertPgClassTuple(), InsertRule(), 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_prepared_statement(), pg_sequence_parameters(), pg_stat_file(), pg_stat_get_activity(), pg_timezone_abbrevs(), pg_timezone_names(), pg_visibility(), pg_visibility_map(), pg_visibility_map_rel(), pg_visibility_rel(), PLyObject_ToBool(), ProcedureCreate(), ri_AttributesEqual(), show_all_file_settings(), ssl_extension_info(), TypeCreate(), TypeShellMake(), update_attstats(), and UpdateIndexRelation().
#define CharGetDatum | ( | X | ) | ((Datum) SET_1_BYTE(X)) |
Definition at line 424 of file postgres.h.
Referenced by AggregateCreate(), CreateAccessMethod(), CreateCast(), CreateConstraintEntry(), CreatePolicy(), CreateTrigger(), do_autovacuum(), EnableDisableRule(), get_default_acl_internal(), get_object_address_defacl(), get_op_opfamily_properties(), get_op_opfamily_sortfamily(), get_op_opfamily_strategy(), getRelationsInNamespace(), insert_event_trigger_tuple(), InsertPgAttributeTuple(), InsertPgClassTuple(), InsertRule(), interpret_function_parameter_list(), leftmostvalue_char(), op_in_opfamily(), OperatorCreate(), OperatorShellMake(), ProcedureCreate(), recordExtensionInitPriv(), recordMultipleDependencies(), SetDefaultACL(), shdepAddDependency(), shdepChangeDep(), storeOperators(), TypeCreate(), and TypeShellMake().
#define CommandIdGetDatum | ( | X | ) | ((Datum) SET_4_BYTES(X)) |
Definition at line 550 of file postgres.h.
Referenced by heap_getsysattr().
#define CStringGetDatum | ( | X | ) | PointerGetDatum(X) |
Definition at line 586 of file postgres.h.
Referenced by AddEnumLabel(), AfterTriggerSetState(), AlterEventTrigger(), AlterEventTriggerOwner(), AlterForeignDataWrapper(), AlterForeignDataWrapperOwner(), AlterForeignServer(), AlterForeignServerOwner(), AlterObjectRename_internal(), AlterOpFamily(), AlterPolicy(), AlterRole(), AlterSchemaOwner(), AlterTableSpaceOptions(), AlterTypeNamespaceInternal(), check_timezone(), ChooseConstraintName(), ConstraintNameIsUsed(), convert_function_name(), convert_type_name(), CreateAccessMethod(), CreateConversionCommand(), createdb(), CreateEventTrigger(), CreateForeignDataWrapper(), CreateForeignServer(), CreateOpFamily(), CreatePolicy(), CreateRole(), CreateTableSpace(), CreateTrigger(), current_schema(), current_schemas(), current_user(), datum_to_jsonb(), defGetInt64(), DefineCompositeType(), DefineDomain(), DefineEnum(), DefineOpClass(), DefineRange(), DefineType(), DropTableSpace(), EnableDisableTrigger(), enum_in(), enum_recv(), ExecAlterExtensionStmt(), flatten_set_variable_args(), FuncnameGetCandidates(), funny_dup17(), get_am_type_oid(), get_available_versions_for_extension(), get_database_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_relation_policy_oid(), get_rewrite_oid_without_relid(), get_role_oid(), get_rolespec_tuple(), get_tablespace_oid(), get_trigger_oid(), getdatabaseencoding(), GetDatabaseTuple(), 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(), make_const(), make_tuple_from_result_row(), makeArrayTypeName(), MergeWithExistingConstraint(), moddatetime(), NextCopyFrom(), numeric_float4(), numeric_float8(), numeric_to_number(), OpernameGetCandidates(), OpernameGetOprid(), parsetinterval(), 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_exec_trigger(), poly2path(), readRecoveryCommandFile(), regclassin(), regconfigin(), regdictionaryin(), regnamespacein(), regoperatorin(), regoperin(), regprocedurein(), regprocin(), regrolein(), regtypein(), rename_policy(), RenameRole(), RenameSchema(), RenameTableSpace(), RenameTypeInternal(), SearchSysCacheAttName(), session_user(), ssl_client_serial(), string_to_datum(), tsa_headline_byname(), TypeCreate(), typenameTypeMod(), and uuid_generate_internal().
#define DatumGetBool | ( | X | ) | ((bool) (GET_1_BYTE(X) != 0)) |
Definition at line 401 of file postgres.h.
Referenced by _bt_checkkeys(), _bt_compare_scankey_args(), _bt_find_extreme_element(), _hash_checkqual(), _int_different(), abs_interval(), advance_aggregates(), advance_windowaggregate(), advance_windowaggregate_base(), 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(), close_pb(), close_sb(), compute_distinct_stats(), convert_numeric_to_scalar(), datum_to_json(), datum_to_jsonb(), directBoolConsistentFn(), domain_check_input(), eqjoinsel_inner(), eqjoinsel_semi(), equalsJsonbScalarValue(), eval_const_expressions_mutator(), examine_attribute(), exec_eval_boolean(), ExecEvalAnd(), ExecEvalBooleanTest(), ExecEvalCase(), ExecEvalCoerceToDomain(), ExecEvalDistinct(), ExecEvalNot(), ExecEvalNullIf(), ExecEvalOr(), ExecEvalScalarArrayOp(), ExecEvalXml(), ExecQual(), ExecScanSubPlan(), execTuplesMatch(), execTuplesUnequal(), 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_intveq(), gbt_intvge(), gbt_intvgt(), gbt_intvle(), gbt_intvlt(), 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(), get_rule_expr(), get_variable_range(), gist_box_leaf_consistent(), gist_point_consistent(), gistindex_keytest(), histogram_selectivity(), index_recheck_constraint(), ineq_histogram_selectivity(), inet_mcv_join_sel(), inet_semi_join_sel(), inter_sb(), interpt_pp(), intinterval(), is_dummy_plan(), line_distance(), line_interpt_internal(), line_intersect(), lt_q_regex(), ltree_consistent(), make_ands_implicit(), make_greater_string(), make_ruledef(), map_sql_value_to_xml_value(), mcv_selectivity(), mode_final(), negate_clause(), numeric_half_rounded(), numeric_is_less(), on_sb(), on_sl(), operator_predicate_proof(), pg_start_backup_callback(), PLyBool_FromBool(), poly_contain(), process_implied_equality(), process_ordered_aggregate_single(), range_intersect(), range_union_internal(), record_eq(), record_image_ne(), record_ne(), relation_excluded_by_constraints(), restriction_is_constant_false(), ri_AttributesEqual(), rtree_internal_consistent(), set_append_rel_size(), simplify_and_arguments(), simplify_boolean_equality(), simplify_or_arguments(), spg_box_quad_leaf_consistent(), spg_quad_inner_consistent(), spgLeafTest(), text_isequal(), tintervalct(), tintervalov(), tintervalsame(), ts_match_tq(), ts_match_tt(), validateDomainConstraint(), and var_eq_const().
#define DatumGetChar | ( | X | ) | ((char) GET_1_BYTE(X)) |
Definition at line 417 of file postgres.h.
Referenced by AlterPolicy(), convert_string_datum(), EnableDisableRule(), make_ruledef(), RelationBuildRowSecurity(), and tsvector_filter().
#define DatumGetCommandId | ( | X | ) | ((CommandId) GET_4_BYTES(X)) |
Definition at line 543 of file postgres.h.
#define DatumGetCString | ( | X | ) | ((char *) DatumGetPointer(X)) |
Definition at line 574 of file postgres.h.
Referenced by ArrayGetIntegerTypmods(), build_dummy_tuple(), coerce_type(), compute_distinct_stats(), compute_scalar_stats(), compute_trivial_stats(), CopyOneRowTo(), datum_write(), exec_eval_using_params(), flatten_set_variable_args(), heap_fill_tuple(), int4_to_char(), int8_to_char(), jsonb_array_element_text(), jsonb_object_field_text(), jsonb_put_escaped_value(), make_greater_string(), make_row_from_rec_and_jsonb(), numeric_float4(), numeric_float8(), numeric_to_char(), numeric_to_cstring(), numeric_to_double_no_overflow(), OutputFunctionCall(), patternsel(), pg_column_size(), plperl_trigger_build_args(), pltcl_trigger_handler(), PLy_trigger_build_args(), PLyDecimal_FromNumeric(), populate_record_worker(), prefix_quals(), printTypmod(), RelationBuildTriggers(), set_timetravel(), table_to_xml_internal(), timestamp_izone(), timestamptz_izone(), timetz_izone(), tintervalout(), and tsa_set_curcfg().
#define DatumGetFloat4 | ( | X | ) | (* ((float4 *) DatumGetPointer(X))) |
Definition at line 669 of file postgres.h.
Referenced by AddEnumLabel(), bernoulli_beginsamplescan(), bernoulli_samplescangetsamplesize(), btfloat4fastcmp(), convert_numeric_to_scalar(), gbt_num_compress(), PLyFloat_FromFloat4(), similarity_dist(), similarity_op(), system_beginsamplescan(), and system_samplescangetsamplesize().
#define DatumGetFloat8 | ( | X | ) | (* ((float8 *) DatumGetPointer(X))) |
Definition at line 692 of file postgres.h.
Referenced by btfloat8fastcmp(), calc_length_hist_frac(), call_subtype_diff(), compute_range_stats(), convert_numeric_to_scalar(), float8_lerp(), g_cube_distance(), gbt_num_compress(), gbt_numeric_penalty(), get_distance(), get_position(), gistindex_keytest(), join_selectivity(), length_hist_bsearch(), neqjoinsel(), neqsel(), numrange_subdiff(), path_distance(), PLyFloat_FromFloat8(), regress_dist_ptpath(), regress_path_dist(), 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) GET_2_BYTES(X)) |
Definition at line 452 of file postgres.h.
Referenced by btint2fastcmp(), convert_numeric_to_scalar(), decompile_column_index_array(), gbt_num_compress(), PLyInt_FromInt16(), searchChar(), spg_text_inner_consistent(), and text_format().
#define DatumGetInt32 | ( | X | ) | ((int32) GET_4_BYTES(X)) |
Definition at line 480 of file postgres.h.
Referenced by _bt_check_rowcompare(), _bt_compare(), _bt_compare_array_elements(), _bt_isequal(), _bt_sort_array_elements(), array_cmp(), autoinc(), AuxiliaryProcKill(), btint4fastcmp(), c_overpaid(), CleanupProcSignalState(), cmpEntries(), collectMatchBitmap(), compare_val_int4(), compareJsonbScalarValue(), convert_numeric_to_scalar(), date_dist(), element_compare(), exec_eval_integer(), exec_stmt_fori(), ExecEvalArrayRef(), ExecEvalMinMax(), ExecEvalRowCompare(), ExecEvalXml(), ExecMergeAppend(), exprIsLengthCoercion(), fetch_tuple_flag(), funny_dup17(), gbt_bitcmp(), gbt_byteacmp(), gbt_date_penalty(), gbt_datekey_cmp(), gbt_intvkey_cmp(), gbt_macadkey_cmp(), gbt_num_compress(), gbt_numeric_cmp(), gbt_textcmp(), gbt_timekey_cmp(), gbt_tskey_cmp(), gdb_date_dist(), get_rule_expr(), gin_btree_compare_prefix(), 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(), int8_to_char(), interval_transform(), IpcMemoryDelete(), leadlag_common(), matchPartialInPendingList(), numeric_to_char(), numeric_transform(), oidvectoreq(), oidvectorge(), oidvectorgt(), oidvectorle(), oidvectorlt(), oidvectorne(), overpaid(), parsetext(), pg_stat_get_activity(), PLyInt_FromInt32(), prs_setup_firstcall(), range_cmp_bound_values(), range_cmp_bounds(), range_contains_elem_internal(), record_cmp(), ReorderBufferIterCompare(), ReorderBufferIterTXNNext(), ReorderBufferToastAppendChunk(), signValue(), TemporalTransform(), test_shm_mq_main(), text_format(), timetravel(), toast_fetch_datum(), toast_fetch_datum_slice(), typenameTypeMod(), varbit_transform(), varchar_transform(), width_bucket_array_fixed(), width_bucket_array_variable(), window_nth_value(), and window_ntile().
#define DatumGetInt64 | ( | X | ) | (* ((int64 *) DatumGetPointer(X))) |
Definition at line 615 of file postgres.h.
Referenced by autoinc(), btint8fastcmp(), convert_numeric_to_scalar(), defGetInt64(), ExecWindowAgg(), gbt_num_compress(), initialize_worker_spi(), int4_cash(), int8_cash(), int8_to_char(), limit_needed(), numeric_cash(), pg_size_bytes(), PLyLong_FromInt64(), preprocess_limit(), recompute_limits(), row_is_in_frame(), simplify_EXISTS_query(), system_rows_beginsamplescan(), system_rows_samplescangetsamplesize(), ttdummy(), update_frameheadpos(), update_frametailpos(), and validate_index_heapscan().
#define DatumGetName | ( | X | ) | ((Name) DatumGetPointer(X)) |
Definition at line 593 of file postgres.h.
Referenced by AlterObjectNamespace_internal(), AlterObjectOwner_internal(), AlterObjectRename_internal(), btnamefastcmp(), EventTriggerSQLDropAddObject(), make_ruledef(), pg_identify_object(), and RelationBuildRowSecurity().
#define DatumGetObjectId | ( | X | ) | ((Oid) GET_4_BYTES(X)) |
Definition at line 508 of file postgres.h.
Referenced by AlterObjectNamespace_internal(), AlterObjectOwner_internal(), AlterObjectRename_internal(), AlterPolicy(), btoidfastcmp(), build_dummy_tuple(), convert_function_name(), convert_numeric_to_scalar(), convert_type_name(), CreatePolicy(), DefineTSParser(), DefineTSTemplate(), EvalPlanQualFetchRowMarks(), EventTriggerSQLDropAddObject(), execCurrentOf(), ExecLockRows(), find_expr_references_walker(), fix_expr_common(), gbt_num_compress(), generateClonedIndexStmt(), get_object_namespace(), GetUserMappingById(), heap_tuple_attr_equals(), inclusion_get_strategy_procinfo(), LexizeExec(), make_ruledef(), minmax_get_strategy_procinfo(), NextCopyFrom(), 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(), tsa_headline_byname(), and tsvector_update_trigger().
#define DatumGetPointer | ( | X | ) | ((Pointer) (X)) |
Definition at line 557 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(), advance_combine_function(), advance_transition_function(), advance_windowaggregate(), advance_windowaggregate_base(), AlterForeignDataWrapper(), AlterForeignServer(), AlterUserMapping(), 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(), BufferSync(), CheckIndexCompatible(), cleanup_background_workers(), CleanupInvalidationState(), collectMatchBitmap(), compileTheLexeme(), compileTheSubstitute(), compute_distinct_stats(), compute_range_stats(), compute_scalar_stats(), compute_trivial_stats(), compute_tsvector_stats(), convert_bytea_to_scalar(), convert_string_datum(), CopyArrayEls(), createdb_failure_callback(), CreateForeignDataWrapper(), CreateForeignServer(), CreateForeignTable(), CreateTrigger(), CreateUserMapping(), datum_compute_size(), datum_write(), datumCopy(), DatumGetAnyArray(), DatumGetEOHP(), DatumGetExpandedArray(), DatumGetExpandedArrayX(), datumGetSize(), datumIsEqual(), datumSerialize(), datumTransfer(), DeleteExpandedObject(), do_text_output_multiline(), dsm_postmaster_shutdown(), eval_windowaggregates(), eval_windowfunction(), EvalPlanQualFetchRowMarks(), exec_assign_value(), exec_stmt_foreach_a(), ExecCallTriggerFunc(), execCurrentOf(), ExecEvalXml(), ExecInitCteScan(), ExecLockRows(), ExecModifyTable(), ExecSetParamPlan(), ExecWorkTableScan(), expand_array(), finalize_aggregate(), finalize_partialaggregate(), finalize_windowaggregate(), fmgr(), free_attstatsslot(), free_params_data(), freeScanStackEntry(), 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_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_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_var_bin_union(), gbt_var_decompress(), gbt_var_fetch(), gbt_var_penalty(), gbt_var_picksplit(), gbt_var_same(), gbt_var_union(), generateClonedIndexStmt(), get_attstatsslot(), getDatumCopy(), GetFdwRoutine(), GetIndexAmRoutine(), getNextNearest(), 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(), gseg_consistent(), gseg_penalty(), gseg_picksplit(), gseg_union(), gtrgm_compress(), gtrgm_consistent(), gtrgm_decompress(), gtrgm_distance(), gtrgm_penalty(), gtsvector_compress(), gtsvector_consistent(), gtsvector_decompress(), gtsvector_penalty(), gtsvectorout(), heap_compute_data_size(), heap_fill_tuple(), hlparsetext(), hstore_slice_to_array(), hstoreUpgrade(), index_form_tuple(), index_reloptions(), inet_gist_compress(), int2vectorrecv(), InvalidateTSCacheCallBack(), IpcMemoryDetach(), LexizeExec(), like_fixed_prefix(), lookup_ts_dictionary_cache(), ltree_addtext(), ltree_compress(), ltree_consistent(), ltree_decompress(), ltree_penalty(), ltree_textadd(), make_array_ref(), make_greater_string(), make_tuple_from_result_row(), make_tuple_indirect(), MakeExpandedObjectReadOnlyInternal(), match_special_index_operator(), mcelem_tsquery_selec(), memcpyDatum(), mode_final(), movedb_failure_callback(), numeric_abbrev_convert(), numeric_fast_cmp(), oidvectorrecv(), ordered_set_shutdown(), outDatum(), parseRelOptions(), parsetext(), patternsel(), pg_attribute_aclmask(), pg_class_aclmask(), pg_database_aclmask(), pg_foreign_data_wrapper_aclmask(), pg_foreign_server_aclmask(), pg_get_indexdef_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_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(), postgresExecForeignDelete(), postgresExecForeignUpdate(), printtup(), ProcedureCreate(), process_ordered_aggregate_single(), prs_setup_firstcall(), prune_element_hashtable(), pushval_morph(), record_image_cmp(), record_image_eq(), RelationGetIndexList(), RelationInitIndexAccessInfo(), ReorderBufferToastAppendChunk(), ReorderBufferToastReplace(), reorderqueue_pop(), ResourceOwnerReleaseInternal(), ri_LoadConstraintInfo(), sepgsql_fmgr_hook(), shm_mq_detach_callback(), show_trgm(), ShowAllGUCConfig(), shutdown_MultiFuncCall(), ShutdownFuncExpr(), ShutdownSQLFunction(), ShutdownTupleDescRef(), simplify_function(), spg_text_inner_consistent(), spg_text_leaf_consistent(), StoreAttrDefault(), text2ltree(), text_substring(), thesaurus_lexize(), TidListCreate(), 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_insert_or_update(), toast_raw_datum_size(), toast_save_datum(), TransferExpandedObject(), transformFkeyCheckAttrs(), transformFkeyGetPrimaryKey(), transformGenericOptions(), transformIndexConstraint(), transformRelOptions(), ts_accum(), ts_lexize(), tsquery_rewrite_query(), tstoreReceiveSlot_detoast(), tsvector_update_trigger(), tt_setup_firstcall(), tuplesort_putdatum(), unaccent_dict(), untransformRelOptions(), and validate_index_heapscan().
#define DatumGetTransactionId | ( | X | ) | ((TransactionId) GET_4_BYTES(X)) |
Definition at line 522 of file postgres.h.
#define DatumGetUInt16 | ( | X | ) | ((uint16) GET_2_BYTES(X)) |
Definition at line 466 of file postgres.h.
Referenced by gintuple_get_attrnum().
#define DatumGetUInt32 | ( | X | ) | ((uint32) GET_4_BYTES(X)) |
Definition at line 494 of file postgres.h.
Referenced by _hash_datum2hashkey(), _hash_datum2hashkey_type(), bernoulli_nextsampletuple(), bms_hash_value(), CatalogCacheComputeHashValue(), comparetup_index_hash(), element_hash(), ExecHashBuildSkewHash(), ExecHashGetHashValue(), hash_array(), hash_range(), JsonbHashScalarValue(), lexeme_hash(), make_text_key(), 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 642 of file postgres.h.
#define DatumGetUInt8 | ( | X | ) | ((uint8) GET_1_BYTE(X)) |
Definition at line 438 of file postgres.h.
#define Float4GetDatumFast | ( | X | ) | PointerGetDatum(&(X)) |
Definition at line 731 of file postgres.h.
#define Float8GetDatumFast | ( | X | ) | PointerGetDatum(&(X)) |
Definition at line 725 of file postgres.h.
Referenced by float4_accum(), float8_accum(), float8_regr_accum(), interval_hash(), interval_lerp(), pg_stat_statements_internal(), and timetz_hash().
#define GET_1_BYTE | ( | datum | ) | (((Datum) (datum)) & 0x000000ff) |
Definition at line 380 of file postgres.h.
Referenced by record_image_cmp(), and record_image_eq().
#define GET_2_BYTES | ( | datum | ) | (((Datum) (datum)) & 0x0000ffff) |
Definition at line 381 of file postgres.h.
Referenced by record_image_cmp(), and record_image_eq().
#define GET_4_BYTES | ( | datum | ) | (((Datum) (datum)) & 0xffffffff) |
Definition at line 382 of file postgres.h.
Referenced by record_image_cmp(), and record_image_eq().
#define Int16GetDatum | ( | X | ) | ((Datum) SET_2_BYTES(X)) |
Definition at line 459 of file postgres.h.
Referenced by AggregateCreate(), btcostestimate(), column_privilege_check(), CreateConstraintEntry(), CreateTrigger(), DeleteSystemAttributeTuples(), dropOperators(), dropProcedures(), examine_simple_variable(), examine_variable(), ExecGrant_Attribute(), ExecHashBuildSkewHash(), expand_all_col_privileges(), fixup_whole_row_references(), gbt_num_fetch(), get_attavgwidth(), get_attname(), get_attribute_options(), get_atttype(), get_atttypetypmodcoll(), get_atttypmod(), 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(), 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_exec_trigger(), RelationBuildTupleDesc(), RemoveAttrDefault(), RemoveAttrDefaultById(), RemoveAttributeById(), RemoveStatistics(), scalararraysel(), scanRTEForColumn(), sepgsql_attribute_post_create(), spg_text_choose(), spg_text_picksplit(), StoreAttrDefault(), StoreCatalogInheritance1(), storeOperators(), storeProcedures(), tsvector_unnest(), TypeCreate(), TypeShellMake(), update_attstats(), and UpdateIndexRelation().
#define Int32GetDatum | ( | X | ) | ((Datum) SET_4_BYTES(X)) |
Definition at line 487 of file postgres.h.
Referenced by _PG_init(), AggregateCreate(), AlterDatabase(), AlterRole(), array_positions(), ATExecAlterColumnType(), autoinc(), bitshiftleft(), bitshiftright(), brin_metapage_info(), build_coercion_expression(), build_regexp_matches_result(), build_regexp_split_result(), cash_numeric(), check_timezone(), CollationCreate(), CollationGetCollid(), compileTheLexeme(), compileTheSubstitute(), ConversionCreate(), CreateComments(), CreateConstraintEntry(), CreateConversionCommand(), createdb(), CreateRole(), daterange_canonical(), dblink_get_notify(), DeleteComments(), DeleteInitPrivs(), deleteOneObject(), DeleteSecurityLabel(), drop_parent_dependency(), DropConfigurationMapping(), eval_const_expressions_mutator(), exec_stmt_fori(), ExecEvalArrayCoerceExpr(), ExecMergeAppend(), FindDefaultConversion(), findDependentObjects(), flatten_set_variable_args(), gbt_num_fetch(), gbt_numeric_penalty(), generate_series_step_int4(), generate_setop_tlist(), generate_subscripts(), get_collation_oid(), get_constraint_index(), get_index_constraint(), GetComment(), GetSecurityLabel(), gin_extract_query_trgm(), gin_extract_value_trgm(), gin_metapage_info(), gin_page_opaque_info(), ginint4_queryextract(), hlparsetext(), hypothetical_dense_rank_final(), hypothetical_rank_common(), InitAuxiliaryProcess(), InputFunctionCall(), InsertPgAttributeTuple(), InsertPgClassTuple(), int2vectorrecv(), int4_to_char(), int4range_canonical(), InternalIpcMemoryCreate(), inv_read(), inv_truncate(), inv_write(), IsThereCollationInNamespace(), leftmostvalue_bit(), leftmostvalue_int4(), leftmostvalue_varbit(), LexizeExec(), make_const(), MakeConfigurationMapping(), moddatetime(), neqsel(), network_scan_last(), 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_size_bytes(), pg_stat_get_activity(), pg_stat_get_backend_idset(), pg_stat_get_progress_info(), pg_stat_get_wal_receiver(), pg_stat_get_wal_senders(), pgstatginindex(), printTypmod(), ProcSignalInit(), prs_setup_firstcall(), readRecoveryCommandFile(), ReceiveFunctionCall(), recordExtensionInitPriv(), recordMultipleDependencies(), ReorderBufferIterTXNInit(), ReorderBufferIterTXNNext(), restriction_selectivity(), ri_AttributesEqual(), scalararraysel(), SetSecurityLabel(), shdepAddDependency(), shdepChangeDep(), shdepDropDependency(), show_all_file_settings(), ssl_client_serial(), textregexsubstr(), toast_fetch_datum_slice(), toast_save_datum(), transformArraySubscripts(), ts_lexize(), tsquery_phrase(), ttdummy(), TypeCreate(), TypeShellMake(), unaccent_dict(), update_attstats(), and worker_spi_launch().
#define Int64GetDatumFast | ( | X | ) | PointerGetDatum(&(X)) |
Definition at line 724 of file postgres.h.
Referenced by DefineSequence(), FunctionNext(), int2int4_sum(), int8_avg(), interval_hash(), numeric_poly_avg(), pg_stat_statements_internal(), and timetz_hash().
#define Int8GetDatum | ( | X | ) | ((Datum) SET_1_BYTE(X)) |
Definition at line 431 of file postgres.h.
#define MultiXactIdGetDatum | ( | X | ) | ((Datum) SET_4_BYTES((X))) |
Definition at line 536 of file postgres.h.
Referenced by InsertPgClassTuple().
#define NameGetDatum | ( | X | ) | PointerGetDatum(X) |
Definition at line 603 of file postgres.h.
Referenced by AddEnumLabel(), AlterDatabase(), AlterDatabaseOwner(), AlterObjectRename_internal(), build_dummy_tuple(), CollationCreate(), ConversionCreate(), create_proc_lang(), CreateConstraintEntry(), CreateOpFamily(), DefineOpClass(), DefineSequence(), DefineTSConfiguration(), DefineTSDictionary(), DefineTSParser(), DefineTSTemplate(), EnumValuesCreate(), find_language_template(), get_db_info(), insert_event_trigger_tuple(), InsertPgAttributeTuple(), InsertPgClassTuple(), InsertRule(), movedb(), nameiclike(), nameicnlike(), NamespaceCreate(), OperatorCreate(), OperatorShellMake(), pg_create_physical_replication_slot(), pg_get_replication_slots(), ProcedureCreate(), RelationBuildTriggers(), set_timetravel(), TypeCreate(), and TypeShellMake().
#define ObjectIdGetDatum | ( | X | ) | ((Datum) SET_4_BYTES(X)) |
Definition at line 515 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(), AddEnumLabel(), AddRoleMems(), AfterTriggerSetState(), AggregateCreate(), 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(), AlterRelationNamespaceInternal(), AlterRole(), AlterSchemaOwner_internal(), AlterSchemaOwner_oid(), AlterSeqNamespaces(), AlterSetting(), AlterTableMoveAll(), AlterTSDictionary(), AlterTypeNamespaceInternal(), AlterTypeOwner_oid(), AlterTypeOwnerInternal(), AlterUserMapping(), amvalidate(), ApplyExtensionUpdates(), ApplySetting(), assignOperTypes(), assignProcTypes(), ATAddForeignKeyConstraint(), ATExecAddColumn(), ATExecAddInherit(), ATExecAddOf(), ATExecAlterColumnType(), ATExecAlterConstraint(), ATExecChangeOwner(), ATExecDisableRowSecurity(), ATExecDropColumn(), ATExecDropConstraint(), ATExecDropInherit(), ATExecDropNotNull(), ATExecDropOf(), ATExecEnableRowSecurity(), ATExecForceNoForceRowSecurity(), ATExecSetRelOptions(), ATExecSetTableSpace(), ATExecValidateConstraint(), ATPostAlterTypeCleanup(), ATPrepChangePersistence(), AttrDefaultFetch(), blvalidate(), brinvalidate(), btcostestimate(), btvalidate(), build_coercion_expression(), build_regtype_array(), BuildIndexValueDescription(), CacheInvalidateRelcacheByRelid(), CatalogCacheComputeTupleHashValue(), change_owner_fix_column_acls(), change_owner_recurse_to_sequences(), changeDependencyFor(), check_amop_signature(), check_amproc_signature(), check_enable_rls(), check_for_column_name_collision(), check_hash_func_signature(), check_timezone(), check_TSCurrentConfig(), CheckConstraintFetch(), CheckFunctionValidatorAccess(), CheckIndexCompatible(), CheckMyDatabase(), checkSharedDependencies(), ChooseConstraintName(), cluster(), cluster_rel(), CollationCreate(), CollationGetCollid(), CollationIsVisible(), column_privilege_check(), compile_plperl_function(), compile_pltcl_function(), ComputeIndexAttrs(), ConstraintNameIsUsed(), ConstructTupleDescriptor(), ConversionCreate(), ConversionGetConid(), ConversionIsVisible(), CopyOneRowTo(), copyTemplateDependencies(), create_proc_lang(), create_toast_table(), CreateAccessMethod(), CreateCast(), CreateComments(), CreateConstraintEntry(), createdb(), CreateForeignDataWrapper(), CreateForeignServer(), CreateForeignTable(), CreateFunction(), CreateOpFamily(), CreatePolicy(), CreateRole(), CreateSchemaCommand(), CreateSharedComments(), CreateTableSpace(), CreateTransform(), CreateTrigger(), CreateUserMapping(), currtid_for_view(), decompile_conbin(), DefineCollation(), DefineCompositeType(), DefineDomain(), DefineEnum(), DefineOpClass(), DefineQueryRewrite(), DefineRange(), DefineTSConfiguration(), DefineTSDictionary(), DefineTSParser(), DefineTSTemplate(), DefineType(), DeleteAttributeTuples(), DeleteComments(), deleteDependencyRecordsFor(), deleteDependencyRecordsForClass(), DeleteInitPrivs(), deleteOneObject(), DeleteRelationTuple(), DeleteSecurityLabel(), DeleteSharedComments(), DeleteSharedSecurityLabel(), DeleteSystemAttributeTuples(), DelRoleMems(), deparseFuncExpr(), deparseOpExpr(), deparseScalarArrayOpExpr(), do_autovacuum(), do_compile(), 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_getdiag(), ExecGrant_Attribute(), ExecGrant_Database(), ExecGrant_Fdw(), ExecGrant_ForeignServer(), ExecGrant_Function(), ExecGrant_Language(), ExecGrant_Largeobject(), ExecGrant_Namespace(), ExecGrant_Relation(), ExecGrant_Tablespace(), ExecGrant_Type(), ExecHashBuildSkewHash(), ExecInitAgg(), expand_all_col_privileges(), extension_config_remove(), fetch_agg_sort_op(), fetch_fp_info(), find_coercion_pathway(), find_composite_type_dependencies(), find_expr_references_walker(), find_inheritance_children(), find_typed_table_dependencies(), find_typmod_coercion_function(), find_user_mapping(), 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(), ForceTransactionIdLimitUpdate(), format_operator_internal(), format_operator_parts(), format_procedure_internal(), format_procedure_parts(), format_type_internal(), func_get_detail(), func_parallel(), func_strict(), func_volatile(), FunctionIsVisible(), gbt_num_fetch(), generate_collation_name(), generate_function_name(), generate_operator_name(), generate_qualified_relation_name(), generate_relation_name(), generateClonedIndexStmt(), get_agg_clause_costs_walker(), get_am_name(), get_array_type(), get_attavgwidth(), get_attname(), get_attribute_options(), get_attstatsslot(), get_atttype(), get_atttypetypmodcoll(), get_atttypmod(), get_base_element_type(), get_cast_oid(), get_catalog_object_by_oid(), get_collation(), get_collation_name(), get_collation_oid(), 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_domain_constraint_oid(), get_element_type(), get_extension_name(), get_extension_schema(), get_func_cost(), get_func_leakproof(), get_func_name(), get_func_namespace(), get_func_nargs(), get_func_result_name(), get_func_retset(), get_func_rettype(), get_func_rows(), get_func_signature(), get_func_variadictype(), get_index_constraint(), 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_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_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_pkey_attnames(), get_primary_key_attnos(), get_range_subtype(), get_rel_name(), get_rel_namespace(), get_rel_persistence(), get_rel_relkind(), get_rel_tablespace(), get_rel_type_id(), get_relation_constraint_oid(), get_relation_policy_oid(), get_relname_relid(), get_rels_with_domain(), get_rewrite_oid(), get_rte_attribute_is_dropped(), get_rte_attribute_type(), 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(), GetDatabaseTupleByOid(), GetDefaultOpClass(), getExtensionOfObject(), GetFdwRoutineByServerId(), GetForeignColumnOptions(), GetForeignDataWrapper(), GetForeignServer(), GetForeignServerIdByRelId(), GetForeignTable(), GetIndexAmRoutineByAmId(), GetIndexOpClass(), GetNewOidWithIndex(), getObjectDescription(), getObjectIdentityParts(), getOpFamilyDescription(), getOpFamilyIdentity(), getOwnedSequences(), getProcedureTypeDescription(), getRelationDescription(), getRelationIdentity(), getRelationsInNamespace(), getRelationTypeDescription(), GetRemapClass(), GetSecurityLabel(), GetSharedSecurityLabel(), GetTSConfigTuple(), getTypeBinaryInputInfo(), getTypeBinaryOutputInfo(), getTypeInputInfo(), getTypeOutputInfo(), GetUserMappingById(), GetUserNameFromId(), ginvalidate(), gistindex_keytest(), 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_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_subclass(), has_table_privilege_id(), has_table_privilege_id_id(), has_table_privilege_name_id(), has_type_privilege_id(), has_type_privilege_id_id(), has_type_privilege_name_id(), hash_ok_operator(), hashvalidate(), have_createdb_privilege(), heap_create_with_catalog(), heap_drop_with_catalog(), heap_getsysattr(), inclusion_get_strategy_procinfo(), index_build(), index_check_primary_key(), index_constraint_create(), index_drop(), index_set_state_flags(), index_update_stats(), IndexGetRelation(), IndexSupportsBackwardScan(), init_sql_fcache(), initialize_peragg(), InitializeSessionUserId(), inline_set_returning_function(), InputFunctionCall(), insert_event_trigger_tuple(), InsertExtensionTuple(), InsertPgAttributeTuple(), InsertPgClassTuple(), InsertRule(), int2vectorrecv(), 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(), LargeObjectCreate(), LargeObjectDrop(), LargeObjectExists(), lastval(), left_oper(), leftmostvalue_bit(), leftmostvalue_oid(), leftmostvalue_varbit(), lo_manage(), load_domaintype_info(), load_enum_cache_data(), load_rangetype_info(), LockTableRecurse(), lookup_collation_cache(), lookup_ts_config_cache(), lookup_ts_dictionary_cache(), lookup_ts_parser_cache(), lookup_type_cache(), LookupAggNameTypeNames(), LookupOpclassInfo(), LookupTypeName(), 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(), mv_GenerateOper(), myLargeObjectExists(), NamespaceCreate(), neqjoinsel(), neqsel(), 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(), pg_attribute_aclcheck_all(), pg_attribute_aclmask(), pg_backup_start_time(), pg_buffercache_pages(), pg_class_aclmask(), pg_class_ownercheck(), 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_ruledef_worker(), pg_get_serial_sequence(), 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_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_prepared_xact(), pg_proc_aclmask(), pg_proc_ownercheck(), pg_relation_filenode(), pg_relation_filepath(), pg_show_replication_origin_status(), pg_size_bytes(), pg_stat_get_activity(), pg_stat_get_progress_info(), pg_stat_statements_internal(), 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(), phraseto_tsquery(), plainto_tsquery(), plperl_trigger_build_args(), plperl_validator(), plpgsql_build_datatype(), plpgsql_compile(), plpgsql_exec_trigger(), plpgsql_parse_cwordtype(), plpgsql_validator(), plpython_validator(), pltcl_trigger_handler(), PLy_input_tuple_funcs(), PLy_output_tuple_funcs(), PLy_procedure_argument_valid(), PLy_procedure_create(), PLy_procedure_get(), PLy_spi_prepare(), PLy_trigger_build_args(), PLyString_ToComposite(), policy_role_list_to_array(), print_function_arguments(), ProcedureCreate(), RangeCreate(), RangeDelete(), RangeVarCallbackForAlterRelation(), RangeVarCallbackForDropRelation(), RangeVarCallbackForPolicy(), RangeVarCallbackForRenameAttribute(), RangeVarCallbackForRenameRule(), RangeVarCallbackForRenameTrigger(), RangeVarCallbackOwnsRelation(), readRecoveryCommandFile(), ReceiveFunctionCall(), recomputeNamespacePath(), record_plan_function_dependency(), recordExtensionInitPriv(), recordMultipleDependencies(), regclassout(), regconfigout(), regdictionaryout(), regoperout(), regprocout(), regtypeout(), reindex_index(), ReindexMultipleTables(), relation_has_policies(), relation_mark_replica_identity(), RelationBuildRowSecurity(), RelationBuildRuleLock(), RelationBuildTriggers(), RelationBuildTupleDesc(), RelationCacheInitializePhase3(), RelationGetExclusionInfo(), RelationGetFKeyList(), RelationGetIndexList(), relationHasPrimaryKey(), RelationHasUnloggedIndex(), RelationInitIndexAccessInfo(), RelationIsVisible(), RelationReloadIndexInfo(), RelationRemoveInheritance(), RelationSetNewRelfilenode(), RelidByRelfilenode(), RemoveAccessMethodById(), RemoveAmOpEntryById(), RemoveAmProcEntryById(), RemoveAttrDefault(), RemoveAttrDefaultById(), RemoveAttributeById(), RemoveCollationById(), RemoveConstraintById(), RemoveConversionById(), RemoveDefaultACLById(), RemoveEventTriggerById(), RemoveExtensionById(), RemoveForeignDataWrapperById(), RemoveForeignServerById(), RemoveFunctionById(), RemoveObjects(), RemoveOpClassById(), RemoveOperatorById(), RemoveOpFamilyById(), RemovePolicyById(), RemoveRewriteRuleById(), RemoveRoleFromObjectACL(), RemoveRoleFromObjectPolicy(), RemoveSchemaById(), RemoveStatistics(), RemoveTriggerById(), RemoveTSConfigurationById(), RemoveTSDictionaryById(), RemoveTSParserById(), RemoveTSTemplateById(), RemoveTypeById(), RemoveUserMapping(), RemoveUserMappingById(), rename_constraint_internal(), rename_policy(), RenameConstraint(), RenameConstraintById(), RenameDatabase(), RenameRelationInternal(), RenameRewriteRule(), renametrig(), RenameType(), RenameTypeInternal(), replorigin_by_oid(), replorigin_create(), replorigin_drop(), restriction_selectivity(), ri_add_cast_to(), ri_GenerateQual(), ri_GenerateQualCollation(), ri_LoadConstraintInfo(), right_oper(), roles_has_privs_of(), roles_is_member_of(), scalararraysel(), ScanPgRelation(), scanRTEForColumn(), SearchSysCacheAttName(), 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(), SetDefaultACL(), SetFunctionArgType(), SetFunctionReturnType(), SetMatViewPopulatedState(), SetRelationHasSubclass(), SetRelationNumChecks(), SetRelationRuleStatus(), SetSecurityLabel(), SetSharedSecurityLabel(), shdepAddDependency(), shdepChangeDep(), shdepDropDependency(), shdepDropOwned(), shdepLockAndCheckObject(), shdepReassignOwned(), simplify_function(), spgvalidate(), SPI_gettype(), ssl_client_serial(), StoreAttrDefault(), StoreCatalogInheritance1(), storeOperators(), storeProcedures(), superuser_arg(), 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(), transformArrayType(), transformFkeyCheckAttrs(), transformFkeyGetPrimaryKey(), transformGenericOptions(), triggered_change_notification(), try_relation_open(), TryReuseForeignKey(), ts_headline(), ts_headline_opt(), tsa_headline_byname(), tsa_lexize_bycurrent(), tsa_lexize_byname(), tsa_parse_current(), tsa_plainto_tsquery_name(), tsa_set_curcfg(), tsa_set_curdict(), tsa_set_curprs(), tsa_to_tsquery_name(), tsa_to_tsvector_name(), tsa_token_type_current(), TSConfigIsVisible(), TSDictionaryIsVisible(), TSParserIsVisible(), TSTemplateIsVisible(), TupleDescInitEntry(), TypeCreate(), typeidType(), typeidTypeRelid(), typeInheritsFrom(), typeIsOfTypedTable(), TypeIsVisible(), TypenameGetTypid(), TypeShellMake(), update_attstats(), UpdateIndexRelation(), vac_update_datfrozenxid(), vac_update_relstats(), and verify_dictoptions().
#define PointerGetDatum | ( | X | ) | ((Datum) (X)) |
Definition at line 564 of file postgres.h.
Referenced by _int_different(), _ltree_compress(), _ltree_picksplit(), accumArrayResult(), 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(), ATExecAlterColumnGenericOptions(), ATExecChangeOwner(), ATExecGenericOptions(), autoinc(), binary_upgrade_create_empty_extension(), bpcharfastcmp_c(), brin_revmap_data(), brinbuildCallback(), bringetbitmap(), brininsert(), btbulkdelete(), BufferSync(), build_function_result_tupdesc_d(), build_function_result_tupdesc_t(), build_regexp_matches_result(), build_regexp_split_result(), build_regtype_array(), 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(), coerce_type(), CollationCreate(), CollationGetCollid(), collectMatchBitmap(), combine_aggregates(), 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(), create_proc_lang(), CreateConstraintEntry(), createdb(), CreateExtensionInternal(), CreateForeignDataWrapper(), CreateForeignServer(), CreateForeignTable(), CreateFunction(), CreatePolicy(), CreateProceduralLanguage(), CreateSchemaCommand(), CreateTrigger(), CreateUserMapping(), currtid_for_view(), date_mi_interval(), date_pl_interval(), datumCopy(), datumRestore(), DefineAggregate(), DefineIndex(), DefineOpClass(), DefineTSDictionary(), directBoolConsistentFn(), directTriConsistentFn(), do_text_output_multiline(), doPickSplit(), DropRole(), 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(), exec_stmt_return(), ExecEvalArray(), ExecEvalArrayRef(), ExecEvalWholeRowFast(), ExecEvalWholeRowSlow(), ExecEvalXml(), 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(), ExecMakeFunctionResult(), ExecPrepareTuplestoreResult(), ExecSetParamPlan(), ExecuteDoStmt(), extension_config_remove(), filter_list_to_array(), FinishSortSupportFunction(), Float4GetDatum(), Float8GetDatum(), fmgr(), fmgr_oldstyle(), fmgr_sql(), formTextDatum(), funny_dup17(), 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_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_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_available_versions_for_extension(), get_cached_rowtype(), get_collation_oid(), get_conversion_oid(), get_func_input_arg_names(), get_relname_relid(), get_rewrite_oid(), get_text_array_contents(), get_ts_config_oid(), get_ts_dict_oid(), get_ts_parser_oid(), get_ts_template_oid(), GetIndexOpClass(), 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(), heap_copy_tuple_as_datum(), heap_create_with_catalog(), heap_getsysattr(), heap_page_items(), heap_tuple_fetch_attr(), 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(), join_selectivity(), jsonb_array_element_text(), jsonb_object_field_text(), jsonb_put_escaped_value(), leftmostvalue_numeric(), leftmostvalue_text(), LexizeExec(), lo_manage(), LogicalOutputWrite(), lookup_ts_dictionary_cache(), lookup_ts_parser_cache(), LookupTypeName(), lt_q_regex(), ltree_addtext(), ltree_compress(), ltree_consistent(), ltree_decompress(), ltree_picksplit(), ltree_textadd(), ltree_to_plpython(), make_greater_string(), make_row_from_rec_and_jsonb(), make_text_key(), make_tuple_indirect(), makeArrayResultArr(), makeConst(), makeMdArrayResult(), makeRangeConstructors(), matchPartialInPendingList(), md5_crypt_verify(), MJExamineQuals(), moddatetime(), movedb(), NamespaceCreate(), neqjoinsel(), neqsel(), 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(), 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_exec_function(), plpgsql_exec_trigger(), plpython_call_handler(), pltcl_handler(), PLy_cursor_plan(), PLy_spi_execute_plan(), PLy_spi_prepare(), PLyObject_ToBytea(), PLyObject_ToTransform(), PLySequence_ToArray(), populate_record_worker(), prepare_sql_fn_parse_info(), ProcedureCreate(), proclock_hash(), ProcLockHashCode(), prs_setup_firstcall(), quote_ident_cstr(), range_gist_double_sorting_split(), range_send(), range_serialize(), ReadArrayBinary(), ReadArrayStr(), readDatum(), readtup_datum(), ReceiveFunctionCall(), recordExtensionInitPriv(), regexp_matches(), RemoveRoleFromObjectPolicy(), RenameRewriteRule(), renametrig(), ReorderBufferToastReplace(), ResourceOwnerCreate(), ResourceOwnerForgetCatCacheListRef(), ResourceOwnerForgetCatCacheRef(), ResourceOwnerForgetDSM(), ResourceOwnerForgetPlanCacheRef(), ResourceOwnerForgetRelationRef(), ResourceOwnerForgetSnapshot(), ResourceOwnerForgetTupleDesc(), ResourceOwnerRememberCatCacheListRef(), ResourceOwnerRememberCatCacheRef(), ResourceOwnerRememberDSM(), ResourceOwnerRememberPlanCacheRef(), ResourceOwnerRememberRelationRef(), ResourceOwnerRememberSnapshot(), ResourceOwnerRememberTupleDesc(), restriction_selectivity(), RI_FKey_cascade_del(), RI_FKey_cascade_upd(), RI_FKey_check(), RI_FKey_setdefault_del(), RI_FKey_setdefault_upd(), RI_FKey_setnull_del(), RI_FKey_setnull_upd(), ri_restrict_del(), ri_restrict_upd(), rtree_internal_consistent(), scalararraysel(), sepgsql_fmgr_hook(), SetDefaultACL(), setup_background_workers(), SharedInvalBackendInit(), shimBoolConsistentFn(), shm_mq_attach(), show_all_file_settings(), show_trgm(), ShowAllGUCConfig(), simplify_function(), spg_quad_inner_consistent(), spg_range_quad_picksplit(), spg_text_inner_consistent(), spg_text_leaf_consistent(), spgdoinsert(), spgGetCache(), spgLeafTest(), spgWalk(), split_text(), ssl_extension_info(), 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(), timetravel(), timetz_izone(), to_tsquery(), to_tsquery_byid(), to_tsvector(), toast_compress_datum(), toast_datum_size(), toast_delete(), toast_flatten_tuple(), toast_flatten_tuple_to_datum(), toast_insert_or_update(), toast_raw_datum_size(), toast_save_datum(), transformGenericOptions(), transformRelOptions(), triggered_change_notification(), ts_headline_byid_opt(), ts_lexize(), TSConfigIsVisible(), TSDictionaryIsVisible(), TSParserIsVisible(), tsqueryin(), TSTemplateIsVisible(), tstoreReceiveSlot_detoast(), tsvector_to_array(), tsvector_unnest(), tsvector_update_trigger(), ttdummy(), tuple_data_split_internal(), tuple_to_stringinfo(), TupleQueueRemapArray(), tuplesort_getdatum(), tuplesort_putdatum(), TypeCreate(), TypeIsVisible(), TypenameGetTypid(), typenameTypeMod(), unaccent_dict(), union_tuples(), update_attstats(), UpdateIndexRelation(), varstr_abbrev_convert(), varstrfastcmp_c(), varstrfastcmp_locale(), verify_dictoptions(), writetup_datum(), and xmlconcat().
Definition at line 386 of file postgres.h.
Definition at line 387 of file postgres.h.
Definition at line 388 of file postgres.h.
Referenced by Float4GetDatum().
#define SET_VARSIZE | ( | PTR, | |
len | |||
) | SET_VARSIZE_4B(PTR, len) |
Definition at line 330 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(), 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_fakeval_and_phrase(), 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(), EA_flatten_into(), encrypt_internal(), ExecEvalArray(), 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(), heap_tuple_untoast_attr(), heap_tuple_untoast_attr_slice(), hstore_concat(), hstore_delete(), hstore_delete_array(), hstore_delete_hstore(), hstorePairs(), inner_subltree(), int2vectorin(), inv_truncate(), inv_write(), JsonbValueToJsonb(), lca_inner(), lo_get_fragment_internal(), loread(), lpad(), lquery_in(), ltree2text(), ltree_compress(), ltree_concat(), ltree_in(), ltree_picksplit(), ltree_union(), make_greater_string(), make_result(), make_text_key(), make_tsvector(), makeArrayResultArr(), makeDefaultBloomOptions(), makeitem(), 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(), show_trgm(), similar_escape(), spg_text_inner_consistent(), spg_text_leaf_consistent(), string_to_bytea_const(), text_catenate(), text_reverse(), text_substring(), to_tsvector_byid(), toast_decompress_datum(), toast_fetch_datum(), toast_fetch_datum_slice(), toast_save_datum(), transformRelOptions(), translate(), tsa_rewrite_accum(), tsa_rewrite_finish(), tsquery_rewrite(), tsquery_rewrite_query(), tsqueryrecv(), tsquerytree(), tsvector_concat(), tsvector_delete_by_indices(), tsvector_filter(), tsvector_strip(), tsvector_update_trigger(), 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 262 of file postgres.h.
#define SET_VARSIZE_4B | ( | PTR, | |
len | |||
) | (((varattrib_4b *) (PTR))->va_4byte.va_header = (((uint32) (len)) << 2)) |
Definition at line 258 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 260 of file postgres.h.
#define SET_VARSIZE_COMPRESSED | ( | PTR, | |
len | |||
) | SET_VARSIZE_4B_C(PTR, len) |
Definition at line 332 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 331 of file postgres.h.
Referenced by datum_write(), formTextDatum(), and heap_fill_tuple().
#define SET_VARTAG_1B_E | ( | PTR, | |
tag | |||
) |
Definition at line 264 of file postgres.h.
#define SET_VARTAG_EXTERNAL | ( | PTR, | |
tag | |||
) | SET_VARTAG_1B_E(PTR, tag) |
Definition at line 334 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 376 of file postgres.h.
#define TransactionIdGetDatum | ( | X | ) | ((Datum) SET_4_BYTES((X))) |
Definition at line 529 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) SET_2_BYTES(X)) |
Definition at line 473 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) SET_4_BYTES(X)) |
Definition at line 501 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(), LaunchParallelWorkers(), pg_lock_status(), pg_xlogfile_name_offset(), pgstatginindex(), setup_background_workers(), and shimBoolConsistentFn().
#define UInt64GetDatum | ( | X | ) | Int64GetDatum((int64) (X)) |
Definition at line 656 of file postgres.h.
Referenced by exec_stmt_getdiag().
#define UInt8GetDatum | ( | X | ) | ((Datum) SET_1_BYTE(X)) |
Definition at line 445 of file postgres.h.
Referenced by heap_page_items().
#define VARATT_CAN_MAKE_SHORT | ( | PTR | ) |
Definition at line 271 of file postgres.h.
Referenced by datum_compute_size(), datum_write(), heap_compute_data_size(), and heap_fill_tuple().
#define VARATT_CONVERTED_SHORT_SIZE | ( | PTR | ) | (VARSIZE(PTR) - VARHDRSZ + VARHDRSZ_SHORT) |
Definition at line 274 of file postgres.h.
Referenced by datum_compute_size(), datum_write(), heap_compute_data_size(), and heap_fill_tuple().
#define VARATT_IS_1B | ( | PTR | ) | ((((varattrib_1b *) (PTR))->va_header & 0x01) == 0x01) |
Definition at line 243 of file postgres.h.
#define VARATT_IS_1B_E | ( | PTR | ) | ((((varattrib_1b *) (PTR))->va_header) == 0x01) |
Definition at line 245 of file postgres.h.
#define VARATT_IS_4B | ( | PTR | ) | ((((varattrib_1b *) (PTR))->va_header & 0x01) == 0x00) |
Definition at line 237 of file postgres.h.
#define VARATT_IS_4B_C | ( | PTR | ) | ((((varattrib_1b *) (PTR))->va_header & 0x03) == 0x02) |
Definition at line 241 of file postgres.h.
#define VARATT_IS_4B_U | ( | PTR | ) | ((((varattrib_1b *) (PTR))->va_header & 0x03) == 0x00) |
Definition at line 239 of file postgres.h.
#define VARATT_IS_COMPRESSED | ( | PTR | ) | VARATT_IS_4B_C(PTR) |
Definition at line 315 of file postgres.h.
Referenced by heap_tuple_untoast_attr(), heap_tuple_untoast_attr_slice(), mcelem_tsquery_selec(), pg_detoast_datum_packed(), text_substring(), toast_compress_datum(), toast_decompress_datum(), toast_flatten_tuple_to_datum(), toast_insert_or_update(), toast_raw_datum_size(), and toast_save_datum().
#define VARATT_IS_EXTENDED | ( | PTR | ) | (!VARATT_IS_4B_U(PTR)) |
Definition at line 328 of file postgres.h.
Referenced by getdatafield(), heap_tuple_untoast_attr(), 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 316 of file postgres.h.
Referenced by datum_write(), heap_fill_tuple(), heap_tuple_fetch_attr(), heap_tuple_untoast_attr_slice(), index_form_tuple(), mcelem_tsquery_selec(), pg_detoast_datum_packed(), ReorderBufferToastReplace(), text_substring(), toast_compress_datum(), toast_flatten_tuple(), toast_flatten_tuple_to_datum(), toast_insert_or_update(), toast_save_datum(), 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 325 of file postgres.h.
Referenced by array_get_element(), array_set_element(), datumCopy(), datumEstimateSpace(), DatumGetAnyArray(), DatumGetEOHP(), datumSerialize(), expand_array(), heap_compute_data_size(), heap_fill_tuple(), heap_tuple_fetch_attr(), heap_tuple_untoast_attr(), heap_tuple_untoast_attr_slice(), toast_datum_size(), and toast_raw_datum_size().
#define VARATT_IS_EXTERNAL_EXPANDED_RO | ( | PTR | ) | (VARATT_IS_EXTERNAL(PTR) && VARTAG_EXTERNAL(PTR) == VARTAG_EXPANDED_RO) |
Definition at line 321 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 323 of file postgres.h.
Referenced by DatumGetExpandedArray(), DatumGetExpandedArrayX(), datumTransfer(), DeleteExpandedObject(), exec_assign_value(), MakeExpandedObjectReadOnlyInternal(), plpgsql_exec_function(), and TransferExpandedObject().
#define VARATT_IS_EXTERNAL_INDIRECT | ( | PTR | ) | (VARATT_IS_EXTERNAL(PTR) && VARTAG_EXTERNAL(PTR) == VARTAG_INDIRECT) |
Definition at line 319 of file postgres.h.
Referenced by heap_tuple_fetch_attr(), heap_tuple_untoast_attr(), heap_tuple_untoast_attr_slice(), make_tuple_indirect(), toast_datum_size(), toast_raw_datum_size(), and tuple_data_split_internal().
#define VARATT_IS_EXTERNAL_ONDISK | ( | PTR | ) | (VARATT_IS_EXTERNAL(PTR) && VARTAG_EXTERNAL(PTR) == VARTAG_ONDISK) |
Definition at line 317 of file postgres.h.
Referenced by heap_tuple_fetch_attr(), heap_tuple_untoast_attr(), heap_tuple_untoast_attr_slice(), make_tuple_indirect(), toast_datum_size(), toast_delete(), toast_delete_datum(), toast_fetch_datum(), toast_fetch_datum_slice(), toast_insert_or_update(), toast_raw_datum_size(), toast_save_datum(), tuple_data_split_internal(), and tuple_to_stringinfo().
#define VARATT_IS_SHORT | ( | PTR | ) | VARATT_IS_1B(PTR) |
Definition at line 327 of file postgres.h.
Referenced by datum_write(), heap_fill_tuple(), heap_tuple_untoast_attr(), heap_tuple_untoast_attr_slice(), 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 247 of file postgres.h.
#define VARATT_SHORT_MAX 0x7F |
Definition at line 270 of file postgres.h.
Referenced by formTextDatum(), numeric_abbrev_convert(), and numeric_sortsupport().
#define VARDATA | ( | PTR | ) | VARDATA_4B(PTR) |
Definition at line 305 of file postgres.h.
Referenced by add_block_entropy(), array_send(), array_to_tsvector(), binary_decode(), binary_encode(), bpchar(), bpchar_input(), brin_page_type(), bytea_catenate(), bytea_string_agg_finalfn(), byteain(), bytearecv(), byteaSetBit(), byteaSetByte(), byteatrim(), catenate_stringinfo_string(), char_bpchar(), char_text(), chr(), concat_text(), convert_bytea_to_scalar(), convert_charset(), CopyOneRowTo(), copytext(), create_mbuf_from_vardata(), cstring_to_text_with_len(), datum_write(), decrypt_internal(), deserialize_deflist(), encode_to_ascii(), encrypt_internal(), find_provider(), 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(), Generic_Text_IC_like(), get_raw_page_internal(), ghstore_consistent(), gin_extract_hstore_query(), gin_extract_query_trgm(), gin_extract_value_trgm(), gin_leafpage_items(), gin_metapage_info(), gin_page_opaque_info(), gtrgm_compress(), gtrgm_consistent(), gtrgm_distance(), heap_fill_tuple(), heap_page_items(), heap_tuple_untoast_attr(), heap_tuple_untoast_attr_slice(), hstore_hash(), hstore_slice_to_array(), hstoreArrayToPairs(), init_work(), int8_avg_deserialize(), int8_avg_serialize(), inv_read(), inv_truncate(), inv_write(), jsonb_exists_all(), jsonb_exists_any(), JsonbValueToJsonb(), like_fixed_prefix(), lo_get_fragment_internal(), loread(), lowrite(), lpad(), ltree2text(), make_greater_string(), make_text_key(), makeitem(), makeJsonLexContext(), numeric_abbrev_convert(), numeric_avg_deserialize(), numeric_avg_serialize(), numeric_deserialize(), numeric_poly_deserialize(), numeric_poly_serialize(), numeric_serialize(), numeric_to_number(), optionListToArray(), page_header(), parseRelOptions(), pg_armor(), pg_convert(), pg_dearmor(), pg_decrypt(), pg_decrypt_iv(), pg_digest(), pg_encrypt(), pg_encrypt_iv(), pg_file_write(), pg_get_triggerdef_worker(), pg_hmac(), pg_random_bytes(), pgp_key_id_w(), pgxml_xpath(), PLyBytes_FromBytea(), PLyObject_ToBytea(), printtup(), printtup_internal_20(), prs_setup_firstcall(), quote_literal(), range_send(), read_binary_file(), read_text_file(), record_send(), RelationBuildTriggers(), ReorderBufferToastReplace(), repeat(), rpad(), SendFunctionResult(), show_trgm(), similar_escape(), similarity(), sort(), spg_text_inner_consistent(), spg_text_leaf_consistent(), string_to_bytea_const(), text_catenate(), text_char(), text_reverse(), text_substring(), to_tsvector_byid(), toast_decompress_datum(), toast_fetch_datum(), toast_fetch_datum_slice(), toast_save_datum(), transformRelOptions(), translate(), ts_headline_byid_opt(), ts_lexize(), ts_stat_sql(), tsvector_delete_arr(), tsvector_delete_str(), tsvector_setweight_by_filter(), tsvector_update_trigger(), tuple_data_split_internal(), unaccent_dict(), uuid_generate_v3(), uuid_generate_v5(), verify_brin_page(), xml_is_well_formed(), xml_recv(), xmlcomment(), xpath_string(), and xslt_process().
#define VARDATA_1B | ( | PTR | ) | (((varattrib_1b *) (PTR))->va_data) |
Definition at line 281 of file postgres.h.
#define VARDATA_1B_E | ( | PTR | ) | (((varattrib_1b_e *) (PTR))->va_data) |
Definition at line 282 of file postgres.h.
#define VARDATA_4B | ( | PTR | ) | (((varattrib_4b *) (PTR))->va_4byte.va_data) |
Definition at line 279 of file postgres.h.
#define VARDATA_4B_C | ( | PTR | ) | (((varattrib_4b *) (PTR))->va_compressed.va_data) |
Definition at line 280 of file postgres.h.
#define VARDATA_ANY | ( | PTR | ) | (VARATT_IS_1B(PTR) ? VARDATA_1B(PTR) : VARDATA_4B(PTR)) |
Definition at line 349 of file postgres.h.
Referenced by appendStringInfoRegexpSubstr(), appendStringInfoText(), ascii(), bcTruelen(), bpchar(), bpchar_larger(), bpchar_name(), bpchar_smaller(), bpcharcmp(), bpchareq(), bpcharfastcmp_c(), bpcharge(), bpchargt(), bpcharle(), bpcharlen(), bpcharlt(), bpcharne(), btrim(), btrim1(), 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_ne(), citextcmp(), compare_lexeme_textfreq(), Generic_Text_IC_like(), get_jsonb_path_all(), ghstore_consistent(), gin_cmp_prefix(), gin_cmp_tslexeme(), gin_compare_jsonb(), gin_extract_hstore_query(), gin_extract_jsonb_query(), hashbpchar(), hashinet(), hashtext(), hashvarlena(), hstore_defined(), hstore_delete(), hstore_exists(), hstore_fetchval(), hstore_from_array(), hstore_from_arrays(), hstore_from_text(), initcap(), internal_bpchar_pattern_compare(), internal_text_pattern_compare(), interval_part(), interval_trunc(), json_send(), jsonb_delete(), jsonb_exists(), jsonb_object_field(), jsonb_object_field_text(), length_in_encoding(), levenshtein(), levenshtein_less_equal(), levenshtein_less_equal_with_costs(), levenshtein_with_costs(), lo_from_bytea(), lo_put(), lower(), lpad(), ltrim(), ltrim1(), map_sql_value_to_xml_value(), md5_bytea(), md5_text(), namelike(), namenlike(), parse_re_flags(), pg_convert(), pg_logical_emit_message_bytea(), pgp_armor_headers(), RE_compile(), RE_compile_and_cache(), record_image_cmp(), record_image_eq(), repeat(), replace_text(), replace_text_regexp(), rpad(), rtrim(), rtrim1(), setPathObject(), setup_regexp_matches(), similar_escape(), spg_text_choose(), spg_text_inner_consistent(), spg_text_leaf_consistent(), spg_text_picksplit(), test_shm_mq(), test_shm_mq_pipelined(), text_catenate(), text_cmp(), text_format(), text_left(), text_length(), text_name(), text_position_setup(), text_reverse(), text_right(), text_substring(), text_to_array_internal(), text_to_cstring(), text_to_cstring_buffer(), texteq(), texticregexeq(), texticregexne(), textlike(), textne(), textnlike(), textregexeq(), textregexne(), textregexsubstr(), textsend(), time_part(), timestamp_part(), timestamp_trunc(), timestamptz_part(), timestamptz_trunc(), timetz_part(), toast_compress_datum(), translate(), tsquery_opr_selec(), upper(), varchar(), varstr_abbrev_convert(), varstrfastcmp_c(), varstrfastcmp_locale(), word_similarity(), word_similarity_commutator_op(), word_similarity_dist_commutator_op(), word_similarity_dist_op(), and word_similarity_op().
#define VARDATA_EXTERNAL | ( | PTR | ) | VARDATA_1B_E(PTR) |
Definition at line 313 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 309 of file postgres.h.
Referenced by heap_tuple_untoast_attr(), heap_tuple_untoast_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 277 of file postgres.h.
#define VARHDRSZ_SHORT offsetof(varattrib_1b, va_data) |
Definition at line 269 of file postgres.h.
Referenced by formTextDatum(), heap_tuple_untoast_attr(), heap_tuple_untoast_attr_slice(), 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 284 of file postgres.h.
Referenced by toast_raw_datum_size(), and toast_save_datum().
#define VARSIZE | ( | PTR | ) | VARSIZE_4B(PTR) |
Definition at line 306 of file postgres.h.
Referenced by _ltq_extract_regex(), _ltree_extract_isparent(), _ltree_extract_risparent(), _ltxtq_extract_exec(), add_block_entropy(), array_send(), binary_decode(), binary_encode(), bit_and(), bit_or(), bitnot(), bitsetbit(), bitshiftleft(), bitshiftright(), bitxor(), brin_page_type(), byteaSetBit(), byteaSetByte(), clear_and_pfree(), CompareTSQ(), concat_text(), convert_bytea_to_scalar(), convert_charset(), copy_ltree(), CopyOneRowTo(), copytext(), create_mbuf_from_vardata(), datum_write(), decrypt_internal(), deserialize_deflist(), encode_to_ascii(), encrypt_internal(), find_provider(), 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(), Generic_Text_IC_like(), get_attribute_options(), get_jsonb_path_all(), get_tablespace(), getdatafield(), ghstore_consistent(), gin_extract_hstore_query(), gin_extract_query_trgm(), gin_extract_value_trgm(), gin_leafpage_items(), gin_metapage_info(), gin_page_opaque_info(), gtrgm_compress(), gtrgm_consistent(), gtrgm_distance(), gtrgm_penalty(), gtsvector_compress(), heap_fill_tuple(), heap_page_items(), heap_tuple_untoast_attr_slice(), hstore_concat(), hstore_delete(), hstore_delete_array(), hstore_delete_hstore(), hstore_hash(), hstore_slice_to_array(), hstoreArrayToPairs(), hstoreUpgrade(), hstoreValidNewFormat(), hstoreValidOldFormat(), index_form_tuple(), init_work(), int8_avg_deserialize(), int8_avg_serialize(), interval_to_char(), jsonb_exists_all(), jsonb_exists_any(), jsonb_out(), jsonb_pretty(), jsonb_send(), like_fixed_prefix(), load_relcache_init_file(), lowrite(), ltree2text(), ltree_compress(), ltree_concat(), ltree_out(), ltree_picksplit(), ltree_union(), make_greater_string(), makeJsonLexContext(), numeric(), numeric_abs(), numeric_avg_deserialize(), numeric_avg_serialize(), numeric_deserialize(), numeric_poly_deserialize(), numeric_poly_serialize(), numeric_serialize(), numeric_to_number(), numeric_uminus(), numeric_uplus(), oldstyle_length(), page_header(), parseRelOptions(), pg_armor(), pg_dearmor(), pg_decrypt(), pg_decrypt_iv(), pg_detoast_datum_copy(), pg_digest(), pg_encrypt(), pg_encrypt_iv(), pg_file_write(), pg_hmac(), pgxml_xpath(), PLyBytes_FromBytea(), printtup(), printtup_internal_20(), prs_setup_firstcall(), quote_literal(), range_deserialize(), range_get_flags(), range_send(), range_set_contain_empty(), read_text_file(), record_send(), RelationParseRelOptions(), ReorderBufferToastAppendChunk(), ReorderBufferToastReplace(), SendFunctionResult(), setup_firstcall(), show_trgm(), silly_cmp_tsvector(), similarity(), sort(), text_char(), timestamp_to_char(), timestamptz_to_char(), to_tsvector_byid(), toast_datum_size(), toast_decompress_datum(), toast_fetch_datum(), toast_fetch_datum_slice(), toast_insert_or_update(), toast_raw_datum_size(), toast_save_datum(), transformRelOptions(), ts_headline_byid_opt(), ts_lexize(), ts_stat_sql(), tsa_rewrite_accum(), tsa_rewrite_finish(), tsvector_concat(), tsvector_delete_by_indices(), tsvector_filter(), tsvector_setweight(), tsvector_setweight_by_filter(), tsvector_update_trigger(), tuple_data_split(), txid_snapshot_xip(), unaccent_dict(), uuid_generate_v3(), uuid_generate_v5(), verify_brin_page(), write_relcache_init_file(), xml_is_well_formed(), xmlcomment(), xmlconcat(), xmlroot(), xpath_string(), and xslt_process().
#define VARSIZE_1B | ( | PTR | ) | ((((varattrib_1b *) (PTR))->va_header >> 1) & 0x7F) |
Definition at line 253 of file postgres.h.
#define VARSIZE_4B | ( | PTR | ) | ((((varattrib_4b *) (PTR))->va_4byte.va_header >> 2) & 0x3FFFFFFF) |
Definition at line 251 of file postgres.h.
#define VARSIZE_ANY | ( | PTR | ) |
Definition at line 336 of file postgres.h.
Referenced by cidr_set_masklen(), compute_distinct_stats(), compute_range_stats(), compute_scalar_stats(), compute_trivial_stats(), compute_tsvector_stats(), convertJsonbScalar(), datumCopy(), datumGetSize(), heap_tuple_fetch_attr(), heap_tuple_untoast_attr(), inet_set_masklen(), inet_to_cidr(), make_tuple_indirect(), memcpyDatum(), printtup(), replace_text(), replace_text_regexp(), SpGistGetTypeSize(), text_to_array_internal(), toast_insert_or_update(), and tuple_data_split_internal().
#define VARSIZE_ANY_EXHDR | ( | PTR | ) |
Definition at line 342 of file postgres.h.
Referenced by appendStringInfoRegexpSubstr(), appendStringInfoText(), array_to_tsvector(), ascii(), bcTruelen(), bpchar(), bpchar_name(), bpcharfastcmp_c(), btrim(), btrim1(), 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_ne(), citextcmp(), compare_lexeme_textfreq(), do_to_timestamp(), Generic_Text_IC_like(), get_jsonb_path_all(), ghstore_consistent(), gin_cmp_prefix(), gin_cmp_tslexeme(), gin_compare_jsonb(), gin_extract_hstore_query(), gin_extract_jsonb_query(), hashtext(), hashvarlena(), hstore_defined(), hstore_delete(), hstore_exists(), hstore_fetchval(), hstore_from_array(), hstore_from_arrays(), hstore_from_text(), initcap(), internal_text_pattern_compare(), interval_part(), interval_trunc(), json_send(), jsonb_delete(), jsonb_exists(), jsonb_object_field(), jsonb_object_field_text(), length_in_encoding(), levenshtein(), levenshtein_less_equal(), levenshtein_less_equal_with_costs(), levenshtein_with_costs(), lo_from_bytea(), lo_put(), lower(), lpad(), ltrim(), ltrim1(), map_sql_value_to_xml_value(), md5_bytea(), md5_text(), namelike(), namenlike(), parse_re_flags(), pg_convert(), pg_logical_emit_message_bytea(), pg_size_bytes(), pgp_armor_headers(), RE_compile(), RE_compile_and_cache(), repeat(), replace_text_regexp(), rpad(), rtrim(), rtrim1(), setPathObject(), setup_regexp_matches(), similar_escape(), spg_text_choose(), spg_text_inner_consistent(), spg_text_leaf_consistent(), spg_text_picksplit(), test_shm_mq(), test_shm_mq_pipelined(), text_catenate(), text_cmp(), text_format(), text_left(), text_length(), text_name(), text_position_setup(), text_reverse(), text_right(), text_substring(), text_to_array_internal(), text_to_cstring(), text_to_cstring_buffer(), texticregexeq(), texticregexne(), textlike(), textnlike(), textregexeq(), textregexne(), textregexsubstr(), textsend(), time_part(), timestamp_part(), timestamp_trunc(), timestamptz_part(), timestamptz_trunc(), timetz_part(), toast_compress_datum(), translate(), tsquery_opr_selec(), tsvector_delete_arr(), tsvector_delete_str(), tsvector_setweight_by_filter(), upper(), varchar(), varstr_abbrev_convert(), varstrfastcmp_c(), varstrfastcmp_locale(), word_similarity(), word_similarity_commutator_op(), word_similarity_dist_commutator_op(), word_similarity_dist_op(), and word_similarity_op().
#define VARSIZE_EXTERNAL | ( | PTR | ) | (VARHDRSZ_EXTERNAL + VARTAG_SIZE(VARTAG_EXTERNAL(PTR))) |
Definition at line 312 of file postgres.h.
Referenced by heap_fill_tuple(), and toast_insert_or_update().
#define VARSIZE_SHORT | ( | PTR | ) | VARSIZE_1B(PTR) |
Definition at line 308 of file postgres.h.
Referenced by datum_write(), heap_fill_tuple(), heap_tuple_untoast_attr(), heap_tuple_untoast_attr_slice(), 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 255 of file postgres.h.
#define VARTAG_EXTERNAL | ( | PTR | ) | VARTAG_1B_E(PTR) |
Definition at line 311 of file postgres.h.
#define VARTAG_IS_EXPANDED | ( | tag | ) | (((tag) & ~1) == VARTAG_EXPANDED_RO) |
Definition at line 121 of file postgres.h.
#define VARTAG_SIZE | ( | tag | ) |
Definition at line 124 of file postgres.h.
Definition at line 374 of file postgres.h.
Definition at line 378 of file postgres.h.
Definition at line 100 of file postgres.h.
enum vartag_external |
Enumerator | |
---|---|
VARTAG_INDIRECT | |
VARTAG_EXPANDED_RO | |
VARTAG_EXPANDED_RW | |
VARTAG_ONDISK |
Definition at line 112 of file postgres.h.
void ExceptionalCondition | ( | const char * | conditionName, |
const char * | errorType, | ||
const char * | fileName, | ||
int | lineNumber | ||
) |
Definition at line 26 of file assert.c.
References PointerIsValid, and write_stderr.
Referenced by pg_re_throw().
Definition at line 2157 of file fmgr.c.
References palloc(), PointerGetDatum, SET_4_BYTES, and value.
Referenced by AddEnumLabel(), EnumValuesCreate(), gbt_num_fetch(), getNextNearest(), InsertPgClassTuple(), leftmostvalue_float4(), ProcedureCreate(), set_limit(), and update_attstats().
Definition at line 2193 of file fmgr.c.
References palloc(), PointerGetDatum, and value.
Referenced by assign_random_seed(), compute_range_stats(), float8_lerp(), gbt_num_fetch(), getNextNearest(), int8_to_char(), interval_avg(), leftmostvalue_float8(), normal_rand(), pgstattuple_approx(), and spg_kd_picksplit().
Datum Int64GetDatum | ( | int64 | X | ) |
Definition at line 2147 of file fmgr.c.
References palloc(), and PointerGetDatum.
Referenced by brin_metapage_info(), build_minmax_path(), cash_numeric(), DefineSequence(), gbt_num_fetch(), generate_series_step_int8(), gin_metapage_info(), gin_page_opaque_info(), 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(), pg_buffercache_pages(), pg_control_system(), pg_sequence_parameters(), pg_size_bytes(), pg_stat_file(), pg_stat_get_archiver(), pg_stat_get_progress_info(), pg_visibility_map_rel(), pg_visibility_map_summary(), pg_visibility_rel(), pgstatginindex(), pgstattuple_approx(), txid_snapshot_xip(), and validate_index_callback().