PostgreSQL Source Code
git master
|
#include "postgres_fe.h"
#include <math.h>
#include <ctype.h>
#include <limits.h>
#include "ecpg_informix.h"
#include "ecpgerrno.h"
#include "ecpgtype.h"
#include "pgtypes_date.h"
#include "pgtypes_error.h"
#include "pgtypes_numeric.h"
#include "sqlca.h"
#include "sqltypes.h"
Go to the source code of this file.
Macros | |
#define | POSTGRES_ECPG_INTERNAL |
Functions | |
static int | deccall2 (decimal *arg1, decimal *arg2, int(*ptr)(numeric *, numeric *)) |
static int | deccall3 (decimal *arg1, decimal *arg2, decimal *result, int(*ptr)(numeric *, numeric *, numeric *)) |
int | decadd (decimal *arg1, decimal *arg2, decimal *sum) |
int | deccmp (decimal *arg1, decimal *arg2) |
void | deccopy (decimal *src, decimal *target) |
int | deccvasc (const char *cp, int len, decimal *np) |
int | deccvdbl (double dbl, decimal *np) |
int | deccvint (int in, decimal *np) |
int | deccvlong (long lng, decimal *np) |
int | decdiv (decimal *n1, decimal *n2, decimal *result) |
int | decmul (decimal *n1, decimal *n2, decimal *result) |
int | decsub (decimal *n1, decimal *n2, decimal *result) |
int | dectoasc (decimal *np, char *cp, int len, int right) |
int | dectodbl (decimal *np, double *dblp) |
int | dectoint (decimal *np, int *ip) |
int | dectolong (decimal *np, long *lngp) |
int | rdatestr (date d, char *str) |
int | rstrdate (const char *str, date *d) |
void | rtoday (date *d) |
int | rjulmdy (date d, short mdy[3]) |
int | rdefmtdate (date *d, const char *fmt, const char *str) |
int | rfmtdate (date d, const char *fmt, char *str) |
int | rmdyjul (short mdy[3], date *d) |
int | rdayofweek (date d) |
void | dtcurrent (timestamp *ts) |
int | dtcvasc (char *str, timestamp *ts) |
int | dtcvfmtasc (char *inbuf, char *fmtstr, timestamp *dtvalue) |
int | dtsub (timestamp *ts1, timestamp *ts2, interval *iv) |
int | dttoasc (timestamp *ts, char *output) |
int | dttofmtasc (timestamp *ts, char *output, int str_len, char *fmtstr) |
int | intoasc (interval *i, char *str) |
static int | initValue (long lng_val) |
static int | getRightMostDot (const char *str) |
int | rfmtlong (long lng_val, const char *fmt, char *outbuf) |
void | rupshift (char *str) |
int | byleng (char *str, int len) |
void | ldchar (char *src, int len, char *dest) |
int | rgetmsg (int msgnum, char *s, int maxsize) |
int | rtypalign (int offset, int type) |
int | rtypmsize (int type, int len) |
int | rtypwidth (int sqltype, int sqllen) |
void | ECPG_informix_set_var (int number, void *pointer, int lineno) |
void * | ECPG_informix_get_var (int number) |
void | ECPG_informix_reset_sqlca (void) |
int | rsetnull (int t, char *ptr) |
int | risnull (int t, const char *ptr) |
Variables | |
static struct sqlca_t | sqlca_init |
struct { | |
long val | |
int maxdigits | |
int digits | |
int remaining | |
char sign | |
char * val_string | |
} | value |
#define POSTGRES_ECPG_INTERNAL |
Definition at line 3 of file informix.c.
int byleng | ( | char * | str, |
int | len | ||
) |
Definition at line 151 of file informix.c.
References deccall3(), ECPG_INFORMIX_NUM_OVERFLOW, ECPG_INFORMIX_NUM_UNDERFLOW, PGTYPES_NUM_OVERFLOW, PGTYPES_NUM_UNDERFLOW, and PGTYPESnumeric_add().
Referenced by main().
Definition at line 48 of file informix.c.
References a1, a2, ECPG_INFORMIX_OUT_OF_MEMORY, i, PGTYPESnumeric_free(), PGTYPESnumeric_from_decimal(), and PGTYPESnumeric_new().
Referenced by deccmp().
|
static |
Definition at line 86 of file informix.c.
References a1, a2, CDECIMALTYPE, ECPG_INFORMIX_OUT_OF_MEMORY, i, PGTYPESnumeric_free(), PGTYPESnumeric_from_decimal(), PGTYPESnumeric_new(), PGTYPESnumeric_to_decimal(), risnull(), and rsetnull().
Referenced by decadd(), decdiv(), decmul(), and decsub().
Definition at line 167 of file informix.c.
References deccall2(), and PGTYPESnumeric_cmp().
Referenced by main().
Definition at line 173 of file informix.c.
int deccvasc | ( | const char * | cp, |
int | len, | ||
decimal * | np | ||
) |
Definition at line 179 of file informix.c.
References CDECIMALTYPE, CSTRINGTYPE, ECPG_INFORMIX_BAD_EXPONENT, ECPG_INFORMIX_BAD_NUMERIC, ECPG_INFORMIX_NUM_OVERFLOW, ECPG_INFORMIX_NUM_UNDERFLOW, free, i, PGTYPES_NUM_BAD_NUMERIC, PGTYPES_NUM_OVERFLOW, PGTYPESnumeric_free(), PGTYPESnumeric_from_asc(), PGTYPESnumeric_to_decimal(), pnstrdup(), risnull(), rsetnull(), and generate_unaccent_rules::str.
Referenced by main().
int deccvdbl | ( | double | dbl, |
decimal * | np | ||
) |
Definition at line 227 of file informix.c.
References CDECIMALTYPE, CDOUBLETYPE, ECPG_INFORMIX_OUT_OF_MEMORY, PGTYPESnumeric_free(), PGTYPESnumeric_from_double(), PGTYPESnumeric_new(), PGTYPESnumeric_to_decimal(), risnull(), and rsetnull().
int deccvint | ( | int | in, |
decimal * | np | ||
) |
Definition at line 249 of file informix.c.
References CDECIMALTYPE, CINTTYPE, ECPG_INFORMIX_OUT_OF_MEMORY, PGTYPESnumeric_free(), PGTYPESnumeric_from_int(), PGTYPESnumeric_new(), PGTYPESnumeric_to_decimal(), risnull(), and rsetnull().
Referenced by main().
int deccvlong | ( | long | lng, |
decimal * | np | ||
) |
Definition at line 271 of file informix.c.
References CDECIMALTYPE, CLONGTYPE, ECPG_INFORMIX_OUT_OF_MEMORY, PGTYPESnumeric_free(), PGTYPESnumeric_from_long(), PGTYPESnumeric_new(), PGTYPESnumeric_to_decimal(), risnull(), and rsetnull().
Referenced by main().
Definition at line 293 of file informix.c.
References deccall3(), ECPG_INFORMIX_DIVIDE_ZERO, ECPG_INFORMIX_NUM_OVERFLOW, ECPG_INFORMIX_NUM_UNDERFLOW, i, PGTYPES_NUM_DIVIDE_ZERO, PGTYPES_NUM_OVERFLOW, and PGTYPESnumeric_div().
Referenced by main().
Definition at line 318 of file informix.c.
References deccall3(), ECPG_INFORMIX_NUM_OVERFLOW, ECPG_INFORMIX_NUM_UNDERFLOW, i, PGTYPES_NUM_OVERFLOW, and PGTYPESnumeric_mul().
Referenced by main().
Definition at line 340 of file informix.c.
References deccall3(), ECPG_INFORMIX_NUM_OVERFLOW, ECPG_INFORMIX_NUM_UNDERFLOW, i, PGTYPES_NUM_OVERFLOW, and PGTYPESnumeric_sub().
Referenced by main().
int dectoasc | ( | decimal * | np, |
char * | cp, | ||
int | len, | ||
int | right | ||
) |
Definition at line 362 of file informix.c.
References CDECIMALTYPE, CSTRINGTYPE, numeric::dscale, ECPG_INFORMIX_OUT_OF_MEMORY, free, PGTYPESnumeric_free(), PGTYPESnumeric_from_decimal(), PGTYPESnumeric_new(), PGTYPESnumeric_to_asc(), risnull(), rsetnull(), and generate_unaccent_rules::str.
Referenced by dump_sqlda(), and main().
int dectodbl | ( | decimal * | np, |
double * | dblp | ||
) |
Definition at line 413 of file informix.c.
References ECPG_INFORMIX_OUT_OF_MEMORY, i, PGTYPESnumeric_free(), PGTYPESnumeric_from_decimal(), PGTYPESnumeric_new(), and PGTYPESnumeric_to_double().
Referenced by main().
int dectoint | ( | decimal * | np, |
int * | ip | ||
) |
Definition at line 434 of file informix.c.
References ECPG_INFORMIX_NUM_OVERFLOW, ECPG_INFORMIX_OUT_OF_MEMORY, PGTYPES_NUM_OVERFLOW, PGTYPESnumeric_free(), PGTYPESnumeric_from_decimal(), PGTYPESnumeric_new(), and PGTYPESnumeric_to_int().
Referenced by main().
int dectolong | ( | decimal * | np, |
long * | lngp | ||
) |
Definition at line 458 of file informix.c.
References ECPG_INFORMIX_NUM_OVERFLOW, ECPG_INFORMIX_OUT_OF_MEMORY, PGTYPES_NUM_OVERFLOW, PGTYPESnumeric_free(), PGTYPESnumeric_from_decimal(), PGTYPESnumeric_new(), and PGTYPESnumeric_to_long().
Referenced by main().
void dtcurrent | ( | timestamp * | ts | ) |
int dtcvasc | ( | char * | str, |
timestamp * | ts | ||
) |
Definition at line 593 of file informix.c.
References ECPG_INFORMIX_EXTRA_CHARS, i, PGTYPEStimestamp_from_asc(), and generate_unaccent_rules::str.
int dtcvfmtasc | ( | char * | inbuf, |
char * | fmtstr, | ||
timestamp * | dtvalue | ||
) |
Definition at line 619 of file informix.c.
References PGTYPEStimestamp_defmt_asc().
Definition at line 625 of file informix.c.
References PGTYPEStimestamp_sub().
int dttoasc | ( | timestamp * | ts, |
char * | output | ||
) |
int dttofmtasc | ( | timestamp * | ts, |
char * | output, | ||
int | str_len, | ||
char * | fmtstr | ||
) |
Definition at line 641 of file informix.c.
References PGTYPEStimestamp_fmt_asc().
void* ECPG_informix_get_var | ( | int | number | ) |
void ECPG_informix_reset_sqlca | ( | void | ) |
Definition at line 1006 of file informix.c.
References ECPGget_sqlca(), and sqlca.
void ECPG_informix_set_var | ( | int | number, |
void * | pointer, | ||
int | lineno | ||
) |
|
static |
|
static |
initialize the struct, which holds the different forms of the long value
Definition at line 677 of file informix.c.
References i, malloc, and value.
Referenced by build_pertrans_for_aggref(), ExecInitAgg(), preprocess_aggref(), and rfmtlong().
int intoasc | ( | interval * | i, |
char * | str | ||
) |
void ldchar | ( | char * | src, |
int | len, | ||
char * | dest | ||
) |
int rdatestr | ( | date | d, |
char * | str | ||
) |
Definition at line 483 of file informix.c.
References ECPG_INFORMIX_DATE_CONVERT, free, and PGTYPESdate_to_asc().
Referenced by date_test_defmt(), date_test_strdate(), and main().
int rdayofweek | ( | date | d | ) |
int rdefmtdate | ( | date * | d, |
const char * | fmt, | ||
const char * | str | ||
) |
Definition at line 528 of file informix.c.
References ECPG_INFORMIX_BAD_DAY, ECPG_INFORMIX_BAD_MONTH, ECPG_INFORMIX_BAD_YEAR, ECPG_INFORMIX_ENOSHORTDATE, ECPG_INFORMIX_ENOTDMY, PGTYPES_DATE_BAD_DAY, PGTYPES_DATE_BAD_MONTH, PGTYPES_DATE_ERR_EARGS, PGTYPES_DATE_ERR_ENOSHORTDATE, PGTYPES_DATE_ERR_ENOTDMY, and PGTYPESdate_defmt_asc().
Referenced by date_test_defmt(), and rstrdate().
int rfmtdate | ( | date | d, |
const char * | fmt, | ||
char * | str | ||
) |
Definition at line 554 of file informix.c.
References ECPG_INFORMIX_DATE_CONVERT, ECPG_INFORMIX_OUT_OF_MEMORY, and PGTYPESdate_fmt_asc().
Referenced by date_test_fmt().
int rfmtlong | ( | long | lng_val, |
const char * | fmt, | ||
char * | outbuf | ||
) |
Definition at line 743 of file informix.c.
References fmtchar(), free, getRightMostDot(), i, initValue(), malloc, sign, and value.
Referenced by fmtlong().
int rgetmsg | ( | int | msgnum, |
char * | s, | ||
int | maxsize | ||
) |
Definition at line 961 of file informix.c.
int risnull | ( | int | t, |
const char * | ptr | ||
) |
Definition at line 1024 of file informix.c.
References ECPGis_noind_null().
Referenced by deccall3(), deccvasc(), deccvdbl(), deccvint(), deccvlong(), dectoasc(), main(), and test_null().
int rjulmdy | ( | date | d, |
short | mdy[3] | ||
) |
int rmdyjul | ( | short | mdy[3], |
date * | d | ||
) |
int rsetnull | ( | int | t, |
char * | ptr | ||
) |
Definition at line 1017 of file informix.c.
References ECPGset_noind_null().
Referenced by deccall3(), deccvasc(), deccvdbl(), deccvint(), deccvlong(), dectoasc(), and main().
int rstrdate | ( | const char * | str, |
date * | d | ||
) |
Definition at line 504 of file informix.c.
References rdefmtdate().
Referenced by date_test_strdate().
void rtoday | ( | date * | d | ) |
int rtypalign | ( | int | offset, |
int | type | ||
) |
Definition at line 970 of file informix.c.
int rtypmsize | ( | int | type, |
int | len | ||
) |
Definition at line 978 of file informix.c.
int rtypwidth | ( | int | sqltype, |
int | sqllen | ||
) |
Definition at line 986 of file informix.c.
void rupshift | ( | char * | str | ) |
int digits |
Definition at line 666 of file informix.c.
Referenced by estimate_ln_dweight(), getbits(), getv4(), hash_numeric(), hash_numeric_extended(), inet_cidr_pton_ipv4(), inet_cidr_pton_ipv6(), inet_net_pton_ipv4(), int2int4_sum(), make_result_opt_error(), numericvar_to_int64(), numericvar_to_uint64(), PGTYPESnumeric_div(), round_var(), s_embar(), s_udiv_knuth(), set_var_from_str(), strip_var(), to_hex32(), to_hex64(), and trunc_var().
int maxdigits |
Definition at line 665 of file informix.c.
Referenced by apply_typmod(), mul_var(), and numeric().
int remaining |
Definition at line 667 of file informix.c.
Referenced by aclmask(), ahwrite(), dataBeginPlaceToPageLeaf(), DecodeXLogRecord(), deconstruct_recurse(), do_pg_stop_backup(), dsm_impl_mmap(), ginVacuumItemPointers(), PQescapeStringInternal(), and pqSendSome().
char sign |
Definition at line 668 of file informix.c.
Referenced by _fmt(), _ltree_compress(), abbroffset(), copy_special_str(), dcosd(), dcotd(), dsind(), dtand(), ECPGis_noind_null(), fillcache(), float4_to_char(), float8_to_char(), g_intbig_compress(), gethms(), ghstore_compress(), ghstore_consistent(), gist_between(), gist_qe(), gist_te(), gtrgm_compress(), gtrgm_consistent(), gtrgm_penalty(), gtrgm_picksplit(), gtsquery_compress(), gtsquery_union(), gtsvector_compress(), gtsvector_penalty(), gtsvector_picksplit(), int4_to_char(), int8_to_char(), make_result_opt_error(), makeTSQuerySign(), NUM_processor(), numeric_to_char(), QTNEq(), ReadInt(), restore(), rfmtlong(), set_var_from_str(), and to_chars().
|
static |
Definition at line 21 of file informix.c.
long val |
Definition at line 664 of file informix.c.
Referenced by _bt_spools_heapscan(), _copyAConst(), _copyPLAssignStmt(), _copyResTarget(), _copyValue(), _equalPLAssignStmt(), _equalResTarget(), _equalValue(), _ltree_compress(), _outPLAssignStmt(), _outResTarget(), _readBitmapset(), _ShowOption(), addHeapElement(), addToSimpleStats(), allocateReloptStruct(), AlterDomainValidateConstraint(), assignVariables(), ATExecValidateConstraint(), AttrDefaultFetch(), autoinc(), bitfromint4(), bitfromint8(), brin_page_items(), build_startup_packet(), BuildIndexValueDescription(), BuildRelationExtStatistics(), byteaout(), calc_distr(), calc_hist(), cash_words(), check_new_partition_bound(), check_timezone(), CheckConstraintFetch(), collectTSQueryValues(), composite_to_json(), composite_to_jsonb(), convert_string_datum(), CopyReadAttributesText(), create_list_bounds(), datum_write(), datumRestore(), decode_varbyte(), DecodeDate(), DecodeDateTime(), DecodeInterval(), DecodeISO8601Interval(), DecodeNumber(), DecodePosixTimezone(), DecodeTimeOnly(), DropConfigurationMapping(), dump_sqlda(), each_object_field_end(), each_worker_jsonb(), ean13_out(), ecpg_set_compat_sqlda(), ecpg_set_native_sqlda(), elem_contained_by_multirange(), elem_contained_by_range(), elements_array_element_end(), elements_worker_jsonb(), encode_varbyte(), esc_decode(), evalStandardFunc(), exec_command_pset(), exec_stmt_assert(), ExecBuildSlotPartitionKeyDescription(), ExecBuildSlotValueDescription(), ExecComputeStoredGenerated(), ExecuteCallStmt(), executeItemOptUnwrapTarget(), executeKeyValueMethod(), executeUnaryArithmExpr(), exp_var(), extractModify(), fill_val(), findTargetlistEntrySQL92(), flatten_set_variable_args(), float4_numeric(), float4_to_char(), float4in(), float8_numeric(), float8_to_char(), float8in_internal_opt_error(), FreePageBtreeSearchInternal(), FreePageBtreeSearchLeaf(), get_attstatsslot(), get_prompt(), get_qual_for_list(), get_range_partbound_string(), get_rule_expr(), get_sql_insert(), get_sql_update(), get_stack_depth_rlimit(), get_string_attr(), getbits(), getTokenTypes(), getv4(), ghstore_compress(), gin_extract_query_trgm(), gin_extract_tsquery(), gin_extract_value_trgm(), ginCompressPostingList(), ginint4_queryextract(), ginPostingListDecodeAllSegments(), gtrgm_compress(), gtsvector_compress(), GUCArrayDelete(), GUCArrayReset(), hash_object_field_end(), hashint8(), hashint8extended(), heap_compute_data_size(), hstore_contains(), hstore_from_text(), hstore_subscript_assign(), hstore_to_jsonb(), hstore_to_jsonb_loose(), HV_to_JsonbValue(), in_range_date_interval(), in_range_float4_float8(), in_range_float8_float8(), in_range_int2_int4(), in_range_int4_int4(), in_range_int4_int8(), in_range_int8_int8(), in_range_interval_interval(), in_range_numeric_numeric(), in_range_time_interval(), in_range_timestamp_interval(), in_range_timestamptz_interval(), in_range_timetz_interval(), index_build(), ineq_histogram_selectivity(), inet_aton(), inet_cidr_pton_ipv6(), inet_spg_choose(), initialize_worker_spi(), int2_numeric(), int4_numeric(), int4_to_char(), int64_to_int128(), int64_to_numericvar(), int8_numeric(), int8out(), interval_part(), interval_trunc(), is_superuser(), is_valid(), isbn_cast_from_ean13(), ismn_cast_from_ean13(), isn_out(), issn_cast_from_ean13(), itemptr_to_uint64(), iterate_jsonb_values(), iterate_values_object_field_start(), json_agg_transfn(), jsonb_agg_transfn(), jsonb_contained(), jsonb_contains(), jsonb_object_agg_transfn(), Jsonb_to_SV(), libpq_get_current_wal_insert_lsn(), load_domaintype_info(), ltree_compress(), ltxtq_exec(), LWLockReleaseClearVar(), LWLockUpdateVar(), main(), make_array_ref(), make_const(), make_one_partition_rbound(), make_valid(), MergeWithExistingConstraint(), mode_final(), multirange_contains_elem(), multirange_elem_bsearch_comparison(), nodeRead(), non_negative(), numeric_exp(), numeric_float8_no_overflow(), numeric_int2(), numeric_to_char(), numericvar_to_double(), numericvar_to_double_no_overflow(), numericvar_to_int32(), numericvar_to_int64(), numericvar_to_uint64(), parse_args(), parse_hba_line(), parse_int(), parse_real(), parse_sane_timezone(), parse_scalar(), parse_snapshot(), parseIntFromText(), ParseISO8601Number(), parseXidFromText(), percentile_cont_final_common(), percentile_disc_final(), percentile_disc_multi_final(), perform_base_backup(), pg_atomic_unlocked_write_u32_impl(), pg_atomic_write_u32_impl(), pg_get_constraintdef_worker(), pg_stats_ext_mcvlist_items(), pgstat_progress_update_param(), plperl_build_tuple_result(), plperl_modify_tuple(), plperl_to_hstore(), plpython_to_hstore(), PLy_elog_impl(), PLyObject_FromJsonbContainer(), populate_array_dim_jsonb(), populate_recordset_object_field_end(), postgres_fdw_validator(), power_var(), pqBuildErrorMessage3(), PQencryptPasswordConn(), pqRowProcessor(), pqSetenvPoll(), PrintResultsInCrosstab(), prsd_headline(), putVariable(), putVariableInt(), range_contains_elem(), rankSort(), recompute_limits(), RelationBuildTriggers(), RelationGetExclusionInfo(), removeHeapElement(), ReportGUCOption(), ri_ReportViolation(), SerialGetMinConflictCommitSeqNo(), serialize_deflist(), session_username(), set_string_attr(), setCompoundAffixFlagValue(), simple_oid_list_append(), SPI_getvalue(), sqlda_common_total_size(), standard_strings(), StreamServerPort(), stringlist_to_identifierstr(), strtoint(), sv2cstr(), test_huge_distances(), text_format_parse_digits(), time_part(), timestamp_part(), timestamp_trunc(), timestamp_zone(), timestamptz_part(), timestamptz_trunc_internal(), timestamptz_trunc_zone(), timestamptz_zone(), timetz_part(), timetz_zone(), to_json(), to_jsonb(), transformExprRecurse(), transformInsertStmt(), transformLimitClause(), trgm2int(), ts_match_vq(), tsqueryrecv(), tstoreReceiveSlot_detoast(), tts_virtual_materialize(), tuple_to_stringinfo(), tuplesort_putdatum(), untransformRelOptions(), upc_cast_from_ean13(), update_basebackup_progress(), and validate_index().
char* val_string |
Definition at line 669 of file informix.c.
struct { ... } value |
Referenced by _copyPartitionRangeDatum(), _crypt_gensalt_extended_rn(), _crypt_gensalt_md5_rn(), _equalPartitionRangeDatum(), _outPartitionRangeDatum(), _readPartitionRangeDatum(), AddVerboseIntPart(), AlterSystemSetConfigFile(), appendReloptionsArray(), AppendSeconds(), array_fill(), array_fill_with_lower_bounds(), array_position_common(), array_positions(), array_to_text_internal(), AuxiliaryProcessMain(), AV_to_JsonbValue(), binary_upgrade_set_missing_value(), brin_form_tuple(), brin_minmax_consistent(), build_sorted_items(), bytea_string_agg_transfn(), call_subtype_diff(), cash_in(), cash_out(), cash_words(), check_pghost_envvar(), CloneRowTriggersToPartition(), compute_array_stats(), compute_distinct_stats(), compute_range_stats(), compute_scalar_stats(), compute_trivial_stats(), compute_tsvector_stats(), concat_internal(), conninfo_uri_parse_params(), convert_prep_stmt_params(), CopyOneRowTo(), create_list_bounds(), datumCopy(), DatumGetFloat4(), datumTransfer(), DCH_from_char(), debugtup(), DefineSequence(), do_cast_value(), domain_in(), domain_recv(), dxsyn_lexize(), ecpg_build_params(), exec_assign_c_string(), exec_assign_expr(), exec_cast_value(), exec_command_echo(), exec_command_T(), exec_move_row_from_fields(), exec_stmt_assert(), exec_stmt_case(), exec_stmt_exit(), exec_stmt_foreach_a(), exec_stmt_fori(), exec_stmt_if(), exec_stmt_while(), ExecEvalRowNullInt(), ExecEvalXmlExpr(), executeDateTimeMethod(), ExecWindowAgg(), filter_list_to_array(), float4_to_char(), Float4GetDatum(), float8_to_char(), flushbuffer(), fmtfloat(), from_char_set_int(), fsm_set_avail(), gather_boolean_expression(), get_collation_version_for_oid(), get_int_item(), get_len_position(), get_reloptions(), GetComment(), getDatumCopy(), GROW(), hstore_from_record(), hstore_populate_record(), hstore_to_plperl(), hstore_to_plpython(), index_store_float8_orderby_distances(), initValue(), int4_to_char(), int8_to_char(), IpcSemaphoreInitialize(), is_true_boolean_expression(), Jsonb_to_SV(), llvm_compile_expr(), load_return_type(), logicalrep_read_tuple(), LWLockConflictsWithVar(), main(), mp_int_is_even(), mp_int_mod_value(), num_word(), numeric_abbrev_convert(), numeric_in(), numeric_recv(), numeric_to_char(), numeric_to_number(), optionListToArray(), parse_one_reloption(), parse_psql_options(), pg_atomic_unlocked_write_u32_impl(), pg_column_size(), pg_get_triggerdef_worker(), pg_lltoa(), pg_logging_init(), pg_snapshot_xip(), pg_strfromd(), pg_visible_in_snapshot(), PGTYPESnumeric_from_asc(), plperl_to_hstore(), plpython_to_hstore(), plsample_func_handler(), PLy_output(), PLy_subtransaction_exit(), PLyDict_FromTuple(), PLyGenericObject_ToComposite(), PLyMapping_ToComposite(), PLyMapping_ToJsonbValue(), PLySequence_ToComposite(), PLySequence_ToJsonbValue(), PostmasterMain(), postquel_get_single_result(), pq_parse_errornotice(), pqRowProcessor(), print_param_value(), printsimple(), process_postgres_switches(), process_startup_options(), ProcessGUCArray(), prune_element_hashtable(), psql_get_variable(), push_assignment(), putVariableValue(), read_client_final_message(), read_dictionary(), record_out(), ResourceArrayAdd(), rfmtlong(), s_fake(), SerializeUncommittedEnums(), set_config_by_name(), ShowGUCConfigOption(), statext_mcv_serialize(), statext_ndistinct_serialize(), StoreQueryTuple(), test_single_value_and_filler(), text_format(), tfuncFetchRows(), tfuncInitialize(), to_hex32(), to_hex64(), toast_delete_external(), toast_tuple_externalize(), toast_tuple_try_compression(), transformPartitionBound(), transformPartitionBoundValue(), transformPartitionRangeBounds(), transformRelOptions(), transtime(), and xid8recv().