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) |
static char * | ecpg_strndup (const char *str, size_t len) |
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) |
int | rdefmtdate (date *d, const char *fmt, const char *str) |
int | rfmtdate (date d, const char *fmt, char *str) |
int | rmdyjul (short *mdy, 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 970 of file informix.c.
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().
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 198 of file informix.c.
References CDECIMALTYPE, CSTRINGTYPE, ECPG_INFORMIX_BAD_EXPONENT, ECPG_INFORMIX_BAD_NUMERIC, ECPG_INFORMIX_NUM_OVERFLOW, ECPG_INFORMIX_NUM_UNDERFLOW, ecpg_strndup(), free, i, len, PGTYPES_NUM_BAD_NUMERIC, PGTYPES_NUM_OVERFLOW, PGTYPESnumeric_free(), PGTYPESnumeric_from_asc(), PGTYPESnumeric_to_decimal(), risnull(), rsetnull(), and str.
Referenced by main().
int deccvdbl | ( | double | dbl, |
decimal * | np | ||
) |
Definition at line 246 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 268 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 290 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 312 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 337 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 359 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 381 of file informix.c.
References CDECIMALTYPE, CSTRINGTYPE, numeric::dscale, ECPG_INFORMIX_OUT_OF_MEMORY, free, len, PGTYPESnumeric_free(), PGTYPESnumeric_from_decimal(), PGTYPESnumeric_new(), PGTYPESnumeric_to_asc(), risnull(), rsetnull(), and str.
Referenced by dump_sqlda(), and main().
int dectodbl | ( | decimal * | np, |
double * | dblp | ||
) |
Definition at line 432 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 453 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 480 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 618 of file informix.c.
References ECPG_INFORMIX_EXTRA_CHARS, i, PGTYPEStimestamp_from_asc(), and str.
int dtcvfmtasc | ( | char * | inbuf, |
char * | fmtstr, | ||
timestamp * | dtvalue | ||
) |
Definition at line 644 of file informix.c.
References fmtstr(), and PGTYPEStimestamp_defmt_asc().
Definition at line 650 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 666 of file informix.c.
References fmtstr(), output, and PGTYPEStimestamp_fmt_asc().
void* ECPG_informix_get_var | ( | int | number | ) |
void ECPG_informix_reset_sqlca | ( | void | ) |
Definition at line 1031 of file informix.c.
References ECPGget_sqlca(), sqlca, and sqlca_init.
void ECPG_informix_set_var | ( | int | number, |
void * | pointer, | ||
int | lineno | ||
) |
|
static |
Definition at line 179 of file informix.c.
References len, malloc, and str.
Referenced by deccvasc().
|
static |
|
static |
initialize the struct, which holds the different forms of the long value
Definition at line 702 of file informix.c.
References i, j, malloc, and value.
Referenced by build_pertrans_for_aggref(), ExecInitAgg(), find_compatible_trans(), preprocess_aggref(), and rfmtlong().
int intoasc | ( | interval * | i, |
char * | str | ||
) |
Definition at line 672 of file informix.c.
References free, i, PGTYPESinterval_to_asc(), and str.
Referenced by main().
void ldchar | ( | char * | src, |
int | len, | ||
char * | dest | ||
) |
Definition at line 977 of file informix.c.
References byleng(), generate_unaccent_rules::dest, and len.
Referenced by main().
int rdatestr | ( | date | d, |
char * | str | ||
) |
Definition at line 508 of file informix.c.
References ECPG_INFORMIX_DATE_CONVERT, free, PGTYPESdate_to_asc(), and str.
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 553 of file informix.c.
References ECPG_INFORMIX_BAD_DAY, ECPG_INFORMIX_BAD_MONTH, ECPG_INFORMIX_BAD_YEAR, ECPG_INFORMIX_ENOSHORTDATE, ECPG_INFORMIX_ENOTDMY, fmt, PGTYPES_DATE_BAD_DAY, PGTYPES_DATE_BAD_MONTH, PGTYPES_DATE_ERR_EARGS, PGTYPES_DATE_ERR_ENOSHORTDATE, PGTYPES_DATE_ERR_ENOTDMY, PGTYPESdate_defmt_asc(), and str.
Referenced by date_test_defmt(), and rstrdate().
int rfmtdate | ( | date | d, |
const char * | fmt, | ||
char * | str | ||
) |
Definition at line 579 of file informix.c.
References ECPG_INFORMIX_DATE_CONVERT, ECPG_INFORMIX_OUT_OF_MEMORY, fmt, PGTYPESdate_fmt_asc(), and str.
Referenced by date_test_fmt().
int rfmtlong | ( | long | lng_val, |
const char * | fmt, | ||
char * | outbuf | ||
) |
Definition at line 768 of file informix.c.
References fmt, fmtchar(), free, getRightMostDot(), i, initValue(), j, malloc, sign, and value.
Referenced by fmtlong().
int rgetmsg | ( | int | msgnum, |
char * | s, | ||
int | maxsize | ||
) |
Definition at line 986 of file informix.c.
int risnull | ( | int | t, |
const char * | ptr | ||
) |
Definition at line 1049 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 | ||
) |
int rmdyjul | ( | short * | mdy, |
date * | d | ||
) |
int rsetnull | ( | int | t, |
char * | ptr | ||
) |
Definition at line 1042 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 529 of file informix.c.
References rdefmtdate(), and str.
Referenced by date_test_strdate().
void rtoday | ( | date * | d | ) |
int rtypalign | ( | int | offset, |
int | type | ||
) |
int rtypmsize | ( | int | type, |
int | len | ||
) |
int rtypwidth | ( | int | sqltype, |
int | sqllen | ||
) |
Definition at line 1011 of file informix.c.
void rupshift | ( | char * | str | ) |
int digits |
Definition at line 691 of file informix.c.
Referenced by convert_to_base(), estimate_ln_dweight(), getbits(), getv4(), hash_numeric(), hash_numeric_extended(), inet_cidr_pton_ipv4(), inet_cidr_pton_ipv6(), inet_net_pton_ipv4(), make_result_opt_error(), numericvar_to_int64(), numericvar_to_uint64(), PGTYPESnumeric_div(), round_var(), set_var_from_str(), strip_var(), and trunc_var().
int maxdigits |
Definition at line 690 of file informix.c.
Referenced by apply_typmod(), mul_var(), and numeric().
int remaining |
Definition at line 692 of file informix.c.
Referenced by aclmask(), ahwrite(), ConditionalMultiXactIdWait(), dataBeginPlaceToPageLeaf(), DecodeXLogRecord(), deconstruct_recurse(), dir_write(), Do_MultiXactIdWait(), dsm_impl_mmap(), dumpRoleMembership(), ginVacuumItemPointers(), leafRepackItems(), member_copy_control_data(), MultiXactIdWait(), PQescapeStringInternal(), pqSendSome(), sendFile(), and sendFileWithContent().
char sign |
Definition at line 693 of file informix.c.
Referenced by _fmt(), _intbig_alloc(), _ltree_compress(), abbroffset(), cnt_sml_sign_common(), copy_special_str(), dcosd(), dcotd(), dsind(), dtand(), ECPGis_noind_null(), fillcache(), float4_to_char(), float8_to_char(), g_intbig_compress(), gensign(), gethms(), ghstore_alloc(), ghstore_compress(), ghstore_consistent(), gist_qe(), gist_te(), gtrgm_alloc(), gtrgm_compress(), gtrgm_consistent(), gtrgm_penalty(), gtrgm_picksplit(), gtsquery_compress(), gtsquery_union(), gtsvector_alloc(), gtsvector_compress(), gtsvector_penalty(), gtsvector_picksplit(), hashing(), int4_to_char(), int8_to_char(), ltree_gist_alloc(), make_result_opt_error(), makesign(), makeTSQuerySign(), NUM_processor(), numeric_in(), numeric_to_char(), QTNEq(), ReadInt(), restore(), rfmtlong(), set_var_from_non_decimal_integer_str(), set_var_from_str(), signconsistent(), signValue(), sizebitvec(), and to_chars().
|
static |
Definition at line 1 of file informix.c.
Referenced by ECPG_informix_reset_sqlca().
long val |
Definition at line 689 of file informix.c.
Referenced by _copyA_Const(), _jumbleA_Const(), _ltree_compress(), _readBitmapset(), accum_sum_add(), accum_sum_rescale(), add_json(), add_jsonb(), addCompoundAffixFlagValue(), addToSimpleStats(), AdjustDays(), AdjustMicroseconds(), AdjustMonths(), AdjustYears(), allocateReloptStruct(), AlterDomainValidateConstraint(), appendConnStrItem(), assignVariables(), ATExecValidateConstraint(), AttrDefaultFetch(), autoinc(), basebackup_progress_wait_wal_archive(), bbsink_progress_archive_contents(), bbsink_progress_begin_backup(), bitfromint4(), bitfromint8(), boolop(), bqarr_in(), brin_minmax_multi_consistent(), brin_minmax_multi_summary_out(), brin_page_items(), build_bound_expr(), build_startup_packet(), buildDefItem(), BuildIndexValueDescription(), BuildRelationExtStatistics(), byteaout(), calc_distr(), calc_hist(), cash_words(), check_new_partition_bound(), check_timezone(), checkclass_str(), checkcondition_arr(), checkcondition_bit(), checkcondition_gin(), checkcondition_HL(), checkcondition_QueryOperand(), checkcondition_str(), CheckConstraintFetch(), collectTSQueryValues(), composite_to_json(), composite_to_jsonb(), config_enum_lookup_by_value(), conninfo_array_parse(), convert(), convert64(), convert_string_datum(), convertJsonbArray(), convertJsonbObject(), convertJsonbValue(), convertToJsonb(), CopyGetInt16(), CopyGetInt32(), CopyReadAttributesText(), CopySendInt16(), CopySendInt32(), create_list_bounds(), datum_compute_size(), datum_image_hash(), datum_to_json(), datum_to_json_internal(), datum_to_jsonb(), datum_to_jsonb_internal(), datum_write(), datumRestore(), decode_varbyte(), DecodeDate(), DecodeDateTime(), DecodeInterval(), DecodeISO8601Interval(), DecodeNumber(), DecodePosixTimezone(), DecodeSpecial(), DecodeTimeOnly(), DecodeUnits(), deparseStringLiteral(), discard_stack_value(), do_serialize_binary(), 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(), extract_date(), extractModify(), fill_val(), findoprnd(), flatten_set_variable_args(), float4_numeric(), float4_to_char(), float4in_internal(), float8_numeric(), float8_to_char(), float8in_internal(), FreePageBtreeSearchInternal(), FreePageBtreeSearchLeaf(), get_attstatsslot(), get_non_null_list_datum_count(), 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(), getHashFnv1a(), getHashMurmur2(), GetJsonBehaviorConst(), gettoken(), gettoken_query(), 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_store_string(), 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(), ineq_histogram_selectivity(), inet_aton(), inet_cidr_pton_ipv6(), inet_spg_choose(), inet_spg_node_number(), int128_to_int64(), int2_numeric(), int4_numeric(), int4_to_char(), int64_multiply_add(), int64_to_int128(), int64_to_numeric(), int64_to_numericvar(), int8_numeric(), int8out(), interval_part_common(), interval_trunc(), is_infinite(), 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_worker(), jsonb_agg_transfn_worker(), jsonb_contained(), jsonb_contains(), jsonb_object_agg_transfn_worker(), Jsonb_to_SV(), JsonbDeepContains(), JsonbIteratorNext(), JsonbToJsonbValue(), JsonbTypeName(), JsonbValueToJsonb(), JsonItemFromDatum(), 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(), makeBoolean(), makepol(), MergeWithExistingConstraint(), mod_m(), mode_final(), multirange_contains_elem(), multirange_contains_elem_internal(), 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(), OidOutputFunctionCall(), OidSendFunctionCall(), option_parse_int(), OutputFunctionCall(), PageXLogRecPtrGet(), parse_args(), parse_hba_auth_opt(), parse_hba_line(), parse_int(), parse_real(), parse_sane_timezone(), parse_scalar(), parse_snapshot(), parseIntFromText(), ParseISO8601Number(), parseServiceFile(), parseXidFromText(), percentile_cont_final_common(), percentile_disc_final(), percentile_disc_multi_final(), permute(), pg_atomic_init_u32(), pg_atomic_init_u64(), pg_atomic_unlocked_write_u32(), pg_atomic_unlocked_write_u32_impl(), pg_atomic_write_membarrier_u32(), pg_atomic_write_membarrier_u64(), pg_atomic_write_u32(), pg_atomic_write_u32_impl(), pg_atomic_write_u64(), pg_atomic_write_u64_impl(), pg_get_constraintdef_worker(), pg_prng_int64_range(), pg_prng_uint64_range(), pg_stats_ext_mcvlist_items(), pgstat_progress_update_multi_param(), pgstat_progress_update_param(), plperl_build_tuple_result(), plperl_modify_tuple(), plperl_to_hstore(), plpython_to_hstore(), PLy_elog_impl(), PLy_input_convert(), PLy_output_convert(), PLyObject_FromJsonbContainer(), populate_array_dim_jsonb(), populate_recordset_object_field_end(), power_var(), pqBuildErrorMessage3(), PQcancel(), PQconnectPoll(), PQencryptPasswordConn(), pqRowProcessor(), print_tar_number(), PrintResultInCrosstab(), prsd_headline(), pset_bool_string(), pushquery(), puttzcode(), puttzcodepass(), putVariable(), putVariableInt(), range_contains_elem(), range_contains_elem_internal(), rankSort(), raw_expression_tree_walker_impl(), recompute_limits(), RelationBuildTriggers(), RelationGetExclusionInfo(), relptr_store_eval(), replace_percent_placeholders(), ReportGUCOption(), restore(), ri_ReportViolation(), SendFunctionCall(), SerialGetMinConflictCommitSeqNo(), serialize_deflist(), session_username(), set_arg(), set_stack_value(), set_string_attr(), setCompoundAffixFlagValue(), Setup_AF_UNIX(), ShowGUCOption(), simple_action_list_append(), simple_oid_list_append(), simple_oid_list_member(), simple_quote_literal(), simple_string_list_append(), simple_string_list_member(), SPI_getvalue(), splitmix64(), sqlda_common_total_size(), standard_strings(), stringlist_to_identifierstr(), strtoint(), sv2cstr(), test_huge_distances(), test_pipeline_abort(), test_random(), text_format_parse_digits(), time_part_common(), timestamp_part_common(), timestamp_trunc(), timestamp_zone(), timestamptz_part_common(), timestamptz_trunc_internal(), timestamptz_zone(), timetz_part_common(), timetz_zone(), to_json(), to_jsonb(), transformJsonArrayConstructor(), transformJsonBehavior(), transformJsonObjectAgg(), transformJsonObjectConstructor(), transformPartitionBoundValue(), trgm2int(), ts_match_vq(), tsqueryrecv(), tstoreReceiveSlot_detoast(), tts_virtual_materialize(), tuple_to_stringinfo(), tuplesort_getdatum(), tuplesort_putdatum(), uint64_to_itemptr(), untransformRelOptions(), upc_cast_from_ean13(), useKeepalives(), worker_spi_main(), and xoroshiro128ss().
char* val_string |
Definition at line 694 of file informix.c.
Referenced by ExecEvalJsonExprPath().
struct { ... } value |
Referenced by _crypt_gensalt_extended_rn(), _crypt_gensalt_md5_rn(), AddISO8601IntPart(), AddPostgresIntPart(), AddVerboseIntPart(), AlterSystemSetConfigFile(), append_num_word(), appendJSONKeyValue(), appendJSONKeyValueFmt(), appendPGArray(), appendReloptionsArray(), AppendSeconds(), array_fill(), array_fill_internal(), array_fill_with_lower_bounds(), array_iterate(), array_position_common(), array_positions(), array_to_text_internal(), ArrayCast(), AssertCheckRanges(), AV_to_JsonbValue(), binary_upgrade_set_missing_value(), bloom_add_value(), bloom_contains_value(), BootstrapModeMain(), brin_bloom_consistent(), brin_form_tuple(), brin_minmax_consistent(), brin_minmax_multi_consistent(), build_sorted_items(), bytea_string_agg_transfn(), calculate_frame_offsets(), call_subtype_diff(), cash_in(), cash_out(), cash_words(), check_pghost_envvar(), check_with_filler(), CloneRowTriggersToPartition(), compute_array_stats(), compute_distinct_stats(), compute_range_stats(), compute_scalar_stats(), compute_trivial_stats(), compute_tsvector_stats(), concat_internal(), config_enum_lookup_by_name(), conninfo_storeval(), conninfo_uri_parse_params(), convert_bytea_to_scalar(), convert_int_from_base_unit(), convert_network_to_scalar(), convert_numeric_to_scalar(), convert_one_bytea_to_scalar(), convert_one_string_to_scalar(), convert_prep_stmt_params(), convert_real_from_base_unit(), convert_string_datum(), convert_string_to_scalar(), convert_timevalue_to_scalar(), convert_to_base(), convert_to_base_unit(), convert_to_scalar(), convert_value_to_string(), CopyOneRowTo(), create_list_bounds(), datum_image_hash(), datumCopy(), datumEstimateSpace(), DatumGetFloat4(), DatumGetFloat8(), datumGetSize(), datumSerialize(), datumTransfer(), DCH_from_char(), debugtup(), DecodeDateTime(), DecodeTimeOnly(), deconstruct_composite_datum(), DefineSequence(), do_cast_value(), do_pset(), domain_check(), domain_check_input(), domain_check_internal(), domain_check_safe(), domain_in(), domain_recv(), dxsyn_lexize(), ecpg_build_params(), exec_assign_c_string(), exec_assign_expr(), exec_assign_value(), exec_cast_value(), exec_command_echo(), exec_command_T(), exec_eval_datum(), exec_move_row_from_datum(), 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(), ExecEvalJsonConstructor(), ExecEvalPreOrderedDistinctSingle(), ExecEvalRowNullInt(), ExecEvalXmlExpr(), executeDateTimeMethod(), expect_boolean_value(), expect_integer_value(), ExplainProperty(), ExplainPropertyBool(), ExplainPropertyFloat(), ExplainPropertyInteger(), ExplainPropertyText(), ExplainPropertyUInteger(), filter_list_to_array(), find_next_mcelem(), float4_to_char(), Float4GetDatum(), float8_to_char(), fmgr_security_definer(), fmtchar(), fmtfloat(), fmtint(), fmtptr(), fmtstr(), fn(), from_char_set_int(), fsm_set_avail(), FullTransactionIdFromU64(), gather_boolean_expression(), get_char_item(), get_hexdigit(), get_int_item(), get_len_position(), get_matching_list_bounds(), get_position(), get_reloptions(), GetComment(), getDatumCopy(), getJsonPathItem(), getJsonPathVariable(), ginExtractEntries(), ginHeapTupleBulkInsert(), ginHeapTupleFastCollect(), ginHeapTupleInsert(), gist_page_items(), GUCArrayAdd(), hash_resource_elem(), hstore_from_record(), hstore_populate_record(), hstore_to_plperl(), hstore_to_plpython(), index_store_float8_orderby_distances(), initValue(), InsertOneValue(), int4_to_char(), int8_to_char(), IpcSemaphoreInitialize(), is_true_boolean_expression(), is_visible_fxid(), Jsonb_to_SV(), JsonEncodeDateTime(), JsonTableSetDocument(), length_hist_bsearch(), load_return_type(), logicalrep_read_tuple(), LWLockConflictsWithVar(), lz4_compress_datum(), lz4_decompress_datum(), lz4_decompress_datum_slice(), main(), makeBoolConst(), makeJsonKeyValue(), makeJsonTablePathScan(), map_sql_value_to_xml_value(), MemoryChunkSetHdrMask(), multipleOfPowerOf2(), multipleOfPowerOf5(), numeric_abbrev_convert(), numeric_in(), numeric_recv(), numeric_to_char(), numeric_to_number(), optional_setsockopt(), optionListToArray(), outDatum(), parse_and_validate_value(), parse_bool(), parse_bool_with_len(), parse_compress_specification(), parse_int(), parse_one_reloption(), parse_psql_options(), parse_real(), ParseLongOption(), ParseVariableBool(), ParseVariableNum(), partition_list_bsearch(), partkey_datum_from_expr(), pg_column_size(), pg_get_triggerdef_worker(), pg_lltoa(), pg_logging_init(), pg_ltoa(), pg_snapshot_xip(), pg_strfromd(), pg_ulltoa_n(), pg_ultoa_n(), pg_ultostr(), pg_ultostr_zeropad(), pg_visible_in_snapshot(), pglz_compress_datum(), pglz_decompress_datum(), pglz_decompress_datum_slice(), PGTYPESnumeric_from_asc(), pgwin32_setenv(), plperl_to_hstore(), plpython_to_hstore(), plsample_func_handler(), PLy_output(), PLy_result_ass_subscript(), PLy_subtransaction_exit(), PLyDict_FromTuple(), PLyGenericObject_ToComposite(), PLyMapping_ToComposite(), PLyMapping_ToJsonbValue(), PLySequence_ToComposite(), PLySequence_ToJsonbValue(), postgres_fdw_validator(), postgresAcquireSampleRowsFunc(), PostmasterMain(), postquel_get_single_result(), pow5Factor(), pq_parse_errornotice(), pqParseIntParam(), pqPutInt(), pqRowProcessor(), pqSaveMessageField(), pqSaveParameterStatus(), PQsetvalue(), print_param_value(), printatt(), printsimple(), process_postgres_switches(), process_startup_options(), ProcessGUCArray(), prune_element_hashtable(), psql_get_variable(), PsqlVarEnumError(), push_assignment(), putVariable(), putVariableInt(), putVariableValue(), range_bound_escape(), rbound_bsearch(), read_client_final_message(), read_dictionary(), record_out(), replace_auto_config_value(), replaceVariable(), ResourceOwnerAddToHash(), ResourceOwnerForget(), ResourceOwnerReleaseAll(), ResourceOwnerReleaseAllOfKind(), ResourceOwnerRemember(), rfmtlong(), SerializeUncommittedEnums(), set_config_by_name(), set_config_option(), set_config_option_ext(), set_config_with_handle(), set_descriptors(), set_restrict_relation_kind(), set_unicode_line_style(), set_var_from_var(), SetAttrMissing(), SetConfigOption(), SetVariable(), ShowGUCConfigOption(), signValue(), SPI_datumTransfer(), sprintf_double_value(), sprintf_float_value(), statext_expressions_load(), statext_mcv_serialize(), StoreQueryTuple(), string_agg_transfn(), test_basic(), test_random(), test_single_value(), test_single_value_and_filler(), text_format(), text_format_parse_digits(), text_format_string_conversion(), tfuncFetchRows(), tfuncInitialize(), to_bin32(), to_bin64(), to_hex32(), to_hex64(), to_oct32(), to_oct64(), toast_compress_datum(), toast_datum_size(), toast_delete_datum(), toast_delete_external(), toast_raw_datum_size(), toast_save_datum(), toast_tuple_externalize(), toast_tuple_try_compression(), TransformGUCArray(), transformPartitionBound(), transformPartitionBoundValue(), transformPartitionRangeBounds(), transformRelOptions(), transtime(), validate_option_array_item(), validate_string_option(), wait_for_connection_state(), xid8recv(), and XmlTableSetDocument().