PostgreSQL Source Code git master
Loading...
Searching...
No Matches
autovacuum.c File Reference
#include "postgres.h"
#include <signal.h>
#include <sys/time.h>
#include <unistd.h>
#include "access/heapam.h"
#include "access/htup_details.h"
#include "access/multixact.h"
#include "access/reloptions.h"
#include "access/tableam.h"
#include "access/transam.h"
#include "access/xact.h"
#include "catalog/dependency.h"
#include "catalog/namespace.h"
#include "catalog/pg_database.h"
#include "catalog/pg_namespace.h"
#include "commands/vacuum.h"
#include "common/int.h"
#include "lib/ilist.h"
#include "libpq/pqsignal.h"
#include "miscadmin.h"
#include "nodes/makefuncs.h"
#include "pgstat.h"
#include "postmaster/autovacuum.h"
#include "postmaster/interrupt.h"
#include "postmaster/postmaster.h"
#include "storage/aio_subsys.h"
#include "storage/bufmgr.h"
#include "storage/ipc.h"
#include "storage/latch.h"
#include "storage/lmgr.h"
#include "storage/pmsignal.h"
#include "storage/proc.h"
#include "storage/procsignal.h"
#include "storage/smgr.h"
#include "tcop/tcopprot.h"
#include "utils/fmgroids.h"
#include "utils/fmgrprotos.h"
#include "utils/guc_hooks.h"
#include "utils/injection_point.h"
#include "utils/lsyscache.h"
#include "utils/memutils.h"
#include "utils/ps_status.h"
#include "utils/rel.h"
#include "utils/snapmgr.h"
#include "utils/syscache.h"
#include "utils/timeout.h"
#include "utils/timestamp.h"
Include dependency graph for autovacuum.c:

Go to the source code of this file.

Data Structures

struct  avl_dbase
 
struct  avw_dbase
 
struct  av_relation
 
struct  autovac_table
 
struct  WorkerInfoData
 
struct  AutoVacuumWorkItem
 
struct  AutoVacuumShmemStruct
 

Macros

#define MIN_AUTOVAC_SLEEPTIME   100.0 /* milliseconds */
 
#define MAX_AUTOVAC_SLEEPTIME   300 /* seconds */
 
#define AutoVacNumSignals   (AutoVacRebalance + 1)
 
#define NUM_WORKITEMS   256
 
#define MAX_AUTOVAC_ACTIV_LEN   (NAMEDATALEN * 2 + 56)
 

Typedefs

typedef struct avl_dbase avl_dbase
 
typedef struct avw_dbase avw_dbase
 
typedef struct av_relation av_relation
 
typedef struct autovac_table autovac_table
 
typedef struct WorkerInfoData WorkerInfoData
 
typedef struct WorkerInfoDataWorkerInfo
 
typedef struct AutoVacuumWorkItem AutoVacuumWorkItem
 

Enumerations

enum  AutoVacuumSignal { AutoVacForkFailed , AutoVacRebalance }
 

Functions

static Oid do_start_worker (void)
 
static void ProcessAutoVacLauncherInterrupts (void)
 
static pg_noreturn void AutoVacLauncherShutdown (void)
 
static void launcher_determine_sleep (bool canlaunch, bool recursing, struct timeval *nap)
 
static void launch_worker (TimestampTz now)
 
static Listget_database_list (void)
 
static void rebuild_database_list (Oid newdb)
 
static int db_comparator (const void *a, const void *b)
 
static void autovac_recalculate_workers_for_balance (void)
 
static void do_autovacuum (void)
 
static void FreeWorkerInfo (int code, Datum arg)
 
static autovac_tabletable_recheck_autovac (Oid relid, HTAB *table_toast_map, TupleDesc pg_class_desc, int effective_multixact_freeze_max_age)
 
static void recheck_relation_needs_vacanalyze (Oid relid, AutoVacOpts *avopts, Form_pg_class classForm, int effective_multixact_freeze_max_age, bool *dovacuum, bool *doanalyze, bool *wraparound)
 
static void relation_needs_vacanalyze (Oid relid, AutoVacOpts *relopts, Form_pg_class classForm, PgStat_StatTabEntry *tabentry, int effective_multixact_freeze_max_age, bool *dovacuum, bool *doanalyze, bool *wraparound)
 
static void autovacuum_do_vac_analyze (autovac_table *tab, BufferAccessStrategy bstrategy)
 
static AutoVacOptsextract_autovac_opts (HeapTuple tup, TupleDesc pg_class_desc)
 
static void perform_work_item (AutoVacuumWorkItem *workitem)
 
static void autovac_report_activity (autovac_table *tab)
 
static void autovac_report_workitem (AutoVacuumWorkItem *workitem, const char *nspname, const char *relname)
 
static void avl_sigusr2_handler (SIGNAL_ARGS)
 
static bool av_worker_available (void)
 
static void check_av_worker_gucs (void)
 
void AutoVacLauncherMain (const void *startup_data, size_t startup_data_len)
 
void AutoVacWorkerFailed (void)
 
void AutoVacWorkerMain (const void *startup_data, size_t startup_data_len)
 
void VacuumUpdateCosts (void)
 
void AutoVacuumUpdateCostLimit (void)
 
bool AutoVacuumingActive (void)
 
bool AutoVacuumRequestWork (AutoVacuumWorkItemType type, Oid relationId, BlockNumber blkno)
 
void autovac_init (void)
 
Size AutoVacuumShmemSize (void)
 
void AutoVacuumShmemInit (void)
 
bool check_autovacuum_work_mem (int *newval, void **extra, GucSource source)
 

Variables

bool autovacuum_start_daemon = false
 
int autovacuum_worker_slots
 
int autovacuum_max_workers
 
int autovacuum_work_mem = -1
 
int autovacuum_naptime
 
int autovacuum_vac_thresh
 
int autovacuum_vac_max_thresh
 
double autovacuum_vac_scale
 
int autovacuum_vac_ins_thresh
 
double autovacuum_vac_ins_scale
 
int autovacuum_anl_thresh
 
double autovacuum_anl_scale
 
int autovacuum_freeze_max_age
 
int autovacuum_multixact_freeze_max_age
 
double autovacuum_vac_cost_delay
 
int autovacuum_vac_cost_limit
 
int Log_autovacuum_min_duration = 600000
 
int Log_autoanalyze_min_duration = 600000
 
static double av_storage_param_cost_delay = -1
 
static int av_storage_param_cost_limit = -1
 
static volatile sig_atomic_t got_SIGUSR2 = false
 
static TransactionId recentXid
 
static MultiXactId recentMulti
 
static int default_freeze_min_age
 
static int default_freeze_table_age
 
static int default_multixact_freeze_min_age
 
static int default_multixact_freeze_table_age
 
static MemoryContext AutovacMemCxt
 
static AutoVacuumShmemStructAutoVacuumShmem
 
static dlist_head DatabaseList = DLIST_STATIC_INIT(DatabaseList)
 
static MemoryContext DatabaseListCxt = NULL
 
static WorkerInfo MyWorkerInfo = NULL
 

Macro Definition Documentation

◆ AutoVacNumSignals

#define AutoVacNumSignals   (AutoVacRebalance + 1)

Definition at line 255 of file autovacuum.c.

◆ MAX_AUTOVAC_ACTIV_LEN

#define MAX_AUTOVAC_ACTIV_LEN   (NAMEDATALEN * 2 + 56)

◆ MAX_AUTOVAC_SLEEPTIME

#define MAX_AUTOVAC_SLEEPTIME   300 /* seconds */

Definition at line 140 of file autovacuum.c.

◆ MIN_AUTOVAC_SLEEPTIME

#define MIN_AUTOVAC_SLEEPTIME   100.0 /* milliseconds */

Definition at line 139 of file autovacuum.c.

◆ NUM_WORKITEMS

#define NUM_WORKITEMS   256

Definition at line 273 of file autovacuum.c.

Typedef Documentation

◆ autovac_table

◆ AutoVacuumWorkItem

◆ av_relation

◆ avl_dbase

◆ avw_dbase

◆ WorkerInfo

Definition at line 242 of file autovacuum.c.

◆ WorkerInfoData

Enumeration Type Documentation

◆ AutoVacuumSignal

Enumerator
AutoVacForkFailed 
AutoVacRebalance 

Definition at line 249 of file autovacuum.c.

250{
251 AutoVacForkFailed, /* failed trying to start a worker */
252 AutoVacRebalance, /* rebalance the cost limits */
AutoVacuumSignal
Definition autovacuum.c:250
@ AutoVacRebalance
Definition autovacuum.c:252
@ AutoVacForkFailed
Definition autovacuum.c:251

Function Documentation

◆ autovac_init()

void autovac_init ( void  )

Definition at line 3346 of file autovacuum.c.

3347{
3349 return;
3350 else if (!pgstat_track_counts)
3352 (errmsg("autovacuum not started because of misconfiguration"),
3353 errhint("Enable the \"track_counts\" option.")));
3354 else
3356}
static void check_av_worker_gucs(void)
bool autovacuum_start_daemon
Definition autovacuum.c:117
int errhint(const char *fmt,...)
Definition elog.c:1330
int errmsg(const char *fmt,...)
Definition elog.c:1080
#define WARNING
Definition elog.h:36
#define ereport(elevel,...)
Definition elog.h:150
bool pgstat_track_counts
Definition pgstat.c:203

References autovacuum_start_daemon, check_av_worker_gucs(), ereport, errhint(), errmsg(), pgstat_track_counts, and WARNING.

Referenced by PostmasterMain().

◆ autovac_recalculate_workers_for_balance()

static void autovac_recalculate_workers_for_balance ( void  )
static

Definition at line 1761 of file autovacuum.c.

1762{
1763 dlist_iter iter;
1765 int nworkers_for_balance = 0;
1766
1768
1771
1773 {
1774 WorkerInfo worker = dlist_container(WorkerInfoData, wi_links, iter.cur);
1775
1776 if (worker->wi_proc == NULL ||
1778 continue;
1779
1781 }
1782
1786}
static bool pg_atomic_unlocked_test_flag(volatile pg_atomic_flag *ptr)
Definition atomics.h:194
static void pg_atomic_write_u32(volatile pg_atomic_uint32 *ptr, uint32 val)
Definition atomics.h:274
static uint32 pg_atomic_read_u32(volatile pg_atomic_uint32 *ptr)
Definition atomics.h:237
static AutoVacuumShmemStruct * AutoVacuumShmem
Definition autovacuum.c:304
#define Assert(condition)
Definition c.h:873
#define dlist_foreach(iter, lhead)
Definition ilist.h:623
#define dlist_container(type, membername, ptr)
Definition ilist.h:593
bool LWLockHeldByMe(LWLock *lock)
Definition lwlock.c:1911
static int fb(int x)
pg_atomic_uint32 av_nworkersForBalance
Definition autovacuum.c:301
dlist_head av_runningWorkers
Definition autovacuum.c:298
PGPROC * wi_proc
Definition autovacuum.c:236
pg_atomic_flag wi_dobalance
Definition autovacuum.c:238
dlist_node * cur
Definition ilist.h:179

References Assert, AutoVacuumShmem, AutoVacuumShmemStruct::av_nworkersForBalance, AutoVacuumShmemStruct::av_runningWorkers, dlist_iter::cur, dlist_container, dlist_foreach, fb(), LWLockHeldByMe(), pg_atomic_read_u32(), pg_atomic_unlocked_test_flag(), pg_atomic_write_u32(), WorkerInfoData::wi_dobalance, and WorkerInfoData::wi_proc.

Referenced by AutoVacLauncherMain(), and do_autovacuum().

◆ autovac_report_activity()

static void autovac_report_activity ( autovac_table tab)
static

Definition at line 3217 of file autovacuum.c.

3218{
3219#define MAX_AUTOVAC_ACTIV_LEN (NAMEDATALEN * 2 + 56)
3221 int len;
3222
3223 /* Report the command and possible options */
3224 if (tab->at_params.options & VACOPT_VACUUM)
3226 "autovacuum: VACUUM%s",
3227 tab->at_params.options & VACOPT_ANALYZE ? " ANALYZE" : "");
3228 else
3230 "autovacuum: ANALYZE");
3231
3232 /*
3233 * Report the qualified name of the relation.
3234 */
3235 len = strlen(activity);
3236
3238 " %s.%s%s", tab->at_nspname, tab->at_relname,
3239 tab->at_params.is_wraparound ? " (to prevent wraparound)" : "");
3240
3241 /* Set statement_timestamp() to current time for pg_stat_activity */
3243
3245}
#define MAX_AUTOVAC_ACTIV_LEN
void pgstat_report_activity(BackendState state, const char *cmd_str)
@ STATE_RUNNING
const void size_t len
#define snprintf
Definition port.h:260
bits32 options
Definition vacuum.h:219
bool is_wraparound
Definition vacuum.h:226
char * at_nspname
Definition autovacuum.c:209
char * at_relname
Definition autovacuum.c:208
VacuumParams at_params
Definition autovacuum.c:203
#define VACOPT_VACUUM
Definition vacuum.h:180
#define VACOPT_ANALYZE
Definition vacuum.h:181
void SetCurrentStatementStartTimestamp(void)
Definition xact.c:915

References autovac_table::at_nspname, autovac_table::at_params, autovac_table::at_relname, fb(), VacuumParams::is_wraparound, len, MAX_AUTOVAC_ACTIV_LEN, VacuumParams::options, pgstat_report_activity(), SetCurrentStatementStartTimestamp(), snprintf, STATE_RUNNING, VACOPT_ANALYZE, and VACOPT_VACUUM.

Referenced by autovacuum_do_vac_analyze().

◆ autovac_report_workitem()

static void autovac_report_workitem ( AutoVacuumWorkItem workitem,
const char nspname,
const char relname 
)
static

Definition at line 3252 of file autovacuum.c.

3254{
3255 char activity[MAX_AUTOVAC_ACTIV_LEN + 12 + 2];
3256 char blk[12 + 2];
3257 int len;
3258
3259 switch (workitem->avw_type)
3260 {
3263 "autovacuum: BRIN summarize");
3264 break;
3265 }
3266
3267 /*
3268 * Report the qualified name of the relation, and the block number if any
3269 */
3270 len = strlen(activity);
3271
3272 if (BlockNumberIsValid(workitem->avw_blockNumber))
3273 snprintf(blk, sizeof(blk), " %u", workitem->avw_blockNumber);
3274 else
3275 blk[0] = '\0';
3276
3278 " %s.%s%s", nspname, relname, blk);
3279
3280 /* Set statement_timestamp() to current time for pg_stat_activity */
3282
3284}
@ AVW_BRINSummarizeRange
Definition autovacuum.h:25
static bool BlockNumberIsValid(BlockNumber blockNumber)
Definition block.h:71
NameData relname
Definition pg_class.h:38

References AVW_BRINSummarizeRange, BlockNumberIsValid(), fb(), len, MAX_AUTOVAC_ACTIV_LEN, pgstat_report_activity(), relname, SetCurrentStatementStartTimestamp(), snprintf, and STATE_RUNNING.

Referenced by perform_work_item().

◆ AutoVacLauncherMain()

void AutoVacLauncherMain ( const void startup_data,
size_t  startup_data_len 
)

Definition at line 375 of file autovacuum.c.

376{
378
380
381 /* Release postmaster's working memory context */
383 {
386 }
387
390
392 (errmsg_internal("autovacuum launcher started")));
393
394 if (PostAuthDelay)
395 pg_usleep(PostAuthDelay * 1000000L);
396
398
399 /*
400 * Set up signal handlers. We operate on databases much like a regular
401 * backend, so we use the same signal handling. See equivalent code in
402 * tcop/postgres.c.
403 */
407 /* SIGQUIT handler was already set up by InitPostmasterChild */
408
409 InitializeTimeouts(); /* establishes SIGALRM handler */
410
416
417 /*
418 * Create a per-backend PGPROC struct in shared memory. We must do this
419 * before we can use LWLocks or access any shared memory.
420 */
421 InitProcess();
422
423 /* Early initialization */
424 BaseInit();
425
427
429
430 /*
431 * Create a memory context that we will do all our work in. We do this so
432 * that we can reset the context during error recovery and thereby avoid
433 * possible memory leaks.
434 */
436 "Autovacuum Launcher",
439
440 /*
441 * If an exception is encountered, processing resumes here.
442 *
443 * This code is a stripped down version of PostgresMain error recovery.
444 *
445 * Note that we use sigsetjmp(..., 1), so that the prevailing signal mask
446 * (to wit, BlockSig) will be restored when longjmp'ing to here. Thus,
447 * signals other than SIGQUIT will be blocked until we complete error
448 * recovery. It might seem that this policy makes the HOLD_INTERRUPTS()
449 * call redundant, but it is not since InterruptPending might be set
450 * already.
451 */
452 if (sigsetjmp(local_sigjmp_buf, 1) != 0)
453 {
454 /* since not using PG_TRY, must reset error stack by hand */
456
457 /* Prevents interrupts while cleaning up */
459
460 /* Forget any pending QueryCancel or timeout request */
462 QueryCancelPending = false; /* second to avoid race condition */
463
464 /* Report the error to the server log */
466
467 /* Abort the current transaction in order to recover */
469
470 /*
471 * Release any other resources, for the case where we were not in a
472 * transaction.
473 */
478 /* this is probably dead code, but let's be safe: */
481 AtEOXact_Buffers(false);
483 AtEOXact_Files(false);
484 AtEOXact_HashTables(false);
485
486 /*
487 * Now return to normal top-level context and clear ErrorContext for
488 * next time.
489 */
492
493 /* Flush any leaked data in the top-level context */
495
496 /* don't leave dangling pointers to freed memory */
499
500 /* Now we can allow interrupts again */
502
503 /* if in shutdown mode, no need for anything further; just go away */
506
507 /*
508 * Sleep at least 1 second after any error. We don't want to be
509 * filling the error logs as fast as we can.
510 */
511 pg_usleep(1000000L);
512 }
513
514 /* We can now handle ereport(ERROR) */
516
517 /* must unblock signals before calling rebuild_database_list */
519
520 /*
521 * Set always-secure search path. Launcher doesn't connect to a database,
522 * so this has no effect.
523 */
524 SetConfigOption("search_path", "", PGC_SUSET, PGC_S_OVERRIDE);
525
526 /*
527 * Force zero_damaged_pages OFF in the autovac process, even if it is set
528 * in postgresql.conf. We don't really want such a dangerous option being
529 * applied non-interactively.
530 */
531 SetConfigOption("zero_damaged_pages", "false", PGC_SUSET, PGC_S_OVERRIDE);
532
533 /*
534 * Force settable timeouts off to avoid letting these settings prevent
535 * regular maintenance from being executed.
536 */
537 SetConfigOption("statement_timeout", "0", PGC_SUSET, PGC_S_OVERRIDE);
538 SetConfigOption("transaction_timeout", "0", PGC_SUSET, PGC_S_OVERRIDE);
539 SetConfigOption("lock_timeout", "0", PGC_SUSET, PGC_S_OVERRIDE);
540 SetConfigOption("idle_in_transaction_session_timeout", "0",
542
543 /*
544 * Force default_transaction_isolation to READ COMMITTED. We don't want
545 * to pay the overhead of serializable mode, nor add any risk of causing
546 * deadlocks or delaying other transactions.
547 */
548 SetConfigOption("default_transaction_isolation", "read committed",
550
551 /*
552 * Even when system is configured to use a different fetch consistency,
553 * for autovac we always want fresh stats.
554 */
555 SetConfigOption("stats_fetch_consistency", "none", PGC_SUSET, PGC_S_OVERRIDE);
556
557 /*
558 * In emergency mode, just start a worker (unless shutdown was requested)
559 * and go away.
560 */
561 if (!AutoVacuumingActive())
562 {
565 proc_exit(0); /* done */
566 }
567
569
570 /*
571 * Create the initial database list. The invariant we want this list to
572 * keep is that it's ordered by decreasing next_worker. As soon as an
573 * entry is updated to a higher time, it will be moved to the front (which
574 * is correct because the only operation is to add autovacuum_naptime to
575 * the entry, and time always increases).
576 */
578
579 /* loop until shutdown request */
581 {
582 struct timeval nap;
584 bool can_launch;
585
586 /*
587 * This loop is a bit different from the normal use of WaitLatch,
588 * because we'd like to sleep before the first launch of a child
589 * process. So it's WaitLatch, then ResetLatch, then check for
590 * wakening conditions.
591 */
592
594
595 /*
596 * Wait until naptime expires or we get some type of signal (all the
597 * signal handlers will wake us by calling SetLatch).
598 */
601 (nap.tv_sec * 1000L) + (nap.tv_usec / 1000L),
603
605
607
608 /*
609 * a worker finished, or postmaster signaled failure to start a worker
610 */
611 if (got_SIGUSR2)
612 {
613 got_SIGUSR2 = false;
614
615 /* rebalance cost limits, if needed */
617 {
622 }
623
625 {
626 /*
627 * If the postmaster failed to start a new worker, we sleep
628 * for a little while and resend the signal. The new worker's
629 * state is still in memory, so this is sufficient. After
630 * that, we restart the main loop.
631 *
632 * XXX should we put a limit to the number of times we retry?
633 * I don't think it makes much sense, because a future start
634 * of a worker will continue to fail in the same way.
635 */
637 pg_usleep(1000000L); /* 1s */
639 continue;
640 }
641 }
642
643 /*
644 * There are some conditions that we need to check before trying to
645 * start a worker. First, we need to make sure that there is a worker
646 * slot available. Second, we need to make sure that no other worker
647 * failed while starting up.
648 */
649
652
654
656 {
657 int waittime;
659
660 /*
661 * We can't launch another worker when another one is still
662 * starting up (or failed while doing so), so just sleep for a bit
663 * more; that worker will wake us up again as soon as it's ready.
664 * We will only wait autovacuum_naptime seconds (up to a maximum
665 * of 60 seconds) for this to happen however. Note that failure
666 * to connect to a particular database is not a problem here,
667 * because the worker removes itself from the startingWorker
668 * pointer before trying to connect. Problems detected by the
669 * postmaster (like fork() failure) are also reported and handled
670 * differently. The only problems that may cause this code to
671 * fire are errors in the earlier sections of AutoVacWorkerMain,
672 * before the worker removes the WorkerInfo from the
673 * startingWorker pointer.
674 */
675 waittime = Min(autovacuum_naptime, 60) * 1000;
677 waittime))
678 {
681
682 /*
683 * No other process can put a worker in starting mode, so if
684 * startingWorker is still INVALID after exchanging our lock,
685 * we assume it's the same one we saw above (so we don't
686 * recheck the launch time).
687 */
689 {
691 worker->wi_dboid = InvalidOid;
692 worker->wi_tableoid = InvalidOid;
693 worker->wi_sharedrel = false;
694 worker->wi_proc = NULL;
695 worker->wi_launchtime = 0;
697 &worker->wi_links);
700 errmsg("autovacuum worker took too long to start; canceled"));
701 }
702 }
703 else
704 can_launch = false;
705 }
706 LWLockRelease(AutovacuumLock); /* either shared or exclusive */
707
708 /* if we can't do anything, just go back to sleep */
709 if (!can_launch)
710 continue;
711
712 /* We're OK to start a new worker */
713
715 {
716 /*
717 * Special case when the list is empty: start a worker right away.
718 * This covers the initial case, when no database is in pgstats
719 * (thus the list is empty). Note that the constraints in
720 * launcher_determine_sleep keep us from starting workers too
721 * quickly (at most once every autovacuum_naptime when the list is
722 * empty).
723 */
725 }
726 else
727 {
728 /*
729 * because rebuild_database_list constructs a list with most
730 * distant adl_next_worker first, we obtain our database from the
731 * tail of the list.
732 */
734
736
737 /*
738 * launch a worker if next_worker is right now or it is in the
739 * past
740 */
741 if (TimestampDifferenceExceeds(avdb->adl_next_worker,
742 current_time, 0))
744 }
745 }
746
748}
void pgaio_error_cleanup(void)
Definition aio.c:1165
static Oid do_start_worker(void)
static void launcher_determine_sleep(bool canlaunch, bool recursing, struct timeval *nap)
Definition autovacuum.c:816
static volatile sig_atomic_t got_SIGUSR2
Definition autovacuum.c:155
static void avl_sigusr2_handler(SIGNAL_ARGS)
static bool av_worker_available(void)
int autovacuum_naptime
Definition autovacuum.c:121
bool AutoVacuumingActive(void)
static pg_noreturn void AutoVacLauncherShutdown(void)
Definition autovacuum.c:799
static void launch_worker(TimestampTz now)
static dlist_head DatabaseList
Definition autovacuum.c:310
static void rebuild_database_list(Oid newdb)
Definition autovacuum.c:900
static MemoryContext DatabaseListCxt
Definition autovacuum.c:311
static void autovac_recalculate_workers_for_balance(void)
static MemoryContext AutovacMemCxt
Definition autovacuum.c:168
static void ProcessAutoVacLauncherInterrupts(void)
Definition autovacuum.c:754
sigset_t UnBlockSig
Definition pqsignal.c:22
bool TimestampDifferenceExceeds(TimestampTz start_time, TimestampTz stop_time, int msec)
Definition timestamp.c:1781
TimestampTz GetCurrentTimestamp(void)
Definition timestamp.c:1645
void AtEOXact_Buffers(bool isCommit)
Definition bufmgr.c:4103
void UnlockBuffers(void)
Definition bufmgr.c:5709
#define Min(x, y)
Definition c.h:997
int64 TimestampTz
Definition timestamp.h:39
void AtEOXact_HashTables(bool isCommit)
Definition dynahash.c:1931
int errmsg_internal(const char *fmt,...)
Definition elog.c:1170
void EmitErrorReport(void)
Definition elog.c:1704
ErrorContextCallback * error_context_stack
Definition elog.c:95
void FlushErrorState(void)
Definition elog.c:1884
sigjmp_buf * PG_exception_stack
Definition elog.c:97
#define DEBUG1
Definition elog.h:30
void AtEOXact_Files(bool isCommit)
Definition fd.c:3210
int MyProcPid
Definition globals.c:47
volatile sig_atomic_t QueryCancelPending
Definition globals.c:33
struct Latch * MyLatch
Definition globals.c:63
void SetConfigOption(const char *name, const char *value, GucContext context, GucSource source)
Definition guc.c:4196
@ PGC_S_OVERRIDE
Definition guc.h:123
@ PGC_SUSET
Definition guc.h:78
static void dlist_init(dlist_head *head)
Definition ilist.h:314
#define dlist_tail_element(type, membername, lhead)
Definition ilist.h:612
static bool dlist_is_empty(const dlist_head *head)
Definition ilist.h:336
static void dclist_push_head(dclist_head *head, dlist_node *node)
Definition ilist.h:693
void SignalHandlerForShutdownRequest(SIGNAL_ARGS)
Definition interrupt.c:104
volatile sig_atomic_t ShutdownRequestPending
Definition interrupt.c:28
void SignalHandlerForConfigReload(SIGNAL_ARGS)
Definition interrupt.c:61
void proc_exit(int code)
Definition ipc.c:105
void ResetLatch(Latch *latch)
Definition latch.c:374
int WaitLatch(Latch *latch, int wakeEvents, long timeout, uint32 wait_event_info)
Definition latch.c:172
bool LWLockAcquire(LWLock *lock, LWLockMode mode)
Definition lwlock.c:1176
void LWLockRelease(LWLock *lock)
Definition lwlock.c:1793
void LWLockReleaseAll(void)
Definition lwlock.c:1892
@ LW_SHARED
Definition lwlock.h:113
@ LW_EXCLUSIVE
Definition lwlock.h:112
void MemoryContextReset(MemoryContext context)
Definition mcxt.c:403
MemoryContext TopMemoryContext
Definition mcxt.c:166
MemoryContext PostmasterContext
Definition mcxt.c:168
void MemoryContextDelete(MemoryContext context)
Definition mcxt.c:472
#define AllocSetContextCreate
Definition memutils.h:129
#define ALLOCSET_DEFAULT_SIZES
Definition memutils.h:160
#define RESUME_INTERRUPTS()
Definition miscadmin.h:136
@ NormalProcessing
Definition miscadmin.h:472
@ InitProcessing
Definition miscadmin.h:471
#define GetProcessingMode()
Definition miscadmin.h:481
#define HOLD_INTERRUPTS()
Definition miscadmin.h:134
#define SetProcessingMode(mode)
Definition miscadmin.h:483
@ B_AUTOVAC_LAUNCHER
Definition miscadmin.h:344
BackendType MyBackendType
Definition miscinit.c:64
static MemoryContext MemoryContextSwitchTo(MemoryContext context)
Definition palloc.h:124
void SendPostmasterSignal(PMSignalReason reason)
Definition pmsignal.c:165
@ PMSIGNAL_START_AUTOVAC_WORKER
Definition pmsignal.h:40
#define pqsignal
Definition port.h:547
int PostAuthDelay
Definition postgres.c:100
void FloatExceptionHandler(SIGNAL_ARGS)
Definition postgres.c:3079
void StatementCancelHandler(SIGNAL_ARGS)
Definition postgres.c:3062
#define InvalidOid
void BaseInit(void)
Definition postinit.c:607
void InitPostgres(const char *in_dbname, Oid dboid, const char *username, Oid useroid, bits32 flags, char *out_dbname)
Definition postinit.c:710
void procsignal_sigusr1_handler(SIGNAL_ARGS)
Definition procsignal.c:677
void init_ps_display(const char *fixed_part)
Definition ps_status.c:285
void ReleaseAuxProcessResources(bool isCommit)
Definition resowner.c:1016
ResourceOwner AuxProcessResourceOwner
Definition resowner.c:176
void pg_usleep(long microsec)
Definition signal.c:53
void AtEOXact_SMgr(void)
Definition smgr.c:1017
void InitProcess(void)
Definition proc.c:395
dclist_head av_freeWorkers
Definition autovacuum.c:297
WorkerInfo av_startingWorker
Definition autovacuum.c:299
sig_atomic_t av_signal[AutoVacNumSignals]
Definition autovacuum.c:295
TimestampTz wi_launchtime
Definition autovacuum.c:237
dlist_node wi_links
Definition autovacuum.c:233
void disable_all_timeouts(bool keep_indicators)
Definition timeout.c:751
void InitializeTimeouts(void)
Definition timeout.c:470
static void pgstat_report_wait_end(void)
Definition wait_event.h:85
#define WL_TIMEOUT
#define WL_EXIT_ON_PM_DEATH
#define WL_LATCH_SET
#define SIGCHLD
Definition win32_port.h:168
#define SIGHUP
Definition win32_port.h:158
#define SIGPIPE
Definition win32_port.h:163
#define SIGUSR1
Definition win32_port.h:170
#define SIGUSR2
Definition win32_port.h:171
void AbortCurrentTransaction(void)
Definition xact.c:3472

References AbortCurrentTransaction(), ALLOCSET_DEFAULT_SIZES, AllocSetContextCreate, Assert, AtEOXact_Buffers(), AtEOXact_Files(), AtEOXact_HashTables(), AtEOXact_SMgr(), autovac_recalculate_workers_for_balance(), AutoVacForkFailed, AutoVacLauncherShutdown(), AutovacMemCxt, AutoVacRebalance, autovacuum_naptime, AutoVacuumingActive(), AutoVacuumShmem, AuxProcessResourceOwner, AutoVacuumShmemStruct::av_freeWorkers, AutoVacuumShmemStruct::av_launcherpid, AutoVacuumShmemStruct::av_signal, AutoVacuumShmemStruct::av_startingWorker, av_worker_available(), avl_sigusr2_handler(), B_AUTOVAC_LAUNCHER, BaseInit(), DatabaseList, DatabaseListCxt, dclist_push_head(), DEBUG1, disable_all_timeouts(), dlist_init(), dlist_is_empty(), dlist_tail_element, do_start_worker(), EmitErrorReport(), ereport, errmsg(), errmsg_internal(), error_context_stack, fb(), FloatExceptionHandler(), FlushErrorState(), GetCurrentTimestamp(), GetProcessingMode, got_SIGUSR2, HOLD_INTERRUPTS, init_ps_display(), InitializeTimeouts(), InitPostgres(), InitProcess(), InitProcessing, InvalidOid, launch_worker(), launcher_determine_sleep(), LW_EXCLUSIVE, LW_SHARED, LWLockAcquire(), LWLockRelease(), LWLockReleaseAll(), MemoryContextDelete(), MemoryContextReset(), MemoryContextSwitchTo(), Min, MyBackendType, MyLatch, MyProcPid, NormalProcessing, PG_exception_stack, pg_usleep(), pgaio_error_cleanup(), PGC_S_OVERRIDE, PGC_SUSET, pgstat_report_wait_end(), PMSIGNAL_START_AUTOVAC_WORKER, PostAuthDelay, PostmasterContext, pqsignal, proc_exit(), ProcessAutoVacLauncherInterrupts(), procsignal_sigusr1_handler(), QueryCancelPending, rebuild_database_list(), ReleaseAuxProcessResources(), ResetLatch(), RESUME_INTERRUPTS, SendPostmasterSignal(), SetConfigOption(), SetProcessingMode, ShutdownRequestPending, SIGCHLD, SIGHUP, SignalHandlerForConfigReload(), SignalHandlerForShutdownRequest(), SIGPIPE, SIGUSR1, SIGUSR2, StatementCancelHandler(), TimestampDifferenceExceeds(), TopMemoryContext, UnBlockSig, UnlockBuffers(), WaitLatch(), WARNING, WorkerInfoData::wi_dboid, WorkerInfoData::wi_launchtime, WorkerInfoData::wi_links, WorkerInfoData::wi_proc, WorkerInfoData::wi_sharedrel, WorkerInfoData::wi_tableoid, WL_EXIT_ON_PM_DEATH, WL_LATCH_SET, and WL_TIMEOUT.

◆ AutoVacLauncherShutdown()

static void AutoVacLauncherShutdown ( void  )
static

Definition at line 799 of file autovacuum.c.

800{
802 (errmsg_internal("autovacuum launcher shutting down")));
804
805 proc_exit(0); /* done */
806}

References AutoVacuumShmem, AutoVacuumShmemStruct::av_launcherpid, DEBUG1, ereport, errmsg_internal(), and proc_exit().

Referenced by AutoVacLauncherMain(), and ProcessAutoVacLauncherInterrupts().

◆ autovacuum_do_vac_analyze()

static void autovacuum_do_vac_analyze ( autovac_table tab,
BufferAccessStrategy  bstrategy 
)
static

Definition at line 3177 of file autovacuum.c.

3178{
3180 VacuumRelation *rel;
3181 List *rel_list;
3184
3185 /* Let pgstat know what we're doing */
3187
3188 /* Create a context that vacuum() can use as cross-transaction storage */
3190 "Vacuum",
3192
3193 /* Set up one VacuumRelation target, identified by OID, for vacuum() */
3195 rangevar = makeRangeVar(tab->at_nspname, tab->at_relname, -1);
3197 rel_list = list_make1(rel);
3199
3200 vacuum(rel_list, tab->at_params, bstrategy, vac_context, true);
3201
3203}
static void autovac_report_activity(autovac_table *tab)
VacuumRelation * makeVacuumRelation(RangeVar *relation, Oid oid, List *va_cols)
Definition makefuncs.c:907
RangeVar * makeRangeVar(char *schemaname, char *relname, int location)
Definition makefuncs.c:473
MemoryContext CurrentMemoryContext
Definition mcxt.c:160
#define NIL
Definition pg_list.h:68
#define list_make1(x1)
Definition pg_list.h:212
Definition pg_list.h:54
void vacuum(List *relations, const VacuumParams params, BufferAccessStrategy bstrategy, MemoryContext vac_context, bool isTopLevel)
Definition vacuum.c:494

References ALLOCSET_DEFAULT_SIZES, AllocSetContextCreate, autovac_table::at_nspname, autovac_table::at_params, autovac_table::at_relid, autovac_table::at_relname, autovac_report_activity(), CurrentMemoryContext, fb(), list_make1, makeRangeVar(), makeVacuumRelation(), MemoryContextDelete(), MemoryContextSwitchTo(), NIL, and vacuum().

Referenced by do_autovacuum().

◆ AutoVacuumingActive()

bool AutoVacuumingActive ( void  )

◆ AutoVacuumRequestWork()

bool AutoVacuumRequestWork ( AutoVacuumWorkItemType  type,
Oid  relationId,
BlockNumber  blkno 
)

Definition at line 3304 of file autovacuum.c.

3306{
3307 int i;
3308 bool result = false;
3309
3311
3312 /*
3313 * Locate an unused work item and fill it with the given data.
3314 */
3315 for (i = 0; i < NUM_WORKITEMS; i++)
3316 {
3318
3319 if (workitem->avw_used)
3320 continue;
3321
3322 workitem->avw_used = true;
3323 workitem->avw_active = false;
3324 workitem->avw_type = type;
3325 workitem->avw_database = MyDatabaseId;
3326 workitem->avw_relation = relationId;
3327 workitem->avw_blockNumber = blkno;
3328 result = true;
3329
3330 /* done */
3331 break;
3332 }
3333
3335
3336 return result;
3337}
#define NUM_WORKITEMS
Definition autovacuum.c:273
Oid MyDatabaseId
Definition globals.c:94
int i
Definition isn.c:77
AutoVacuumWorkItem av_workItems[NUM_WORKITEMS]
Definition autovacuum.c:300
const char * type

References AutoVacuumShmem, AutoVacuumShmemStruct::av_workItems, AutoVacuumWorkItem::avw_used, fb(), i, LW_EXCLUSIVE, LWLockAcquire(), LWLockRelease(), MyDatabaseId, NUM_WORKITEMS, and type.

Referenced by brininsert().

◆ AutoVacuumShmemInit()

void AutoVacuumShmemInit ( void  )

Definition at line 3382 of file autovacuum.c.

3383{
3384 bool found;
3385
3387 ShmemInitStruct("AutoVacuum Data",
3389 &found);
3390
3391 if (!IsUnderPostmaster)
3392 {
3393 WorkerInfo worker;
3394 int i;
3395
3396 Assert(!found);
3397
3404
3405 worker = (WorkerInfo) ((char *) AutoVacuumShmem +
3407
3408 /* initialize the WorkerInfo free list */
3409 for (i = 0; i < autovacuum_worker_slots; i++)
3410 {
3412 &worker[i].wi_links);
3413 pg_atomic_init_flag(&worker[i].wi_dobalance);
3414 }
3415
3417
3418 }
3419 else
3420 Assert(found);
3421}
static void pg_atomic_init_u32(volatile pg_atomic_uint32 *ptr, uint32 val)
Definition atomics.h:219
static void pg_atomic_init_flag(volatile pg_atomic_flag *ptr)
Definition atomics.h:168
int autovacuum_worker_slots
Definition autovacuum.c:118
Size AutoVacuumShmemSize(void)
struct WorkerInfoData * WorkerInfo
Definition autovacuum.c:242
#define MAXALIGN(LEN)
Definition c.h:826
bool IsUnderPostmaster
Definition globals.c:120
static void dclist_init(dclist_head *head)
Definition ilist.h:671
void * ShmemInitStruct(const char *name, Size size, bool *foundPtr)
Definition shmem.c:389

References Assert, autovacuum_worker_slots, AutoVacuumShmem, AutoVacuumShmemSize(), AutoVacuumShmemStruct::av_freeWorkers, AutoVacuumShmemStruct::av_launcherpid, AutoVacuumShmemStruct::av_nworkersForBalance, AutoVacuumShmemStruct::av_runningWorkers, AutoVacuumShmemStruct::av_startingWorker, AutoVacuumShmemStruct::av_workItems, dclist_init(), dclist_push_head(), dlist_init(), fb(), i, IsUnderPostmaster, MAXALIGN, NUM_WORKITEMS, pg_atomic_init_flag(), pg_atomic_init_u32(), ShmemInitStruct(), and WorkerInfoData::wi_links.

Referenced by CreateOrAttachShmemStructs().

◆ AutoVacuumShmemSize()

Size AutoVacuumShmemSize ( void  )

Definition at line 3363 of file autovacuum.c.

3364{
3365 Size size;
3366
3367 /*
3368 * Need the fixed struct and the array of WorkerInfoData.
3369 */
3370 size = sizeof(AutoVacuumShmemStruct);
3371 size = MAXALIGN(size);
3373 sizeof(WorkerInfoData)));
3374 return size;
3375}
size_t Size
Definition c.h:619
Size add_size(Size s1, Size s2)
Definition shmem.c:495
Size mul_size(Size s1, Size s2)
Definition shmem.c:510

References add_size(), autovacuum_worker_slots, MAXALIGN, and mul_size().

Referenced by AutoVacuumShmemInit(), and CalculateShmemSize().

◆ AutoVacuumUpdateCostLimit()

void AutoVacuumUpdateCostLimit ( void  )

Definition at line 1715 of file autovacuum.c.

1716{
1717 if (!MyWorkerInfo)
1718 return;
1719
1720 /*
1721 * note: in cost_limit, zero also means use value from elsewhere, because
1722 * zero is not a valid value.
1723 */
1724
1727 else
1728 {
1730
1733 else
1735
1736 /* Only balance limit if no cost-related storage parameters specified */
1738 return;
1739
1741
1743
1744 /* There is at least 1 autovac worker (this worker) */
1745 if (nworkers_for_balance <= 0)
1746 elog(ERROR, "nworkers_for_balance must be > 0");
1747
1749 }
1750}
int autovacuum_vac_cost_limit
Definition autovacuum.c:133
static int av_storage_param_cost_limit
Definition autovacuum.c:152
static WorkerInfo MyWorkerInfo
Definition autovacuum.c:324
#define Max(x, y)
Definition c.h:991
#define ERROR
Definition elog.h:39
#define elog(elevel,...)
Definition elog.h:226
int VacuumCostLimit
Definition globals.c:154
int vacuum_cost_limit
Definition vacuum.c:92

References Assert, autovacuum_vac_cost_limit, AutoVacuumShmem, AutoVacuumShmemStruct::av_nworkersForBalance, av_storage_param_cost_limit, elog, ERROR, fb(), Max, MyWorkerInfo, pg_atomic_read_u32(), pg_atomic_unlocked_test_flag(), vacuum_cost_limit, VacuumCostLimit, and WorkerInfoData::wi_dobalance.

Referenced by vacuum_delay_point(), and VacuumUpdateCosts().

◆ AutoVacWorkerFailed()

void AutoVacWorkerFailed ( void  )

Definition at line 1365 of file autovacuum.c.

1366{
1368}

References AutoVacForkFailed, AutoVacuumShmem, and AutoVacuumShmemStruct::av_signal.

Referenced by StartAutovacuumWorker().

◆ AutoVacWorkerMain()

void AutoVacWorkerMain ( const void startup_data,
size_t  startup_data_len 
)

Definition at line 1387 of file autovacuum.c.

1388{
1390 Oid dbid;
1391
1393
1394 /* Release postmaster's working memory context */
1396 {
1399 }
1400
1403
1405
1406 /*
1407 * Set up signal handlers. We operate on databases much like a regular
1408 * backend, so we use the same signal handling. See equivalent code in
1409 * tcop/postgres.c.
1410 */
1412
1413 /*
1414 * SIGINT is used to signal canceling the current table's vacuum; SIGTERM
1415 * means abort and exit cleanly, and SIGQUIT means abandon ship.
1416 */
1419 /* SIGQUIT handler was already set up by InitPostmasterChild */
1420
1421 InitializeTimeouts(); /* establishes SIGALRM handler */
1422
1428
1429 /*
1430 * Create a per-backend PGPROC struct in shared memory. We must do this
1431 * before we can use LWLocks or access any shared memory.
1432 */
1433 InitProcess();
1434
1435 /* Early initialization */
1436 BaseInit();
1437
1438 /*
1439 * If an exception is encountered, processing resumes here.
1440 *
1441 * Unlike most auxiliary processes, we don't attempt to continue
1442 * processing after an error; we just clean up and exit. The autovac
1443 * launcher is responsible for spawning another worker later.
1444 *
1445 * Note that we use sigsetjmp(..., 1), so that the prevailing signal mask
1446 * (to wit, BlockSig) will be restored when longjmp'ing to here. Thus,
1447 * signals other than SIGQUIT will be blocked until we exit. It might
1448 * seem that this policy makes the HOLD_INTERRUPTS() call redundant, but
1449 * it is not since InterruptPending might be set already.
1450 */
1451 if (sigsetjmp(local_sigjmp_buf, 1) != 0)
1452 {
1453 /* since not using PG_TRY, must reset error stack by hand */
1455
1456 /* Prevents interrupts while cleaning up */
1458
1459 /* Report the error to the server log */
1461
1462 /*
1463 * We can now go away. Note that because we called InitProcess, a
1464 * callback was registered to do ProcKill, which will clean up
1465 * necessary state.
1466 */
1467 proc_exit(0);
1468 }
1469
1470 /* We can now handle ereport(ERROR) */
1472
1474
1475 /*
1476 * Set always-secure search path, so malicious users can't redirect user
1477 * code (e.g. pg_index.indexprs). (That code runs in a
1478 * SECURITY_RESTRICTED_OPERATION sandbox, so malicious users could not
1479 * take control of the entire autovacuum worker in any case.)
1480 */
1481 SetConfigOption("search_path", "", PGC_SUSET, PGC_S_OVERRIDE);
1482
1483 /*
1484 * Force zero_damaged_pages OFF in the autovac process, even if it is set
1485 * in postgresql.conf. We don't really want such a dangerous option being
1486 * applied non-interactively.
1487 */
1488 SetConfigOption("zero_damaged_pages", "false", PGC_SUSET, PGC_S_OVERRIDE);
1489
1490 /*
1491 * Force settable timeouts off to avoid letting these settings prevent
1492 * regular maintenance from being executed.
1493 */
1494 SetConfigOption("statement_timeout", "0", PGC_SUSET, PGC_S_OVERRIDE);
1495 SetConfigOption("transaction_timeout", "0", PGC_SUSET, PGC_S_OVERRIDE);
1496 SetConfigOption("lock_timeout", "0", PGC_SUSET, PGC_S_OVERRIDE);
1497 SetConfigOption("idle_in_transaction_session_timeout", "0",
1499
1500 /*
1501 * Force default_transaction_isolation to READ COMMITTED. We don't want
1502 * to pay the overhead of serializable mode, nor add any risk of causing
1503 * deadlocks or delaying other transactions.
1504 */
1505 SetConfigOption("default_transaction_isolation", "read committed",
1507
1508 /*
1509 * Force synchronous replication off to allow regular maintenance even if
1510 * we are waiting for standbys to connect. This is important to ensure we
1511 * aren't blocked from performing anti-wraparound tasks.
1512 */
1514 SetConfigOption("synchronous_commit", "local",
1516
1517 /*
1518 * Even when system is configured to use a different fetch consistency,
1519 * for autovac we always want fresh stats.
1520 */
1521 SetConfigOption("stats_fetch_consistency", "none", PGC_SUSET, PGC_S_OVERRIDE);
1522
1523 /*
1524 * Get the info about the database we're going to work on.
1525 */
1527
1528 /*
1529 * beware of startingWorker being INVALID; this should normally not
1530 * happen, but if a worker fails after forking and before this, the
1531 * launcher might have decided to remove it from the queue and start
1532 * again.
1533 */
1535 {
1537 dbid = MyWorkerInfo->wi_dboid;
1539
1540 /* insert into the running list */
1543
1544 /*
1545 * remove from the "starting" pointer, so that the launcher can start
1546 * a new worker if required
1547 */
1550
1552
1553 /* wake up the launcher */
1556 }
1557 else
1558 {
1559 /* no worker entry for me, go away */
1560 elog(WARNING, "autovacuum worker started without a worker entry");
1561 dbid = InvalidOid;
1563 }
1564
1565 if (OidIsValid(dbid))
1566 {
1567 char dbname[NAMEDATALEN];
1568
1569 /*
1570 * Report autovac startup to the cumulative stats system. We
1571 * deliberately do this before InitPostgres, so that the
1572 * last_autovac_time will get updated even if the connection attempt
1573 * fails. This is to prevent autovac from getting "stuck" repeatedly
1574 * selecting an unopenable database, rather than making any progress
1575 * on stuff it can connect to.
1576 */
1578
1579 /*
1580 * Connect to the selected database, specifying no particular user,
1581 * and ignoring datallowconn. Collect the database's name for
1582 * display.
1583 *
1584 * Note: if we have selected a just-deleted database (due to using
1585 * stale stats info), we'll fail and exit here.
1586 */
1589 dbname);
1593 (errmsg_internal("autovacuum: processing database \"%s\"", dbname)));
1594
1595 if (PostAuthDelay)
1596 pg_usleep(PostAuthDelay * 1000000L);
1597
1598 /* And do an appropriate amount of work */
1601 do_autovacuum();
1602 }
1603
1604 /* All done, go away */
1605 proc_exit(0);
1606}
static void FreeWorkerInfo(int code, Datum arg)
static TransactionId recentXid
Definition autovacuum.c:158
static void do_autovacuum(void)
static MultiXactId recentMulti
Definition autovacuum.c:159
#define OidIsValid(objectId)
Definition c.h:788
static void dlist_push_head(dlist_head *head, dlist_node *node)
Definition ilist.h:347
void on_shmem_exit(pg_on_exit_callback function, Datum arg)
Definition ipc.c:372
@ B_AUTOVAC_WORKER
Definition miscadmin.h:345
#define INIT_PG_OVERRIDE_ALLOW_CONNS
Definition miscadmin.h:500
MultiXactId ReadNextMultiXactId(void)
Definition multixact.c:620
#define NAMEDATALEN
#define die(msg)
void pgstat_report_autovac(Oid dboid)
unsigned int Oid
static void set_ps_display(const char *activity)
Definition ps_status.h:40
PGPROC * MyProc
Definition proc.c:67
char * dbname
Definition streamutil.c:49
static TransactionId ReadNextTransactionId(void)
Definition transam.h:377
#define kill(pid, sig)
Definition win32_port.h:490
int synchronous_commit
Definition xact.c:88
@ SYNCHRONOUS_COMMIT_LOCAL_FLUSH
Definition xact.h:72

References Assert, AutoVacuumShmem, AutoVacuumShmemStruct::av_launcherpid, AutoVacuumShmemStruct::av_runningWorkers, AutoVacuumShmemStruct::av_startingWorker, B_AUTOVAC_WORKER, BaseInit(), dbname, DEBUG1, die, dlist_push_head(), do_autovacuum(), elog, EmitErrorReport(), ereport, errmsg_internal(), error_context_stack, fb(), FloatExceptionHandler(), FreeWorkerInfo(), GetProcessingMode, HOLD_INTERRUPTS, INIT_PG_OVERRIDE_ALLOW_CONNS, init_ps_display(), InitializeTimeouts(), InitPostgres(), InitProcess(), InitProcessing, InvalidOid, kill, LW_EXCLUSIVE, LWLockAcquire(), LWLockRelease(), MemoryContextDelete(), MyBackendType, MyProc, MyWorkerInfo, NAMEDATALEN, NormalProcessing, OidIsValid, on_shmem_exit(), PG_exception_stack, pg_usleep(), PGC_S_OVERRIDE, PGC_SUSET, pgstat_report_autovac(), PostAuthDelay, PostmasterContext, pqsignal, proc_exit(), procsignal_sigusr1_handler(), ReadNextMultiXactId(), ReadNextTransactionId(), recentMulti, recentXid, set_ps_display(), SetConfigOption(), SetProcessingMode, SIGCHLD, SIGHUP, SignalHandlerForConfigReload(), SIGPIPE, SIGUSR1, SIGUSR2, StatementCancelHandler(), synchronous_commit, SYNCHRONOUS_COMMIT_LOCAL_FLUSH, UnBlockSig, WARNING, WorkerInfoData::wi_dboid, WorkerInfoData::wi_links, and WorkerInfoData::wi_proc.

◆ av_worker_available()

static bool av_worker_available ( void  )
static

Definition at line 3453 of file autovacuum.c.

3454{
3455 int free_slots;
3456 int reserved_slots;
3457
3459
3462
3463 return free_slots > reserved_slots;
3464}
int autovacuum_max_workers
Definition autovacuum.c:119
static uint32 dclist_count(const dclist_head *head)
Definition ilist.h:932

References autovacuum_max_workers, autovacuum_worker_slots, AutoVacuumShmem, AutoVacuumShmemStruct::av_freeWorkers, dclist_count(), fb(), and Max.

Referenced by AutoVacLauncherMain(), and do_start_worker().

◆ avl_sigusr2_handler()

static void avl_sigusr2_handler ( SIGNAL_ARGS  )
static

Definition at line 1372 of file autovacuum.c.

1373{
1374 got_SIGUSR2 = true;
1376}
void SetLatch(Latch *latch)
Definition latch.c:290

References got_SIGUSR2, MyLatch, and SetLatch().

Referenced by AutoVacLauncherMain().

◆ check_autovacuum_work_mem()

bool check_autovacuum_work_mem ( int newval,
void **  extra,
GucSource  source 
)

Definition at line 3427 of file autovacuum.c.

3428{
3429 /*
3430 * -1 indicates fallback.
3431 *
3432 * If we haven't yet changed the boot_val default of -1, just let it be.
3433 * Autovacuum will look to maintenance_work_mem instead.
3434 */
3435 if (*newval == -1)
3436 return true;
3437
3438 /*
3439 * We clamp manually-set values to at least 64kB. Since
3440 * maintenance_work_mem is always set to at least this value, do the same
3441 * here.
3442 */
3443 if (*newval < 64)
3444 *newval = 64;
3445
3446 return true;
3447}
#define newval

References newval.

◆ check_av_worker_gucs()

static void check_av_worker_gucs ( void  )
static

Definition at line 3470 of file autovacuum.c.

3471{
3475 errmsg("\"autovacuum_max_workers\" (%d) should be less than or equal to \"autovacuum_worker_slots\" (%d)",
3477 errdetail("The server will only start up to \"autovacuum_worker_slots\" (%d) autovacuum workers at a given time.",
3479}
int errdetail(const char *fmt,...)
Definition elog.c:1216
int errcode(int sqlerrcode)
Definition elog.c:863

References autovacuum_max_workers, autovacuum_worker_slots, ereport, errcode(), errdetail(), errmsg(), fb(), and WARNING.

Referenced by autovac_init(), and ProcessAutoVacLauncherInterrupts().

◆ db_comparator()

static int db_comparator ( const void a,
const void b 
)
static

Definition at line 1083 of file autovacuum.c.

1084{
1085 return pg_cmp_s32(((const avl_dbase *) a)->adl_score,
1086 ((const avl_dbase *) b)->adl_score);
1087}
static int pg_cmp_s32(int32 a, int32 b)
Definition int.h:713
int b
Definition isn.c:74
int a
Definition isn.c:73

References a, b, and pg_cmp_s32().

Referenced by rebuild_database_list().

◆ do_autovacuum()

static void do_autovacuum ( void  )
static

Definition at line 1877 of file autovacuum.c.

1878{
1880 HeapTuple tuple;
1883 List *table_oids = NIL;
1884 List *orphan_oids = NIL;
1885 HASHCTL ctl;
1887 ListCell *volatile cell;
1888 BufferAccessStrategy bstrategy;
1892 bool did_vacuum = false;
1893 bool found_concurrent_worker = false;
1894 int i;
1895
1896 /*
1897 * StartTransactionCommand and CommitTransactionCommand will automatically
1898 * switch to other contexts. We need this one to keep the list of
1899 * relations to vacuum/analyze across transactions.
1900 */
1902 "Autovacuum worker",
1905
1906 /* Start a transaction so our commands have one to play into. */
1908
1909 /*
1910 * This injection point is put in a transaction block to work with a wait
1911 * that uses a condition variable.
1912 */
1913 INJECTION_POINT("autovacuum-worker-start", NULL);
1914
1915 /*
1916 * Compute the multixact age for which freezing is urgent. This is
1917 * normally autovacuum_multixact_freeze_max_age, but may be less if
1918 * multixact members are bloated.
1919 */
1921
1922 /*
1923 * Find the pg_database entry and select the default freeze ages. We use
1924 * zero in template and nonconnectable databases, else the system-wide
1925 * default.
1926 */
1928 if (!HeapTupleIsValid(tuple))
1929 elog(ERROR, "cache lookup failed for database %u", MyDatabaseId);
1931
1932 if (dbForm->datistemplate || !dbForm->datallowconn)
1933 {
1938 }
1939 else
1940 {
1945 }
1946
1947 ReleaseSysCache(tuple);
1948
1949 /* StartTransactionCommand changed elsewhere */
1951
1953
1954 /* create a copy so we can use it after closing pg_class */
1956
1957 /* create hash table for toast <-> main relid mapping */
1958 ctl.keysize = sizeof(Oid);
1959 ctl.entrysize = sizeof(av_relation);
1960
1961 table_toast_map = hash_create("TOAST to main relid map",
1962 100,
1963 &ctl,
1965
1966 /*
1967 * Scan pg_class to determine which tables to vacuum.
1968 *
1969 * We do this in two passes: on the first one we collect the list of plain
1970 * relations and materialized views, and on the second one we collect
1971 * TOAST tables. The reason for doing the second pass is that during it we
1972 * want to use the main relation's pg_class.reloptions entry if the TOAST
1973 * table does not have any, and we cannot obtain it unless we know
1974 * beforehand what's the main table OID.
1975 *
1976 * We need to check TOAST tables separately because in cases with short,
1977 * wide tables there might be proportionally much more activity in the
1978 * TOAST table than in its parent.
1979 */
1981
1982 /*
1983 * On the first pass, we collect main tables to vacuum, and also the main
1984 * table relid to TOAST relid mapping.
1985 */
1986 while ((tuple = heap_getnext(relScan, ForwardScanDirection)) != NULL)
1987 {
1991 Oid relid;
1992 bool dovacuum;
1993 bool doanalyze;
1994 bool wraparound;
1995
1996 if (classForm->relkind != RELKIND_RELATION &&
1997 classForm->relkind != RELKIND_MATVIEW)
1998 continue;
1999
2000 relid = classForm->oid;
2001
2002 /*
2003 * Check if it is a temp table (presumably, of some other backend's).
2004 * We cannot safely process other backends' temp tables.
2005 */
2006 if (classForm->relpersistence == RELPERSISTENCE_TEMP)
2007 {
2008 /*
2009 * We just ignore it if the owning backend is still active and
2010 * using the temporary schema. Also, for safety, ignore it if the
2011 * namespace doesn't exist or isn't a temp namespace after all.
2012 */
2014 {
2015 /*
2016 * The table seems to be orphaned -- although it might be that
2017 * the owning backend has already deleted it and exited; our
2018 * pg_class scan snapshot is not necessarily up-to-date
2019 * anymore, so we could be looking at a committed-dead entry.
2020 * Remember it so we can try to delete it later.
2021 */
2023 }
2024 continue;
2025 }
2026
2027 /* Fetch reloptions and the pgstat entry for this table */
2030 relid);
2031
2032 /* Check if it needs vacuum or analyze */
2036
2037 /* Relations that need work are added to table_oids */
2038 if (dovacuum || doanalyze)
2040
2041 /*
2042 * Remember TOAST associations for the second pass. Note: we must do
2043 * this whether or not the table is going to be vacuumed, because we
2044 * don't automatically vacuum toast tables along the parent table.
2045 */
2046 if (OidIsValid(classForm->reltoastrelid))
2047 {
2049 bool found;
2050
2052 &classForm->reltoastrelid,
2053 HASH_ENTER, &found);
2054
2055 if (!found)
2056 {
2057 /* hash_search already filled in the key */
2058 hentry->ar_relid = relid;
2059 hentry->ar_hasrelopts = false;
2060 if (relopts != NULL)
2061 {
2062 hentry->ar_hasrelopts = true;
2063 memcpy(&hentry->ar_reloptions, relopts,
2064 sizeof(AutoVacOpts));
2065 }
2066 }
2067 }
2068
2069 /* Release stuff to avoid per-relation leakage */
2070 if (relopts)
2071 pfree(relopts);
2072 if (tabentry)
2073 pfree(tabentry);
2074 }
2075
2077
2078 /* second pass: check TOAST tables */
2079 ScanKeyInit(&key,
2083
2085 while ((tuple = heap_getnext(relScan, ForwardScanDirection)) != NULL)
2086 {
2089 Oid relid;
2091 bool free_relopts = false;
2092 bool dovacuum;
2093 bool doanalyze;
2094 bool wraparound;
2095
2096 /*
2097 * We cannot safely process other backends' temp tables, so skip 'em.
2098 */
2099 if (classForm->relpersistence == RELPERSISTENCE_TEMP)
2100 continue;
2101
2102 relid = classForm->oid;
2103
2104 /*
2105 * fetch reloptions -- if this toast table does not have them, try the
2106 * main rel
2107 */
2109 if (relopts)
2110 free_relopts = true;
2111 else
2112 {
2114 bool found;
2115
2116 hentry = hash_search(table_toast_map, &relid, HASH_FIND, &found);
2117 if (found && hentry->ar_hasrelopts)
2118 relopts = &hentry->ar_reloptions;
2119 }
2120
2121 /* Fetch the pgstat entry for this table */
2123 relid);
2124
2128
2129 /* ignore analyze for toast tables */
2130 if (dovacuum)
2132
2133 /* Release stuff to avoid leakage */
2134 if (free_relopts)
2135 pfree(relopts);
2136 if (tabentry)
2137 pfree(tabentry);
2138 }
2139
2142
2143 /*
2144 * Recheck orphan temporary tables, and if they still seem orphaned, drop
2145 * them. We'll eat a transaction per dropped table, which might seem
2146 * excessive, but we should only need to do anything as a result of a
2147 * previous backend crash, so this should not happen often enough to
2148 * justify "optimizing". Using separate transactions ensures that we
2149 * don't bloat the lock table if there are many temp tables to be dropped,
2150 * and it ensures that we don't lose work if a deletion attempt fails.
2151 */
2152 foreach(cell, orphan_oids)
2153 {
2154 Oid relid = lfirst_oid(cell);
2156 ObjectAddress object;
2157
2158 /*
2159 * Check for user-requested abort.
2160 */
2162
2163 /*
2164 * Try to lock the table. If we can't get the lock immediately,
2165 * somebody else is using (or dropping) the table, so it's not our
2166 * concern anymore. Having the lock prevents race conditions below.
2167 */
2169 continue;
2170
2171 /*
2172 * Re-fetch the pg_class tuple and re-check whether it still seems to
2173 * be an orphaned temp table. If it's not there or no longer the same
2174 * relation, ignore it.
2175 */
2177 if (!HeapTupleIsValid(tuple))
2178 {
2179 /* be sure to drop useless lock so we don't bloat lock table */
2181 continue;
2182 }
2184
2185 /*
2186 * Make all the same tests made in the loop above. In event of OID
2187 * counter wraparound, the pg_class entry we have now might be
2188 * completely unrelated to the one we saw before.
2189 */
2190 if (!((classForm->relkind == RELKIND_RELATION ||
2191 classForm->relkind == RELKIND_MATVIEW) &&
2192 classForm->relpersistence == RELPERSISTENCE_TEMP))
2193 {
2195 continue;
2196 }
2197
2199 {
2201 continue;
2202 }
2203
2204 /*
2205 * Try to lock the temp namespace, too. Even though we have lock on
2206 * the table itself, there's a risk of deadlock against an incoming
2207 * backend trying to clean out the temp namespace, in case this table
2208 * has dependencies (such as sequences) that the backend's
2209 * performDeletion call might visit in a different order. If we can
2210 * get AccessShareLock on the namespace, that's sufficient to ensure
2211 * we're not running concurrently with RemoveTempRelations. If we
2212 * can't, back off and let RemoveTempRelations do its thing.
2213 */
2215 classForm->relnamespace, 0,
2217 {
2219 continue;
2220 }
2221
2222 /* OK, let's delete it */
2223 ereport(LOG,
2224 (errmsg("autovacuum: dropping orphan temp table \"%s.%s.%s\"",
2226 get_namespace_name(classForm->relnamespace),
2227 NameStr(classForm->relname))));
2228
2229 /*
2230 * Deletion might involve TOAST table access, so ensure we have a
2231 * valid snapshot.
2232 */
2234
2235 object.classId = RelationRelationId;
2236 object.objectId = relid;
2237 object.objectSubId = 0;
2242
2243 /*
2244 * To commit the deletion, end current transaction and start a new
2245 * one. Note this also releases the locks we took.
2246 */
2250
2251 /* StartTransactionCommand changed current memory context */
2253 }
2254
2255 /*
2256 * Optionally, create a buffer access strategy object for VACUUM to use.
2257 * We use the same BufferAccessStrategy object for all tables VACUUMed by
2258 * this worker to prevent autovacuum from blowing out shared buffers.
2259 *
2260 * VacuumBufferUsageLimit being set to 0 results in
2261 * GetAccessStrategyWithSize returning NULL, effectively meaning we can
2262 * use up to all of shared buffers.
2263 *
2264 * If we later enter failsafe mode on any of the tables being vacuumed, we
2265 * will cease use of the BufferAccessStrategy only for that table.
2266 *
2267 * XXX should we consider adding code to adjust the size of this if
2268 * VacuumBufferUsageLimit changes?
2269 */
2271
2272 /*
2273 * create a memory context to act as fake PortalContext, so that the
2274 * contexts created in the vacuum code are cleaned up for each table.
2275 */
2277 "Autovacuum Portal",
2279
2280 /*
2281 * Perform operations on collected tables.
2282 */
2283 foreach(cell, table_oids)
2284 {
2285 Oid relid = lfirst_oid(cell);
2287 autovac_table *tab;
2288 bool isshared;
2289 bool skipit;
2290 dlist_iter iter;
2291
2293
2294 /*
2295 * Check for config changes before processing each collected table.
2296 */
2298 {
2299 ConfigReloadPending = false;
2301
2302 /*
2303 * You might be tempted to bail out if we see autovacuum is now
2304 * disabled. Must resist that temptation -- this might be a
2305 * for-wraparound emergency worker, in which case that would be
2306 * entirely inappropriate.
2307 */
2308 }
2309
2310 /*
2311 * Find out whether the table is shared or not. (It's slightly
2312 * annoying to fetch the syscache entry just for this, but in typical
2313 * cases it adds little cost because table_recheck_autovac would
2314 * refetch the entry anyway. We could buy that back by copying the
2315 * tuple here and passing it to table_recheck_autovac, but that
2316 * increases the odds of that function working with stale data.)
2317 */
2320 continue; /* somebody deleted the rel, forget it */
2323
2324 /*
2325 * Hold schedule lock from here until we've claimed the table. We
2326 * also need the AutovacuumLock to walk the worker array, but that one
2327 * can just be a shared lock.
2328 */
2331
2332 /*
2333 * Check whether the table is being vacuumed concurrently by another
2334 * worker.
2335 */
2336 skipit = false;
2338 {
2339 WorkerInfo worker = dlist_container(WorkerInfoData, wi_links, iter.cur);
2340
2341 /* ignore myself */
2342 if (worker == MyWorkerInfo)
2343 continue;
2344
2345 /* ignore workers in other databases (unless table is shared) */
2346 if (!worker->wi_sharedrel && worker->wi_dboid != MyDatabaseId)
2347 continue;
2348
2349 if (worker->wi_tableoid == relid)
2350 {
2351 skipit = true;
2353 break;
2354 }
2355 }
2357 if (skipit)
2358 {
2360 continue;
2361 }
2362
2363 /*
2364 * Store the table's OID in shared memory before releasing the
2365 * schedule lock, so that other workers don't try to vacuum it
2366 * concurrently. (We claim it here so as not to hold
2367 * AutovacuumScheduleLock while rechecking the stats.)
2368 */
2369 MyWorkerInfo->wi_tableoid = relid;
2370 MyWorkerInfo->wi_sharedrel = isshared;
2372
2373 /*
2374 * Check whether pgstat data still says we need to vacuum this table.
2375 * It could have changed if something else processed the table while
2376 * we weren't looking. This doesn't entirely close the race condition,
2377 * but it is very small.
2378 */
2382 if (tab == NULL)
2383 {
2384 /* someone else vacuumed the table, or it went away */
2387 MyWorkerInfo->wi_sharedrel = false;
2389 continue;
2390 }
2391
2392 /*
2393 * Save the cost-related storage parameter values in global variables
2394 * for reference when updating vacuum_cost_delay and vacuum_cost_limit
2395 * during vacuuming this table.
2396 */
2399
2400 /*
2401 * We only expect this worker to ever set the flag, so don't bother
2402 * checking the return value. We shouldn't have to retry.
2403 */
2404 if (tab->at_dobalance)
2406 else
2408
2412
2413 /*
2414 * We wait until this point to update cost delay and cost limit
2415 * values, even though we reloaded the configuration file above, so
2416 * that we can take into account the cost-related storage parameters.
2417 */
2419
2420
2421 /* clean up memory before each iteration */
2423
2424 /*
2425 * Save the relation name for a possible error message, to avoid a
2426 * catalog lookup in case of an error. If any of these return NULL,
2427 * then the relation has been dropped since last we checked; skip it.
2428 * Note: they must live in a long-lived memory context because we call
2429 * vacuum and analyze in different transactions.
2430 */
2431
2432 tab->at_relname = get_rel_name(tab->at_relid);
2435 if (!tab->at_relname || !tab->at_nspname || !tab->at_datname)
2436 goto deleted;
2437
2438 /*
2439 * We will abort vacuuming the current table if something errors out,
2440 * and continue with the next one in schedule; in particular, this
2441 * happens if we are interrupted with SIGINT.
2442 */
2443 PG_TRY();
2444 {
2445 /* Use PortalContext for any per-table allocations */
2447
2448 /* have at it */
2449 autovacuum_do_vac_analyze(tab, bstrategy);
2450
2451 /*
2452 * Clear a possible query-cancel signal, to avoid a late reaction
2453 * to an automatically-sent signal because of vacuuming the
2454 * current table (we're done with it, so it would make no sense to
2455 * cancel at this point.)
2456 */
2457 QueryCancelPending = false;
2458 }
2459 PG_CATCH();
2460 {
2461 /*
2462 * Abort the transaction, start a new one, and proceed with the
2463 * next table in our list.
2464 */
2466 if (tab->at_params.options & VACOPT_VACUUM)
2467 errcontext("automatic vacuum of table \"%s.%s.%s\"",
2468 tab->at_datname, tab->at_nspname, tab->at_relname);
2469 else
2470 errcontext("automatic analyze of table \"%s.%s.%s\"",
2471 tab->at_datname, tab->at_nspname, tab->at_relname);
2473
2474 /* this resets ProcGlobal->statusFlags[i] too */
2478
2479 /* restart our transaction for the following operations */
2482 }
2483 PG_END_TRY();
2484
2485 /* Make sure we're back in AutovacMemCxt */
2487
2488 did_vacuum = true;
2489
2490 /* ProcGlobal->statusFlags[i] are reset at the next end of xact */
2491
2492 /* be tidy */
2493deleted:
2494 if (tab->at_datname != NULL)
2495 pfree(tab->at_datname);
2496 if (tab->at_nspname != NULL)
2497 pfree(tab->at_nspname);
2498 if (tab->at_relname != NULL)
2499 pfree(tab->at_relname);
2500 pfree(tab);
2501
2502 /*
2503 * Remove my info from shared memory. We set wi_dobalance on the
2504 * assumption that we are more likely than not to vacuum a table with
2505 * no cost-related storage parameters next, so we want to claim our
2506 * share of I/O as soon as possible to avoid thrashing the global
2507 * balance.
2508 */
2511 MyWorkerInfo->wi_sharedrel = false;
2514 }
2515
2517
2518 /*
2519 * Perform additional work items, as requested by backends.
2520 */
2522 for (i = 0; i < NUM_WORKITEMS; i++)
2523 {
2525
2526 if (!workitem->avw_used)
2527 continue;
2528 if (workitem->avw_active)
2529 continue;
2530 if (workitem->avw_database != MyDatabaseId)
2531 continue;
2532
2533 /* claim this one, and release lock while performing it */
2534 workitem->avw_active = true;
2536
2539 if (ActiveSnapshotSet()) /* transaction could have aborted */
2541
2542 /*
2543 * Check for config changes before acquiring lock for further jobs.
2544 */
2547 {
2548 ConfigReloadPending = false;
2551 }
2552
2554
2555 /* and mark it done */
2556 workitem->avw_active = false;
2557 workitem->avw_used = false;
2558 }
2560
2561 /*
2562 * We leak table_toast_map here (among other things), but since we're
2563 * going away soon, it's not a problem normally. But when using Valgrind,
2564 * release some stuff to reduce complaints about leaked storage.
2565 */
2566#ifdef USE_VALGRIND
2569 if (bstrategy)
2570 pfree(bstrategy);
2571#endif
2572
2573 /* Run the rest in xact context, mainly to avoid Valgrind leak warnings */
2575
2576 /*
2577 * Update pg_database.datfrozenxid, and truncate pg_xact if possible. We
2578 * only need to do this once, not after each table.
2579 *
2580 * Even if we didn't vacuum anything, it may still be important to do
2581 * this, because one indirect effect of vac_update_datfrozenxid() is to
2582 * update TransamVariables->xidVacLimit. That might need to be done even
2583 * if we haven't vacuumed anything, because relations with older
2584 * relfrozenxid values or other databases with older datfrozenxid values
2585 * might have been dropped, allowing xidVacLimit to advance.
2586 *
2587 * However, it's also important not to do this blindly in all cases,
2588 * because when autovacuum=off this will restart the autovacuum launcher.
2589 * If we're not careful, an infinite loop can result, where workers find
2590 * no work to do and restart the launcher, which starts another worker in
2591 * the same database that finds no work to do. To prevent that, we skip
2592 * this if (1) we found no work to do and (2) we skipped at least one
2593 * table due to concurrent autovacuum activity. In that case, the other
2594 * worker has already done it, or will do so when it finishes.
2595 */
2598
2599 /* Finally close out the last transaction. */
2601}
static void pg_atomic_clear_flag(volatile pg_atomic_flag *ptr)
Definition atomics.h:205
static bool pg_atomic_test_set_flag(volatile pg_atomic_flag *ptr)
Definition atomics.h:181
static void relation_needs_vacanalyze(Oid relid, AutoVacOpts *relopts, Form_pg_class classForm, PgStat_StatTabEntry *tabentry, int effective_multixact_freeze_max_age, bool *dovacuum, bool *doanalyze, bool *wraparound)
void VacuumUpdateCosts(void)
static int default_multixact_freeze_table_age
Definition autovacuum.c:165
static int default_multixact_freeze_min_age
Definition autovacuum.c:164
static double av_storage_param_cost_delay
Definition autovacuum.c:151
static void perform_work_item(AutoVacuumWorkItem *workitem)
static int default_freeze_min_age
Definition autovacuum.c:162
static autovac_table * table_recheck_autovac(Oid relid, HTAB *table_toast_map, TupleDesc pg_class_desc, int effective_multixact_freeze_max_age)
static AutoVacOpts * extract_autovac_opts(HeapTuple tup, TupleDesc pg_class_desc)
static int default_freeze_table_age
Definition autovacuum.c:163
static void autovacuum_do_vac_analyze(autovac_table *tab, BufferAccessStrategy bstrategy)
@ BAS_VACUUM
Definition bufmgr.h:40
#define NameStr(name)
Definition c.h:765
void performDeletion(const ObjectAddress *object, DropBehavior behavior, int flags)
Definition dependency.c:274
#define PERFORM_DELETION_SKIP_EXTENSIONS
Definition dependency.h:96
#define PERFORM_DELETION_QUIETLY
Definition dependency.h:94
#define PERFORM_DELETION_INTERNAL
Definition dependency.h:92
void * hash_search(HTAB *hashp, const void *keyPtr, HASHACTION action, bool *foundPtr)
Definition dynahash.c:952
HTAB * hash_create(const char *tabname, int64 nelem, const HASHCTL *info, int flags)
Definition dynahash.c:358
void hash_destroy(HTAB *hashp)
Definition dynahash.c:865
#define LOG
Definition elog.h:31
#define errcontext
Definition elog.h:198
#define PG_TRY(...)
Definition elog.h:372
#define PG_END_TRY(...)
Definition elog.h:397
#define PG_CATCH(...)
Definition elog.h:382
BufferAccessStrategy GetAccessStrategyWithSize(BufferAccessStrategyType btype, int ring_size_kb)
Definition freelist.c:546
int VacuumBufferUsageLimit
Definition globals.c:149
void ProcessConfigFile(GucContext context)
Definition guc-file.l:120
@ PGC_SIGHUP
Definition guc.h:75
HeapTuple heap_getnext(TableScanDesc sscan, ScanDirection direction)
Definition heapam.c:1408
@ HASH_FIND
Definition hsearch.h:113
@ HASH_ENTER
Definition hsearch.h:114
#define HASH_ELEM
Definition hsearch.h:95
#define HASH_BLOBS
Definition hsearch.h:97
#define HeapTupleIsValid(tuple)
Definition htup.h:78
static void * GETSTRUCT(const HeapTupleData *tuple)
#define INJECTION_POINT(name, arg)
volatile sig_atomic_t ConfigReloadPending
Definition interrupt.c:27
List * lappend_oid(List *list, Oid datum)
Definition list.c:375
void list_free(List *list)
Definition list.c:1546
bool ConditionalLockRelationOid(Oid relid, LOCKMODE lockmode)
Definition lmgr.c:151
void UnlockRelationOid(Oid relid, LOCKMODE lockmode)
Definition lmgr.c:229
bool ConditionalLockDatabaseObject(Oid classid, Oid objid, uint16 objsubid, LOCKMODE lockmode)
Definition lmgr.c:1032
#define AccessExclusiveLock
Definition lockdefs.h:43
#define AccessShareLock
Definition lockdefs.h:36
char * get_rel_name(Oid relid)
Definition lsyscache.c:2078
char * get_database_name(Oid dbid)
Definition lsyscache.c:1242
Oid get_rel_namespace(Oid relid)
Definition lsyscache.c:2102
char * get_namespace_name(Oid nspid)
Definition lsyscache.c:3516
MemoryContext TopTransactionContext
Definition mcxt.c:171
void pfree(void *pointer)
Definition mcxt.c:1616
MemoryContext PortalContext
Definition mcxt.c:175
#define CHECK_FOR_INTERRUPTS()
Definition miscadmin.h:123
int MultiXactMemberFreezeThreshold(void)
Definition multixact.c:2511
TempNamespaceStatus checkTempNamespaceStatus(Oid namespaceId)
Definition namespace.c:3799
@ TEMP_NAMESPACE_IDLE
Definition namespace.h:66
@ DROP_CASCADE
FormData_pg_class * Form_pg_class
Definition pg_class.h:156
FormData_pg_database * Form_pg_database
Definition pg_database.h:96
#define lfirst_oid(lc)
Definition pg_list.h:174
PgStat_StatTabEntry * pgstat_fetch_stat_tabentry_ext(bool shared, Oid reloid)
static Datum ObjectIdGetDatum(Oid X)
Definition postgres.h:262
static Datum CharGetDatum(char X)
Definition postgres.h:132
tree ctl
Definition radixtree.h:1838
#define RelationGetDescr(relation)
Definition rel.h:540
void ScanKeyInit(ScanKey entry, AttrNumber attributeNumber, StrategyNumber strategy, RegProcedure procedure, Datum argument)
Definition scankey.c:76
@ ForwardScanDirection
Definition sdir.h:28
Snapshot GetTransactionSnapshot(void)
Definition snapmgr.c:272
void PushActiveSnapshot(Snapshot snapshot)
Definition snapmgr.c:682
bool ActiveSnapshotSet(void)
Definition snapmgr.c:812
void PopActiveSnapshot(void)
Definition snapmgr.c:775
#define BTEqualStrategyNumber
Definition stratnum.h:31
double at_storage_param_vac_cost_delay
Definition autovacuum.c:204
int at_storage_param_vac_cost_limit
Definition autovacuum.c:205
char * at_datname
Definition autovacuum.c:210
void ReleaseSysCache(HeapTuple tuple)
Definition syscache.c:264
HeapTuple SearchSysCache1(int cacheId, Datum key1)
Definition syscache.c:220
#define SearchSysCacheCopy1(cacheId, key1)
Definition syscache.h:91
void table_close(Relation relation, LOCKMODE lockmode)
Definition table.c:126
Relation table_open(Oid relationId, LOCKMODE lockmode)
Definition table.c:40
TableScanDesc table_beginscan_catalog(Relation relation, int nkeys, ScanKeyData *key)
Definition tableam.c:113
static void table_endscan(TableScanDesc scan)
Definition tableam.h:985
void FreeTupleDesc(TupleDesc tupdesc)
Definition tupdesc.c:502
TupleDesc CreateTupleDescCopy(TupleDesc tupdesc)
Definition tupdesc.c:252
int vacuum_freeze_min_age
Definition vacuum.c:75
int vacuum_multixact_freeze_table_age
Definition vacuum.c:78
int vacuum_freeze_table_age
Definition vacuum.c:76
int vacuum_multixact_freeze_min_age
Definition vacuum.c:77
void vac_update_datfrozenxid(void)
Definition vacuum.c:1608
void StartTransactionCommand(void)
Definition xact.c:3080
void CommitTransactionCommand(void)
Definition xact.c:3178
void AbortOutOfAnyTransaction(void)
Definition xact.c:4884

References AbortOutOfAnyTransaction(), AccessExclusiveLock, AccessShareLock, ActiveSnapshotSet(), ALLOCSET_DEFAULT_SIZES, AllocSetContextCreate, autovac_table::at_datname, autovac_table::at_dobalance, autovac_table::at_nspname, autovac_table::at_params, autovac_table::at_relid, autovac_table::at_relname, autovac_table::at_storage_param_vac_cost_delay, autovac_table::at_storage_param_vac_cost_limit, autovac_recalculate_workers_for_balance(), AutovacMemCxt, autovacuum_do_vac_analyze(), AutoVacuumShmem, AutoVacuumShmemStruct::av_runningWorkers, av_storage_param_cost_delay, av_storage_param_cost_limit, AutoVacuumShmemStruct::av_workItems, AutoVacuumWorkItem::avw_active, BAS_VACUUM, BTEqualStrategyNumber, CharGetDatum(), CHECK_FOR_INTERRUPTS, checkTempNamespaceStatus(), CommitTransactionCommand(), ConditionalLockDatabaseObject(), ConditionalLockRelationOid(), ConfigReloadPending, CreateTupleDescCopy(), ctl, dlist_iter::cur, default_freeze_min_age, default_freeze_table_age, default_multixact_freeze_min_age, default_multixact_freeze_table_age, dlist_container, dlist_foreach, DROP_CASCADE, elog, EmitErrorReport(), ereport, errcontext, errmsg(), ERROR, extract_autovac_opts(), fb(), FlushErrorState(), ForwardScanDirection, FreeTupleDesc(), get_database_name(), get_namespace_name(), get_rel_name(), get_rel_namespace(), GetAccessStrategyWithSize(), GETSTRUCT(), GetTransactionSnapshot(), HASH_BLOBS, hash_create(), hash_destroy(), HASH_ELEM, HASH_ENTER, HASH_FIND, hash_search(), heap_getnext(), HeapTupleIsValid, HOLD_INTERRUPTS, i, INJECTION_POINT, InvalidOid, lappend_oid(), lfirst_oid, list_free(), LOG, LW_EXCLUSIVE, LW_SHARED, LWLockAcquire(), LWLockRelease(), MemoryContextReset(), MemoryContextSwitchTo(), MultiXactMemberFreezeThreshold(), MyDatabaseId, MyWorkerInfo, NameStr, NIL, NUM_WORKITEMS, ObjectIdGetDatum(), OidIsValid, VacuumParams::options, PERFORM_DELETION_INTERNAL, PERFORM_DELETION_QUIETLY, PERFORM_DELETION_SKIP_EXTENSIONS, perform_work_item(), performDeletion(), pfree(), pg_atomic_clear_flag(), pg_atomic_test_set_flag(), PG_CATCH, PG_END_TRY, PG_TRY, PGC_SIGHUP, pgstat_fetch_stat_tabentry_ext(), PopActiveSnapshot(), PortalContext, ProcessConfigFile(), PushActiveSnapshot(), QueryCancelPending, relation_needs_vacanalyze(), RelationGetDescr, ReleaseSysCache(), RESUME_INTERRUPTS, ScanKeyInit(), SearchSysCache1(), SearchSysCacheCopy1, StartTransactionCommand(), table_beginscan_catalog(), table_close(), table_endscan(), table_open(), table_recheck_autovac(), TEMP_NAMESPACE_IDLE, TopMemoryContext, TopTransactionContext, UnlockRelationOid(), vac_update_datfrozenxid(), VACOPT_VACUUM, vacuum_freeze_min_age, vacuum_freeze_table_age, vacuum_multixact_freeze_min_age, vacuum_multixact_freeze_table_age, VacuumBufferUsageLimit, VacuumUpdateCosts(), WorkerInfoData::wi_dboid, WorkerInfoData::wi_dobalance, WorkerInfoData::wi_sharedrel, and WorkerInfoData::wi_tableoid.

Referenced by AutoVacWorkerMain().

◆ do_start_worker()

static Oid do_start_worker ( void  )
static

Definition at line 1101 of file autovacuum.c.

1102{
1103 List *dblist;
1104 ListCell *cell;
1107 bool for_xid_wrap;
1108 bool for_multi_wrap;
1109 avw_dbase *avdb;
1111 bool skipit = false;
1112 Oid retval = InvalidOid;
1114 oldcxt;
1115
1116 /* return quickly when there are no free workers */
1118 if (!av_worker_available())
1119 {
1121 return InvalidOid;
1122 }
1124
1125 /*
1126 * Create and switch to a temporary context to avoid leaking the memory
1127 * allocated for the database list.
1128 */
1130 "Autovacuum start worker (tmp)",
1133
1134 /* Get a list of databases */
1136
1137 /*
1138 * Determine the oldest datfrozenxid/relfrozenxid that we will allow to
1139 * pass without forcing a vacuum. (This limit can be tightened for
1140 * particular tables, but not loosened.)
1141 */
1144 /* ensure it's a "normal" XID, else TransactionIdPrecedes misbehaves */
1145 /* this can cause the limit to go backwards by 3, but that's OK */
1148
1149 /* Also determine the oldest datminmxid we will consider. */
1154
1155 /*
1156 * Choose a database to connect to. We pick the database that was least
1157 * recently auto-vacuumed, or one that needs vacuuming to prevent Xid
1158 * wraparound-related data loss. If any db at risk of Xid wraparound is
1159 * found, we pick the one with oldest datfrozenxid, independently of
1160 * autovacuum times; similarly we pick the one with the oldest datminmxid
1161 * if any is in MultiXactId wraparound. Note that those in Xid wraparound
1162 * danger are given more priority than those in multi wraparound danger.
1163 *
1164 * Note that a database with no stats entry is not considered, except for
1165 * Xid wraparound purposes. The theory is that if no one has ever
1166 * connected to it since the stats were last initialized, it doesn't need
1167 * vacuuming.
1168 *
1169 * XXX This could be improved if we had more info about whether it needs
1170 * vacuuming before connecting to it. Perhaps look through the pgstats
1171 * data for the database's tables? One idea is to keep track of the
1172 * number of new and dead tuples per database in pgstats. However it
1173 * isn't clear how to construct a metric that measures that and not cause
1174 * starvation for less busy databases.
1175 */
1176 avdb = NULL;
1177 for_xid_wrap = false;
1178 for_multi_wrap = false;
1180 foreach(cell, dblist)
1181 {
1182 avw_dbase *tmp = lfirst(cell);
1183 dlist_iter iter;
1184
1185 /* Check to see if this one is at risk of wraparound */
1187 {
1188 if (avdb == NULL ||
1190 avdb->adw_frozenxid))
1191 avdb = tmp;
1192 for_xid_wrap = true;
1193 continue;
1194 }
1195 else if (for_xid_wrap)
1196 continue; /* ignore not-at-risk DBs */
1198 {
1199 if (avdb == NULL ||
1200 MultiXactIdPrecedes(tmp->adw_minmulti, avdb->adw_minmulti))
1201 avdb = tmp;
1202 for_multi_wrap = true;
1203 continue;
1204 }
1205 else if (for_multi_wrap)
1206 continue; /* ignore not-at-risk DBs */
1207
1208 /* Find pgstat entry if any */
1210
1211 /*
1212 * Skip a database with no pgstat entry; it means it hasn't seen any
1213 * activity.
1214 */
1215 if (!tmp->adw_entry)
1216 continue;
1217
1218 /*
1219 * Also, skip a database that appears on the database list as having
1220 * been processed recently (less than autovacuum_naptime seconds ago).
1221 * We do this so that we don't select a database which we just
1222 * selected, but that pgstat hasn't gotten around to updating the last
1223 * autovacuum time yet.
1224 */
1225 skipit = false;
1226
1228 {
1229 avl_dbase *dbp = dlist_container(avl_dbase, adl_node, iter.cur);
1230
1231 if (dbp->adl_datid == tmp->adw_datid)
1232 {
1233 /*
1234 * Skip this database if its next_worker value falls between
1235 * the current time and the current time plus naptime.
1236 */
1237 if (!TimestampDifferenceExceeds(dbp->adl_next_worker,
1238 current_time, 0) &&
1240 dbp->adl_next_worker,
1241 autovacuum_naptime * 1000))
1242 skipit = true;
1243
1244 break;
1245 }
1246 }
1247 if (skipit)
1248 continue;
1249
1250 /*
1251 * Remember the db with oldest autovac time. (If we are here, both
1252 * tmp->entry and db->entry must be non-null.)
1253 */
1254 if (avdb == NULL ||
1255 tmp->adw_entry->last_autovac_time < avdb->adw_entry->last_autovac_time)
1256 avdb = tmp;
1257 }
1258
1259 /* Found a database -- process it */
1260 if (avdb != NULL)
1261 {
1262 WorkerInfo worker;
1264
1266
1267 /*
1268 * Get a worker entry from the freelist. We checked above, so there
1269 * really should be a free slot.
1270 */
1272
1273 worker = dlist_container(WorkerInfoData, wi_links, wptr);
1274 worker->wi_dboid = avdb->adw_datid;
1275 worker->wi_proc = NULL;
1277
1279
1281
1283
1284 retval = avdb->adw_datid;
1285 }
1286 else if (skipit)
1287 {
1288 /*
1289 * If we skipped all databases on the list, rebuild it, because it
1290 * probably contains a dropped database.
1291 */
1293 }
1294
1297
1298 return retval;
1299}
static List * get_database_list(void)
int autovacuum_freeze_max_age
Definition autovacuum.c:129
TransactionId MultiXactId
Definition c.h:676
uint32 TransactionId
Definition c.h:666
#define dlist_reverse_foreach(iter, lhead)
Definition ilist.h:654
static dlist_node * dclist_pop_head_node(dclist_head *head)
Definition ilist.h:789
bool MultiXactIdPrecedes(MultiXactId multi1, MultiXactId multi2)
Definition multixact.c:2765
#define FirstMultiXactId
Definition multixact.h:26
#define lfirst(lc)
Definition pg_list.h:172
_stringlist * dblist
Definition pg_regress.c:97
PgStat_StatDBEntry * pgstat_fetch_stat_dbentry(Oid dboid)
TimestampTz last_autovac_time
Definition pgstat.h:356
PgStat_StatDBEntry * adw_entry
Definition autovacuum.c:186
Oid adw_datid
Definition autovacuum.c:182
TransactionId adw_frozenxid
Definition autovacuum.c:184
MultiXactId adw_minmulti
Definition autovacuum.c:185
#define FirstNormalTransactionId
Definition transam.h:34
static bool TransactionIdPrecedes(TransactionId id1, TransactionId id2)
Definition transam.h:263

References avw_dbase::adw_datid, avw_dbase::adw_entry, avw_dbase::adw_frozenxid, avw_dbase::adw_minmulti, ALLOCSET_DEFAULT_SIZES, AllocSetContextCreate, autovacuum_freeze_max_age, autovacuum_naptime, AutoVacuumShmem, AutoVacuumShmemStruct::av_freeWorkers, AutoVacuumShmemStruct::av_startingWorker, av_worker_available(), dlist_iter::cur, CurrentMemoryContext, DatabaseList, dblist, dclist_pop_head_node(), dlist_container, dlist_reverse_foreach, fb(), FirstMultiXactId, FirstNormalTransactionId, get_database_list(), GetCurrentTimestamp(), InvalidOid, PgStat_StatDBEntry::last_autovac_time, lfirst, LW_EXCLUSIVE, LW_SHARED, LWLockAcquire(), LWLockRelease(), MemoryContextDelete(), MemoryContextSwitchTo(), MultiXactIdPrecedes(), MultiXactMemberFreezeThreshold(), pgstat_fetch_stat_dbentry(), PMSIGNAL_START_AUTOVAC_WORKER, ReadNextMultiXactId(), ReadNextTransactionId(), rebuild_database_list(), recentMulti, recentXid, SendPostmasterSignal(), TimestampDifferenceExceeds(), TransactionIdPrecedes(), WorkerInfoData::wi_dboid, WorkerInfoData::wi_launchtime, and WorkerInfoData::wi_proc.

Referenced by AutoVacLauncherMain(), and launch_worker().

◆ extract_autovac_opts()

static AutoVacOpts * extract_autovac_opts ( HeapTuple  tup,
TupleDesc  pg_class_desc 
)
static

Definition at line 2721 of file autovacuum.c.

2722{
2723 bytea *relopts;
2724 AutoVacOpts *av;
2725
2727 ((Form_pg_class) GETSTRUCT(tup))->relkind == RELKIND_MATVIEW ||
2729
2731 if (relopts == NULL)
2732 return NULL;
2733
2735 memcpy(av, &(((StdRdOptions *) relopts)->autovacuum), sizeof(AutoVacOpts));
2736 pfree(relopts);
2737
2738 return av;
2739}
#define palloc_object(type)
Definition fe_memutils.h:74
bytea * extractRelOptions(HeapTuple tuple, TupleDesc tupdesc, amoptions_function amoptions)
struct @10::@11 av[32]
Definition c.h:706

References Assert, av, extractRelOptions(), fb(), GETSTRUCT(), palloc_object, and pfree().

Referenced by do_autovacuum(), and table_recheck_autovac().

◆ FreeWorkerInfo()

◆ get_database_list()

static List * get_database_list ( void  )
static

Definition at line 1801 of file autovacuum.c.

1802{
1803 List *dblist = NIL;
1804 Relation rel;
1805 TableScanDesc scan;
1806 HeapTuple tup;
1808
1809 /* This is the context that we will allocate our output data in */
1811
1812 /*
1813 * Start a transaction so we can access pg_database.
1814 */
1816
1818 scan = table_beginscan_catalog(rel, 0, NULL);
1819
1821 {
1823 avw_dbase *avdb;
1825
1826 /*
1827 * If database has partially been dropped, we can't, nor need to,
1828 * vacuum it.
1829 */
1831 {
1832 elog(DEBUG2,
1833 "autovacuum: skipping invalid database \"%s\"",
1834 NameStr(pgdatabase->datname));
1835 continue;
1836 }
1837
1838 /*
1839 * Allocate our results in the caller's context, not the
1840 * transaction's. We do this inside the loop, and restore the original
1841 * context at the end, so that leaky things like heap_getnext() are
1842 * not called in a potentially long-lived context.
1843 */
1845
1847
1848 avdb->adw_datid = pgdatabase->oid;
1849 avdb->adw_name = pstrdup(NameStr(pgdatabase->datname));
1850 avdb->adw_frozenxid = pgdatabase->datfrozenxid;
1851 avdb->adw_minmulti = pgdatabase->datminmxid;
1852 /* this gets set later: */
1853 avdb->adw_entry = NULL;
1854
1857 }
1858
1859 table_endscan(scan);
1861
1863
1864 /* Be sure to restore caller's memory context */
1866
1867 return dblist;
1868}
bool database_is_invalid_form(Form_pg_database datform)
#define DEBUG2
Definition elog.h:29
List * lappend(List *list, void *datum)
Definition list.c:339
char * pstrdup(const char *in)
Definition mcxt.c:1781

References AccessShareLock, CommitTransactionCommand(), CurrentMemoryContext, database_is_invalid_form(), dblist, DEBUG2, elog, fb(), ForwardScanDirection, GETSTRUCT(), heap_getnext(), HeapTupleIsValid, lappend(), MemoryContextSwitchTo(), NameStr, NIL, palloc_object, pstrdup(), StartTransactionCommand(), table_beginscan_catalog(), table_close(), table_endscan(), and table_open().

Referenced by do_start_worker(), and rebuild_database_list().

◆ launch_worker()

static void launch_worker ( TimestampTz  now)
static

Definition at line 1313 of file autovacuum.c.

1314{
1315 Oid dbid;
1316 dlist_iter iter;
1317
1318 dbid = do_start_worker();
1319 if (OidIsValid(dbid))
1320 {
1321 bool found = false;
1322
1323 /*
1324 * Walk the database list and update the corresponding entry. If the
1325 * database is not on the list, we'll recreate the list.
1326 */
1328 {
1329 avl_dbase *avdb = dlist_container(avl_dbase, adl_node, iter.cur);
1330
1331 if (avdb->adl_datid == dbid)
1332 {
1333 found = true;
1334
1335 /*
1336 * add autovacuum_naptime seconds to the current time, and use
1337 * that as the new "next_worker" field for this database.
1338 */
1339 avdb->adl_next_worker =
1341
1343 break;
1344 }
1345 }
1346
1347 /*
1348 * If the database was not present in the database list, we rebuild
1349 * the list. It's possible that the database does not get into the
1350 * list anyway, for example if it's a database that doesn't have a
1351 * pgstat entry, but this is not a problem because we don't want to
1352 * schedule workers regularly into those in any case.
1353 */
1354 if (!found)
1356 }
1357}
Datum now(PG_FUNCTION_ARGS)
Definition timestamp.c:1609
static void dlist_move_head(dlist_head *head, dlist_node *node)
Definition ilist.h:467
#define TimestampTzPlusMilliseconds(tz, ms)
Definition timestamp.h:85

References autovacuum_naptime, dlist_iter::cur, DatabaseList, dlist_container, dlist_foreach, dlist_move_head(), do_start_worker(), fb(), now(), OidIsValid, rebuild_database_list(), and TimestampTzPlusMilliseconds.

Referenced by AutoVacLauncherMain().

◆ launcher_determine_sleep()

static void launcher_determine_sleep ( bool  canlaunch,
bool  recursing,
struct timeval nap 
)
static

Definition at line 816 of file autovacuum.c.

817{
818 /*
819 * We sleep until the next scheduled vacuum. We trust that when the
820 * database list was built, care was taken so that no entries have times
821 * in the past; if the first entry has too close a next_worker value, or a
822 * time in the past, we will sleep a small nominal time.
823 */
824 if (!canlaunch)
825 {
826 nap->tv_sec = autovacuum_naptime;
827 nap->tv_usec = 0;
828 }
829 else if (!dlist_is_empty(&DatabaseList))
830 {
834 long secs;
835 int usecs;
836
838
839 next_wakeup = avdb->adl_next_worker;
841
842 nap->tv_sec = secs;
843 nap->tv_usec = usecs;
844 }
845 else
846 {
847 /* list is empty, sleep for whole autovacuum_naptime seconds */
848 nap->tv_sec = autovacuum_naptime;
849 nap->tv_usec = 0;
850 }
851
852 /*
853 * If the result is exactly zero, it means a database had an entry with
854 * time in the past. Rebuild the list so that the databases are evenly
855 * distributed again, and recalculate the time to sleep. This can happen
856 * if there are more tables needing vacuum than workers, and they all take
857 * longer to vacuum than autovacuum_naptime.
858 *
859 * We only recurse once. rebuild_database_list should always return times
860 * in the future, but it seems best not to trust too much on that.
861 */
862 if (nap->tv_sec == 0 && nap->tv_usec == 0 && !recursing)
863 {
866 return;
867 }
868
869 /* The smallest time we'll allow the launcher to sleep. */
870 if (nap->tv_sec <= 0 && nap->tv_usec <= MIN_AUTOVAC_SLEEPTIME * 1000)
871 {
872 nap->tv_sec = 0;
873 nap->tv_usec = MIN_AUTOVAC_SLEEPTIME * 1000;
874 }
875
876 /*
877 * If the sleep time is too large, clamp it to an arbitrary maximum (plus
878 * any fractional seconds, for simplicity). This avoids an essentially
879 * infinite sleep in strange cases like the system clock going backwards a
880 * few years.
881 */
882 if (nap->tv_sec > MAX_AUTOVAC_SLEEPTIME)
883 nap->tv_sec = MAX_AUTOVAC_SLEEPTIME;
884}
#define MIN_AUTOVAC_SLEEPTIME
Definition autovacuum.c:139
#define MAX_AUTOVAC_SLEEPTIME
Definition autovacuum.c:140
void TimestampDifference(TimestampTz start_time, TimestampTz stop_time, long *secs, int *microsecs)
Definition timestamp.c:1721

References autovacuum_naptime, DatabaseList, dlist_is_empty(), dlist_tail_element, fb(), GetCurrentTimestamp(), InvalidOid, launcher_determine_sleep(), MAX_AUTOVAC_SLEEPTIME, MIN_AUTOVAC_SLEEPTIME, rebuild_database_list(), and TimestampDifference().

Referenced by AutoVacLauncherMain(), and launcher_determine_sleep().

◆ perform_work_item()

static void perform_work_item ( AutoVacuumWorkItem workitem)
static

Definition at line 2607 of file autovacuum.c.

2608{
2609 char *cur_datname = NULL;
2610 char *cur_nspname = NULL;
2611 char *cur_relname = NULL;
2612
2613 /*
2614 * Note we do not store table info in MyWorkerInfo, since this is not
2615 * vacuuming proper.
2616 */
2617
2618 /*
2619 * Save the relation name for a possible error message, to avoid a catalog
2620 * lookup in case of an error. If any of these return NULL, then the
2621 * relation has been dropped since last we checked; skip it.
2622 */
2624
2625 cur_relname = get_rel_name(workitem->avw_relation);
2628 if (!cur_relname || !cur_nspname || !cur_datname)
2629 goto deleted2;
2630
2632
2633 /* clean up memory before each work item */
2635
2636 /*
2637 * We will abort the current work item if something errors out, and
2638 * continue with the next one; in particular, this happens if we are
2639 * interrupted with SIGINT. Note that this means that the work item list
2640 * can be lossy.
2641 */
2642 PG_TRY();
2643 {
2644 /* Use PortalContext for any per-work-item allocations */
2646
2647 /*
2648 * Have at it. Functions called here are responsible for any required
2649 * user switch and sandbox.
2650 */
2651 switch (workitem->avw_type)
2652 {
2655 ObjectIdGetDatum(workitem->avw_relation),
2656 Int64GetDatum((int64) workitem->avw_blockNumber));
2657 break;
2658 default:
2659 elog(WARNING, "unrecognized work item found: type %d",
2660 workitem->avw_type);
2661 break;
2662 }
2663
2664 /*
2665 * Clear a possible query-cancel signal, to avoid a late reaction to
2666 * an automatically-sent signal because of vacuuming the current table
2667 * (we're done with it, so it would make no sense to cancel at this
2668 * point.)
2669 */
2670 QueryCancelPending = false;
2671 }
2672 PG_CATCH();
2673 {
2674 /*
2675 * Abort the transaction, start a new one, and proceed with the next
2676 * table in our list.
2677 */
2679 errcontext("processing work entry for relation \"%s.%s.%s\"",
2680 cur_datname, cur_nspname, cur_relname);
2682
2683 /* this resets ProcGlobal->statusFlags[i] too */
2687
2688 /* restart our transaction for the following operations */
2691 }
2692 PG_END_TRY();
2693
2694 /* Make sure we're back in AutovacMemCxt */
2696
2697 /* We intentionally do not set did_vacuum here */
2698
2699 /* be tidy */
2700deleted2:
2701 if (cur_datname)
2703 if (cur_nspname)
2705 if (cur_relname)
2706 pfree(cur_relname);
2707}
static void autovac_report_workitem(AutoVacuumWorkItem *workitem, const char *nspname, const char *relname)
Datum brin_summarize_range(PG_FUNCTION_ARGS)
Definition brin.c:1382
int64_t int64
Definition c.h:543
#define DirectFunctionCall2(func, arg1, arg2)
Definition fmgr.h:686
static Datum Int64GetDatum(int64 X)
Definition postgres.h:423

References AbortOutOfAnyTransaction(), Assert, autovac_report_workitem(), AutovacMemCxt, AVW_BRINSummarizeRange, brin_summarize_range(), CurrentMemoryContext, DirectFunctionCall2, elog, EmitErrorReport(), errcontext, fb(), FlushErrorState(), get_database_name(), get_namespace_name(), get_rel_name(), get_rel_namespace(), HOLD_INTERRUPTS, Int64GetDatum(), MemoryContextReset(), MemoryContextSwitchTo(), MyDatabaseId, ObjectIdGetDatum(), pfree(), PG_CATCH, PG_END_TRY, PG_TRY, PortalContext, QueryCancelPending, RESUME_INTERRUPTS, StartTransactionCommand(), and WARNING.

Referenced by do_autovacuum().

◆ ProcessAutoVacLauncherInterrupts()

static void ProcessAutoVacLauncherInterrupts ( void  )
static

Definition at line 754 of file autovacuum.c.

755{
756 /* the normal shutdown case */
759
761 {
763
764 ConfigReloadPending = false;
766
767 /* shutdown requested in config file? */
768 if (!AutoVacuumingActive())
770
771 /*
772 * If autovacuum_max_workers changed, emit a WARNING if
773 * autovacuum_worker_slots < autovacuum_max_workers. If it didn't
774 * change, skip this to avoid too many repeated log messages.
775 */
778
779 /* rebuild the list in case the naptime changed */
781 }
782
783 /* Process barrier events */
786
787 /* Perform logging of memory contexts of this process */
790
791 /* Process sinval catchup interrupts that happened while sleeping */
793}
volatile sig_atomic_t LogMemoryContextPending
Definition globals.c:41
volatile sig_atomic_t ProcSignalBarrierPending
Definition globals.c:40
void ProcessLogMemoryContextInterrupt(void)
Definition mcxt.c:1340
void ProcessProcSignalBarrier(void)
Definition procsignal.c:499
void ProcessCatchupInterrupt(void)
Definition sinval.c:174

References AutoVacLauncherShutdown(), autovacuum_max_workers, AutoVacuumingActive(), check_av_worker_gucs(), ConfigReloadPending, fb(), InvalidOid, LogMemoryContextPending, PGC_SIGHUP, ProcessCatchupInterrupt(), ProcessConfigFile(), ProcessLogMemoryContextInterrupt(), ProcessProcSignalBarrier(), ProcSignalBarrierPending, rebuild_database_list(), and ShutdownRequestPending.

Referenced by AutoVacLauncherMain().

◆ rebuild_database_list()

static void rebuild_database_list ( Oid  newdb)
static

Definition at line 900 of file autovacuum.c.

901{
902 List *dblist;
903 ListCell *cell;
907 HASHCTL hctl;
908 int score;
909 int nelems;
910 HTAB *dbhash;
911 dlist_iter iter;
912
914 "Autovacuum database list",
917 "Autovacuum database list (tmp)",
920
921 /*
922 * Implementing this is not as simple as it sounds, because we need to put
923 * the new database at the end of the list; next the databases that were
924 * already on the list, and finally (at the tail of the list) all the
925 * other databases that are not on the existing list.
926 *
927 * To do this, we build an empty hash table of scored databases. We will
928 * start with the lowest score (zero) for the new database, then
929 * increasing scores for the databases in the existing list, in order, and
930 * lastly increasing scores for all databases gotten via
931 * get_database_list() that are not already on the hash.
932 *
933 * Then we will put all the hash elements into an array, sort the array by
934 * score, and finally put the array elements into the new doubly linked
935 * list.
936 */
937 hctl.keysize = sizeof(Oid);
938 hctl.entrysize = sizeof(avl_dbase);
939 hctl.hcxt = tmpcxt;
940 dbhash = hash_create("autovacuum db hash", 20, &hctl, /* magic number here
941 * FIXME */
943
944 /* start by inserting the new database */
945 score = 0;
946 if (OidIsValid(newdb))
947 {
948 avl_dbase *db;
949 PgStat_StatDBEntry *entry;
950
951 /* only consider this database if it has a pgstat entry */
953 if (entry != NULL)
954 {
955 /* we assume it isn't found because the hash was just created */
957
958 /* hash_search already filled in the key */
959 db->adl_score = score++;
960 /* next_worker is filled in later */
961 }
962 }
963
964 /* Now insert the databases from the existing list */
966 {
967 avl_dbase *avdb = dlist_container(avl_dbase, adl_node, iter.cur);
968 avl_dbase *db;
969 bool found;
970 PgStat_StatDBEntry *entry;
971
972 /*
973 * skip databases with no stat entries -- in particular, this gets rid
974 * of dropped databases
975 */
976 entry = pgstat_fetch_stat_dbentry(avdb->adl_datid);
977 if (entry == NULL)
978 continue;
979
980 db = hash_search(dbhash, &(avdb->adl_datid), HASH_ENTER, &found);
981
982 if (!found)
983 {
984 /* hash_search already filled in the key */
985 db->adl_score = score++;
986 /* next_worker is filled in later */
987 }
988 }
989
990 /* finally, insert all qualifying databases not previously inserted */
992 foreach(cell, dblist)
993 {
994 avw_dbase *avdb = lfirst(cell);
995 avl_dbase *db;
996 bool found;
997 PgStat_StatDBEntry *entry;
998
999 /* only consider databases with a pgstat entry */
1000 entry = pgstat_fetch_stat_dbentry(avdb->adw_datid);
1001 if (entry == NULL)
1002 continue;
1003
1004 db = hash_search(dbhash, &(avdb->adw_datid), HASH_ENTER, &found);
1005 /* only update the score if the database was not already on the hash */
1006 if (!found)
1007 {
1008 /* hash_search already filled in the key */
1009 db->adl_score = score++;
1010 /* next_worker is filled in later */
1011 }
1012 }
1013 nelems = score;
1014
1015 /* from here on, the allocated memory belongs to the new list */
1018
1019 if (nelems > 0)
1020 {
1022 int millis_increment;
1024 avl_dbase *db;
1026 int i;
1027
1028 /* put all the hash elements into an array */
1029 dbary = palloc(nelems * sizeof(avl_dbase));
1030 /* keep Valgrind quiet */
1031#ifdef USE_VALGRIND
1033#endif
1034
1035 i = 0;
1037 while ((db = hash_seq_search(&seq)) != NULL)
1038 memcpy(&(dbary[i++]), db, sizeof(avl_dbase));
1039
1040 /* sort the array */
1041 qsort(dbary, nelems, sizeof(avl_dbase), db_comparator);
1042
1043 /*
1044 * Determine the time interval between databases in the schedule. If
1045 * we see that the configured naptime would take us to sleep times
1046 * lower than our min sleep time (which launcher_determine_sleep is
1047 * coded not to allow), silently use a larger naptime (but don't touch
1048 * the GUC variable).
1049 */
1050 millis_increment = 1000.0 * autovacuum_naptime / nelems;
1053
1055
1056 /*
1057 * move the elements from the array into the dlist, setting the
1058 * next_worker while walking the array
1059 */
1060 for (i = 0; i < nelems; i++)
1061 {
1062 db = &(dbary[i]);
1063
1067
1068 /* later elements should go closer to the head of the list */
1070 }
1071 }
1072
1073 /* all done, clean up memory */
1074 if (DatabaseListCxt != NULL)
1079}
static int db_comparator(const void *a, const void *b)
void * hash_seq_search(HASH_SEQ_STATUS *status)
Definition dynahash.c:1415
void hash_seq_init(HASH_SEQ_STATUS *status, HTAB *hashp)
Definition dynahash.c:1380
#define HASH_CONTEXT
Definition hsearch.h:102
void * palloc(Size size)
Definition mcxt.c:1387
#define qsort(a, b, c, d)
Definition port.h:495
Size keysize
Definition hsearch.h:75
Size entrysize
Definition hsearch.h:76
MemoryContext hcxt
Definition hsearch.h:86
dlist_node adl_node
Definition autovacuum.c:176
int adl_score
Definition autovacuum.c:175
TimestampTz adl_next_worker
Definition autovacuum.c:174

References avl_dbase::adl_next_worker, avl_dbase::adl_node, avl_dbase::adl_score, ALLOCSET_DEFAULT_SIZES, AllocSetContextCreate, AutovacMemCxt, autovacuum_naptime, dlist_iter::cur, DatabaseList, DatabaseListCxt, db_comparator(), dblist, dlist_container, dlist_foreach, dlist_init(), dlist_push_head(), HASHCTL::entrysize, fb(), get_database_list(), GetCurrentTimestamp(), HASH_BLOBS, HASH_CONTEXT, hash_create(), HASH_ELEM, HASH_ENTER, hash_search(), hash_seq_init(), hash_seq_search(), HASHCTL::hcxt, i, HASHCTL::keysize, lfirst, MemoryContextDelete(), MemoryContextSwitchTo(), MIN_AUTOVAC_SLEEPTIME, OidIsValid, palloc(), pgstat_fetch_stat_dbentry(), qsort, and TimestampTzPlusMilliseconds.

Referenced by AutoVacLauncherMain(), do_start_worker(), launch_worker(), launcher_determine_sleep(), and ProcessAutoVacLauncherInterrupts().

◆ recheck_relation_needs_vacanalyze()

static void recheck_relation_needs_vacanalyze ( Oid  relid,
AutoVacOpts avopts,
Form_pg_class  classForm,
int  effective_multixact_freeze_max_age,
bool dovacuum,
bool doanalyze,
bool wraparound 
)
static

Definition at line 2909 of file autovacuum.c.

2916{
2918
2919 /* fetch the pgstat table entry */
2921 relid);
2922
2926
2927 /* Release tabentry to avoid leakage */
2928 if (tabentry)
2929 pfree(tabentry);
2930
2931 /* ignore ANALYZE for toast tables */
2932 if (classForm->relkind == RELKIND_TOASTVALUE)
2933 *doanalyze = false;
2934}

References fb(), pfree(), pgstat_fetch_stat_tabentry_ext(), and relation_needs_vacanalyze().

Referenced by table_recheck_autovac().

◆ relation_needs_vacanalyze()

static void relation_needs_vacanalyze ( Oid  relid,
AutoVacOpts relopts,
Form_pg_class  classForm,
PgStat_StatTabEntry tabentry,
int  effective_multixact_freeze_max_age,
bool dovacuum,
bool doanalyze,
bool wraparound 
)
static

Definition at line 2976 of file autovacuum.c.

2985{
2986 bool force_vacuum;
2987 bool av_enabled;
2988
2989 /* constants from reloptions or GUC variables */
2990 int vac_base_thresh,
2997
2998 /* thresholds calculated from above constants */
3001 anlthresh;
3002
3003 /* number of vacuum (resp. analyze) tuples at this time */
3005 instuples,
3006 anltuples;
3007
3008 /* freeze parameters */
3009 int freeze_max_age;
3010 int multixact_freeze_max_age;
3012 TransactionId relfrozenxid;
3014
3015 Assert(classForm != NULL);
3016 Assert(OidIsValid(relid));
3017
3018 /*
3019 * Determine vacuum/analyze equation parameters. We have two possible
3020 * sources: the passed reloptions (which could be a main table or a toast
3021 * table), or the autovacuum GUC variables.
3022 */
3023
3024 /* -1 in autovac setting means use plain vacuum_scale_factor */
3025 vac_scale_factor = (relopts && relopts->vacuum_scale_factor >= 0)
3026 ? relopts->vacuum_scale_factor
3028
3029 vac_base_thresh = (relopts && relopts->vacuum_threshold >= 0)
3030 ? relopts->vacuum_threshold
3032
3033 /* -1 is used to disable max threshold */
3034 vac_max_thresh = (relopts && relopts->vacuum_max_threshold >= -1)
3035 ? relopts->vacuum_max_threshold
3037
3038 vac_ins_scale_factor = (relopts && relopts->vacuum_ins_scale_factor >= 0)
3039 ? relopts->vacuum_ins_scale_factor
3041
3042 /* -1 is used to disable insert vacuums */
3043 vac_ins_base_thresh = (relopts && relopts->vacuum_ins_threshold >= -1)
3044 ? relopts->vacuum_ins_threshold
3046
3047 anl_scale_factor = (relopts && relopts->analyze_scale_factor >= 0)
3048 ? relopts->analyze_scale_factor
3050
3051 anl_base_thresh = (relopts && relopts->analyze_threshold >= 0)
3052 ? relopts->analyze_threshold
3054
3055 freeze_max_age = (relopts && relopts->freeze_max_age >= 0)
3056 ? Min(relopts->freeze_max_age, autovacuum_freeze_max_age)
3058
3059 multixact_freeze_max_age = (relopts && relopts->multixact_freeze_max_age >= 0)
3060 ? Min(relopts->multixact_freeze_max_age, effective_multixact_freeze_max_age)
3062
3063 av_enabled = (relopts ? relopts->enabled : true);
3064
3065 /* Force vacuum if table is at risk of wraparound */
3066 xidForceLimit = recentXid - freeze_max_age;
3069 relfrozenxid = classForm->relfrozenxid;
3070 force_vacuum = (TransactionIdIsNormal(relfrozenxid) &&
3071 TransactionIdPrecedes(relfrozenxid, xidForceLimit));
3072 if (!force_vacuum)
3073 {
3074 MultiXactId relminmxid = classForm->relminmxid;
3075
3076 multiForceLimit = recentMulti - multixact_freeze_max_age;
3079 force_vacuum = MultiXactIdIsValid(relminmxid) &&
3081 }
3083
3084 /* User disabled it in pg_class.reloptions? (But ignore if at risk) */
3085 if (!av_enabled && !force_vacuum)
3086 {
3087 *doanalyze = false;
3088 *dovacuum = false;
3089 return;
3090 }
3091
3092 /*
3093 * If we found stats for the table, and autovacuum is currently enabled,
3094 * make a threshold-based decision whether to vacuum and/or analyze. If
3095 * autovacuum is currently disabled, we must be here for anti-wraparound
3096 * vacuuming only, so don't vacuum (or analyze) anything that's not being
3097 * forced.
3098 */
3100 {
3102 float4 reltuples = classForm->reltuples;
3103 int32 relpages = classForm->relpages;
3104 int32 relallfrozen = classForm->relallfrozen;
3105
3106 vactuples = tabentry->dead_tuples;
3107 instuples = tabentry->ins_since_vacuum;
3108 anltuples = tabentry->mod_since_analyze;
3109
3110 /* If the table hasn't yet been vacuumed, take reltuples as zero */
3111 if (reltuples < 0)
3112 reltuples = 0;
3113
3114 /*
3115 * If we have data for relallfrozen, calculate the unfrozen percentage
3116 * of the table to modify insert scale factor. This helps us decide
3117 * whether or not to vacuum an insert-heavy table based on the number
3118 * of inserts to the more "active" part of the table.
3119 */
3120 if (relpages > 0 && relallfrozen > 0)
3121 {
3122 /*
3123 * It could be the stats were updated manually and relallfrozen >
3124 * relpages. Clamp relallfrozen to relpages to avoid nonsensical
3125 * calculations.
3126 */
3127 relallfrozen = Min(relallfrozen, relpages);
3128 pcnt_unfrozen = 1 - ((float4) relallfrozen / relpages);
3129 }
3130
3134
3136 vac_ins_scale_factor * reltuples * pcnt_unfrozen;
3138
3139 if (vac_ins_base_thresh >= 0)
3140 elog(DEBUG3, "%s: vac: %.0f (threshold %.0f), ins: %.0f (threshold %.0f), anl: %.0f (threshold %.0f)",
3141 NameStr(classForm->relname),
3143 else
3144 elog(DEBUG3, "%s: vac: %.0f (threshold %.0f), ins: (disabled), anl: %.0f (threshold %.0f)",
3145 NameStr(classForm->relname),
3147
3148 /* Determine if this table needs vacuum or analyze. */
3152 }
3153 else
3154 {
3155 /*
3156 * Skip a table not found in stat hash, unless we have to force vacuum
3157 * for anti-wrap purposes. If it's not acted upon, there's no need to
3158 * vacuum it.
3159 */
3161 *doanalyze = false;
3162 }
3163
3164 /* ANALYZE refuses to work with pg_statistic */
3165 if (relid == StatisticRelationId)
3166 *doanalyze = false;
3167}
double autovacuum_vac_scale
Definition autovacuum.c:124
int autovacuum_anl_thresh
Definition autovacuum.c:127
int autovacuum_vac_thresh
Definition autovacuum.c:122
double autovacuum_anl_scale
Definition autovacuum.c:128
int autovacuum_vac_ins_thresh
Definition autovacuum.c:125
double autovacuum_vac_ins_scale
Definition autovacuum.c:126
int autovacuum_vac_max_thresh
Definition autovacuum.c:123
int32_t int32
Definition c.h:542
float float4
Definition c.h:643
#define DEBUG3
Definition elog.h:28
#define MultiXactIdIsValid(multi)
Definition multixact.h:29
#define TransactionIdIsNormal(xid)
Definition transam.h:42

References Assert, autovacuum_anl_scale, autovacuum_anl_thresh, autovacuum_freeze_max_age, autovacuum_vac_ins_scale, autovacuum_vac_ins_thresh, autovacuum_vac_max_thresh, autovacuum_vac_scale, autovacuum_vac_thresh, AutoVacuumingActive(), DEBUG3, elog, fb(), FirstMultiXactId, FirstNormalTransactionId, Min, MultiXactIdIsValid, MultiXactIdPrecedes(), NameStr, OidIsValid, recentMulti, recentXid, TransactionIdIsNormal, and TransactionIdPrecedes().

Referenced by do_autovacuum(), and recheck_relation_needs_vacanalyze().

◆ table_recheck_autovac()

static autovac_table * table_recheck_autovac ( Oid  relid,
HTAB table_toast_map,
TupleDesc  pg_class_desc,
int  effective_multixact_freeze_max_age 
)
static

Definition at line 2751 of file autovacuum.c.

2754{
2757 bool dovacuum;
2758 bool doanalyze;
2759 autovac_table *tab = NULL;
2760 bool wraparound;
2762 bool free_avopts = false;
2763
2764 /* fetch the relation's relcache entry */
2767 return NULL;
2769
2770 /*
2771 * Get the applicable reloptions. If it is a TOAST table, try to get the
2772 * main table reloptions if the toast table itself doesn't have.
2773 */
2775 if (avopts)
2776 free_avopts = true;
2777 else if (classForm->relkind == RELKIND_TOASTVALUE &&
2779 {
2781 bool found;
2782
2783 hentry = hash_search(table_toast_map, &relid, HASH_FIND, &found);
2784 if (found && hentry->ar_hasrelopts)
2785 avopts = &hentry->ar_reloptions;
2786 }
2787
2791
2792 /* OK, it needs something done */
2793 if (doanalyze || dovacuum)
2794 {
2795 int freeze_min_age;
2796 int freeze_table_age;
2797 int multixact_freeze_min_age;
2798 int multixact_freeze_table_age;
2799 int log_vacuum_min_duration;
2800 int log_analyze_min_duration;
2801
2802 /*
2803 * Calculate the vacuum cost parameters and the freeze ages. If there
2804 * are options set in pg_class.reloptions, use them; in the case of a
2805 * toast table, try the main table too. Otherwise use the GUC
2806 * defaults, autovacuum's own first and plain vacuum second.
2807 */
2808
2809 /* -1 in autovac setting means use log_autovacuum_min_duration */
2810 log_vacuum_min_duration = (avopts && avopts->log_vacuum_min_duration >= 0)
2811 ? avopts->log_vacuum_min_duration
2813
2814 /* -1 in autovac setting means use log_autoanalyze_min_duration */
2815 log_analyze_min_duration = (avopts && avopts->log_analyze_min_duration >= 0)
2816 ? avopts->log_analyze_min_duration
2818
2819 /* these do not have autovacuum-specific settings */
2820 freeze_min_age = (avopts && avopts->freeze_min_age >= 0)
2821 ? avopts->freeze_min_age
2823
2824 freeze_table_age = (avopts && avopts->freeze_table_age >= 0)
2825 ? avopts->freeze_table_age
2827
2828 multixact_freeze_min_age = (avopts &&
2829 avopts->multixact_freeze_min_age >= 0)
2830 ? avopts->multixact_freeze_min_age
2832
2833 multixact_freeze_table_age = (avopts &&
2834 avopts->multixact_freeze_table_age >= 0)
2835 ? avopts->multixact_freeze_table_age
2837
2839 tab->at_relid = relid;
2840 tab->at_sharedrel = classForm->relisshared;
2841
2842 /*
2843 * Select VACUUM options. Note we don't say VACOPT_PROCESS_TOAST, so
2844 * that vacuum() skips toast relations. Also note we tell vacuum() to
2845 * skip vac_update_datfrozenxid(); we'll do that separately.
2846 */
2847 tab->at_params.options =
2851 (doanalyze ? VACOPT_ANALYZE : 0) |
2853
2854 /*
2855 * index_cleanup and truncate are unspecified at first in autovacuum.
2856 * They will be filled in with usable values using their reloptions
2857 * (or reloption defaults) later.
2858 */
2861 /* As of now, we don't support parallel vacuum for autovacuum */
2862 tab->at_params.nworkers = -1;
2863 tab->at_params.freeze_min_age = freeze_min_age;
2864 tab->at_params.freeze_table_age = freeze_table_age;
2865 tab->at_params.multixact_freeze_min_age = multixact_freeze_min_age;
2866 tab->at_params.multixact_freeze_table_age = multixact_freeze_table_age;
2868 tab->at_params.log_vacuum_min_duration = log_vacuum_min_duration;
2869 tab->at_params.log_analyze_min_duration = log_analyze_min_duration;
2871
2872 /*
2873 * Later, in vacuum_rel(), we check reloptions for any
2874 * vacuum_max_eager_freeze_failure_rate override.
2875 */
2878 avopts->vacuum_cost_limit : 0;
2880 avopts->vacuum_cost_delay : -1;
2881 tab->at_relname = NULL;
2882 tab->at_nspname = NULL;
2883 tab->at_datname = NULL;
2884
2885 /*
2886 * If any of the cost delay parameters has been set individually for
2887 * this table, disable the balancing algorithm.
2888 */
2889 tab->at_dobalance =
2890 !(avopts && (avopts->vacuum_cost_limit > 0 ||
2891 avopts->vacuum_cost_delay >= 0));
2892 }
2893
2894 if (free_avopts)
2895 pfree(avopts);
2897 return tab;
2898}
int Log_autovacuum_min_duration
Definition autovacuum.c:135
static void recheck_relation_needs_vacanalyze(Oid relid, AutoVacOpts *avopts, Form_pg_class classForm, int effective_multixact_freeze_max_age, bool *dovacuum, bool *doanalyze, bool *wraparound)
int Log_autoanalyze_min_duration
Definition autovacuum.c:136
void heap_freetuple(HeapTuple htup)
Definition heaptuple.c:1435
int nworkers
Definition vacuum.h:251
int freeze_table_age
Definition vacuum.h:221
VacOptValue truncate
Definition vacuum.h:236
int freeze_min_age
Definition vacuum.h:220
int log_vacuum_min_duration
Definition vacuum.h:227
int multixact_freeze_min_age
Definition vacuum.h:222
int multixact_freeze_table_age
Definition vacuum.h:224
Oid toast_parent
Definition vacuum.h:237
VacOptValue index_cleanup
Definition vacuum.h:235
int log_analyze_min_duration
Definition vacuum.h:231
double max_eager_freeze_failure_rate
Definition vacuum.h:244
double vacuum_max_eager_freeze_failure_rate
Definition vacuum.c:81
#define VACOPT_SKIP_LOCKED
Definition vacuum.h:185
#define VACOPT_SKIP_DATABASE_STATS
Definition vacuum.h:189
@ VACOPTVALUE_UNSPECIFIED
Definition vacuum.h:202
#define VACOPT_PROCESS_MAIN
Definition vacuum.h:186

References autovac_table::at_datname, autovac_table::at_dobalance, autovac_table::at_nspname, autovac_table::at_params, autovac_table::at_relid, autovac_table::at_relname, autovac_table::at_sharedrel, autovac_table::at_storage_param_vac_cost_delay, autovac_table::at_storage_param_vac_cost_limit, default_freeze_min_age, default_freeze_table_age, default_multixact_freeze_min_age, default_multixact_freeze_table_age, extract_autovac_opts(), fb(), VacuumParams::freeze_min_age, VacuumParams::freeze_table_age, GETSTRUCT(), HASH_FIND, hash_search(), heap_freetuple(), HeapTupleIsValid, VacuumParams::index_cleanup, InvalidOid, VacuumParams::is_wraparound, VacuumParams::log_analyze_min_duration, Log_autoanalyze_min_duration, Log_autovacuum_min_duration, VacuumParams::log_vacuum_min_duration, VacuumParams::max_eager_freeze_failure_rate, VacuumParams::multixact_freeze_min_age, VacuumParams::multixact_freeze_table_age, VacuumParams::nworkers, ObjectIdGetDatum(), VacuumParams::options, palloc_object, pfree(), recheck_relation_needs_vacanalyze(), SearchSysCacheCopy1, VacuumParams::toast_parent, VacuumParams::truncate, VACOPT_ANALYZE, VACOPT_PROCESS_MAIN, VACOPT_SKIP_DATABASE_STATS, VACOPT_SKIP_LOCKED, VACOPT_VACUUM, VACOPTVALUE_UNSPECIFIED, and vacuum_max_eager_freeze_failure_rate.

Referenced by do_autovacuum().

◆ VacuumUpdateCosts()

void VacuumUpdateCosts ( void  )

Definition at line 1646 of file autovacuum.c.

1647{
1648 if (MyWorkerInfo)
1649 {
1652 else if (autovacuum_vac_cost_delay >= 0)
1654 else
1655 /* fall back to VacuumCostDelay */
1657
1659 }
1660 else
1661 {
1662 /* Must be explicit VACUUM or ANALYZE */
1665 }
1666
1667 /*
1668 * If configuration changes are allowed to impact VacuumCostActive, make
1669 * sure it is updated.
1670 */
1673 else if (vacuum_cost_delay > 0)
1674 VacuumCostActive = true;
1675 else
1676 {
1677 VacuumCostActive = false;
1679 }
1680
1681 /*
1682 * Since the cost logging requires a lock, avoid rendering the log message
1683 * in case we are using a message level where the log wouldn't be emitted.
1684 */
1686 {
1687 Oid dboid,
1688 tableoid;
1689
1691
1693 dboid = MyWorkerInfo->wi_dboid;
1694 tableoid = MyWorkerInfo->wi_tableoid;
1696
1697 elog(DEBUG2,
1698 "Autovacuum VacuumUpdateCosts(db=%u, rel=%u, dobalance=%s, cost_limit=%d, cost_delay=%g active=%s failsafe=%s)",
1699 dboid, tableoid, pg_atomic_unlocked_test_flag(&MyWorkerInfo->wi_dobalance) ? "no" : "yes",
1701 vacuum_cost_delay > 0 ? "yes" : "no",
1702 VacuumFailsafeActive ? "yes" : "no");
1703 }
1704}
double autovacuum_vac_cost_delay
Definition autovacuum.c:132
void AutoVacuumUpdateCostLimit(void)
bool message_level_is_interesting(int elevel)
Definition elog.c:273
bool VacuumCostActive
Definition globals.c:158
int VacuumCostBalance
Definition globals.c:157
double VacuumCostDelay
Definition globals.c:155
double vacuum_cost_delay
Definition vacuum.c:91
bool VacuumFailsafeActive
Definition vacuum.c:110

References Assert, autovacuum_vac_cost_delay, AutoVacuumUpdateCostLimit(), av_storage_param_cost_delay, DEBUG2, elog, fb(), LW_SHARED, LWLockAcquire(), LWLockHeldByMe(), LWLockRelease(), message_level_is_interesting(), MyWorkerInfo, pg_atomic_unlocked_test_flag(), vacuum_cost_delay, vacuum_cost_limit, VacuumCostActive, VacuumCostBalance, VacuumCostDelay, VacuumCostLimit, VacuumFailsafeActive, WorkerInfoData::wi_dboid, WorkerInfoData::wi_dobalance, and WorkerInfoData::wi_tableoid.

Referenced by do_autovacuum(), parallel_vacuum_main(), vacuum(), and vacuum_delay_point().

Variable Documentation

◆ AutovacMemCxt

MemoryContext AutovacMemCxt
static

◆ autovacuum_anl_scale

double autovacuum_anl_scale

Definition at line 128 of file autovacuum.c.

Referenced by relation_needs_vacanalyze().

◆ autovacuum_anl_thresh

int autovacuum_anl_thresh

Definition at line 127 of file autovacuum.c.

Referenced by relation_needs_vacanalyze().

◆ autovacuum_freeze_max_age

◆ autovacuum_max_workers

int autovacuum_max_workers

◆ autovacuum_multixact_freeze_max_age

int autovacuum_multixact_freeze_max_age

◆ autovacuum_naptime

◆ autovacuum_start_daemon

bool autovacuum_start_daemon = false

Definition at line 117 of file autovacuum.c.

Referenced by autovac_init(), AutoVacuumingActive(), and removable_cutoff().

◆ autovacuum_vac_cost_delay

double autovacuum_vac_cost_delay

Definition at line 132 of file autovacuum.c.

Referenced by VacuumUpdateCosts().

◆ autovacuum_vac_cost_limit

int autovacuum_vac_cost_limit

Definition at line 133 of file autovacuum.c.

Referenced by AutoVacuumUpdateCostLimit().

◆ autovacuum_vac_ins_scale

double autovacuum_vac_ins_scale

Definition at line 126 of file autovacuum.c.

Referenced by relation_needs_vacanalyze().

◆ autovacuum_vac_ins_thresh

int autovacuum_vac_ins_thresh

Definition at line 125 of file autovacuum.c.

Referenced by relation_needs_vacanalyze().

◆ autovacuum_vac_max_thresh

int autovacuum_vac_max_thresh

Definition at line 123 of file autovacuum.c.

Referenced by relation_needs_vacanalyze().

◆ autovacuum_vac_scale

double autovacuum_vac_scale

Definition at line 124 of file autovacuum.c.

Referenced by relation_needs_vacanalyze().

◆ autovacuum_vac_thresh

int autovacuum_vac_thresh

Definition at line 122 of file autovacuum.c.

Referenced by relation_needs_vacanalyze().

◆ autovacuum_work_mem

int autovacuum_work_mem = -1

Definition at line 120 of file autovacuum.c.

Referenced by dead_items_alloc(), and ginInsertCleanup().

◆ autovacuum_worker_slots

◆ AutoVacuumShmem

◆ av_storage_param_cost_delay

double av_storage_param_cost_delay = -1
static

Definition at line 151 of file autovacuum.c.

Referenced by do_autovacuum(), and VacuumUpdateCosts().

◆ av_storage_param_cost_limit

int av_storage_param_cost_limit = -1
static

Definition at line 152 of file autovacuum.c.

Referenced by AutoVacuumUpdateCostLimit(), and do_autovacuum().

◆ DatabaseList

dlist_head DatabaseList = DLIST_STATIC_INIT(DatabaseList)
static

◆ DatabaseListCxt

MemoryContext DatabaseListCxt = NULL
static

Definition at line 311 of file autovacuum.c.

Referenced by AutoVacLauncherMain(), and rebuild_database_list().

◆ default_freeze_min_age

int default_freeze_min_age
static

Definition at line 162 of file autovacuum.c.

Referenced by do_autovacuum(), and table_recheck_autovac().

◆ default_freeze_table_age

int default_freeze_table_age
static

Definition at line 163 of file autovacuum.c.

Referenced by do_autovacuum(), and table_recheck_autovac().

◆ default_multixact_freeze_min_age

int default_multixact_freeze_min_age
static

Definition at line 164 of file autovacuum.c.

Referenced by do_autovacuum(), and table_recheck_autovac().

◆ default_multixact_freeze_table_age

int default_multixact_freeze_table_age
static

Definition at line 165 of file autovacuum.c.

Referenced by do_autovacuum(), and table_recheck_autovac().

◆ got_SIGUSR2

volatile sig_atomic_t got_SIGUSR2 = false
static

Definition at line 155 of file autovacuum.c.

Referenced by AutoVacLauncherMain(), and avl_sigusr2_handler().

◆ Log_autoanalyze_min_duration

int Log_autoanalyze_min_duration = 600000

Definition at line 136 of file autovacuum.c.

Referenced by table_recheck_autovac().

◆ Log_autovacuum_min_duration

int Log_autovacuum_min_duration = 600000

Definition at line 135 of file autovacuum.c.

Referenced by table_recheck_autovac().

◆ MyWorkerInfo

◆ recentMulti

MultiXactId recentMulti
static

Definition at line 159 of file autovacuum.c.

Referenced by AutoVacWorkerMain(), do_start_worker(), and relation_needs_vacanalyze().

◆ recentXid

TransactionId recentXid
static

Definition at line 158 of file autovacuum.c.

Referenced by AutoVacWorkerMain(), do_start_worker(), and relation_needs_vacanalyze().