PostgreSQL Source Code
git master
|
#include "utils/guc.h"
Go to the source code of this file.
void assign_application_name | ( | const char * | newval, |
void * | extra | ||
) |
Definition at line 1104 of file variable.c.
References newval, and pgstat_report_appname().
void assign_backtrace_functions | ( | const char * | newval, |
void * | extra | ||
) |
void assign_checkpoint_completion_target | ( | double | newval, |
void * | extra | ||
) |
Definition at line 2198 of file xlog.c.
References CalculateCheckpointSegments(), CheckPointCompletionTarget, and newval.
void assign_client_encoding | ( | const char * | newval, |
void * | extra | ||
) |
Definition at line 784 of file variable.c.
References elog, encoding, IsParallelWorker, LOG, and SetClientEncoding().
void assign_datestyle | ( | const char * | newval, |
void * | extra | ||
) |
Definition at line 244 of file variable.c.
void assign_debug_io_direct | ( | const char * | newval, |
void * | extra | ||
) |
void assign_default_text_search_config | ( | const char * | newval, |
void * | extra | ||
) |
void assign_locale_messages | ( | const char * | newval, |
void * | extra | ||
) |
Definition at line 439 of file pg_locale.c.
References newval, and pg_perm_setlocale().
void assign_locale_monetary | ( | const char * | newval, |
void * | extra | ||
) |
void assign_locale_numeric | ( | const char * | newval, |
void * | extra | ||
) |
Definition at line 388 of file pg_locale.c.
References CurrentLocaleConvValid.
void assign_locale_time | ( | const char * | newval, |
void * | extra | ||
) |
void assign_log_destination | ( | const char * | newval, |
void * | extra | ||
) |
void assign_log_timezone | ( | const char * | newval, |
void * | extra | ||
) |
void assign_maintenance_io_concurrency | ( | int | newval, |
void * | extra | ||
) |
Definition at line 1140 of file variable.c.
References AmStartupProcess, maintenance_io_concurrency, newval, and XLogPrefetchReconfigure().
void assign_max_stack_depth | ( | int | newval, |
void * | extra | ||
) |
void assign_max_wal_size | ( | int | newval, |
void * | extra | ||
) |
Definition at line 2191 of file xlog.c.
References CalculateCheckpointSegments(), max_wal_size_mb, and newval.
void assign_random_seed | ( | double | newval, |
void * | extra | ||
) |
Definition at line 666 of file variable.c.
References DirectFunctionCall1, Float8GetDatum(), newval, and setseed().
void assign_recovery_prefetch | ( | int | new_value, |
void * | extra | ||
) |
Definition at line 1095 of file xlogprefetcher.c.
References AmStartupProcess, recovery_prefetch, and XLogPrefetchReconfigure().
void assign_recovery_target | ( | const char * | newval, |
void * | extra | ||
) |
Definition at line 4794 of file xlogrecovery.c.
References newval, RECOVERY_TARGET_IMMEDIATE, RECOVERY_TARGET_UNSET, and recoveryTarget.
void assign_recovery_target_lsn | ( | const char * | newval, |
void * | extra | ||
) |
Definition at line 4833 of file xlogrecovery.c.
References newval, RECOVERY_TARGET_LSN, RECOVERY_TARGET_UNSET, recoveryTarget, and recoveryTargetLSN.
void assign_recovery_target_name | ( | const char * | newval, |
void * | extra | ||
) |
Definition at line 4868 of file xlogrecovery.c.
References newval, RECOVERY_TARGET_NAME, RECOVERY_TARGET_UNSET, recoveryTarget, and recoveryTargetName.
void assign_recovery_target_time | ( | const char * | newval, |
void * | extra | ||
) |
Definition at line 4948 of file xlogrecovery.c.
References newval, RECOVERY_TARGET_TIME, RECOVERY_TARGET_UNSET, and recoveryTarget.
void assign_recovery_target_timeline | ( | const char * | newval, |
void * | extra | ||
) |
Definition at line 4997 of file xlogrecovery.c.
References newval, RECOVERY_TARGET_TIMELINE_NUMERIC, recoveryTargetTimeLineGoal, and recoveryTargetTLIRequested.
void assign_recovery_target_xid | ( | const char * | newval, |
void * | extra | ||
) |
Definition at line 5033 of file xlogrecovery.c.
References newval, RECOVERY_TARGET_UNSET, RECOVERY_TARGET_XID, recoveryTarget, and recoveryTargetXid.
void assign_restrict_nonsystem_relation_kind | ( | const char * | newval, |
void * | extra | ||
) |
void assign_role | ( | const char * | newval, |
void * | extra | ||
) |
Definition at line 1024 of file variable.c.
References role_auth_extra::is_superuser, role_auth_extra::roleid, and SetCurrentRoleId().
void assign_search_path | ( | const char * | newval, |
void * | extra | ||
) |
Definition at line 4713 of file namespace.c.
References Assert, baseSearchPathValid, and IsBootstrapProcessingMode.
void assign_session_authorization | ( | const char * | newval, |
void * | extra | ||
) |
Definition at line 910 of file variable.c.
References role_auth_extra::is_superuser, role_auth_extra::roleid, and SetSessionAuthorization().
void assign_session_replication_role | ( | int | newval, |
void * | extra | ||
) |
Definition at line 6585 of file trigger.c.
References newval, ResetPlanCache(), and SessionReplicationRole.
void assign_stats_fetch_consistency | ( | int | newval, |
void * | extra | ||
) |
Definition at line 2069 of file pgstat.c.
References force_stats_snapshot_clear, newval, and pgstat_fetch_consistency.
void assign_synchronized_standby_slots | ( | const char * | newval, |
void * | extra | ||
) |
Definition at line 2557 of file slot.c.
References InvalidXLogRecPtr, ss_oldest_flush_lsn, and synchronized_standby_slots_config.
void assign_synchronous_commit | ( | int | newval, |
void * | extra | ||
) |
Definition at line 1055 of file syncrep.c.
References newval, SYNC_REP_NO_WAIT, SYNC_REP_WAIT_APPLY, SYNC_REP_WAIT_FLUSH, SYNC_REP_WAIT_WRITE, SYNCHRONOUS_COMMIT_REMOTE_APPLY, SYNCHRONOUS_COMMIT_REMOTE_FLUSH, SYNCHRONOUS_COMMIT_REMOTE_WRITE, and SyncRepWaitMode.
void assign_synchronous_standby_names | ( | const char * | newval, |
void * | extra | ||
) |
void assign_syslog_facility | ( | int | newval, |
void * | extra | ||
) |
void assign_syslog_ident | ( | const char * | newval, |
void * | extra | ||
) |
void assign_tcp_keepalives_count | ( | int | newval, |
void * | extra | ||
) |
Definition at line 2008 of file pqcomm.c.
References MyProcPort, newval, and pq_setkeepalivescount().
void assign_tcp_keepalives_idle | ( | int | newval, |
void * | extra | ||
) |
Definition at line 1952 of file pqcomm.c.
References MyProcPort, newval, and pq_setkeepalivesidle().
void assign_tcp_keepalives_interval | ( | int | newval, |
void * | extra | ||
) |
Definition at line 1985 of file pqcomm.c.
References MyProcPort, newval, and pq_setkeepalivesinterval().
void assign_tcp_user_timeout | ( | int | newval, |
void * | extra | ||
) |
Definition at line 2031 of file pqcomm.c.
References MyProcPort, newval, and pq_settcpusertimeout().
void assign_temp_tablespaces | ( | const char * | newval, |
void * | extra | ||
) |
Definition at line 1306 of file tablespace.c.
References temp_tablespaces_extra::numSpcs, SetTempTablespaces(), and temp_tablespaces_extra::tblSpcs.
void assign_timezone | ( | const char * | newval, |
void * | extra | ||
) |
void assign_timezone_abbreviations | ( | const char * | newval, |
void * | extra | ||
) |
Definition at line 517 of file variable.c.
References InstallTimeZoneAbbrevs().
void assign_transaction_timeout | ( | int | newval, |
void * | extra | ||
) |
Definition at line 3699 of file postgres.c.
References disable_timeout(), enable_timeout_after(), get_timeout_active(), IsTransactionState(), newval, and TRANSACTION_TIMEOUT.
void assign_wal_consistency_checking | ( | const char * | newval, |
void * | extra | ||
) |
void assign_wal_sync_method | ( | int | new_wal_sync_method, |
void * | extra | ||
) |
Definition at line 8641 of file xlog.c.
References ereport, errcode_for_file_access(), errmsg(), get_sync_bit(), MAXFNAMELEN, openLogFile, openLogSegNo, openLogTLI, PANIC, pg_fsync(), pgstat_report_wait_end(), pgstat_report_wait_start(), wal_segment_size, wal_sync_method, XLogFileClose(), and XLogFileName().
bool check_application_name | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 1078 of file variable.c.
References guc_strdup(), MCXT_ALLOC_NO_OOM, newval, pfree(), pg_clean_ascii(), and WARNING.
bool check_autovacuum_work_mem | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
bool check_backtrace_functions | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 2167 of file elog.c.
References ERROR, GUC_check_errdetail, guc_malloc(), i, j, and newval.
bool check_bonjour | ( | bool * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
bool check_canonical_path | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
bool check_client_connection_check_interval | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 3649 of file postgres.c.
References GUC_check_errdetail, newval, and WaitEventSetCanReportClosed().
bool check_client_encoding | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 686 of file variable.c.
References encoding, GetDatabaseEncodingName(), GUC_check_errcode(), GUC_check_errdetail, guc_free(), guc_malloc(), guc_strdup(), InitializingParallelWorker, IsParallelWorker, IsTransactionState(), LOG, newval, pg_encoding_to_char, pg_valid_client_encoding(), and PrepareClientEncoding().
bool check_cluster_name | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 1114 of file variable.c.
References guc_strdup(), MCXT_ALLOC_NO_OOM, newval, pfree(), pg_clean_ascii(), and WARNING.
bool check_commit_ts_buffers | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
bool check_datestyle | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 52 of file variable.c.
References DateOrder, DATEORDER_DMY, DATEORDER_MDY, DATEORDER_YMD, DateStyle, GetConfigOptionResetString(), GUC_check_errdetail, guc_free(), guc_malloc(), guc_strdup(), lfirst, list_free(), LOG, newval, pfree(), pg_strcasecmp(), pg_strncasecmp(), pstrdup(), source, SplitIdentifierString(), USE_GERMAN_DATES, USE_ISO_DATES, USE_POSTGRES_DATES, and USE_SQL_DATES.
bool check_debug_io_direct | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 3965 of file fd.c.
References ERROR, GUC_check_errdetail, guc_malloc(), IO_DIRECT_DATA, IO_DIRECT_WAL, IO_DIRECT_WAL_INIT, lfirst, list_free(), newval, pfree(), pg_strcasecmp(), pstrdup(), and SplitGUCList().
bool check_default_table_access_method | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 105 of file tableamapi.c.
References ereport, errcode(), errmsg(), get_table_am_oid(), GUC_check_errdetail, InvalidOid, IsTransactionState(), MyDatabaseId, NAMEDATALEN, newval, NOTICE, OidIsValid, PGC_S_TEST, and source.
bool check_default_tablespace | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 1091 of file tablespace.c.
References ereport, errcode(), errmsg(), get_tablespace_oid(), GUC_check_errdetail, InvalidOid, IsTransactionState(), MyDatabaseId, newval, NOTICE, OidIsValid, PGC_S_TEST, and source.
bool check_default_text_search_config | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 602 of file ts_cache.c.
References buf, elog, ereport, errcode(), errmsg(), ERROR, get_namespace_name(), get_ts_config_oid(), GETSTRUCT, guc_free(), guc_strdup(), HeapTupleIsValid, InvalidOid, IsTransactionState(), LOG, MyDatabaseId, NameStr, newval, NIL, NOTICE, ObjectIdGetDatum(), OidIsValid, pfree(), PGC_S_TEST, quote_qualified_identifier(), ReleaseSysCache(), SearchSysCache1(), source, and stringToQualifiedNameList().
bool check_default_with_oids | ( | bool * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 1214 of file variable.c.
References GUC_check_errcode(), GUC_check_errmsg, and newval.
bool check_effective_io_concurrency | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 1229 of file variable.c.
References GUC_check_errdetail, and newval.
bool check_huge_page_size | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
bool check_locale_messages | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 416 of file pg_locale.c.
References check_locale(), newval, PGC_S_DEFAULT, and source.
bool check_locale_monetary | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 370 of file pg_locale.c.
References check_locale(), and newval.
bool check_locale_numeric | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 382 of file pg_locale.c.
References check_locale(), and newval.
bool check_locale_time | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 394 of file pg_locale.c.
References check_locale(), and newval.
bool check_log_destination | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 2235 of file elog.c.
References ERROR, GUC_check_errdetail, guc_malloc(), lfirst, list_free(), LOG_DESTINATION_CSVLOG, LOG_DESTINATION_EVENTLOG, LOG_DESTINATION_JSONLOG, LOG_DESTINATION_STDERR, LOG_DESTINATION_SYSLOG, newval, pfree(), pg_strcasecmp(), pstrdup(), and SplitIdentifierString().
bool check_log_stats | ( | bool * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 3684 of file postgres.c.
References GUC_check_errdetail, log_executor_stats, log_parser_stats, log_planner_stats, and newval.
bool check_log_timezone | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 416 of file variable.c.
References GUC_check_errdetail, GUC_check_errmsg, guc_malloc(), LOG, newval, pg_tz_acceptable(), and pg_tzset().
bool check_maintenance_io_concurrency | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 1243 of file variable.c.
References GUC_check_errdetail, and newval.
bool check_max_slot_wal_keep_size | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 2223 of file xlog.c.
References GUC_check_errdetail, IsBinaryUpgrade, and newval.
bool check_max_stack_depth | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 3621 of file postgres.c.
References get_stack_depth_rlimit(), GUC_check_errdetail, GUC_check_errhint, newval, and STACK_DEPTH_SLOP.
bool check_multixact_member_buffers | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 2023 of file multixact.c.
References check_slru_buffers(), and newval.
bool check_multixact_offset_buffers | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 2014 of file multixact.c.
References check_slru_buffers(), and newval.
bool check_notify_buffers | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 2394 of file async.c.
References check_slru_buffers(), and newval.
bool check_primary_slot_name | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 4739 of file xlogrecovery.c.
References newval, ReplicationSlotValidateName(), and WARNING.
bool check_random_seed | ( | double * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 654 of file variable.c.
References guc_malloc(), LOG, PGC_S_INTERACTIVE, and source.
bool check_recovery_prefetch | ( | int * | new_value, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 1081 of file xlogprefetcher.c.
References GUC_check_errdetail, and RECOVERY_PREFETCH_ON.
bool check_recovery_target | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
bool check_recovery_target_lsn | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 4810 of file xlogrecovery.c.
References ERROR, guc_malloc(), newval, and pg_lsn_in_internal().
bool check_recovery_target_name | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 4852 of file xlogrecovery.c.
References GUC_check_errdetail, MAXFNAMELEN, and newval.
bool check_recovery_target_time | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 4893 of file xlogrecovery.c.
References DecodeDateTime(), DTK_DATE, GUC_check_errdetail, MAXDATEFIELDS, MAXDATELEN, newval, ParseDateTime(), str, tm, and tm2timestamp().
bool check_recovery_target_timeline | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 4964 of file xlogrecovery.c.
References ERROR, GUC_check_errdetail, guc_malloc(), newval, RECOVERY_TARGET_TIMELINE_CONTROLFILE, RECOVERY_TARGET_TIMELINE_LATEST, and RECOVERY_TARGET_TIMELINE_NUMERIC.
bool check_recovery_target_xid | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
bool check_restrict_nonsystem_relation_kind | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 3718 of file postgres.c.
References ERROR, GUC_check_errdetail, guc_malloc(), lfirst, list_free(), newval, pfree(), pg_strcasecmp(), pstrdup(), RESTRICT_RELKIND_FOREIGN_TABLE, RESTRICT_RELKIND_VIEW, and SplitIdentifierString().
bool check_role | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 931 of file variable.c.
References current_role_is_superuser, ereport, errcode(), errmsg(), GetCurrentRoleId(), GetSessionUserId(), GETSTRUCT, GUC_check_errcode(), GUC_check_errmsg, guc_malloc(), HeapTupleIsValid, InitializingParallelWorker, InvalidOid, role_auth_extra::is_superuser, is_superuser(), IsTransactionState(), LOG, member_can_set_role(), newval, NOTICE, PGC_S_TEST, PointerGetDatum(), ReleaseSysCache(), role_auth_extra::roleid, SearchSysCache1(), and source.
bool check_search_path | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 4657 of file namespace.c.
References GetUserId(), GUC_check_errdetail, InvalidOid, list_free(), newval, pfree(), pstrdup(), SearchPathCacheContext, spcache_init(), spcache_insert(), spcache_lookup(), and SplitIdentifierString().
bool check_serial_buffers | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 847 of file predicate.c.
References check_slru_buffers(), and newval.
bool check_session_authorization | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 813 of file variable.c.
References ereport, errcode(), errmsg(), GetAuthenticatedUserId(), GetSessionUserId(), GetSessionUserIsSuperuser(), GETSTRUCT, GUC_check_errcode(), GUC_check_errmsg, guc_malloc(), HeapTupleIsValid, InitializingParallelWorker, role_auth_extra::is_superuser, is_superuser(), IsTransactionState(), LOG, newval, NOTICE, PGC_S_TEST, PointerGetDatum(), ReleaseSysCache(), role_auth_extra::roleid, SearchSysCache1(), source, and superuser_arg().
bool check_ssl | ( | bool * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
bool check_stage_log_stats | ( | bool * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 3670 of file postgres.c.
References GUC_check_errdetail, log_statement_stats, and newval.
bool check_subtrans_buffers | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 254 of file subtrans.c.
References check_slru_buffers(), and newval.
bool check_synchronized_standby_slots | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 2503 of file slot.c.
References foreach_ptr, guc_malloc(), list_free(), list_length(), LOG, newval, NIL, SyncStandbySlotsConfigData::nslotnames, pfree(), pstrdup(), size, SyncStandbySlotsConfigData::slot_names, and validate_sync_standby_slots().
bool check_synchronous_standby_names | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 991 of file syncrep.c.
References SyncRepConfigData::config_size, GUC_check_errcode(), GUC_check_errdetail, GUC_check_errmsg, guc_malloc(), LOG, newval, SyncRepConfigData::num_sync, syncrep_parse_error_msg, syncrep_parse_result, syncrep_scanner_finish(), syncrep_scanner_init(), and syncrep_yyparse().
bool check_temp_buffers | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 704 of file localbuf.c.
References GUC_check_errdetail, newval, NLocBuffer, PGC_S_TEST, and source.
bool check_temp_tablespaces | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 1198 of file tablespace.c.
References ACL_CREATE, aclcheck_error(), ACLCHECK_OK, ereport, errcode(), errmsg(), get_tablespace_oid(), GetUserId(), GUC_check_errdetail, guc_malloc(), InvalidOid, IsTransactionState(), lfirst, list_free(), list_length(), LOG, MyDatabaseId, MyDatabaseTableSpace, newval, NOTICE, temp_tablespaces_extra::numSpcs, object_aclcheck(), OBJECT_TABLESPACE, palloc(), pfree(), PGC_S_INTERACTIVE, PGC_S_TEST, pstrdup(), source, SplitIdentifierString(), and temp_tablespaces_extra::tblSpcs.
bool check_timezone | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 261 of file variable.c.
References CStringGetDatum(), DatumGetIntervalP(), DirectFunctionCall3, GUC_check_errdetail, GUC_check_errmsg, guc_malloc(), Int32GetDatum(), interval_in(), InvalidOid, LOG, interval::month, newval, ObjectIdGetDatum(), pfree(), pg_strncasecmp(), pg_tz_acceptable(), pg_tzset(), pg_tzset_offset(), pstrdup(), SECS_PER_HOUR, interval::time, USECS_PER_SEC, and val.
bool check_timezone_abbreviations | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 485 of file variable.c.
References Assert, load_tzoffsets(), newval, PGC_S_DEFAULT, and source.
bool check_transaction_buffers | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 821 of file clog.c.
References check_slru_buffers(), and newval.
bool check_transaction_deferrable | ( | bool * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 622 of file variable.c.
References FirstSnapshotSet, GUC_check_errcode(), GUC_check_errmsg, InitializingParallelWorker, and IsSubTransaction().
bool check_transaction_isolation | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 584 of file variable.c.
References FirstSnapshotSet, GUC_check_errcode(), GUC_check_errhint, GUC_check_errmsg, InitializingParallelWorker, IsSubTransaction(), IsTransactionState(), newval, RecoveryInProgress(), XACT_SERIALIZABLE, and XactIsoLevel.
bool check_transaction_read_only | ( | bool * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 544 of file variable.c.
References FirstSnapshotSet, GUC_check_errcode(), GUC_check_errmsg, InitializingParallelWorker, IsSubTransaction(), IsTransactionState(), newval, RecoveryInProgress(), and XactReadOnly.
bool check_vacuum_buffer_usage_limit | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 124 of file vacuum.c.
References GUC_check_errdetail, MAX_BAS_VAC_RING_SIZE_KB, MIN_BAS_VAC_RING_SIZE_KB, and newval.
bool check_wal_buffers | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
bool check_wal_consistency_checking | ( | char ** | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 4672 of file xlog.c.
References check_wal_consistency_checking_deferred, ERROR, GetRmgr(), GUC_check_errdetail, guc_malloc(), lfirst, list_free(), MemSet, newval, pfree(), pg_strcasecmp(), process_shared_preload_libraries_done, pstrdup(), RmgrData::rm_mask, RM_MAX_ID, RmgrIdExists(), and SplitIdentifierString().
bool check_wal_segment_size | ( | int * | newval, |
void ** | extra, | ||
GucSource | source | ||
) |
Definition at line 2205 of file xlog.c.
References GUC_check_errdetail, IsValidWalSegSize, and newval.
const char* show_archive_command | ( | void | ) |
const char* show_data_directory_mode | ( | void | ) |
const char* show_in_hot_standby | ( | void | ) |
const char* show_log_file_mode | ( | void | ) |
const char* show_log_timezone | ( | void | ) |
const char* show_random_seed | ( | void | ) |
Definition at line 675 of file variable.c.
const char* show_role | ( | void | ) |
Definition at line 1032 of file variable.c.
References GetCurrentRoleId(), OidIsValid, and role_string.
const char* show_tcp_keepalives_count | ( | void | ) |
Definition at line 2018 of file pqcomm.c.
References MyProcPort, pq_getkeepalivescount(), and snprintf.
const char* show_tcp_keepalives_idle | ( | void | ) |
Definition at line 1972 of file pqcomm.c.
References MyProcPort, pq_getkeepalivesidle(), and snprintf.
const char* show_tcp_keepalives_interval | ( | void | ) |
Definition at line 1995 of file pqcomm.c.
References MyProcPort, pq_getkeepalivesinterval(), and snprintf.
const char* show_tcp_user_timeout | ( | void | ) |
Definition at line 2041 of file pqcomm.c.
References MyProcPort, pq_gettcpusertimeout(), and snprintf.
const char* show_timezone | ( | void | ) |
const char* show_unix_socket_permissions | ( | void | ) |