PostgreSQL Source Code
git master
|
#include "postgres_fe.h"
#include <ctype.h>
#include <sys/resource.h>
#include <sys/stat.h>
#include <sys/time.h>
#include <sys/wait.h>
#include <signal.h>
#include <unistd.h>
#include "common/logging.h"
#include "common/restricted_token.h"
#include "common/string.h"
#include "common/username.h"
#include "getopt_long.h"
#include "lib/stringinfo.h"
#include "libpq/pqcomm.h"
#include "pg_config_paths.h"
#include "pg_regress.h"
#include "portability/instr_time.h"
Go to the source code of this file.
Data Structures | |
struct | _resultmap |
Macros | |
#define | psql_command(database, ...) |
#define | MAX_PARALLEL_TESTS 100 |
#define | ULONGPID(x) (unsigned long) (x) |
Typedefs | |
typedef struct _resultmap | _resultmap |
Functions | |
static bool | directory_exists (const char *dir) |
static void | make_directory (const char *dir) |
static void | header (const char *fmt,...) pg_attribute_printf(1 |
static void static void | status (const char *fmt,...) pg_attribute_printf(1 |
static void static void static StringInfo | psql_start_command (void) |
static void | psql_add_command (StringInfo buf, const char *query,...) pg_attribute_printf(2 |
static void static void | psql_end_command (StringInfo buf, const char *database) |
static void | unlimit_core_size (void) |
void | add_stringlist_item (_stringlist **listhead, const char *str) |
static void | free_stringlist (_stringlist **listhead) |
static void | split_to_stringlist (const char *s, const char *delim, _stringlist **listhead) |
static void | status_end (void) |
static void | stop_postmaster (void) |
static void | remove_temp (void) |
static void | signal_remove_temp (SIGNAL_ARGS) |
static const char * | make_temp_sockdir (void) |
static bool | string_matches_pattern (const char *str, const char *pattern) |
static void | load_resultmap (void) |
static const char * | get_expectfile (const char *testname, const char *file) |
static void | initialize_environment (void) |
PID_TYPE | spawn_process (const char *cmdline) |
static long | file_size (const char *file) |
static int | file_line_count (const char *file) |
bool | file_exists (const char *file) |
static char * | get_alternative_expectfile (const char *expectfile, int i) |
static int | run_diff (const char *cmd, const char *filename) |
static bool | results_differ (const char *testname, const char *resultsfile, const char *default_expectfile) |
static void | wait_for_tests (PID_TYPE *pids, int *statuses, instr_time *stoptimes, char **names, int num_tests) |
static void | log_child_failure (int exitstatus) |
static void | run_schedule (const char *schedule, test_start_function startfunc, postprocess_result_function postfunc) |
static void | run_single_test (const char *test, test_start_function startfunc, postprocess_result_function postfunc) |
static void | open_result_files (void) |
static void | drop_database_if_exists (const char *dbname) |
static void | create_database (const char *dbname) |
static void | drop_role_if_exists (const char *rolename) |
static void | create_role (const char *rolename, const _stringlist *granted_dbs) |
static void | help (void) |
int | regression_main (int argc, char *argv[], init_function ifunc, test_start_function startfunc, postprocess_result_function postfunc) |
Variables | |
char * | host_platform = HOST_TUPLE |
static char * | shellprog = SHELLPROG |
const char * | basic_diff_opts = "" |
const char * | pretty_diff_opts = "-U3" |
_stringlist * | dblist = NULL |
bool | debug = false |
char * | inputdir = "." |
char * | outputdir = "." |
char * | expecteddir = "." |
char * | bindir = PGBINDIR |
char * | launcher = NULL |
static _stringlist * | loadextension = NULL |
static int | max_connections = 0 |
static int | max_concurrent_tests = 0 |
static char * | encoding = NULL |
static _stringlist * | schedulelist = NULL |
static _stringlist * | extra_tests = NULL |
static char * | temp_instance = NULL |
static _stringlist * | temp_configs = NULL |
static bool | nolocale = false |
static bool | use_existing = false |
static char * | hostname = NULL |
static int | port = -1 |
static bool | port_specified_by_user = false |
static char * | dlpath = PKGLIBDIR |
static char * | user = NULL |
static _stringlist * | extraroles = NULL |
static char * | config_auth_datadir = NULL |
static const char * | progname |
static char * | logfilename |
static FILE * | logfile |
static char * | difffilename |
static const char * | sockdir |
static const char * | temp_sockdir |
static char | sockself [MAXPGPATH] |
static char | socklock [MAXPGPATH] |
static _resultmap * | resultmap = NULL |
static PID_TYPE | postmaster_pid = INVALID_PID |
static bool | postmaster_running = false |
static int | success_count = 0 |
static int | fail_count = 0 |
#define MAX_PARALLEL_TESTS 100 |
#define psql_command | ( | database, | |
... | |||
) |
Definition at line 1044 of file pg_regress.c.
typedef struct _resultmap _resultmap |
void add_stringlist_item | ( | _stringlist ** | listhead, |
const char * | str | ||
) |
Definition at line 154 of file pg_regress.c.
References _stringlist::next, pg_malloc(), pg_strdup(), generate_unaccent_rules::str, and _stringlist::str.
Referenced by ecpg_start_test(), isolation_init(), isolation_start_test(), psql_init(), psql_start_test(), regression_main(), and split_to_stringlist().
|
static |
Definition at line 1857 of file pg_regress.c.
References _, buf, dbname, encoding, header(), loadextension, _stringlist::next, nolocale, psql_add_command(), psql_command, psql_end_command(), psql_start_command(), and _stringlist::str.
Referenced by regression_main().
|
static |
Definition at line 1907 of file pg_regress.c.
References _, buf, header(), _stringlist::next, psql_add_command(), psql_end_command(), psql_start_command(), and _stringlist::str.
Referenced by regression_main().
|
static |
Definition at line 1178 of file pg_regress.c.
References S_ISDIR, stat::st_mode, and stat.
Referenced by open_result_files(), and regression_main().
|
static |
Definition at line 1845 of file pg_regress.c.
References _, buf, dbname, header(), psql_add_command(), psql_end_command(), and psql_start_command().
Referenced by regression_main().
|
static |
Definition at line 1895 of file pg_regress.c.
References _, buf, header(), psql_add_command(), psql_end_command(), and psql_start_command().
Referenced by regression_main().
bool file_exists | ( | const char * | file | ) |
|
static |
Definition at line 1145 of file pg_regress.c.
References _, fprintf, progname, and strerror.
Referenced by results_differ().
|
static |
Definition at line 1124 of file pg_regress.c.
References _, fprintf, progname, and strerror.
Referenced by regression_main(), and run_diff().
|
static |
Definition at line 175 of file pg_regress.c.
References free.
Referenced by regression_main(), and run_schedule().
|
static |
Definition at line 1205 of file pg_regress.c.
References free, i, malloc, and snprintf.
Referenced by results_differ().
|
static |
Definition at line 527 of file pg_regress.c.
References _resultmap::next, _resultmap::resultfile, resultmap, _resultmap::test, and _resultmap::type.
Referenced by results_differ().
|
static |
Definition at line 207 of file pg_regress.c.
References fflush(), fmt, fprintf, generate_unaccent_rules::stdout, va_end(), va_start(), and vsnprintf.
Referenced by _tarPositionTo(), BTPageSetDeleted(), check_toast_tuple(), convertJsonbArray(), convertJsonbObject(), convertJsonbScalar(), convertJsonbValue(), create_database(), create_role(), cube_recv(), datumRestore(), datumSerialize(), DecodeMultiInsert(), DecodeXLogTuple(), drop_database_if_exists(), drop_role_if_exists(), ExecHashJoinGetSavedTuple(), GetMemoryChunkMethodID(), isValidTarHeader(), pgss_shmem_startup(), pgstat_database_reset_timestamp_cb(), pgstat_read_statsfile(), pgstat_replslot_reset_timestamp_cb(), pgstat_reset_matching_entries(), pgstat_subscription_reset_timestamp_cb(), printTableAddHeader(), refresh_utf8format(), regression_main(), scan_file(), shared_stat_reset_contents(), tar_close(), tarChecksum(), and XLogFindNextRecord().
|
static |
Definition at line 1922 of file pg_regress.c.
References _, printf, and progname.
Referenced by regression_main().
|
static |
Definition at line 556 of file pg_regress.c.
References _, DEFAULT_PGSOCKET_DIR, dlpath, encoding, free, hostname, inputdir, load_resultmap(), make_temp_sockdir(), nolocale, outputdir, pghost, pgport, port, printf, psprintf(), setenv, sockdir, sprintf, temp_instance, unsetenv, and user.
Referenced by regression_main().
|
static |
Definition at line 445 of file pg_regress.c.
References _, buf, exit(), fprintf, host_platform, i, inputdir, MAXPGPATH, _resultmap::next, pg_malloc(), pg_strdup(), progname, _resultmap::resultfile, resultmap, snprintf, strerror, string_matches_pattern(), _resultmap::test, and _resultmap::type.
Referenced by initialize_environment().
|
static |
Definition at line 1495 of file pg_regress.c.
References _, pg_strsignal(), status(), WEXITSTATUS, WIFEXITED, WIFSIGNALED, and WTERMSIG.
Referenced by run_schedule(), and run_single_test().
|
static |
Definition at line 1191 of file pg_regress.c.
References _, exit(), fprintf, mkdir, progname, S_IRWXG, S_IRWXO, S_IRWXU, and strerror.
Referenced by open_result_files(), and regression_main().
|
static |
Definition at line 326 of file pg_regress.c.
References _, exit(), fprintf, mkdtemp(), port, pqsignal(), progname, psprintf(), remove_temp(), SIGHUP, signal_remove_temp(), SIGPIPE, snprintf, socklock, sockself, strerror, temp_sockdir, and UNIXSOCK_PATH.
Referenced by initialize_environment().
|
static |
Definition at line 1805 of file pg_regress.c.
References _, difffilename, directory_exists(), exit(), fprintf, logfile, logfilename, make_directory(), MAXPGPATH, outputdir, pg_strdup(), progname, snprintf, and strerror.
Referenced by regression_main().
|
static |
Definition at line 983 of file pg_regress.c.
References appendStringInfoChar(), appendStringInfoString(), appendStringInfoVA(), generate_unaccent_rules::args, buf, StringInfoData::data, enlargeStringInfo(), initStringInfo(), pfree(), va_end(), and va_start().
Referenced by create_database(), create_role(), drop_database_if_exists(), and drop_role_if_exists().
|
static |
Definition at line 1020 of file pg_regress.c.
References _, appendStringInfo(), buf, exit(), fflush(), fprintf, and pfree().
Referenced by create_database(), create_role(), drop_database_if_exists(), and drop_role_if_exists().
|
static |
Definition at line 971 of file pg_regress.c.
References appendStringInfo(), bindir, buf, and makeStringInfo().
Referenced by create_database(), create_role(), drop_database_if_exists(), and drop_role_if_exists().
int regression_main | ( | int | argc, |
char * | argv[], | ||
init_function | ifunc, | ||
test_start_function | startfunc, | ||
postprocess_result_function | postfunc | ||
) |
Definition at line 1972 of file pg_regress.c.
References _, add_stringlist_item(), bindir, buf, config_auth_datadir, create_database(), create_role(), dblist, debug, DEVNULL, difffilename, directory_exists(), dlpath, drop_database_if_exists(), drop_role_if_exists(), encoding, exit(), expecteddir, extra_tests, extraroles, fail_count, fflush(), file_size(), fprintf, free_stringlist(), get_progname(), get_restricted_token(), getopt_long(), header(), help(), hostname, i, initialize_environment(), inputdir, INVALID_PID, kill, launcher, loadextension, logfile, logfilename, make_absolute_path(), make_directory(), max_concurrent_tests, max_connections, MAXPGPATH, _stringlist::next, no_argument, nolocale, open_result_files(), optarg, optind, outputdir, pg_logging_init(), pg_strdup(), PG_TEXTDOMAIN, pg_usleep(), port, port_specified_by_user, postmaster_pid, postmaster_running, pretty_diff_opts, printf, progname, required_argument, rmtree(), run_schedule(), run_single_test(), schedulelist, set_pglocale_pgservice(), setenv, SIGKILL, snprintf, sockdir, spawn_process(), split_to_stringlist(), sprintf, stop_postmaster(), _stringlist::str, strerror, success_count, temp_configs, temp_instance, true, ULONGPID, unlimit_core_size(), use_existing, user, and wait_seconds.
Referenced by main().
|
static |
Definition at line 293 of file pg_regress.c.
References Assert(), socklock, sockself, and temp_sockdir.
Referenced by make_temp_sockdir(), and signal_remove_temp().
|
static |
Definition at line 1273 of file pg_regress.c.
References _, basic_diff_opts, difffilename, exit(), file_exists(), file_line_count(), fprintf, free, get_alternative_expectfile(), get_expectfile(), i, MAXPGPATH, pretty_diff_opts, run_diff(), snprintf, strerror, and strlcpy().
Referenced by run_schedule(), and run_single_test().
|
static |
Definition at line 1239 of file pg_regress.c.
References _, exit(), fflush(), file_size(), filename, fprintf, WEXITSTATUS, and WIFEXITED.
Referenced by results_differ().
|
static |
Definition at line 1519 of file pg_regress.c.
References _, exit(), fail_count, fprintf, free_stringlist(), i, INSTR_TIME_GET_MILLISEC, INSTR_TIME_SET_CURRENT, INSTR_TIME_SUBTRACT, log_child_failure(), max_concurrent_tests, max_connections, MAX_PARALLEL_TESTS, _stringlist::next, pg_free(), pg_strdup(), PID_TYPE, printf, progname, results_differ(), status(), status_end(), _stringlist::str, strerror, success_count, test(), and wait_for_tests().
Referenced by regression_main().
|
static |
Definition at line 1737 of file pg_regress.c.
References _, fail_count, INSTR_TIME_GET_MILLISEC, INSTR_TIME_SET_CURRENT, INSTR_TIME_SUBTRACT, log_child_failure(), _stringlist::next, PID_TYPE, printf, results_differ(), status(), status_end(), _stringlist::str, success_count, test(), and wait_for_tests().
Referenced by regression_main().
|
static |
Definition at line 305 of file pg_regress.c.
References pqsignal(), remove_temp(), and SIG_DFL.
Referenced by make_temp_sockdir().
PID_TYPE spawn_process | ( | const char * | cmdline | ) |
Definition at line 1057 of file pg_regress.c.
References _, exit(), fflush(), fprintf, progname, psprintf(), shellprog, and strerror.
Referenced by ecpg_start_test(), isolation_start_test(), psql_start_test(), and regression_main().
|
static |
Definition at line 190 of file pg_regress.c.
References add_stringlist_item(), free, and pg_strdup().
Referenced by regression_main().
|
static |
Definition at line 224 of file pg_regress.c.
References fflush(), fmt, logfile, generate_unaccent_rules::stdout, va_end(), va_start(), and vfprintf().
Referenced by _bt_first(), _bt_parallel_seize(), _bt_readnextpage(), _bt_steppage(), apw_start_leader_worker(), AtAbort_Portals(), AtCleanup_Portals(), AtEOSubXact_RelationCache(), AtEOXact_RelationCache(), AtPrepare_Locks(), AtSubAbort_Portals(), AtSubCleanup_Portals(), AtSubCommit_Portals(), auth_delay_checks(), auth_failed(), BackendInitialize(), BaseBackup(), be_lo_lseek(), be_lo_lseek64(), BeginReportingGUCOptions(), bf_check_supported_key_len(), buildWorkerResponse(), check_icu_locale(), check_worker_status(), CheckForSessionAndXactLocks(), ClientAuthentication(), compute_new_xmax_infomask(), ConditionalMultiXactIdWait(), dblink_get_connections(), DestroyPartitionDirectory(), do_lo_export(), do_lo_unlink(), Do_MultiXactIdWait(), DoesMultiXactIdConflict(), dshash_delete_current(), dshash_seq_init(), dshash_seq_next(), dshash_seq_term(), ecpg_process_output(), ecpg_store_result(), exec_command(), exec_command_bind(), exec_command_crosstabview(), exec_command_d(), exec_command_edit(), exec_command_ef_ev(), exec_command_g(), exec_command_gdesc(), exec_command_gexec(), exec_command_gset(), exec_command_lo(), exec_command_quit(), exec_command_sf_sv(), exec_command_write(), executeQueryOrDie(), ExecuteSqlQuery(), ExitPostmaster(), fdatasync(), FindStreamingStart(), finish_spin_delay(), forget_invalid_pages(), forget_invalid_pages_db(), ForgetPortalSnapshots(), get_collation_actual_version(), get_guc_variables(), get_prompt(), GetMultiXactIdHintBits(), HandleSlashCmds(), hash_seq_init(), hash_seq_search(), hash_seq_term(), heap_lock_tuple(), heap_lock_updated_tuple_rec(), HoldPinnedPortals(), init_spin_delay(), InitializeGUCOptions(), InvalidateAttoptCacheCallback(), InvalidateOprCacheCallBack(), InvalidateOprProofCacheCallBack(), InvalidateShippableCacheCallback(), InvalidateTableSpaceCacheCallback(), InvalidateTSCacheCallBack(), libpqsrv_connect_internal(), ListenToWorkers(), lo_read(), lo_write(), LockReassignCurrentOwner(), LockReleaseAll(), LockReleaseCurrentOwner(), LockReleaseSession(), log_child_failure(), logicalrep_partmap_invalidate_cb(), logicalrep_partmap_reset_relmap(), logicalrep_relmap_invalidate_cb(), make_icu_collator(), mark_dump_job_done(), mark_restore_job_done(), MarkGUCPrefixReserved(), MultiXactIdCreateFromMembers(), MultiXactIdExpand(), MultiXactIdGetUpdateXid(), MultiXactIdWait(), mxid_to_string(), mxstatus_to_string(), parallel_restore(), parseServiceInfo(), parseWorkerResponse(), perform_spin_delay(), pg_backup_start(), pg_backup_stop(), pg_cryptohash_final(), pg_cryptohash_init(), pg_cryptohash_update(), pg_hmac_final(), pg_hmac_init(), pg_hmac_update(), pg_prepared_xact(), pg_xact_status(), pgrowlocks(), plperl_spi_execute_fetch_result(), PLy_spi_execute_fetch_result(), PortalErrorCleanup(), PortalHashTableDeleteAll(), PostmasterMain(), PostPrepare_Locks(), pqFunctionCall3(), pqGetline3(), PQmakeEmptyPGresult(), PQresetPoll(), PQresStatus(), PQsetClientEncoding(), PreCommit_Portals(), ProcessConfigFileInternal(), RecordNewMultiXact(), rel_sync_cache_publication_cb(), rel_sync_cache_relation_cb(), RelationCacheInitializePhase3(), RelationCacheInvalidate(), RelfilenumberMapInvalidateCallback(), restore_toc_entry(), run_reindex_command(), run_schedule(), run_single_test(), run_vacuum_command(), SendBaseBackup(), sepgsql_client_auth(), SerializeUncommittedEnums(), set_status_by_pages(), shm_mq_counterparty_gone(), shm_mq_wait_internal(), smgrcloseall(), smgrreleaseall(), StandbyReleaseAllLocks(), StandbyReleaseOldLocks(), test_config_settings(), test_lockmode_for_conflict(), test_pipelined_insert(), ThereAreNoReadyPortals(), TransactionGroupUpdateXidStatus(), TransactionIdGetStatus(), TransactionIdSetPageStatus(), TransactionIdSetPageStatusInternal(), TransactionIdSetStatusBit(), TransactionIdSetTreeStatus(), TypeCacheOpcCallback(), TypeCacheRelCallback(), TypeCacheTypCallback(), usage(), uuid_generate_internal(), varstr_abbrev_convert(), varstr_cmp(), varstrfastcmp_locale(), wait_for_postmaster_start(), wait_for_tests(), WaitForBackgroundWorkerShutdown(), WaitForBackgroundWorkerStartup(), WaitForCommands(), WaitForParallelWorkersToAttach(), WaitForParallelWorkersToExit(), WaitForReplicationWorkerAttach(), WaitForTerminatingWorkers(), worker_spi_launch(), write_relcache_init_file(), and XLogCheckInvalidPages().
|
static |
Definition at line 245 of file pg_regress.c.
References fflush(), fprintf, logfile, and generate_unaccent_rules::stdout.
Referenced by run_schedule(), and run_single_test().
|
static |
Definition at line 257 of file pg_regress.c.
References _, bindir, buf, fflush(), fprintf, MAXPGPATH, postmaster_running, progname, snprintf, and temp_instance.
Referenced by regression_main().
|
static |
Definition at line 371 of file pg_regress.c.
References generate_unaccent_rules::str.
Referenced by load_resultmap().
|
static |
Definition at line 129 of file pg_regress.c.
References _, fprintf, and progname.
Referenced by regression_main().
|
static |
Definition at line 1423 of file pg_regress.c.
References _, exit(), fprintf, free, i, INSTR_TIME_SET_CURRENT, INVALID_PID, pg_malloc(), PID_TYPE, status(), and strerror.
Referenced by run_schedule(), and run_single_test().
const char* basic_diff_opts = "" |
Definition at line 64 of file pg_regress.c.
Referenced by results_differ().
char* bindir = PGBINDIR |
Definition at line 77 of file pg_regress.c.
Referenced by psql_start_command(), psql_start_test(), regression_main(), and stop_postmaster().
|
static |
Definition at line 95 of file pg_regress.c.
Referenced by regression_main().
_stringlist* dblist = NULL |
Definition at line 72 of file pg_regress.c.
Referenced by do_start_worker(), get_database_list(), isolation_init(), isolation_start_test(), psql_init(), psql_start_test(), rebuild_database_list(), and regression_main().
Definition at line 73 of file pg_regress.c.
Referenced by regression_main().
|
static |
Definition at line 101 of file pg_regress.c.
Referenced by open_result_files(), regression_main(), and results_differ().
|
static |
Definition at line 92 of file pg_regress.c.
Referenced by initialize_environment(), and regression_main().
|
static |
Definition at line 82 of file pg_regress.c.
Referenced by create_database(), initialize_environment(), and regression_main().
char* expecteddir = "." |
Definition at line 76 of file pg_regress.c.
Referenced by ecpg_start_test(), and regression_main().
|
static |
Definition at line 84 of file pg_regress.c.
Referenced by regression_main().
|
static |
Definition at line 94 of file pg_regress.c.
Referenced by regression_main().
|
static |
Definition at line 113 of file pg_regress.c.
Referenced by regression_main(), run_schedule(), and run_single_test().
char* host_platform = HOST_TUPLE |
Definition at line 52 of file pg_regress.c.
Referenced by load_resultmap().
|
static |
Definition at line 89 of file pg_regress.c.
Referenced by check_hostname(), initialize_environment(), passwordFromFile(), pg_getaddrinfo_all(), and regression_main().
char* inputdir = "." |
Definition at line 74 of file pg_regress.c.
Referenced by ecpg_start_test(), initialize_environment(), isolation_start_test(), load_resultmap(), psql_start_test(), and regression_main().
char* launcher = NULL |
Definition at line 78 of file pg_regress.c.
Referenced by isolation_start_test(), psql_start_test(), and regression_main().
|
static |
Definition at line 79 of file pg_regress.c.
Referenced by create_database(), and regression_main().
|
static |
Definition at line 100 of file pg_regress.c.
Referenced by doLog(), open_result_files(), regression_main(), status(), status_end(), and write_syslogger_file().
|
static |
Definition at line 99 of file pg_regress.c.
Referenced by open_result_files(), and regression_main().
|
static |
Definition at line 81 of file pg_regress.c.
Referenced by regression_main(), and run_schedule().
|
static |
Definition at line 80 of file pg_regress.c.
Referenced by regression_main(), and run_schedule().
Definition at line 87 of file pg_regress.c.
Referenced by create_database(), initialize_environment(), and regression_main().
char* outputdir = "." |
Definition at line 75 of file pg_regress.c.
Referenced by ecpg_start_test(), initialize_environment(), isolation_start_test(), open_result_files(), psql_start_test(), and regression_main().
|
static |
Definition at line 90 of file pg_regress.c.
Referenced by auth_delay_checks(), auth_failed(), auth_peer(), BackendInitialize(), BackendRun(), BackendStartup(), be_gssapi_get_auth(), be_gssapi_get_enc(), be_gssapi_get_princ(), be_gssapi_read(), be_gssapi_write(), be_tls_close(), be_tls_get_cipher(), be_tls_get_cipher_bits(), be_tls_get_peer_issuer_name(), be_tls_get_peer_serial(), be_tls_get_peer_subject_name(), be_tls_get_version(), be_tls_open_server(), be_tls_read(), be_tls_write(), check_hba(), check_hostname(), CheckMD5Auth(), CheckPasswordAuth(), CheckPWChallengeAuth(), CheckRADIUSAuth(), CheckSASLAuth(), ClientAuthentication(), ConnCreate(), ConnFree(), conninfo_uri_parse_options(), do_connect(), ECPGconnect(), hba_getauthmethod(), ident_inet(), inet_client_addr(), inet_client_port(), inet_server_addr(), inet_server_port(), initialize_environment(), log_disconnections(), main(), make_temp_sockdir(), my_SSL_set_fd(), passwordFromFile(), PerformAuthentication(), PerformRadiusTransaction(), pq_getkeepalivescount(), pq_getkeepalivesidle(), pq_getkeepalivesinterval(), pq_gettcpusertimeout(), pq_setkeepalivescount(), pq_setkeepalivesidle(), pq_setkeepalivesinterval(), pq_settcpusertimeout(), process_startup_options(), ProcessStartupPacket(), read_or_wait(), regression_main(), report_fork_failure_to_client(), scram_get_mechanisms(), scram_init(), secure_close(), secure_open_gssapi(), secure_open_server(), secure_raw_read(), secure_raw_write(), secure_read(), secure_write(), sepgsql_client_auth(), ServerLoop(), set_authn_id(), and StreamConnection().
Definition at line 91 of file pg_regress.c.
Referenced by regression_main().
|
static |
Definition at line 109 of file pg_regress.c.
Referenced by regression_main().
Definition at line 110 of file pg_regress.c.
Referenced by regression_main(), and stop_postmaster().
const char* pretty_diff_opts = "-U3" |
Definition at line 65 of file pg_regress.c.
Referenced by regression_main(), and results_differ().
|
static |
Definition at line 98 of file pg_regress.c.
Referenced by file_line_count(), file_size(), help(), load_resultmap(), make_directory(), make_temp_sockdir(), open_result_files(), regression_main(), run_schedule(), spawn_process(), stop_postmaster(), and unlimit_core_size().
|
static |
Definition at line 107 of file pg_regress.c.
Referenced by get_expectfile(), and load_resultmap().
|
static |
Definition at line 83 of file pg_regress.c.
Referenced by regression_main().
|
static |
Definition at line 55 of file pg_regress.c.
Referenced by spawn_process().
|
static |
Definition at line 102 of file pg_regress.c.
Referenced by initialize_environment(), and regression_main().
|
static |
Definition at line 105 of file pg_regress.c.
Referenced by make_temp_sockdir(), and remove_temp().
|
static |
Definition at line 104 of file pg_regress.c.
Referenced by make_temp_sockdir(), and remove_temp().
|
static |
Definition at line 112 of file pg_regress.c.
Referenced by regression_main(), run_schedule(), and run_single_test().
|
static |
Definition at line 86 of file pg_regress.c.
Referenced by regression_main().
|
static |
Definition at line 85 of file pg_regress.c.
Referenced by initialize_environment(), regression_main(), and stop_postmaster().
|
static |
Definition at line 103 of file pg_regress.c.
Referenced by make_temp_sockdir(), and remove_temp().
Definition at line 88 of file pg_regress.c.
Referenced by regression_main().
|
static |
Definition at line 93 of file pg_regress.c.
Referenced by _becomeUser(), _doSetSessionAuth(), check_conn_params(), connect_pg_server(), conninfo_uri_parse_options(), create_foreign_modify(), do_connect(), ECPGconnect(), exec_command_password(), GetConnection(), initialize_environment(), LockGXact(), main(), make_new_connection(), postgresAcquireSampleRowsFunc(), postgresAnalyzeForeignTable(), postgresBeginDirectModify(), postgresBeginForeignScan(), postgresExecForeignTruncate(), postgresGetAnalyzeInfoForForeignTable(), PQencryptPassword(), PQencryptPasswordConn(), regression_main(), ShowUsage(), usage(), and UserMappingPasswordRequired().