PostgreSQL Source Code git master
parallel.c
Go to the documentation of this file.
1/*-------------------------------------------------------------------------
2 *
3 * parallel.c
4 * Infrastructure for launching parallel workers
5 *
6 * Portions Copyright (c) 1996-2026, PostgreSQL Global Development Group
7 * Portions Copyright (c) 1994, Regents of the University of California
8 *
9 * IDENTIFICATION
10 * src/backend/access/transam/parallel.c
11 *
12 *-------------------------------------------------------------------------
13 */
14
15#include "postgres.h"
16
17#include "access/brin.h"
18#include "access/gin.h"
19#include "access/nbtree.h"
20#include "access/parallel.h"
21#include "access/session.h"
22#include "access/xact.h"
23#include "access/xlog.h"
24#include "catalog/index.h"
25#include "catalog/namespace.h"
26#include "catalog/pg_enum.h"
27#include "catalog/storage.h"
28#include "commands/async.h"
29#include "commands/vacuum.h"
31#include "libpq/libpq.h"
32#include "libpq/pqformat.h"
33#include "libpq/pqmq.h"
34#include "miscadmin.h"
35#include "optimizer/optimizer.h"
36#include "pgstat.h"
37#include "storage/ipc.h"
38#include "storage/predicate.h"
39#include "storage/spin.h"
40#include "tcop/tcopprot.h"
41#include "utils/combocid.h"
42#include "utils/guc.h"
43#include "utils/inval.h"
44#include "utils/memutils.h"
45#include "utils/relmapper.h"
46#include "utils/snapmgr.h"
47
48/*
49 * We don't want to waste a lot of memory on an error queue which, most of
50 * the time, will process only a handful of small messages. However, it is
51 * desirable to make it large enough that a typical ErrorResponse can be sent
52 * without blocking. That way, a worker that errors out can write the whole
53 * message into the queue and terminate without waiting for the user backend.
54 */
55#define PARALLEL_ERROR_QUEUE_SIZE 16384
56
57/* Magic number for parallel context TOC. */
58#define PARALLEL_MAGIC 0x50477c7c
59
60/*
61 * Magic numbers for per-context parallel state sharing. Higher-level code
62 * should use smaller values, leaving these very large ones for use by this
63 * module.
64 */
65#define PARALLEL_KEY_FIXED UINT64CONST(0xFFFFFFFFFFFF0001)
66#define PARALLEL_KEY_ERROR_QUEUE UINT64CONST(0xFFFFFFFFFFFF0002)
67#define PARALLEL_KEY_LIBRARY UINT64CONST(0xFFFFFFFFFFFF0003)
68#define PARALLEL_KEY_GUC UINT64CONST(0xFFFFFFFFFFFF0004)
69#define PARALLEL_KEY_COMBO_CID UINT64CONST(0xFFFFFFFFFFFF0005)
70#define PARALLEL_KEY_TRANSACTION_SNAPSHOT UINT64CONST(0xFFFFFFFFFFFF0006)
71#define PARALLEL_KEY_ACTIVE_SNAPSHOT UINT64CONST(0xFFFFFFFFFFFF0007)
72#define PARALLEL_KEY_TRANSACTION_STATE UINT64CONST(0xFFFFFFFFFFFF0008)
73#define PARALLEL_KEY_ENTRYPOINT UINT64CONST(0xFFFFFFFFFFFF0009)
74#define PARALLEL_KEY_SESSION_DSM UINT64CONST(0xFFFFFFFFFFFF000A)
75#define PARALLEL_KEY_PENDING_SYNCS UINT64CONST(0xFFFFFFFFFFFF000B)
76#define PARALLEL_KEY_REINDEX_STATE UINT64CONST(0xFFFFFFFFFFFF000C)
77#define PARALLEL_KEY_RELMAPPER_STATE UINT64CONST(0xFFFFFFFFFFFF000D)
78#define PARALLEL_KEY_UNCOMMITTEDENUMS UINT64CONST(0xFFFFFFFFFFFF000E)
79#define PARALLEL_KEY_CLIENTCONNINFO UINT64CONST(0xFFFFFFFFFFFF000F)
80
81/* Fixed-size parallel state. */
82typedef struct FixedParallelState
83{
84 /* Fixed-size state that workers must restore. */
101
102 /* Mutex protects remaining fields. */
103 slock_t mutex;
104
105 /* Maximum XactLastRecEnd of any worker. */
108
109/*
110 * Our parallel worker number. We initialize this to -1, meaning that we are
111 * not a parallel worker. In parallel workers, it will be set to a value >= 0
112 * and < the number of workers before any user code is invoked; each parallel
113 * worker will get a different parallel worker number.
114 */
116
117/* Is there a parallel message pending which we need to receive? */
118volatile sig_atomic_t ParallelMessagePending = false;
119
120/* Are we initializing a parallel worker? */
122
123/* Pointer to our fixed parallel state. */
125
126/* List of active parallel contexts. */
128
129/* Backend-local copy of data from FixedParallelState. */
130static pid_t ParallelLeaderPid;
131
132/*
133 * List of internal parallel worker entry points. We need this for
134 * reasons explained in LookupParallelWorkerFunction(), below.
135 */
136static const struct
137{
138 const char *fn_name;
141
142{
143 {
144 "ParallelQueryMain", ParallelQueryMain
145 },
146 {
147 "_bt_parallel_build_main", _bt_parallel_build_main
148 },
149 {
150 "_brin_parallel_build_main", _brin_parallel_build_main
151 },
152 {
153 "_gin_parallel_build_main", _gin_parallel_build_main
154 },
155 {
156 "parallel_vacuum_main", parallel_vacuum_main
157 }
159
160/* Private functions. */
161static void ProcessParallelMessage(ParallelContext *pcxt, int i, StringInfo msg);
163static parallel_worker_main_type LookupParallelWorkerFunction(const char *libraryname, const char *funcname);
164static void ParallelWorkerShutdown(int code, Datum arg);
165
166
167/*
168 * Establish a new parallel context. This should be done after entering
169 * parallel mode, and (unless there is an error) the context should be
170 * destroyed before exiting the current subtransaction.
171 */
173CreateParallelContext(const char *library_name, const char *function_name,
174 int nworkers)
175{
176 MemoryContext oldcontext;
177 ParallelContext *pcxt;
178
179 /* It is unsafe to create a parallel context if not in parallel mode. */
181
182 /* Number of workers should be non-negative. */
183 Assert(nworkers >= 0);
184
185 /* We might be running in a short-lived memory context. */
187
188 /* Initialize a new ParallelContext. */
191 pcxt->nworkers = nworkers;
192 pcxt->nworkers_to_launch = nworkers;
193 pcxt->library_name = pstrdup(library_name);
194 pcxt->function_name = pstrdup(function_name);
198
199 /* Restore previous memory context. */
200 MemoryContextSwitchTo(oldcontext);
201
202 return pcxt;
203}
204
205/*
206 * Establish the dynamic shared memory segment for a parallel context and
207 * copy state and other bookkeeping information that will be needed by
208 * parallel workers into it.
209 */
210void
212{
213 MemoryContext oldcontext;
214 Size library_len = 0;
215 Size guc_len = 0;
216 Size combocidlen = 0;
217 Size tsnaplen = 0;
218 Size asnaplen = 0;
219 Size tstatelen = 0;
220 Size pendingsyncslen = 0;
221 Size reindexlen = 0;
222 Size relmapperlen = 0;
223 Size uncommittedenumslen = 0;
224 Size clientconninfolen = 0;
225 Size segsize = 0;
226 int i;
228 dsm_handle session_dsm_handle = DSM_HANDLE_INVALID;
229 Snapshot transaction_snapshot = GetTransactionSnapshot();
230 Snapshot active_snapshot = GetActiveSnapshot();
231
232 /* We might be running in a very short-lived memory context. */
234
235 /* Allow space to store the fixed-size parallel state. */
238
239 /*
240 * If we manage to reach here while non-interruptible, it's unsafe to
241 * launch any workers: we would fail to process interrupts sent by them.
242 * We can deal with that edge case by pretending no workers were
243 * requested.
244 */
246 pcxt->nworkers = 0;
247
248 /*
249 * Normally, the user will have requested at least one worker process, but
250 * if by chance they have not, we can skip a bunch of things here.
251 */
252 if (pcxt->nworkers > 0)
253 {
254 /* Get (or create) the per-session DSM segment's handle. */
255 session_dsm_handle = GetSessionDsmHandle();
256
257 /*
258 * If we weren't able to create a per-session DSM segment, then we can
259 * continue but we can't safely launch any workers because their
260 * record typmods would be incompatible so they couldn't exchange
261 * tuples.
262 */
263 if (session_dsm_handle == DSM_HANDLE_INVALID)
264 pcxt->nworkers = 0;
265 }
266
267 if (pcxt->nworkers > 0)
268 {
271 "parallel error queue size not buffer-aligned");
272
273 /* Estimate space for various kinds of state sharing. */
274 library_len = EstimateLibraryStateSpace();
275 shm_toc_estimate_chunk(&pcxt->estimator, library_len);
276 guc_len = EstimateGUCStateSpace();
277 shm_toc_estimate_chunk(&pcxt->estimator, guc_len);
278 combocidlen = EstimateComboCIDStateSpace();
279 shm_toc_estimate_chunk(&pcxt->estimator, combocidlen);
281 {
282 tsnaplen = EstimateSnapshotSpace(transaction_snapshot);
283 shm_toc_estimate_chunk(&pcxt->estimator, tsnaplen);
284 }
285 asnaplen = EstimateSnapshotSpace(active_snapshot);
286 shm_toc_estimate_chunk(&pcxt->estimator, asnaplen);
287 tstatelen = EstimateTransactionStateSpace();
288 shm_toc_estimate_chunk(&pcxt->estimator, tstatelen);
290 pendingsyncslen = EstimatePendingSyncsSpace();
291 shm_toc_estimate_chunk(&pcxt->estimator, pendingsyncslen);
292 reindexlen = EstimateReindexStateSpace();
293 shm_toc_estimate_chunk(&pcxt->estimator, reindexlen);
294 relmapperlen = EstimateRelationMapSpace();
295 shm_toc_estimate_chunk(&pcxt->estimator, relmapperlen);
296 uncommittedenumslen = EstimateUncommittedEnumsSpace();
297 shm_toc_estimate_chunk(&pcxt->estimator, uncommittedenumslen);
298 clientconninfolen = EstimateClientConnectionInfoSpace();
299 shm_toc_estimate_chunk(&pcxt->estimator, clientconninfolen);
300 /* If you add more chunks here, you probably need to add keys. */
302
303 /* Estimate space need for error queues. */
306 pcxt->nworkers));
308
309 /* Estimate how much we'll need for the entrypoint info. */
310 shm_toc_estimate_chunk(&pcxt->estimator, strlen(pcxt->library_name) +
311 strlen(pcxt->function_name) + 2);
313 }
314
315 /*
316 * Create DSM and initialize with new table of contents. But if the user
317 * didn't request any workers, then don't bother creating a dynamic shared
318 * memory segment; instead, just use backend-private memory.
319 *
320 * Also, if we can't create a dynamic shared memory segment because the
321 * maximum number of segments have already been created, then fall back to
322 * backend-private memory, and plan not to use any workers. We hope this
323 * won't happen very often, but it's better to abandon the use of
324 * parallelism than to fail outright.
325 */
326 segsize = shm_toc_estimate(&pcxt->estimator);
327 if (pcxt->nworkers > 0)
329 if (pcxt->seg != NULL)
332 segsize);
333 else
334 {
335 pcxt->nworkers = 0;
338 segsize);
339 }
340
341 /* Initialize fixed-size state in shared memory. */
342 fps = (FixedParallelState *)
359 SpinLockInit(&fps->mutex);
360 fps->last_xlog_end = 0;
362
363 /* We can skip the rest of this if we're not budgeting for any workers. */
364 if (pcxt->nworkers > 0)
365 {
366 char *libraryspace;
367 char *gucspace;
368 char *combocidspace;
369 char *tsnapspace;
370 char *asnapspace;
371 char *tstatespace;
372 char *pendingsyncsspace;
373 char *reindexspace;
374 char *relmapperspace;
375 char *error_queue_space;
376 char *session_dsm_handle_space;
377 char *entrypointstate;
378 char *uncommittedenumsspace;
379 char *clientconninfospace;
380 Size lnamelen;
381
382 /* Serialize shared libraries we have loaded. */
383 libraryspace = shm_toc_allocate(pcxt->toc, library_len);
384 SerializeLibraryState(library_len, libraryspace);
385 shm_toc_insert(pcxt->toc, PARALLEL_KEY_LIBRARY, libraryspace);
386
387 /* Serialize GUC settings. */
388 gucspace = shm_toc_allocate(pcxt->toc, guc_len);
389 SerializeGUCState(guc_len, gucspace);
390 shm_toc_insert(pcxt->toc, PARALLEL_KEY_GUC, gucspace);
391
392 /* Serialize combo CID state. */
393 combocidspace = shm_toc_allocate(pcxt->toc, combocidlen);
394 SerializeComboCIDState(combocidlen, combocidspace);
395 shm_toc_insert(pcxt->toc, PARALLEL_KEY_COMBO_CID, combocidspace);
396
397 /*
398 * Serialize the transaction snapshot if the transaction isolation
399 * level uses a transaction snapshot.
400 */
402 {
403 tsnapspace = shm_toc_allocate(pcxt->toc, tsnaplen);
404 SerializeSnapshot(transaction_snapshot, tsnapspace);
406 tsnapspace);
407 }
408
409 /* Serialize the active snapshot. */
410 asnapspace = shm_toc_allocate(pcxt->toc, asnaplen);
411 SerializeSnapshot(active_snapshot, asnapspace);
413
414 /* Provide the handle for per-session segment. */
415 session_dsm_handle_space = shm_toc_allocate(pcxt->toc,
416 sizeof(dsm_handle));
417 *(dsm_handle *) session_dsm_handle_space = session_dsm_handle;
419 session_dsm_handle_space);
420
421 /* Serialize transaction state. */
422 tstatespace = shm_toc_allocate(pcxt->toc, tstatelen);
423 SerializeTransactionState(tstatelen, tstatespace);
425
426 /* Serialize pending syncs. */
427 pendingsyncsspace = shm_toc_allocate(pcxt->toc, pendingsyncslen);
428 SerializePendingSyncs(pendingsyncslen, pendingsyncsspace);
430 pendingsyncsspace);
431
432 /* Serialize reindex state. */
433 reindexspace = shm_toc_allocate(pcxt->toc, reindexlen);
434 SerializeReindexState(reindexlen, reindexspace);
435 shm_toc_insert(pcxt->toc, PARALLEL_KEY_REINDEX_STATE, reindexspace);
436
437 /* Serialize relmapper state. */
438 relmapperspace = shm_toc_allocate(pcxt->toc, relmapperlen);
439 SerializeRelationMap(relmapperlen, relmapperspace);
441 relmapperspace);
442
443 /* Serialize uncommitted enum state. */
444 uncommittedenumsspace = shm_toc_allocate(pcxt->toc,
445 uncommittedenumslen);
446 SerializeUncommittedEnums(uncommittedenumsspace, uncommittedenumslen);
448 uncommittedenumsspace);
449
450 /* Serialize our ClientConnectionInfo. */
451 clientconninfospace = shm_toc_allocate(pcxt->toc, clientconninfolen);
452 SerializeClientConnectionInfo(clientconninfolen, clientconninfospace);
454 clientconninfospace);
455
456 /* Allocate space for worker information. */
458
459 /*
460 * Establish error queues in dynamic shared memory.
461 *
462 * These queues should be used only for transmitting ErrorResponse,
463 * NoticeResponse, and NotifyResponse protocol messages. Tuple data
464 * should be transmitted via separate (possibly larger?) queues.
465 */
466 error_queue_space =
467 shm_toc_allocate(pcxt->toc,
469 pcxt->nworkers));
470 for (i = 0; i < pcxt->nworkers; ++i)
471 {
472 char *start;
473 shm_mq *mq;
474
475 start = error_queue_space + i * PARALLEL_ERROR_QUEUE_SIZE;
478 pcxt->worker[i].error_mqh = shm_mq_attach(mq, pcxt->seg, NULL);
479 }
480 shm_toc_insert(pcxt->toc, PARALLEL_KEY_ERROR_QUEUE, error_queue_space);
481
482 /*
483 * Serialize entrypoint information. It's unsafe to pass function
484 * pointers across processes, as the function pointer may be different
485 * in each process in EXEC_BACKEND builds, so we always pass library
486 * and function name. (We use library name "postgres" for functions
487 * in the core backend.)
488 */
489 lnamelen = strlen(pcxt->library_name);
490 entrypointstate = shm_toc_allocate(pcxt->toc, lnamelen +
491 strlen(pcxt->function_name) + 2);
492 strcpy(entrypointstate, pcxt->library_name);
493 strcpy(entrypointstate + lnamelen + 1, pcxt->function_name);
494 shm_toc_insert(pcxt->toc, PARALLEL_KEY_ENTRYPOINT, entrypointstate);
495 }
496
497 /* Update nworkers_to_launch, in case we changed nworkers above. */
498 pcxt->nworkers_to_launch = pcxt->nworkers;
499
500 /* Restore previous memory context. */
501 MemoryContextSwitchTo(oldcontext);
502}
503
504/*
505 * Reinitialize the dynamic shared memory segment for a parallel context such
506 * that we could launch workers for it again.
507 */
508void
510{
511 MemoryContext oldcontext;
513
514 /* We might be running in a very short-lived memory context. */
516
517 /* Wait for any old workers to exit. */
518 if (pcxt->nworkers_launched > 0)
519 {
522 pcxt->nworkers_launched = 0;
523 if (pcxt->known_attached_workers)
524 {
526 pcxt->known_attached_workers = NULL;
527 pcxt->nknown_attached_workers = 0;
528 }
529 }
530
531 /* Reset a few bits of fixed parallel state to a clean state. */
532 fps = shm_toc_lookup(pcxt->toc, PARALLEL_KEY_FIXED, false);
533 fps->last_xlog_end = 0;
534
535 /* Recreate error queues (if they exist). */
536 if (pcxt->nworkers > 0)
537 {
538 char *error_queue_space;
539 int i;
540
541 error_queue_space =
543 for (i = 0; i < pcxt->nworkers; ++i)
544 {
545 char *start;
546 shm_mq *mq;
547
548 start = error_queue_space + i * PARALLEL_ERROR_QUEUE_SIZE;
551 pcxt->worker[i].error_mqh = shm_mq_attach(mq, pcxt->seg, NULL);
552 }
553 }
554
555 /* Restore previous memory context. */
556 MemoryContextSwitchTo(oldcontext);
557}
558
559/*
560 * Reinitialize parallel workers for a parallel context such that we could
561 * launch a different number of workers. This is required for cases where
562 * we need to reuse the same DSM segment, but the number of workers can
563 * vary from run-to-run.
564 */
565void
566ReinitializeParallelWorkers(ParallelContext *pcxt, int nworkers_to_launch)
567{
568 /*
569 * The number of workers that need to be launched must be less than the
570 * number of workers with which the parallel context is initialized. But
571 * the caller might not know that InitializeParallelDSM reduced nworkers,
572 * so just silently trim the request.
573 */
574 pcxt->nworkers_to_launch = Min(pcxt->nworkers, nworkers_to_launch);
575}
576
577/*
578 * Launch parallel workers.
579 */
580void
582{
583 MemoryContext oldcontext;
584 BackgroundWorker worker;
585 int i;
586 bool any_registrations_failed = false;
587
588 /* Skip this if we have no workers. */
589 if (pcxt->nworkers == 0 || pcxt->nworkers_to_launch == 0)
590 return;
591
592 /* We need to be a lock group leader. */
594
595 /* If we do have workers, we'd better have a DSM segment. */
596 Assert(pcxt->seg != NULL);
597
598 /* We might be running in a short-lived memory context. */
600
601 /* Configure a worker. */
602 memset(&worker, 0, sizeof(worker));
603 snprintf(worker.bgw_name, BGW_MAXLEN, "parallel worker for PID %d",
604 MyProcPid);
605 snprintf(worker.bgw_type, BGW_MAXLEN, "parallel worker");
606 worker.bgw_flags =
611 sprintf(worker.bgw_library_name, "postgres");
612 sprintf(worker.bgw_function_name, "ParallelWorkerMain");
614 worker.bgw_notify_pid = MyProcPid;
615
616 /*
617 * Start workers.
618 *
619 * The caller must be able to tolerate ending up with fewer workers than
620 * expected, so there is no need to throw an error here if registration
621 * fails. It wouldn't help much anyway, because registering the worker in
622 * no way guarantees that it will start up and initialize successfully.
623 */
624 for (i = 0; i < pcxt->nworkers_to_launch; ++i)
625 {
626 memcpy(worker.bgw_extra, &i, sizeof(int));
627 if (!any_registrations_failed &&
629 &pcxt->worker[i].bgwhandle))
630 {
632 pcxt->worker[i].bgwhandle);
633 pcxt->nworkers_launched++;
634 }
635 else
636 {
637 /*
638 * If we weren't able to register the worker, then we've bumped up
639 * against the max_worker_processes limit, and future
640 * registrations will probably fail too, so arrange to skip them.
641 * But we still have to execute this code for the remaining slots
642 * to make sure that we forget about the error queues we budgeted
643 * for those workers. Otherwise, we'll wait for them to start,
644 * but they never will.
645 */
646 any_registrations_failed = true;
647 pcxt->worker[i].bgwhandle = NULL;
649 pcxt->worker[i].error_mqh = NULL;
650 }
651 }
652
653 /*
654 * Now that nworkers_launched has taken its final value, we can initialize
655 * known_attached_workers.
656 */
657 if (pcxt->nworkers_launched > 0)
658 {
660 pcxt->nknown_attached_workers = 0;
661 }
662
663 /* Restore previous memory context. */
664 MemoryContextSwitchTo(oldcontext);
665}
666
667/*
668 * Wait for all workers to attach to their error queues, and throw an error if
669 * any worker fails to do this.
670 *
671 * Callers can assume that if this function returns successfully, then the
672 * number of workers given by pcxt->nworkers_launched have initialized and
673 * attached to their error queues. Whether or not these workers are guaranteed
674 * to still be running depends on what code the caller asked them to run;
675 * this function does not guarantee that they have not exited. However, it
676 * does guarantee that any workers which exited must have done so cleanly and
677 * after successfully performing the work with which they were tasked.
678 *
679 * If this function is not called, then some of the workers that were launched
680 * may not have been started due to a fork() failure, or may have exited during
681 * early startup prior to attaching to the error queue, so nworkers_launched
682 * cannot be viewed as completely reliable. It will never be less than the
683 * number of workers which actually started, but it might be more. Any workers
684 * that failed to start will still be discovered by
685 * WaitForParallelWorkersToFinish and an error will be thrown at that time,
686 * provided that function is eventually reached.
687 *
688 * In general, the leader process should do as much work as possible before
689 * calling this function. fork() failures and other early-startup failures
690 * are very uncommon, and having the leader sit idle when it could be doing
691 * useful work is undesirable. However, if the leader needs to wait for
692 * all of its workers or for a specific worker, it may want to call this
693 * function before doing so. If not, it must make some other provision for
694 * the failure-to-start case, lest it wait forever. On the other hand, a
695 * leader which never waits for a worker that might not be started yet, or
696 * at least never does so prior to WaitForParallelWorkersToFinish(), need not
697 * call this function at all.
698 */
699void
701{
702 int i;
703
704 /* Skip this if we have no launched workers. */
705 if (pcxt->nworkers_launched == 0)
706 return;
707
708 for (;;)
709 {
710 /*
711 * This will process any parallel messages that are pending and it may
712 * also throw an error propagated from a worker.
713 */
715
716 for (i = 0; i < pcxt->nworkers_launched; ++i)
717 {
718 BgwHandleStatus status;
719 shm_mq *mq;
720 int rc;
721 pid_t pid;
722
723 if (pcxt->known_attached_workers[i])
724 continue;
725
726 /*
727 * If error_mqh is NULL, then the worker has already exited
728 * cleanly.
729 */
730 if (pcxt->worker[i].error_mqh == NULL)
731 {
732 pcxt->known_attached_workers[i] = true;
734 continue;
735 }
736
737 status = GetBackgroundWorkerPid(pcxt->worker[i].bgwhandle, &pid);
738 if (status == BGWH_STARTED)
739 {
740 /* Has the worker attached to the error queue? */
741 mq = shm_mq_get_queue(pcxt->worker[i].error_mqh);
742 if (shm_mq_get_sender(mq) != NULL)
743 {
744 /* Yes, so it is known to be attached. */
745 pcxt->known_attached_workers[i] = true;
747 }
748 }
749 else if (status == BGWH_STOPPED)
750 {
751 /*
752 * If the worker stopped without attaching to the error queue,
753 * throw an error.
754 */
755 mq = shm_mq_get_queue(pcxt->worker[i].error_mqh);
756 if (shm_mq_get_sender(mq) == NULL)
758 (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
759 errmsg("parallel worker failed to initialize"),
760 errhint("More details may be available in the server log.")));
761
762 pcxt->known_attached_workers[i] = true;
764 }
765 else
766 {
767 /*
768 * Worker not yet started, so we must wait. The postmaster
769 * will notify us if the worker's state changes. Our latch
770 * might also get set for some other reason, but if so we'll
771 * just end up waiting for the same worker again.
772 */
773 rc = WaitLatch(MyLatch,
775 -1, WAIT_EVENT_BGWORKER_STARTUP);
776
777 if (rc & WL_LATCH_SET)
779 }
780 }
781
782 /* If all workers are known to have started, we're done. */
784 {
786 break;
787 }
788 }
789}
790
791/*
792 * Wait for all workers to finish computing.
793 *
794 * Even if the parallel operation seems to have completed successfully, it's
795 * important to call this function afterwards. We must not miss any errors
796 * the workers may have thrown during the parallel operation, or any that they
797 * may yet throw while shutting down.
798 *
799 * Also, we want to update our notion of XactLastRecEnd based on worker
800 * feedback.
801 */
802void
804{
805 for (;;)
806 {
807 bool anyone_alive = false;
808 int nfinished = 0;
809 int i;
810
811 /*
812 * This will process any parallel messages that are pending, which may
813 * change the outcome of the loop that follows. It may also throw an
814 * error propagated from a worker.
815 */
817
818 for (i = 0; i < pcxt->nworkers_launched; ++i)
819 {
820 /*
821 * If error_mqh is NULL, then the worker has already exited
822 * cleanly. If we have received a message through error_mqh from
823 * the worker, we know it started up cleanly, and therefore we're
824 * certain to be notified when it exits.
825 */
826 if (pcxt->worker[i].error_mqh == NULL)
827 ++nfinished;
828 else if (pcxt->known_attached_workers[i])
829 {
830 anyone_alive = true;
831 break;
832 }
833 }
834
835 if (!anyone_alive)
836 {
837 /* If all workers are known to have finished, we're done. */
838 if (nfinished >= pcxt->nworkers_launched)
839 {
840 Assert(nfinished == pcxt->nworkers_launched);
841 break;
842 }
843
844 /*
845 * We didn't detect any living workers, but not all workers are
846 * known to have exited cleanly. Either not all workers have
847 * launched yet, or maybe some of them failed to start or
848 * terminated abnormally.
849 */
850 for (i = 0; i < pcxt->nworkers_launched; ++i)
851 {
852 pid_t pid;
853 shm_mq *mq;
854
855 /*
856 * If the worker is BGWH_NOT_YET_STARTED or BGWH_STARTED, we
857 * should just keep waiting. If it is BGWH_STOPPED, then
858 * further investigation is needed.
859 */
860 if (pcxt->worker[i].error_mqh == NULL ||
861 pcxt->worker[i].bgwhandle == NULL ||
863 &pid) != BGWH_STOPPED)
864 continue;
865
866 /*
867 * Check whether the worker ended up stopped without ever
868 * attaching to the error queue. If so, the postmaster was
869 * unable to fork the worker or it exited without initializing
870 * properly. We must throw an error, since the caller may
871 * have been expecting the worker to do some work before
872 * exiting.
873 */
874 mq = shm_mq_get_queue(pcxt->worker[i].error_mqh);
875 if (shm_mq_get_sender(mq) == NULL)
877 (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
878 errmsg("parallel worker failed to initialize"),
879 errhint("More details may be available in the server log.")));
880
881 /*
882 * The worker is stopped, but is attached to the error queue.
883 * Unless there's a bug somewhere, this will only happen when
884 * the worker writes messages and terminates after the
885 * CHECK_FOR_INTERRUPTS() near the top of this function and
886 * before the call to GetBackgroundWorkerPid(). In that case,
887 * our latch should have been set as well and the right things
888 * will happen on the next pass through the loop.
889 */
890 }
891 }
892
894 WAIT_EVENT_PARALLEL_FINISH);
896 }
897
898 if (pcxt->toc != NULL)
899 {
901
902 fps = shm_toc_lookup(pcxt->toc, PARALLEL_KEY_FIXED, false);
903 if (fps->last_xlog_end > XactLastRecEnd)
905 }
906}
907
908/*
909 * Wait for all workers to exit.
910 *
911 * This function ensures that workers have been completely shutdown. The
912 * difference between WaitForParallelWorkersToFinish and this function is
913 * that the former just ensures that last message sent by a worker backend is
914 * received by the leader backend whereas this ensures the complete shutdown.
915 */
916static void
918{
919 int i;
920
921 /* Wait until the workers actually die. */
922 for (i = 0; i < pcxt->nworkers_launched; ++i)
923 {
924 BgwHandleStatus status;
925
926 if (pcxt->worker == NULL || pcxt->worker[i].bgwhandle == NULL)
927 continue;
928
930
931 /*
932 * If the postmaster kicked the bucket, we have no chance of cleaning
933 * up safely -- we won't be able to tell when our workers are actually
934 * dead. This doesn't necessitate a PANIC since they will all abort
935 * eventually, but we can't safely continue this session.
936 */
937 if (status == BGWH_POSTMASTER_DIED)
939 (errcode(ERRCODE_ADMIN_SHUTDOWN),
940 errmsg("postmaster exited during a parallel transaction")));
941
942 /* Release memory. */
943 pfree(pcxt->worker[i].bgwhandle);
944 pcxt->worker[i].bgwhandle = NULL;
945 }
946}
947
948/*
949 * Destroy a parallel context.
950 *
951 * If expecting a clean exit, you should use WaitForParallelWorkersToFinish()
952 * first, before calling this function. When this function is invoked, any
953 * remaining workers are forcibly killed; the dynamic shared memory segment
954 * is unmapped; and we then wait (uninterruptibly) for the workers to exit.
955 */
956void
958{
959 int i;
960
961 /*
962 * Be careful about order of operations here! We remove the parallel
963 * context from the list before we do anything else; otherwise, if an
964 * error occurs during a subsequent step, we might try to nuke it again
965 * from AtEOXact_Parallel or AtEOSubXact_Parallel.
966 */
967 dlist_delete(&pcxt->node);
968
969 /* Kill each worker in turn, and forget their error queues. */
970 if (pcxt->worker != NULL)
971 {
972 for (i = 0; i < pcxt->nworkers_launched; ++i)
973 {
974 if (pcxt->worker[i].error_mqh != NULL)
975 {
977
979 pcxt->worker[i].error_mqh = NULL;
980 }
981 }
982 }
983
984 /*
985 * If we have allocated a shared memory segment, detach it. This will
986 * implicitly detach the error queues, and any other shared memory queues,
987 * stored there.
988 */
989 if (pcxt->seg != NULL)
990 {
991 dsm_detach(pcxt->seg);
992 pcxt->seg = NULL;
993 }
994
995 /*
996 * If this parallel context is actually in backend-private memory rather
997 * than shared memory, free that memory instead.
998 */
999 if (pcxt->private_memory != NULL)
1000 {
1001 pfree(pcxt->private_memory);
1002 pcxt->private_memory = NULL;
1003 }
1004
1005 /*
1006 * We can't finish transaction commit or abort until all of the workers
1007 * have exited. This means, in particular, that we can't respond to
1008 * interrupts at this stage.
1009 */
1013
1014 /* Free the worker array itself. */
1015 if (pcxt->worker != NULL)
1016 {
1017 pfree(pcxt->worker);
1018 pcxt->worker = NULL;
1019 }
1020
1021 /* Free memory. */
1022 pfree(pcxt->library_name);
1023 pfree(pcxt->function_name);
1024 pfree(pcxt);
1025}
1026
1027/*
1028 * Are there any parallel contexts currently active?
1029 */
1030bool
1032{
1033 return !dlist_is_empty(&pcxt_list);
1034}
1035
1036/*
1037 * Handle receipt of an interrupt indicating a parallel worker message.
1038 *
1039 * Note: this is called within a signal handler! All we can do is set
1040 * a flag that will cause the next CHECK_FOR_INTERRUPTS() to invoke
1041 * ProcessParallelMessages().
1042 */
1043void
1045{
1046 InterruptPending = true;
1049}
1050
1051/*
1052 * Process any queued protocol messages received from parallel workers.
1053 */
1054void
1056{
1057 dlist_iter iter;
1058 MemoryContext oldcontext;
1059
1060 static MemoryContext hpm_context = NULL;
1061
1062 /*
1063 * This is invoked from ProcessInterrupts(), and since some of the
1064 * functions it calls contain CHECK_FOR_INTERRUPTS(), there is a potential
1065 * for recursive calls if more signals are received while this runs. It's
1066 * unclear that recursive entry would be safe, and it doesn't seem useful
1067 * even if it is safe, so let's block interrupts until done.
1068 */
1070
1071 /*
1072 * Moreover, CurrentMemoryContext might be pointing almost anywhere. We
1073 * don't want to risk leaking data into long-lived contexts, so let's do
1074 * our work here in a private context that we can reset on each use.
1075 */
1076 if (hpm_context == NULL) /* first time through? */
1078 "ProcessParallelMessages",
1080 else
1081 MemoryContextReset(hpm_context);
1082
1083 oldcontext = MemoryContextSwitchTo(hpm_context);
1084
1085 /* OK to process messages. Reset the flag saying there are more to do. */
1086 ParallelMessagePending = false;
1087
1088 dlist_foreach(iter, &pcxt_list)
1089 {
1090 ParallelContext *pcxt;
1091 int i;
1092
1093 pcxt = dlist_container(ParallelContext, node, iter.cur);
1094 if (pcxt->worker == NULL)
1095 continue;
1096
1097 for (i = 0; i < pcxt->nworkers_launched; ++i)
1098 {
1099 /*
1100 * Read as many messages as we can from each worker, but stop when
1101 * either (1) the worker's error queue goes away, which can happen
1102 * if we receive a Terminate message from the worker; or (2) no
1103 * more messages can be read from the worker without blocking.
1104 */
1105 while (pcxt->worker[i].error_mqh != NULL)
1106 {
1107 shm_mq_result res;
1108 Size nbytes;
1109 void *data;
1110
1111 res = shm_mq_receive(pcxt->worker[i].error_mqh, &nbytes,
1112 &data, true);
1113 if (res == SHM_MQ_WOULD_BLOCK)
1114 break;
1115 else if (res == SHM_MQ_SUCCESS)
1116 {
1117 StringInfoData msg;
1118
1119 initStringInfo(&msg);
1120 appendBinaryStringInfo(&msg, data, nbytes);
1121 ProcessParallelMessage(pcxt, i, &msg);
1122 pfree(msg.data);
1123 }
1124 else
1125 ereport(ERROR,
1126 (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
1127 errmsg("lost connection to parallel worker")));
1128 }
1129 }
1130 }
1131
1132 MemoryContextSwitchTo(oldcontext);
1133
1134 /* Might as well clear the context on our way out */
1135 MemoryContextReset(hpm_context);
1136
1138}
1139
1140/*
1141 * Process a single protocol message received from a single parallel worker.
1142 */
1143static void
1145{
1146 char msgtype;
1147
1148 if (pcxt->known_attached_workers != NULL &&
1149 !pcxt->known_attached_workers[i])
1150 {
1151 pcxt->known_attached_workers[i] = true;
1153 }
1154
1155 msgtype = pq_getmsgbyte(msg);
1156
1157 switch (msgtype)
1158 {
1161 {
1162 ErrorData edata;
1163 ErrorContextCallback *save_error_context_stack;
1164
1165 /* Parse ErrorResponse or NoticeResponse. */
1166 pq_parse_errornotice(msg, &edata);
1167
1168 /* Death of a worker isn't enough justification for suicide. */
1169 edata.elevel = Min(edata.elevel, ERROR);
1170
1171 /*
1172 * If desired, add a context line to show that this is a
1173 * message propagated from a parallel worker. Otherwise, it
1174 * can sometimes be confusing to understand what actually
1175 * happened. (We don't do this in DEBUG_PARALLEL_REGRESS mode
1176 * because it causes test-result instability depending on
1177 * whether a parallel worker is actually used or not.)
1178 */
1180 {
1181 if (edata.context)
1182 edata.context = psprintf("%s\n%s", edata.context,
1183 _("parallel worker"));
1184 else
1185 edata.context = pstrdup(_("parallel worker"));
1186 }
1187
1188 /*
1189 * Context beyond that should use the error context callbacks
1190 * that were in effect when the ParallelContext was created,
1191 * not the current ones.
1192 */
1193 save_error_context_stack = error_context_stack;
1195
1196 /* Rethrow error or print notice. */
1197 ThrowErrorData(&edata);
1198
1199 /* Not an error, so restore previous context stack. */
1200 error_context_stack = save_error_context_stack;
1201
1202 break;
1203 }
1204
1206 {
1207 /* Propagate NotifyResponse. */
1208 int32 pid;
1209 const char *channel;
1210 const char *payload;
1211
1212 pid = pq_getmsgint(msg, 4);
1213 channel = pq_getmsgrawstring(msg);
1214 payload = pq_getmsgrawstring(msg);
1215 pq_endmessage(msg);
1216
1217 NotifyMyFrontEnd(channel, payload, pid);
1218
1219 break;
1220 }
1221
1222 case PqMsg_Progress:
1223 {
1224 /*
1225 * Only incremental progress reporting is currently supported.
1226 * However, it's possible to add more fields to the message to
1227 * allow for handling of other backend progress APIs.
1228 */
1229 int index = pq_getmsgint(msg, 4);
1230 int64 incr = pq_getmsgint64(msg);
1231
1232 pq_getmsgend(msg);
1233
1235
1236 break;
1237 }
1238
1239 case PqMsg_Terminate:
1240 {
1242 pcxt->worker[i].error_mqh = NULL;
1243 break;
1244 }
1245
1246 default:
1247 {
1248 elog(ERROR, "unrecognized message type received from parallel worker: %c (message length %d bytes)",
1249 msgtype, msg->len);
1250 }
1251 }
1252}
1253
1254/*
1255 * End-of-subtransaction cleanup for parallel contexts.
1256 *
1257 * Here we remove only parallel contexts initiated within the current
1258 * subtransaction.
1259 */
1260void
1262{
1263 while (!dlist_is_empty(&pcxt_list))
1264 {
1265 ParallelContext *pcxt;
1266
1268 if (pcxt->subid != mySubId)
1269 break;
1270 if (isCommit)
1271 elog(WARNING, "leaked parallel context");
1273 }
1274}
1275
1276/*
1277 * End-of-transaction cleanup for parallel contexts.
1278 *
1279 * We nuke all remaining parallel contexts.
1280 */
1281void
1282AtEOXact_Parallel(bool isCommit)
1283{
1284 while (!dlist_is_empty(&pcxt_list))
1285 {
1286 ParallelContext *pcxt;
1287
1289 if (isCommit)
1290 elog(WARNING, "leaked parallel context");
1292 }
1293}
1294
1295/*
1296 * Main entrypoint for parallel workers.
1297 */
1298void
1300{
1301 dsm_segment *seg;
1302 shm_toc *toc;
1303 FixedParallelState *fps;
1304 char *error_queue_space;
1305 shm_mq *mq;
1306 shm_mq_handle *mqh;
1307 char *libraryspace;
1308 char *entrypointstate;
1309 char *library_name;
1310 char *function_name;
1312 char *gucspace;
1313 char *combocidspace;
1314 char *tsnapspace;
1315 char *asnapspace;
1316 char *tstatespace;
1317 char *pendingsyncsspace;
1318 char *reindexspace;
1319 char *relmapperspace;
1320 char *uncommittedenumsspace;
1321 char *clientconninfospace;
1322 char *session_dsm_handle_space;
1323 Snapshot tsnapshot;
1324 Snapshot asnapshot;
1325
1326 /* Set flag to indicate that we're initializing a parallel worker. */
1328
1329 /* Establish signal handlers. */
1330 pqsignal(SIGTERM, die);
1332
1333 /* Determine and set our parallel worker number. */
1335 memcpy(&ParallelWorkerNumber, MyBgworkerEntry->bgw_extra, sizeof(int));
1336
1337 /* Set up a memory context to work in, just for cleanliness. */
1339 "Parallel worker",
1341
1342 /*
1343 * Attach to the dynamic shared memory segment for the parallel query, and
1344 * find its table of contents.
1345 *
1346 * Note: at this point, we have not created any ResourceOwner in this
1347 * process. This will result in our DSM mapping surviving until process
1348 * exit, which is fine. If there were a ResourceOwner, it would acquire
1349 * ownership of the mapping, but we have no need for that.
1350 */
1351 seg = dsm_attach(DatumGetUInt32(main_arg));
1352 if (seg == NULL)
1353 ereport(ERROR,
1354 (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
1355 errmsg("could not map dynamic shared memory segment")));
1357 if (toc == NULL)
1358 ereport(ERROR,
1359 (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
1360 errmsg("invalid magic number in dynamic shared memory segment")));
1361
1362 /* Look up fixed parallel state. */
1363 fps = shm_toc_lookup(toc, PARALLEL_KEY_FIXED, false);
1365
1366 /* Arrange to signal the leader if we exit. */
1370
1371 /*
1372 * Now we can find and attach to the error queue provided for us. That's
1373 * good, because until we do that, any errors that happen here will not be
1374 * reported back to the process that requested that this worker be
1375 * launched.
1376 */
1377 error_queue_space = shm_toc_lookup(toc, PARALLEL_KEY_ERROR_QUEUE, false);
1378 mq = (shm_mq *) (error_queue_space +
1381 mqh = shm_mq_attach(mq, seg, NULL);
1382 pq_redirect_to_shm_mq(seg, mqh);
1385
1386 /*
1387 * Hooray! Primary initialization is complete. Now, we need to set up our
1388 * backend-local state to match the original backend.
1389 */
1390
1391 /*
1392 * Join locking group. We must do this before anything that could try to
1393 * acquire a heavyweight lock, because any heavyweight locks acquired to
1394 * this point could block either directly against the parallel group
1395 * leader or against some process which in turn waits for a lock that
1396 * conflicts with the parallel group leader, causing an undetected
1397 * deadlock. (If we can't join the lock group, the leader has gone away,
1398 * so just exit quietly.)
1399 */
1401 fps->parallel_leader_pid))
1402 return;
1403
1404 /*
1405 * Restore transaction and statement start-time timestamps. This must
1406 * happen before anything that would start a transaction, else asserts in
1407 * xact.c will fire.
1408 */
1410
1411 /*
1412 * Identify the entry point to be called. In theory this could result in
1413 * loading an additional library, though most likely the entry point is in
1414 * the core backend or in a library we just loaded.
1415 */
1416 entrypointstate = shm_toc_lookup(toc, PARALLEL_KEY_ENTRYPOINT, false);
1417 library_name = entrypointstate;
1418 function_name = entrypointstate + strlen(library_name) + 1;
1419
1420 entrypt = LookupParallelWorkerFunction(library_name, function_name);
1421
1422 /*
1423 * Restore current session authorization and role id. No verification
1424 * happens here, we just blindly adopt the leader's state. Note that this
1425 * has to happen before InitPostgres, since InitializeSessionUserId will
1426 * not set these variables.
1427 */
1432
1433 /*
1434 * Restore database connection. We skip connection authorization checks,
1435 * reasoning that (a) the leader checked these things when it started, and
1436 * (b) we do not want parallel mode to cause these failures, because that
1437 * would make use of parallel query plans not transparent to applications.
1438 */
1443
1444 /*
1445 * Set the client encoding to the database encoding, since that is what
1446 * the leader will expect. (We're cheating a bit by not calling
1447 * PrepareClientEncoding first. It's okay because this call will always
1448 * result in installing a no-op conversion. No error should be possible,
1449 * but check anyway.)
1450 */
1452 elog(ERROR, "SetClientEncoding(%d) failed", GetDatabaseEncoding());
1453
1454 /*
1455 * Load libraries that were loaded by original backend. We want to do
1456 * this before restoring GUCs, because the libraries might define custom
1457 * variables.
1458 */
1459 libraryspace = shm_toc_lookup(toc, PARALLEL_KEY_LIBRARY, false);
1461 RestoreLibraryState(libraryspace);
1463
1464 /* Crank up a transaction state appropriate to a parallel worker. */
1465 tstatespace = shm_toc_lookup(toc, PARALLEL_KEY_TRANSACTION_STATE, false);
1466 StartParallelWorkerTransaction(tstatespace);
1467
1468 /*
1469 * Restore state that affects catalog access. Ideally we'd do this even
1470 * before calling InitPostgres, but that has order-of-initialization
1471 * problems, and also the relmapper would get confused during the
1472 * CommitTransactionCommand call above.
1473 */
1474 pendingsyncsspace = shm_toc_lookup(toc, PARALLEL_KEY_PENDING_SYNCS,
1475 false);
1476 RestorePendingSyncs(pendingsyncsspace);
1477 relmapperspace = shm_toc_lookup(toc, PARALLEL_KEY_RELMAPPER_STATE, false);
1478 RestoreRelationMap(relmapperspace);
1479 reindexspace = shm_toc_lookup(toc, PARALLEL_KEY_REINDEX_STATE, false);
1480 RestoreReindexState(reindexspace);
1481 combocidspace = shm_toc_lookup(toc, PARALLEL_KEY_COMBO_CID, false);
1482 RestoreComboCIDState(combocidspace);
1483
1484 /* Attach to the per-session DSM segment and contained objects. */
1485 session_dsm_handle_space =
1487 AttachSession(*(dsm_handle *) session_dsm_handle_space);
1488
1489 /*
1490 * If the transaction isolation level is REPEATABLE READ or SERIALIZABLE,
1491 * the leader has serialized the transaction snapshot and we must restore
1492 * it. At lower isolation levels, there is no transaction-lifetime
1493 * snapshot, but we need TransactionXmin to get set to a value which is
1494 * less than or equal to the xmin of every snapshot that will be used by
1495 * this worker. The easiest way to accomplish that is to install the
1496 * active snapshot as the transaction snapshot. Code running in this
1497 * parallel worker might take new snapshots via GetTransactionSnapshot()
1498 * or GetLatestSnapshot(), but it shouldn't have any way of acquiring a
1499 * snapshot older than the active snapshot.
1500 */
1501 asnapspace = shm_toc_lookup(toc, PARALLEL_KEY_ACTIVE_SNAPSHOT, false);
1502 tsnapspace = shm_toc_lookup(toc, PARALLEL_KEY_TRANSACTION_SNAPSHOT, true);
1503 asnapshot = RestoreSnapshot(asnapspace);
1504 tsnapshot = tsnapspace ? RestoreSnapshot(tsnapspace) : asnapshot;
1507 PushActiveSnapshot(asnapshot);
1508
1509 /*
1510 * We've changed which tuples we can see, and must therefore invalidate
1511 * system caches.
1512 */
1514
1515 /*
1516 * Restore GUC values from launching backend. We can't do this earlier,
1517 * because GUC check hooks that do catalog lookups need to see the same
1518 * database state as the leader. Also, the check hooks for
1519 * session_authorization and role assume we already set the correct role
1520 * OIDs.
1521 */
1522 gucspace = shm_toc_lookup(toc, PARALLEL_KEY_GUC, false);
1523 RestoreGUCState(gucspace);
1524
1525 /*
1526 * Restore current user ID and security context. No verification happens
1527 * here, we just blindly adopt the leader's state. We can't do this till
1528 * after restoring GUCs, else we'll get complaints about restoring
1529 * session_authorization and role. (In effect, we're assuming that all
1530 * the restored values are okay to set, even if we are now inside a
1531 * restricted context.)
1532 */
1534
1535 /* Restore temp-namespace state to ensure search path matches leader's. */
1538
1539 /* Restore uncommitted enums. */
1540 uncommittedenumsspace = shm_toc_lookup(toc, PARALLEL_KEY_UNCOMMITTEDENUMS,
1541 false);
1542 RestoreUncommittedEnums(uncommittedenumsspace);
1543
1544 /* Restore the ClientConnectionInfo. */
1545 clientconninfospace = shm_toc_lookup(toc, PARALLEL_KEY_CLIENTCONNINFO,
1546 false);
1547 RestoreClientConnectionInfo(clientconninfospace);
1548
1549 /*
1550 * Initialize SystemUser now that MyClientConnectionInfo is restored. Also
1551 * ensure that auth_method is actually valid, aka authn_id is not NULL.
1552 */
1556
1557 /* Attach to the leader's serializable transaction, if SERIALIZABLE. */
1559
1560 /*
1561 * We've initialized all of our state now; nothing should change
1562 * hereafter.
1563 */
1566
1567 /*
1568 * Time to do the real work: invoke the caller-supplied code.
1569 */
1570 entrypt(seg, toc);
1571
1572 /* Must exit parallel mode to pop active snapshot. */
1574
1575 /* Must pop active snapshot so snapmgr.c doesn't complain. */
1577
1578 /* Shut down the parallel-worker transaction. */
1580
1581 /* Detach from the per-session DSM segment. */
1582 DetachSession();
1583
1584 /* Report success. */
1586}
1587
1588/*
1589 * Update shared memory with the ending location of the last WAL record we
1590 * wrote, if it's greater than the value already stored there.
1591 */
1592void
1594{
1596
1597 Assert(fps != NULL);
1598 SpinLockAcquire(&fps->mutex);
1599 if (fps->last_xlog_end < last_xlog_end)
1600 fps->last_xlog_end = last_xlog_end;
1601 SpinLockRelease(&fps->mutex);
1602}
1603
1604/*
1605 * Make sure the leader tries to read from our error queue one more time.
1606 * This guards against the case where we exit uncleanly without sending an
1607 * ErrorResponse to the leader, for example because some code calls proc_exit
1608 * directly.
1609 *
1610 * Also explicitly detach from dsm segment so that subsystems using
1611 * on_dsm_detach() have a chance to send stats before the stats subsystem is
1612 * shut down as part of a before_shmem_exit() hook.
1613 *
1614 * One might think this could instead be solved by carefully ordering the
1615 * attaching to dsm segments, so that the pgstats segments get detached from
1616 * later than the parallel query one. That turns out to not work because the
1617 * stats hash might need to grow which can cause new segments to be allocated,
1618 * which then will be detached from earlier.
1619 */
1620static void
1622{
1626
1628}
1629
1630/*
1631 * Look up (and possibly load) a parallel worker entry point function.
1632 *
1633 * For functions contained in the core code, we use library name "postgres"
1634 * and consult the InternalParallelWorkers array. External functions are
1635 * looked up, and loaded if necessary, using load_external_function().
1636 *
1637 * The point of this is to pass function names as strings across process
1638 * boundaries. We can't pass actual function addresses because of the
1639 * possibility that the function has been loaded at a different address
1640 * in a different process. This is obviously a hazard for functions in
1641 * loadable libraries, but it can happen even for functions in the core code
1642 * on platforms using EXEC_BACKEND (e.g., Windows).
1643 *
1644 * At some point it might be worthwhile to get rid of InternalParallelWorkers[]
1645 * in favor of applying load_external_function() for core functions too;
1646 * but that raises portability issues that are not worth addressing now.
1647 */
1649LookupParallelWorkerFunction(const char *libraryname, const char *funcname)
1650{
1651 /*
1652 * If the function is to be loaded from postgres itself, search the
1653 * InternalParallelWorkers array.
1654 */
1655 if (strcmp(libraryname, "postgres") == 0)
1656 {
1657 int i;
1658
1659 for (i = 0; i < lengthof(InternalParallelWorkers); i++)
1660 {
1661 if (strcmp(InternalParallelWorkers[i].fn_name, funcname) == 0)
1663 }
1664
1665 /* We can only reach this by programming error. */
1666 elog(ERROR, "internal function \"%s\" not found", funcname);
1667 }
1668
1669 /* Otherwise load from external library. */
1671 load_external_function(libraryname, funcname, true, NULL);
1672}
void NotifyMyFrontEnd(const char *channel, const char *payload, int32 srcPid)
Definition: async.c:2344
static parallel_worker_main_type LookupParallelWorkerFunction(const char *libraryname, const char *funcname)
Definition: parallel.c:1649
#define PARALLEL_KEY_TRANSACTION_STATE
Definition: parallel.c:72
int ParallelWorkerNumber
Definition: parallel.c:115
void HandleParallelMessageInterrupt(void)
Definition: parallel.c:1044
struct FixedParallelState FixedParallelState
bool InitializingParallelWorker
Definition: parallel.c:121
#define PARALLEL_KEY_GUC
Definition: parallel.c:68
parallel_worker_main_type fn_addr
Definition: parallel.c:139
#define PARALLEL_KEY_UNCOMMITTEDENUMS
Definition: parallel.c:78
#define PARALLEL_KEY_TRANSACTION_SNAPSHOT
Definition: parallel.c:70
void ProcessParallelMessages(void)
Definition: parallel.c:1055
void InitializeParallelDSM(ParallelContext *pcxt)
Definition: parallel.c:211
#define PARALLEL_KEY_CLIENTCONNINFO
Definition: parallel.c:79
static FixedParallelState * MyFixedParallelState
Definition: parallel.c:124
#define PARALLEL_KEY_PENDING_SYNCS
Definition: parallel.c:75
void WaitForParallelWorkersToFinish(ParallelContext *pcxt)
Definition: parallel.c:803
void LaunchParallelWorkers(ParallelContext *pcxt)
Definition: parallel.c:581
void ReinitializeParallelDSM(ParallelContext *pcxt)
Definition: parallel.c:509
void DestroyParallelContext(ParallelContext *pcxt)
Definition: parallel.c:957
#define PARALLEL_KEY_ACTIVE_SNAPSHOT
Definition: parallel.c:71
void ParallelWorkerReportLastRecEnd(XLogRecPtr last_xlog_end)
Definition: parallel.c:1593
static void ProcessParallelMessage(ParallelContext *pcxt, int i, StringInfo msg)
Definition: parallel.c:1144
#define PARALLEL_KEY_ERROR_QUEUE
Definition: parallel.c:66
#define PARALLEL_KEY_SESSION_DSM
Definition: parallel.c:74
ParallelContext * CreateParallelContext(const char *library_name, const char *function_name, int nworkers)
Definition: parallel.c:173
#define PARALLEL_MAGIC
Definition: parallel.c:58
bool ParallelContextActive(void)
Definition: parallel.c:1031
void ParallelWorkerMain(Datum main_arg)
Definition: parallel.c:1299
static void WaitForParallelWorkersToExit(ParallelContext *pcxt)
Definition: parallel.c:917
static pid_t ParallelLeaderPid
Definition: parallel.c:130
#define PARALLEL_KEY_REINDEX_STATE
Definition: parallel.c:76
#define PARALLEL_KEY_LIBRARY
Definition: parallel.c:67
static void ParallelWorkerShutdown(int code, Datum arg)
Definition: parallel.c:1621
static dlist_head pcxt_list
Definition: parallel.c:127
const char * fn_name
Definition: parallel.c:138
#define PARALLEL_KEY_FIXED
Definition: parallel.c:65
#define PARALLEL_KEY_ENTRYPOINT
Definition: parallel.c:73
volatile sig_atomic_t ParallelMessagePending
Definition: parallel.c:118
void ReinitializeParallelWorkers(ParallelContext *pcxt, int nworkers_to_launch)
Definition: parallel.c:566
#define PARALLEL_KEY_COMBO_CID
Definition: parallel.c:69
static const struct @16 InternalParallelWorkers[]
void WaitForParallelWorkersToAttach(ParallelContext *pcxt)
Definition: parallel.c:700
#define PARALLEL_ERROR_QUEUE_SIZE
Definition: parallel.c:55
void AtEOSubXact_Parallel(bool isCommit, SubTransactionId mySubId)
Definition: parallel.c:1261
void AtEOXact_Parallel(bool isCommit)
Definition: parallel.c:1282
#define PARALLEL_KEY_RELMAPPER_STATE
Definition: parallel.c:77
void pgstat_progress_incr_param(int index, int64 incr)
void TerminateBackgroundWorker(BackgroundWorkerHandle *handle)
Definition: bgworker.c:1312
BgwHandleStatus WaitForBackgroundWorkerShutdown(BackgroundWorkerHandle *handle)
Definition: bgworker.c:1273
void BackgroundWorkerUnblockSignals(void)
Definition: bgworker.c:942
void BackgroundWorkerInitializeConnectionByOid(Oid dboid, Oid useroid, uint32 flags)
Definition: bgworker.c:902
BgwHandleStatus GetBackgroundWorkerPid(BackgroundWorkerHandle *handle, pid_t *pidp)
Definition: bgworker.c:1173
bool RegisterDynamicBackgroundWorker(BackgroundWorker *worker, BackgroundWorkerHandle **handle)
Definition: bgworker.c:1061
#define BGW_NEVER_RESTART
Definition: bgworker.h:92
#define BGWORKER_BYPASS_ROLELOGINCHECK
Definition: bgworker.h:167
#define BGWORKER_CLASS_PARALLEL
Definition: bgworker.h:75
BgwHandleStatus
Definition: bgworker.h:111
@ BGWH_POSTMASTER_DIED
Definition: bgworker.h:115
@ BGWH_STARTED
Definition: bgworker.h:112
@ BGWH_STOPPED
Definition: bgworker.h:114
@ BgWorkerStart_ConsistentState
Definition: bgworker.h:87
#define BGWORKER_BACKEND_DATABASE_CONNECTION
Definition: bgworker.h:60
#define BGWORKER_BYPASS_ALLOWCONN
Definition: bgworker.h:166
#define BGWORKER_SHMEM_ACCESS
Definition: bgworker.h:53
#define BGW_MAXLEN
Definition: bgworker.h:93
void _brin_parallel_build_main(dsm_segment *seg, shm_toc *toc)
Definition: brin.c:2878
#define Min(x, y)
Definition: c.h:995
uint32 SubTransactionId
Definition: c.h:675
#define BUFFERALIGN(LEN)
Definition: c.h:826
int64_t int64
Definition: c.h:549
int32_t int32
Definition: c.h:548
#define lengthof(array)
Definition: c.h:801
#define StaticAssertDecl(condition, errmessage)
Definition: c.h:940
size_t Size
Definition: c.h:624
void RestoreComboCIDState(char *comboCIDstate)
Definition: combocid.c:342
void SerializeComboCIDState(Size maxsize, char *start_address)
Definition: combocid.c:316
Size EstimateComboCIDStateSpace(void)
Definition: combocid.c:297
int64 TimestampTz
Definition: timestamp.h:39
void RestoreLibraryState(char *start_address)
Definition: dfmgr.c:741
void SerializeLibraryState(Size maxsize, char *start_address)
Definition: dfmgr.c:719
Size EstimateLibraryStateSpace(void)
Definition: dfmgr.c:702
void * load_external_function(const char *filename, const char *funcname, bool signalNotFound, void **filehandle)
Definition: dfmgr.c:95
dsm_handle dsm_segment_handle(dsm_segment *seg)
Definition: dsm.c:1123
void dsm_detach(dsm_segment *seg)
Definition: dsm.c:803
void * dsm_segment_address(dsm_segment *seg)
Definition: dsm.c:1095
dsm_segment * dsm_create(Size size, int flags)
Definition: dsm.c:516
dsm_segment * dsm_attach(dsm_handle h)
Definition: dsm.c:665
#define DSM_CREATE_NULL_IF_MAXSEGMENTS
Definition: dsm.h:20
uint32 dsm_handle
Definition: dsm_impl.h:55
#define DSM_HANDLE_INVALID
Definition: dsm_impl.h:58
ErrorContextCallback * error_context_stack
Definition: elog.c:95
int errhint(const char *fmt,...)
Definition: elog.c:1330
void ThrowErrorData(ErrorData *edata)
Definition: elog.c:1912
int errcode(int sqlerrcode)
Definition: elog.c:863
int errmsg(const char *fmt,...)
Definition: elog.c:1080
#define _(x)
Definition: elog.c:91
#define FATAL
Definition: elog.h:41
#define WARNING
Definition: elog.h:36
#define ERROR
Definition: elog.h:39
#define elog(elevel,...)
Definition: elog.h:226
#define ereport(elevel,...)
Definition: elog.h:150
void ParallelQueryMain(dsm_segment *seg, shm_toc *toc)
#define palloc0_array(type, count)
Definition: fe_memutils.h:77
#define palloc0_object(type)
Definition: fe_memutils.h:75
void _gin_parallel_build_main(dsm_segment *seg, shm_toc *toc)
Definition: gininsert.c:2100
ProcNumber ParallelLeaderProcNumber
Definition: globals.c:92
volatile sig_atomic_t InterruptPending
Definition: globals.c:32
int MyProcPid
Definition: globals.c:47
ProcNumber MyProcNumber
Definition: globals.c:90
struct Latch * MyLatch
Definition: globals.c:63
Oid MyDatabaseId
Definition: globals.c:94
void RestoreGUCState(void *gucstate)
Definition: guc.c:6062
void SerializeGUCState(Size maxsize, char *start_address)
Definition: guc.c:5970
Size EstimateGUCStateSpace(void)
Definition: guc.c:5817
bool current_role_is_superuser
Definition: guc_tables.c:537
Assert(PointerIsAligned(start, uint64))
return str start
const char * hba_authname(UserAuth auth_method)
Definition: hba.c:3138
#define dlist_foreach(iter, lhead)
Definition: ilist.h:623
#define dlist_head_element(type, membername, lhead)
Definition: ilist.h:603
static void dlist_delete(dlist_node *node)
Definition: ilist.h:405
static void dlist_push_head(dlist_head *head, dlist_node *node)
Definition: ilist.h:347
static bool dlist_is_empty(const dlist_head *head)
Definition: ilist.h:336
#define DLIST_STATIC_INIT(name)
Definition: ilist.h:281
#define dlist_container(type, membername, ptr)
Definition: ilist.h:593
void(* parallel_worker_main_type)(dsm_segment *seg, shm_toc *toc)
Definition: parallel.h:23
#define funcname
Definition: indent_codes.h:69
void SerializeReindexState(Size maxsize, char *start_address)
Definition: index.c:4251
void RestoreReindexState(const void *reindexstate)
Definition: index.c:4269
Size EstimateReindexStateSpace(void)
Definition: index.c:4240
void InvalidateSystemCaches(void)
Definition: inval.c:916
void before_shmem_exit(pg_on_exit_callback function, Datum arg)
Definition: ipc.c:337
int i
Definition: isn.c:77
void SetLatch(Latch *latch)
Definition: latch.c:290
void ResetLatch(Latch *latch)
Definition: latch.c:374
int WaitLatch(Latch *latch, int wakeEvents, long timeout, uint32 wait_event_info)
Definition: latch.c:172
#define pq_putmessage(msgtype, s, len)
Definition: libpq.h:49
int GetDatabaseEncoding(void)
Definition: mbutils.c:1264
int SetClientEncoding(int encoding)
Definition: mbutils.c:209
void * MemoryContextAlloc(MemoryContext context, Size size)
Definition: mcxt.c:1232
void MemoryContextReset(MemoryContext context)
Definition: mcxt.c:403
MemoryContext TopTransactionContext
Definition: mcxt.c:171
char * pstrdup(const char *in)
Definition: mcxt.c:1781
void pfree(void *pointer)
Definition: mcxt.c:1616
MemoryContext TopMemoryContext
Definition: mcxt.c:166
MemoryContext CurrentMemoryContext
Definition: mcxt.c:160
#define AllocSetContextCreate
Definition: memutils.h:129
#define ALLOCSET_DEFAULT_SIZES
Definition: memutils.h:160
#define RESUME_INTERRUPTS()
Definition: miscadmin.h:136
#define INTERRUPTS_CAN_BE_PROCESSED()
Definition: miscadmin.h:130
#define CHECK_FOR_INTERRUPTS()
Definition: miscadmin.h:123
#define HOLD_INTERRUPTS()
Definition: miscadmin.h:134
void InitializeSystemUser(const char *authn_id, const char *auth_method)
Definition: miscinit.c:874
void GetUserIdAndSecContext(Oid *userid, int *sec_context)
Definition: miscinit.c:612
void SetSessionAuthorization(Oid userid, bool is_superuser)
Definition: miscinit.c:920
bool GetSessionUserIsSuperuser(void)
Definition: miscinit.c:515
Size EstimateClientConnectionInfoSpace(void)
Definition: miscinit.c:1035
Oid GetSessionUserId(void)
Definition: miscinit.c:508
void SetCurrentRoleId(Oid roleid, bool is_superuser)
Definition: miscinit.c:956
Oid GetAuthenticatedUserId(void)
Definition: miscinit.c:545
ClientConnectionInfo MyClientConnectionInfo
Definition: miscinit.c:1018
void RestoreClientConnectionInfo(char *conninfo)
Definition: miscinit.c:1084
void SetAuthenticatedUserId(Oid userid)
Definition: miscinit.c:552
Oid GetCurrentRoleId(void)
Definition: miscinit.c:935
void SerializeClientConnectionInfo(Size maxsize PG_USED_FOR_ASSERTS_ONLY, char *start_address)
Definition: miscinit.c:1051
void SetUserIdAndSecContext(Oid userid, int sec_context)
Definition: miscinit.c:619
void GetTempNamespaceState(Oid *tempNamespaceId, Oid *tempToastNamespaceId)
Definition: namespace.c:3875
void SetTempNamespaceState(Oid tempNamespaceId, Oid tempToastNamespaceId)
Definition: namespace.c:3891
void _bt_parallel_build_main(dsm_segment *seg, shm_toc *toc)
Definition: nbtsort.c:1741
@ DEBUG_PARALLEL_REGRESS
Definition: optimizer.h:98
static MemoryContext MemoryContextSwitchTo(MemoryContext context)
Definition: palloc.h:124
void * arg
const void * data
void RestoreUncommittedEnums(void *space)
Definition: pg_enum.c:886
Size EstimateUncommittedEnumsSpace(void)
Definition: pg_enum.c:826
void SerializeUncommittedEnums(void *space, Size size)
Definition: pg_enum.c:840
#define die(msg)
Definition: pg_test_fsync.c:99
int debug_parallel_query
Definition: planner.c:69
#define pqsignal
Definition: port.h:551
#define sprintf
Definition: port.h:262
#define snprintf
Definition: port.h:260
static uint32 DatumGetUInt32(Datum X)
Definition: postgres.h:232
static Datum PointerGetDatum(const void *X)
Definition: postgres.h:332
uint64_t Datum
Definition: postgres.h:70
static Pointer DatumGetPointer(Datum X)
Definition: postgres.h:322
static Datum UInt32GetDatum(uint32 X)
Definition: postgres.h:242
unsigned int Oid
Definition: postgres_ext.h:32
BackgroundWorker * MyBgworkerEntry
Definition: postmaster.c:200
unsigned int pq_getmsgint(StringInfo msg, int b)
Definition: pqformat.c:414
void pq_getmsgend(StringInfo msg)
Definition: pqformat.c:634
void pq_endmessage(StringInfo buf)
Definition: pqformat.c:296
int pq_getmsgbyte(StringInfo msg)
Definition: pqformat.c:398
const char * pq_getmsgrawstring(StringInfo msg)
Definition: pqformat.c:607
int64 pq_getmsgint64(StringInfo msg)
Definition: pqformat.c:452
void pq_set_parallel_leader(pid_t pid, ProcNumber procNumber)
Definition: pqmq.c:82
void pq_parse_errornotice(StringInfo msg, ErrorData *edata)
Definition: pqmq.c:222
void pq_redirect_to_shm_mq(dsm_segment *seg, shm_mq_handle *mqh)
Definition: pqmq.c:53
void AttachSerializableXact(SerializableXactHandle handle)
Definition: predicate.c:5054
SerializableXactHandle ShareSerializableXact(void)
Definition: predicate.c:5045
void * SerializableXactHandle
Definition: predicate.h:34
int ProcNumber
Definition: procnumber.h:24
int SendProcSignal(pid_t pid, ProcSignalReason reason, ProcNumber procNumber)
Definition: procsignal.c:284
@ PROCSIG_PARALLEL_MESSAGE
Definition: procsignal.h:34
#define PqMsg_NotificationResponse
Definition: protocol.h:41
#define PqMsg_Progress
Definition: protocol.h:70
#define PqMsg_ErrorResponse
Definition: protocol.h:44
#define PqMsg_NoticeResponse
Definition: protocol.h:49
#define PqMsg_Terminate
Definition: protocol.h:28
char * psprintf(const char *fmt,...)
Definition: psprintf.c:43
Size EstimateRelationMapSpace(void)
Definition: relmapper.c:713
void SerializeRelationMap(Size maxSize, char *startAddress)
Definition: relmapper.c:724
void RestoreRelationMap(char *startAddress)
Definition: relmapper.c:741
void DetachSession(void)
Definition: session.c:201
void AttachSession(dsm_handle handle)
Definition: session.c:155
dsm_handle GetSessionDsmHandle(void)
Definition: session.c:70
shm_mq * shm_mq_get_queue(shm_mq_handle *mqh)
Definition: shm_mq.c:905
void shm_mq_set_sender(shm_mq *mq, PGPROC *proc)
Definition: shm_mq.c:224
shm_mq * shm_mq_create(void *address, Size size)
Definition: shm_mq.c:177
void shm_mq_set_handle(shm_mq_handle *mqh, BackgroundWorkerHandle *handle)
Definition: shm_mq.c:319
PGPROC * shm_mq_get_sender(shm_mq *mq)
Definition: shm_mq.c:257
void shm_mq_detach(shm_mq_handle *mqh)
Definition: shm_mq.c:843
void shm_mq_set_receiver(shm_mq *mq, PGPROC *proc)
Definition: shm_mq.c:206
shm_mq_result shm_mq_receive(shm_mq_handle *mqh, Size *nbytesp, void **datap, bool nowait)
Definition: shm_mq.c:572
shm_mq_handle * shm_mq_attach(shm_mq *mq, dsm_segment *seg, BackgroundWorkerHandle *handle)
Definition: shm_mq.c:290
shm_mq_result
Definition: shm_mq.h:37
@ SHM_MQ_SUCCESS
Definition: shm_mq.h:38
@ SHM_MQ_WOULD_BLOCK
Definition: shm_mq.h:39
void * shm_toc_allocate(shm_toc *toc, Size nbytes)
Definition: shm_toc.c:88
Size shm_toc_estimate(shm_toc_estimator *e)
Definition: shm_toc.c:263
shm_toc * shm_toc_create(uint64 magic, void *address, Size nbytes)
Definition: shm_toc.c:40
void shm_toc_insert(shm_toc *toc, uint64 key, void *address)
Definition: shm_toc.c:171
void * shm_toc_lookup(shm_toc *toc, uint64 key, bool noError)
Definition: shm_toc.c:232
shm_toc * shm_toc_attach(uint64 magic, void *address)
Definition: shm_toc.c:64
#define shm_toc_estimate_chunk(e, sz)
Definition: shm_toc.h:51
#define shm_toc_initialize_estimator(e)
Definition: shm_toc.h:49
#define shm_toc_estimate_keys(e, cnt)
Definition: shm_toc.h:53
Size mul_size(Size s1, Size s2)
Definition: shmem.c:510
void SerializeSnapshot(Snapshot snapshot, char *start_address)
Definition: snapmgr.c:1736
Snapshot GetTransactionSnapshot(void)
Definition: snapmgr.c:272
void PushActiveSnapshot(Snapshot snapshot)
Definition: snapmgr.c:682
Snapshot RestoreSnapshot(char *start_address)
Definition: snapmgr.c:1793
void RestoreTransactionSnapshot(Snapshot snapshot, PGPROC *source_pgproc)
Definition: snapmgr.c:1853
void PopActiveSnapshot(void)
Definition: snapmgr.c:775
Size EstimateSnapshotSpace(Snapshot snapshot)
Definition: snapmgr.c:1712
Snapshot GetActiveSnapshot(void)
Definition: snapmgr.c:800
#define SpinLockInit(lock)
Definition: spin.h:57
#define SpinLockRelease(lock)
Definition: spin.h:61
#define SpinLockAcquire(lock)
Definition: spin.h:59
PGPROC * MyProc
Definition: proc.c:67
bool BecomeLockGroupMember(PGPROC *leader, int pid)
Definition: proc.c:2041
void BecomeLockGroupLeader(void)
Definition: proc.c:2011
void SerializePendingSyncs(Size maxSize, char *startAddress)
Definition: storage.c:600
Size EstimatePendingSyncsSpace(void)
Definition: storage.c:587
void RestorePendingSyncs(char *startAddress)
Definition: storage.c:651
void appendBinaryStringInfo(StringInfo str, const void *data, int datalen)
Definition: stringinfo.c:281
void initStringInfo(StringInfo str)
Definition: stringinfo.c:97
char bgw_function_name[BGW_MAXLEN]
Definition: bgworker.h:104
Datum bgw_main_arg
Definition: bgworker.h:105
char bgw_name[BGW_MAXLEN]
Definition: bgworker.h:98
int bgw_restart_time
Definition: bgworker.h:102
char bgw_type[BGW_MAXLEN]
Definition: bgworker.h:99
BgWorkerStartTime bgw_start_time
Definition: bgworker.h:101
char bgw_extra[BGW_EXTRALEN]
Definition: bgworker.h:106
pid_t bgw_notify_pid
Definition: bgworker.h:107
char bgw_library_name[MAXPGPATH]
Definition: bgworker.h:103
const char * authn_id
Definition: libpq-be.h:99
UserAuth auth_method
Definition: libpq-be.h:105
char * context
Definition: elog.h:436
int elevel
Definition: elog.h:421
Oid temp_toast_namespace_id
Definition: parallel.c:91
XLogRecPtr last_xlog_end
Definition: parallel.c:106
bool role_is_superuser
Definition: parallel.c:94
TimestampTz stmt_ts
Definition: parallel.c:99
SerializableXactHandle serializable_xact_handle
Definition: parallel.c:100
TimestampTz xact_ts
Definition: parallel.c:98
PGPROC * parallel_leader_pgproc
Definition: parallel.c:95
bool session_user_is_superuser
Definition: parallel.c:93
pid_t parallel_leader_pid
Definition: parallel.c:96
Oid authenticated_user_id
Definition: parallel.c:86
ProcNumber parallel_leader_proc_number
Definition: parallel.c:97
Definition: proc.h:179
char * library_name
Definition: parallel.h:38
dsm_segment * seg
Definition: parallel.h:42
bool * known_attached_workers
Definition: parallel.h:47
ErrorContextCallback * error_context_stack
Definition: parallel.h:40
SubTransactionId subid
Definition: parallel.h:34
shm_toc_estimator estimator
Definition: parallel.h:41
int nknown_attached_workers
Definition: parallel.h:46
ParallelWorkerInfo * worker
Definition: parallel.h:45
shm_toc * toc
Definition: parallel.h:44
dlist_node node
Definition: parallel.h:33
void * private_memory
Definition: parallel.h:43
int nworkers_launched
Definition: parallel.h:37
int nworkers_to_launch
Definition: parallel.h:36
char * function_name
Definition: parallel.h:39
BackgroundWorkerHandle * bgwhandle
Definition: parallel.h:27
shm_mq_handle * error_mqh
Definition: parallel.h:28
dlist_node * cur
Definition: ilist.h:179
Definition: type.h:96
Definition: shm_mq.c:72
void parallel_vacuum_main(dsm_segment *seg, shm_toc *toc)
#define WL_EXIT_ON_PM_DEATH
Definition: waiteventset.h:39
#define WL_LATCH_SET
Definition: waiteventset.h:34
void SerializeTransactionState(Size maxsize, char *start_address)
Definition: xact.c:5562
void ExitParallelMode(void)
Definition: xact.c:1065
SubTransactionId GetCurrentSubTransactionId(void)
Definition: xact.c:792
void EnterParallelMode(void)
Definition: xact.c:1052
Size EstimateTransactionStateSpace(void)
Definition: xact.c:5534
void StartTransactionCommand(void)
Definition: xact.c:3080
void StartParallelWorkerTransaction(char *tstatespace)
Definition: xact.c:5633
void SetParallelStartTimestamps(TimestampTz xact_ts, TimestampTz stmt_ts)
Definition: xact.c:860
bool IsInParallelMode(void)
Definition: xact.c:1090
TimestampTz GetCurrentStatementStartTimestamp(void)
Definition: xact.c:880
TimestampTz GetCurrentTransactionStartTimestamp(void)
Definition: xact.c:871
void EndParallelWorkerTransaction(void)
Definition: xact.c:5658
void CommitTransactionCommand(void)
Definition: xact.c:3178
#define IsolationUsesXactSnapshot()
Definition: xact.h:52
XLogRecPtr XactLastRecEnd
Definition: xlog.c:257
uint64 XLogRecPtr
Definition: xlogdefs.h:21