PostgreSQL Source Code  git master
logical.c
Go to the documentation of this file.
1 /*-------------------------------------------------------------------------
2  * logical.c
3  * PostgreSQL logical decoding coordination
4  *
5  * Copyright (c) 2012-2024, PostgreSQL Global Development Group
6  *
7  * IDENTIFICATION
8  * src/backend/replication/logical/logical.c
9  *
10  * NOTES
11  * This file coordinates interaction between the various modules that
12  * together provide logical decoding, primarily by providing so
13  * called LogicalDecodingContexts. The goal is to encapsulate most of the
14  * internal complexity for consumers of logical decoding, so they can
15  * create and consume a changestream with a low amount of code. Builtin
16  * consumers are the walsender and SQL SRF interface, but it's possible to
17  * add further ones without changing core code, e.g. to consume changes in
18  * a bgworker.
19  *
20  * The idea is that a consumer provides three callbacks, one to read WAL,
21  * one to prepare a data write, and a final one for actually writing since
22  * their implementation depends on the type of consumer. Check
23  * logicalfuncs.c for an example implementation of a fairly simple consumer
24  * and an implementation of a WAL reading callback that's suitable for
25  * simple consumers.
26  *-------------------------------------------------------------------------
27  */
28 
29 #include "postgres.h"
30 
31 #include "access/xact.h"
32 #include "access/xlogutils.h"
33 #include "fmgr.h"
34 #include "miscadmin.h"
35 #include "pgstat.h"
36 #include "replication/decode.h"
37 #include "replication/logical.h"
39 #include "replication/slotsync.h"
40 #include "replication/snapbuild.h"
41 #include "storage/proc.h"
42 #include "storage/procarray.h"
43 #include "utils/builtins.h"
44 #include "utils/inval.h"
45 #include "utils/memutils.h"
46 
47 /* data for errcontext callback */
49 {
51  const char *callback_name;
54 
55 /* wrappers around output plugin callbacks */
56 static void output_plugin_error_callback(void *arg);
58  bool is_init);
60 static void begin_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn);
61 static void commit_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn,
62  XLogRecPtr commit_lsn);
64 static void prepare_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn,
65  XLogRecPtr prepare_lsn);
67  XLogRecPtr commit_lsn);
69  XLogRecPtr prepare_end_lsn, TimestampTz prepare_time);
70 static void change_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn,
71  Relation relation, ReorderBufferChange *change);
72 static void truncate_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn,
73  int nrelations, Relation relations[], ReorderBufferChange *change);
74 static void message_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn,
75  XLogRecPtr message_lsn, bool transactional,
76  const char *prefix, Size message_size, const char *message);
77 
78 /* streaming callbacks */
80  XLogRecPtr first_lsn);
82  XLogRecPtr last_lsn);
84  XLogRecPtr abort_lsn);
86  XLogRecPtr prepare_lsn);
88  XLogRecPtr commit_lsn);
90  Relation relation, ReorderBufferChange *change);
92  XLogRecPtr message_lsn, bool transactional,
93  const char *prefix, Size message_size, const char *message);
95  int nrelations, Relation relations[], ReorderBufferChange *change);
96 
97 /* callback to update txn's progress */
99  ReorderBufferTXN *txn,
100  XLogRecPtr lsn);
101 
102 static void LoadOutputPlugin(OutputPluginCallbacks *callbacks, const char *plugin);
103 
104 /*
105  * Make sure the current settings & environment are capable of doing logical
106  * decoding.
107  */
108 void
110 {
112 
113  /*
114  * NB: Adding a new requirement likely means that RestoreSlotFromDisk()
115  * needs the same check.
116  */
117 
119  ereport(ERROR,
120  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
121  errmsg("logical decoding requires \"wal_level\" >= \"logical\"")));
122 
123  if (MyDatabaseId == InvalidOid)
124  ereport(ERROR,
125  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
126  errmsg("logical decoding requires a database connection")));
127 
128  if (RecoveryInProgress())
129  {
130  /*
131  * This check may have race conditions, but whenever
132  * XLOG_PARAMETER_CHANGE indicates that wal_level has changed, we
133  * verify that there are no existing logical replication slots. And to
134  * avoid races around creating a new slot,
135  * CheckLogicalDecodingRequirements() is called once before creating
136  * the slot, and once when logical decoding is initially starting up.
137  */
139  ereport(ERROR,
140  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
141  errmsg("logical decoding on standby requires \"wal_level\" >= \"logical\" on the primary")));
142  }
143 }
144 
145 /*
146  * Helper function for CreateInitDecodingContext() and
147  * CreateDecodingContext() performing common tasks.
148  */
149 static LogicalDecodingContext *
150 StartupDecodingContext(List *output_plugin_options,
151  XLogRecPtr start_lsn,
152  TransactionId xmin_horizon,
153  bool need_full_snapshot,
154  bool fast_forward,
155  bool in_create,
156  XLogReaderRoutine *xl_routine,
160 {
161  ReplicationSlot *slot;
163  old_context;
165 
166  /* shorter lines... */
167  slot = MyReplicationSlot;
168 
170  "Logical decoding context",
172  old_context = MemoryContextSwitchTo(context);
173  ctx = palloc0(sizeof(LogicalDecodingContext));
174 
175  ctx->context = context;
176 
177  /*
178  * (re-)load output plugins, so we detect a bad (removed) output plugin
179  * now.
180  */
181  if (!fast_forward)
183 
184  /*
185  * Now that the slot's xmin has been set, we can announce ourselves as a
186  * logical decoding backend which doesn't need to be checked individually
187  * when computing the xmin horizon because the xmin is enforced via
188  * replication slots.
189  *
190  * We can only do so if we're outside of a transaction (i.e. the case when
191  * streaming changes via walsender), otherwise an already setup
192  * snapshot/xid would end up being ignored. That's not a particularly
193  * bothersome restriction since the SQL interface can't be used for
194  * streaming anyway.
195  */
197  {
198  LWLockAcquire(ProcArrayLock, LW_EXCLUSIVE);
201  LWLockRelease(ProcArrayLock);
202  }
203 
204  ctx->slot = slot;
205 
206  ctx->reader = XLogReaderAllocate(wal_segment_size, NULL, xl_routine, ctx);
207  if (!ctx->reader)
208  ereport(ERROR,
209  (errcode(ERRCODE_OUT_OF_MEMORY),
210  errmsg("out of memory"),
211  errdetail("Failed while allocating a WAL reading processor.")));
212 
214  ctx->snapshot_builder =
215  AllocateSnapshotBuilder(ctx->reorder, xmin_horizon, start_lsn,
216  need_full_snapshot, in_create, slot->data.two_phase_at);
217 
218  ctx->reorder->private_data = ctx;
219 
220  /* wrap output plugin callbacks, so we can add error context information */
226 
227  /*
228  * To support streaming, we require start/stop/abort/commit/change
229  * callbacks. The message and truncate callbacks are optional, similar to
230  * regular output plugins. We however enable streaming when at least one
231  * of the methods is enabled so that we can easily identify missing
232  * methods.
233  *
234  * We decide it here, but only check it later in the wrappers.
235  */
236  ctx->streaming = (ctx->callbacks.stream_start_cb != NULL) ||
237  (ctx->callbacks.stream_stop_cb != NULL) ||
238  (ctx->callbacks.stream_abort_cb != NULL) ||
239  (ctx->callbacks.stream_commit_cb != NULL) ||
240  (ctx->callbacks.stream_change_cb != NULL) ||
241  (ctx->callbacks.stream_message_cb != NULL) ||
242  (ctx->callbacks.stream_truncate_cb != NULL);
243 
244  /*
245  * streaming callbacks
246  *
247  * stream_message and stream_truncate callbacks are optional, so we do not
248  * fail with ERROR when missing, but the wrappers simply do nothing. We
249  * must set the ReorderBuffer callbacks to something, otherwise the calls
250  * from there will crash (we don't want to move the checks there).
251  */
260 
261 
262  /*
263  * To support two-phase logical decoding, we require
264  * begin_prepare/prepare/commit-prepare/abort-prepare callbacks. The
265  * filter_prepare callback is optional. We however enable two-phase
266  * logical decoding when at least one of the methods is enabled so that we
267  * can easily identify missing methods.
268  *
269  * We decide it here, but only check it later in the wrappers.
270  */
271  ctx->twophase = (ctx->callbacks.begin_prepare_cb != NULL) ||
272  (ctx->callbacks.prepare_cb != NULL) ||
273  (ctx->callbacks.commit_prepared_cb != NULL) ||
274  (ctx->callbacks.rollback_prepared_cb != NULL) ||
275  (ctx->callbacks.stream_prepare_cb != NULL) ||
276  (ctx->callbacks.filter_prepare_cb != NULL);
277 
278  /*
279  * Callback to support decoding at prepare time.
280  */
285 
286  /*
287  * Callback to support updating progress during sending data of a
288  * transaction (and its subtransactions) to the output plugin.
289  */
291 
292  ctx->out = makeStringInfo();
293  ctx->prepare_write = prepare_write;
294  ctx->write = do_write;
295  ctx->update_progress = update_progress;
296 
297  ctx->output_plugin_options = output_plugin_options;
298 
299  ctx->fast_forward = fast_forward;
300 
301  MemoryContextSwitchTo(old_context);
302 
303  return ctx;
304 }
305 
306 /*
307  * Create a new decoding context, for a new logical slot.
308  *
309  * plugin -- contains the name of the output plugin
310  * output_plugin_options -- contains options passed to the output plugin
311  * need_full_snapshot -- if true, must obtain a snapshot able to read all
312  * tables; if false, one that can read only catalogs is acceptable.
313  * restart_lsn -- if given as invalid, it's this routine's responsibility to
314  * mark WAL as reserved by setting a convenient restart_lsn for the slot.
315  * Otherwise, we set for decoding to start from the given LSN without
316  * marking WAL reserved beforehand. In that scenario, it's up to the
317  * caller to guarantee that WAL remains available.
318  * xl_routine -- XLogReaderRoutine for underlying XLogReader
319  * prepare_write, do_write, update_progress --
320  * callbacks that perform the use-case dependent, actual, work.
321  *
322  * Needs to be called while in a memory context that's at least as long lived
323  * as the decoding context because further memory contexts will be created
324  * inside it.
325  *
326  * Returns an initialized decoding context after calling the output plugin's
327  * startup function.
328  */
331  List *output_plugin_options,
332  bool need_full_snapshot,
333  XLogRecPtr restart_lsn,
334  XLogReaderRoutine *xl_routine,
338 {
339  TransactionId xmin_horizon = InvalidTransactionId;
340  ReplicationSlot *slot;
341  NameData plugin_name;
343  MemoryContext old_context;
344 
345  /*
346  * On a standby, this check is also required while creating the slot.
347  * Check the comments in the function.
348  */
350 
351  /* shorter lines... */
352  slot = MyReplicationSlot;
353 
354  /* first some sanity checks that are unlikely to be violated */
355  if (slot == NULL)
356  elog(ERROR, "cannot perform logical decoding without an acquired slot");
357 
358  if (plugin == NULL)
359  elog(ERROR, "cannot initialize logical decoding without a specified plugin");
360 
361  /* Make sure the passed slot is suitable. These are user facing errors. */
362  if (SlotIsPhysical(slot))
363  ereport(ERROR,
364  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
365  errmsg("cannot use physical replication slot for logical decoding")));
366 
367  if (slot->data.database != MyDatabaseId)
368  ereport(ERROR,
369  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
370  errmsg("replication slot \"%s\" was not created in this database",
371  NameStr(slot->data.name))));
372 
373  if (IsTransactionState() &&
375  ereport(ERROR,
376  (errcode(ERRCODE_ACTIVE_SQL_TRANSACTION),
377  errmsg("cannot create logical replication slot in transaction that has performed writes")));
378 
379  /*
380  * Register output plugin name with slot. We need the mutex to avoid
381  * concurrent reading of a partially copied string. But we don't want any
382  * complicated code while holding a spinlock, so do namestrcpy() outside.
383  */
384  namestrcpy(&plugin_name, plugin);
385  SpinLockAcquire(&slot->mutex);
386  slot->data.plugin = plugin_name;
387  SpinLockRelease(&slot->mutex);
388 
389  if (XLogRecPtrIsInvalid(restart_lsn))
391  else
392  {
393  SpinLockAcquire(&slot->mutex);
394  slot->data.restart_lsn = restart_lsn;
395  SpinLockRelease(&slot->mutex);
396  }
397 
398  /* ----
399  * This is a bit tricky: We need to determine a safe xmin horizon to start
400  * decoding from, to avoid starting from a running xacts record referring
401  * to xids whose rows have been vacuumed or pruned
402  * already. GetOldestSafeDecodingTransactionId() returns such a value, but
403  * without further interlock its return value might immediately be out of
404  * date.
405  *
406  * So we have to acquire the ProcArrayLock to prevent computation of new
407  * xmin horizons by other backends, get the safe decoding xid, and inform
408  * the slot machinery about the new limit. Once that's done the
409  * ProcArrayLock can be released as the slot machinery now is
410  * protecting against vacuum.
411  *
412  * Note that, temporarily, the data, not just the catalog, xmin has to be
413  * reserved if a data snapshot is to be exported. Otherwise the initial
414  * data snapshot created here is not guaranteed to be valid. After that
415  * the data xmin doesn't need to be managed anymore and the global xmin
416  * should be recomputed. As we are fine with losing the pegged data xmin
417  * after crash - no chance a snapshot would get exported anymore - we can
418  * get away with just setting the slot's
419  * effective_xmin. ReplicationSlotRelease will reset it again.
420  *
421  * ----
422  */
423  LWLockAcquire(ProcArrayLock, LW_EXCLUSIVE);
424 
425  xmin_horizon = GetOldestSafeDecodingTransactionId(!need_full_snapshot);
426 
427  SpinLockAcquire(&slot->mutex);
428  slot->effective_catalog_xmin = xmin_horizon;
429  slot->data.catalog_xmin = xmin_horizon;
430  if (need_full_snapshot)
431  slot->effective_xmin = xmin_horizon;
432  SpinLockRelease(&slot->mutex);
433 
435 
436  LWLockRelease(ProcArrayLock);
437 
440 
441  ctx = StartupDecodingContext(NIL, restart_lsn, xmin_horizon,
442  need_full_snapshot, false, true,
443  xl_routine, prepare_write, do_write,
444  update_progress);
445 
446  /* call output plugin initialization callback */
447  old_context = MemoryContextSwitchTo(ctx->context);
448  if (ctx->callbacks.startup_cb != NULL)
449  startup_cb_wrapper(ctx, &ctx->options, true);
450  MemoryContextSwitchTo(old_context);
451 
452  /*
453  * We allow decoding of prepared transactions when the two_phase is
454  * enabled at the time of slot creation, or when the two_phase option is
455  * given at the streaming start, provided the plugin supports all the
456  * callbacks for two-phase.
457  */
458  ctx->twophase &= slot->data.two_phase;
459 
461 
462  return ctx;
463 }
464 
465 /*
466  * Create a new decoding context, for a logical slot that has previously been
467  * used already.
468  *
469  * start_lsn
470  * The LSN at which to start decoding. If InvalidXLogRecPtr, restart
471  * from the slot's confirmed_flush; otherwise, start from the specified
472  * location (but move it forwards to confirmed_flush if it's older than
473  * that, see below).
474  *
475  * output_plugin_options
476  * options passed to the output plugin.
477  *
478  * fast_forward
479  * bypass the generation of logical changes.
480  *
481  * xl_routine
482  * XLogReaderRoutine used by underlying xlogreader
483  *
484  * prepare_write, do_write, update_progress
485  * callbacks that have to be filled to perform the use-case dependent,
486  * actual work.
487  *
488  * Needs to be called while in a memory context that's at least as long lived
489  * as the decoding context because further memory contexts will be created
490  * inside it.
491  *
492  * Returns an initialized decoding context after calling the output plugin's
493  * startup function.
494  */
497  List *output_plugin_options,
498  bool fast_forward,
499  XLogReaderRoutine *xl_routine,
503 {
505  ReplicationSlot *slot;
506  MemoryContext old_context;
507 
508  /* shorter lines... */
509  slot = MyReplicationSlot;
510 
511  /* first some sanity checks that are unlikely to be violated */
512  if (slot == NULL)
513  elog(ERROR, "cannot perform logical decoding without an acquired slot");
514 
515  /* make sure the passed slot is suitable, these are user facing errors */
516  if (SlotIsPhysical(slot))
517  ereport(ERROR,
518  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
519  errmsg("cannot use physical replication slot for logical decoding")));
520 
521  /*
522  * We need to access the system tables during decoding to build the
523  * logical changes unless we are in fast_forward mode where no changes are
524  * generated.
525  */
526  if (slot->data.database != MyDatabaseId && !fast_forward)
527  ereport(ERROR,
528  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
529  errmsg("replication slot \"%s\" was not created in this database",
530  NameStr(slot->data.name))));
531 
532  /*
533  * The slots being synced from the primary can't be used for decoding as
534  * they are used after failover. However, we do allow advancing the LSNs
535  * during the synchronization of slots. See update_local_synced_slot.
536  */
538  ereport(ERROR,
539  errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
540  errmsg("cannot use replication slot \"%s\" for logical decoding",
541  NameStr(slot->data.name)),
542  errdetail("This slot is being synchronized from the primary server."),
543  errhint("Specify another replication slot."));
544 
545  /*
546  * Check if slot has been invalidated due to max_slot_wal_keep_size. Avoid
547  * "cannot get changes" wording in this errmsg because that'd be
548  * confusingly ambiguous about no changes being available when called from
549  * pg_logical_slot_get_changes_guts().
550  */
552  ereport(ERROR,
553  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
554  errmsg("can no longer get changes from replication slot \"%s\"",
556  errdetail("This slot has been invalidated because it exceeded the maximum reserved size.")));
557 
559  ereport(ERROR,
560  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
561  errmsg("can no longer get changes from replication slot \"%s\"",
563  errdetail("This slot has been invalidated because it was conflicting with recovery.")));
564 
567 
568  if (start_lsn == InvalidXLogRecPtr)
569  {
570  /* continue from last position */
571  start_lsn = slot->data.confirmed_flush;
572  }
573  else if (start_lsn < slot->data.confirmed_flush)
574  {
575  /*
576  * It might seem like we should error out in this case, but it's
577  * pretty common for a client to acknowledge a LSN it doesn't have to
578  * do anything for, and thus didn't store persistently, because the
579  * xlog records didn't result in anything relevant for logical
580  * decoding. Clients have to be able to do that to support synchronous
581  * replication.
582  *
583  * Starting at a different LSN than requested might not catch certain
584  * kinds of client errors; so the client may wish to check that
585  * confirmed_flush_lsn matches its expectations.
586  */
587  elog(LOG, "%X/%X has been already streamed, forwarding to %X/%X",
588  LSN_FORMAT_ARGS(start_lsn),
590 
591  start_lsn = slot->data.confirmed_flush;
592  }
593 
594  ctx = StartupDecodingContext(output_plugin_options,
595  start_lsn, InvalidTransactionId, false,
596  fast_forward, false, xl_routine, prepare_write,
597  do_write, update_progress);
598 
599  /* call output plugin initialization callback */
600  old_context = MemoryContextSwitchTo(ctx->context);
601  if (ctx->callbacks.startup_cb != NULL)
602  startup_cb_wrapper(ctx, &ctx->options, false);
603  MemoryContextSwitchTo(old_context);
604 
605  /*
606  * We allow decoding of prepared transactions when the two_phase is
607  * enabled at the time of slot creation, or when the two_phase option is
608  * given at the streaming start, provided the plugin supports all the
609  * callbacks for two-phase.
610  */
611  ctx->twophase &= (slot->data.two_phase || ctx->twophase_opt_given);
612 
613  /* Mark slot to allow two_phase decoding if not already marked */
614  if (ctx->twophase && !slot->data.two_phase)
615  {
616  SpinLockAcquire(&slot->mutex);
617  slot->data.two_phase = true;
618  slot->data.two_phase_at = start_lsn;
619  SpinLockRelease(&slot->mutex);
622  SnapBuildSetTwoPhaseAt(ctx->snapshot_builder, start_lsn);
623  }
624 
626 
627  ereport(LOG,
628  (errmsg("starting logical decoding for slot \"%s\"",
629  NameStr(slot->data.name)),
630  errdetail("Streaming transactions committing after %X/%X, reading WAL from %X/%X.",
632  LSN_FORMAT_ARGS(slot->data.restart_lsn))));
633 
634  return ctx;
635 }
636 
637 /*
638  * Returns true if a consistent initial decoding snapshot has been built.
639  */
640 bool
642 {
644 }
645 
646 /*
647  * Read from the decoding slot, until it is ready to start extracting changes.
648  */
649 void
651 {
652  ReplicationSlot *slot = ctx->slot;
653 
654  /* Initialize from where to start reading WAL. */
655  XLogBeginRead(ctx->reader, slot->data.restart_lsn);
656 
657  elog(DEBUG1, "searching for logical decoding starting point, starting at %X/%X",
659 
660  /* Wait for a consistent starting point */
661  for (;;)
662  {
663  XLogRecord *record;
664  char *err = NULL;
665 
666  /* the read_page callback waits for new WAL */
667  record = XLogReadRecord(ctx->reader, &err);
668  if (err)
669  elog(ERROR, "could not find logical decoding starting point: %s", err);
670  if (!record)
671  elog(ERROR, "could not find logical decoding starting point");
672 
674 
675  /* only continue till we found a consistent spot */
676  if (DecodingContextReady(ctx))
677  break;
678 
680  }
681 
682  SpinLockAcquire(&slot->mutex);
683  slot->data.confirmed_flush = ctx->reader->EndRecPtr;
684  if (slot->data.two_phase)
685  slot->data.two_phase_at = ctx->reader->EndRecPtr;
686  SpinLockRelease(&slot->mutex);
687 }
688 
689 /*
690  * Free a previously allocated decoding context, invoking the shutdown
691  * callback if necessary.
692  */
693 void
695 {
696  if (ctx->callbacks.shutdown_cb != NULL)
697  shutdown_cb_wrapper(ctx);
698 
701  XLogReaderFree(ctx->reader);
703 }
704 
705 /*
706  * Prepare a write using the context's output routine.
707  */
708 void
710 {
711  if (!ctx->accept_writes)
712  elog(ERROR, "writes are only accepted in commit, begin and change callbacks");
713 
714  ctx->prepare_write(ctx, ctx->write_location, ctx->write_xid, last_write);
715  ctx->prepared_write = true;
716 }
717 
718 /*
719  * Perform a write using the context's output routine.
720  */
721 void
722 OutputPluginWrite(struct LogicalDecodingContext *ctx, bool last_write)
723 {
724  if (!ctx->prepared_write)
725  elog(ERROR, "OutputPluginPrepareWrite needs to be called before OutputPluginWrite");
726 
727  ctx->write(ctx, ctx->write_location, ctx->write_xid, last_write);
728  ctx->prepared_write = false;
729 }
730 
731 /*
732  * Update progress tracking (if supported).
733  */
734 void
736  bool skipped_xact)
737 {
738  if (!ctx->update_progress)
739  return;
740 
741  ctx->update_progress(ctx, ctx->write_location, ctx->write_xid,
742  skipped_xact);
743 }
744 
745 /*
746  * Load the output plugin, lookup its output plugin init function, and check
747  * that it provides the required callbacks.
748  */
749 static void
751 {
752  LogicalOutputPluginInit plugin_init;
753 
754  plugin_init = (LogicalOutputPluginInit)
755  load_external_function(plugin, "_PG_output_plugin_init", false, NULL);
756 
757  if (plugin_init == NULL)
758  elog(ERROR, "output plugins have to declare the _PG_output_plugin_init symbol");
759 
760  /* ask the output plugin to fill the callback struct */
761  plugin_init(callbacks);
762 
763  if (callbacks->begin_cb == NULL)
764  elog(ERROR, "output plugins have to register a begin callback");
765  if (callbacks->change_cb == NULL)
766  elog(ERROR, "output plugins have to register a change callback");
767  if (callbacks->commit_cb == NULL)
768  elog(ERROR, "output plugins have to register a commit callback");
769 }
770 
771 static void
773 {
775 
776  /* not all callbacks have an associated LSN */
777  if (state->report_location != InvalidXLogRecPtr)
778  errcontext("slot \"%s\", output plugin \"%s\", in the %s callback, associated LSN %X/%X",
779  NameStr(state->ctx->slot->data.name),
780  NameStr(state->ctx->slot->data.plugin),
781  state->callback_name,
782  LSN_FORMAT_ARGS(state->report_location));
783  else
784  errcontext("slot \"%s\", output plugin \"%s\", in the %s callback",
785  NameStr(state->ctx->slot->data.name),
786  NameStr(state->ctx->slot->data.plugin),
787  state->callback_name);
788 }
789 
790 static void
792 {
794  ErrorContextCallback errcallback;
795 
796  Assert(!ctx->fast_forward);
797 
798  /* Push callback + info on the error context stack */
799  state.ctx = ctx;
800  state.callback_name = "startup";
801  state.report_location = InvalidXLogRecPtr;
803  errcallback.arg = (void *) &state;
804  errcallback.previous = error_context_stack;
805  error_context_stack = &errcallback;
806 
807  /* set output state */
808  ctx->accept_writes = false;
809  ctx->end_xact = false;
810 
811  /* do the actual work: call callback */
812  ctx->callbacks.startup_cb(ctx, opt, is_init);
813 
814  /* Pop the error context stack */
815  error_context_stack = errcallback.previous;
816 }
817 
818 static void
820 {
822  ErrorContextCallback errcallback;
823 
824  Assert(!ctx->fast_forward);
825 
826  /* Push callback + info on the error context stack */
827  state.ctx = ctx;
828  state.callback_name = "shutdown";
829  state.report_location = InvalidXLogRecPtr;
831  errcallback.arg = (void *) &state;
832  errcallback.previous = error_context_stack;
833  error_context_stack = &errcallback;
834 
835  /* set output state */
836  ctx->accept_writes = false;
837  ctx->end_xact = false;
838 
839  /* do the actual work: call callback */
840  ctx->callbacks.shutdown_cb(ctx);
841 
842  /* Pop the error context stack */
843  error_context_stack = errcallback.previous;
844 }
845 
846 
847 /*
848  * Callbacks for ReorderBuffer which add in some more information and then call
849  * output_plugin.h plugins.
850  */
851 static void
853 {
854  LogicalDecodingContext *ctx = cache->private_data;
856  ErrorContextCallback errcallback;
857 
858  Assert(!ctx->fast_forward);
859 
860  /* Push callback + info on the error context stack */
861  state.ctx = ctx;
862  state.callback_name = "begin";
863  state.report_location = txn->first_lsn;
865  errcallback.arg = (void *) &state;
866  errcallback.previous = error_context_stack;
867  error_context_stack = &errcallback;
868 
869  /* set output state */
870  ctx->accept_writes = true;
871  ctx->write_xid = txn->xid;
872  ctx->write_location = txn->first_lsn;
873  ctx->end_xact = false;
874 
875  /* do the actual work: call callback */
876  ctx->callbacks.begin_cb(ctx, txn);
877 
878  /* Pop the error context stack */
879  error_context_stack = errcallback.previous;
880 }
881 
882 static void
884  XLogRecPtr commit_lsn)
885 {
886  LogicalDecodingContext *ctx = cache->private_data;
888  ErrorContextCallback errcallback;
889 
890  Assert(!ctx->fast_forward);
891 
892  /* Push callback + info on the error context stack */
893  state.ctx = ctx;
894  state.callback_name = "commit";
895  state.report_location = txn->final_lsn; /* beginning of commit record */
897  errcallback.arg = (void *) &state;
898  errcallback.previous = error_context_stack;
899  error_context_stack = &errcallback;
900 
901  /* set output state */
902  ctx->accept_writes = true;
903  ctx->write_xid = txn->xid;
904  ctx->write_location = txn->end_lsn; /* points to the end of the record */
905  ctx->end_xact = true;
906 
907  /* do the actual work: call callback */
908  ctx->callbacks.commit_cb(ctx, txn, commit_lsn);
909 
910  /* Pop the error context stack */
911  error_context_stack = errcallback.previous;
912 }
913 
914 /*
915  * The functionality of begin_prepare is quite similar to begin with the
916  * exception that this will have gid (global transaction id) information which
917  * can be used by plugin. Now, we thought about extending the existing begin
918  * but that would break the replication protocol and additionally this looks
919  * cleaner.
920  */
921 static void
923 {
924  LogicalDecodingContext *ctx = cache->private_data;
926  ErrorContextCallback errcallback;
927 
928  Assert(!ctx->fast_forward);
929 
930  /* We're only supposed to call this when two-phase commits are supported */
931  Assert(ctx->twophase);
932 
933  /* Push callback + info on the error context stack */
934  state.ctx = ctx;
935  state.callback_name = "begin_prepare";
936  state.report_location = txn->first_lsn;
938  errcallback.arg = (void *) &state;
939  errcallback.previous = error_context_stack;
940  error_context_stack = &errcallback;
941 
942  /* set output state */
943  ctx->accept_writes = true;
944  ctx->write_xid = txn->xid;
945  ctx->write_location = txn->first_lsn;
946  ctx->end_xact = false;
947 
948  /*
949  * If the plugin supports two-phase commits then begin prepare callback is
950  * mandatory
951  */
952  if (ctx->callbacks.begin_prepare_cb == NULL)
953  ereport(ERROR,
954  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
955  errmsg("logical replication at prepare time requires a %s callback",
956  "begin_prepare_cb")));
957 
958  /* do the actual work: call callback */
959  ctx->callbacks.begin_prepare_cb(ctx, txn);
960 
961  /* Pop the error context stack */
962  error_context_stack = errcallback.previous;
963 }
964 
965 static void
967  XLogRecPtr prepare_lsn)
968 {
969  LogicalDecodingContext *ctx = cache->private_data;
971  ErrorContextCallback errcallback;
972 
973  Assert(!ctx->fast_forward);
974 
975  /* We're only supposed to call this when two-phase commits are supported */
976  Assert(ctx->twophase);
977 
978  /* Push callback + info on the error context stack */
979  state.ctx = ctx;
980  state.callback_name = "prepare";
981  state.report_location = txn->final_lsn; /* beginning of prepare record */
983  errcallback.arg = (void *) &state;
984  errcallback.previous = error_context_stack;
985  error_context_stack = &errcallback;
986 
987  /* set output state */
988  ctx->accept_writes = true;
989  ctx->write_xid = txn->xid;
990  ctx->write_location = txn->end_lsn; /* points to the end of the record */
991  ctx->end_xact = true;
992 
993  /*
994  * If the plugin supports two-phase commits then prepare callback is
995  * mandatory
996  */
997  if (ctx->callbacks.prepare_cb == NULL)
998  ereport(ERROR,
999  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
1000  errmsg("logical replication at prepare time requires a %s callback",
1001  "prepare_cb")));
1002 
1003  /* do the actual work: call callback */
1004  ctx->callbacks.prepare_cb(ctx, txn, prepare_lsn);
1005 
1006  /* Pop the error context stack */
1007  error_context_stack = errcallback.previous;
1008 }
1009 
1010 static void
1012  XLogRecPtr commit_lsn)
1013 {
1014  LogicalDecodingContext *ctx = cache->private_data;
1016  ErrorContextCallback errcallback;
1017 
1018  Assert(!ctx->fast_forward);
1019 
1020  /* We're only supposed to call this when two-phase commits are supported */
1021  Assert(ctx->twophase);
1022 
1023  /* Push callback + info on the error context stack */
1024  state.ctx = ctx;
1025  state.callback_name = "commit_prepared";
1026  state.report_location = txn->final_lsn; /* beginning of commit record */
1027  errcallback.callback = output_plugin_error_callback;
1028  errcallback.arg = (void *) &state;
1029  errcallback.previous = error_context_stack;
1030  error_context_stack = &errcallback;
1031 
1032  /* set output state */
1033  ctx->accept_writes = true;
1034  ctx->write_xid = txn->xid;
1035  ctx->write_location = txn->end_lsn; /* points to the end of the record */
1036  ctx->end_xact = true;
1037 
1038  /*
1039  * If the plugin support two-phase commits then commit prepared callback
1040  * is mandatory
1041  */
1042  if (ctx->callbacks.commit_prepared_cb == NULL)
1043  ereport(ERROR,
1044  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
1045  errmsg("logical replication at prepare time requires a %s callback",
1046  "commit_prepared_cb")));
1047 
1048  /* do the actual work: call callback */
1049  ctx->callbacks.commit_prepared_cb(ctx, txn, commit_lsn);
1050 
1051  /* Pop the error context stack */
1052  error_context_stack = errcallback.previous;
1053 }
1054 
1055 static void
1057  XLogRecPtr prepare_end_lsn,
1058  TimestampTz prepare_time)
1059 {
1060  LogicalDecodingContext *ctx = cache->private_data;
1062  ErrorContextCallback errcallback;
1063 
1064  Assert(!ctx->fast_forward);
1065 
1066  /* We're only supposed to call this when two-phase commits are supported */
1067  Assert(ctx->twophase);
1068 
1069  /* Push callback + info on the error context stack */
1070  state.ctx = ctx;
1071  state.callback_name = "rollback_prepared";
1072  state.report_location = txn->final_lsn; /* beginning of commit record */
1073  errcallback.callback = output_plugin_error_callback;
1074  errcallback.arg = (void *) &state;
1075  errcallback.previous = error_context_stack;
1076  error_context_stack = &errcallback;
1077 
1078  /* set output state */
1079  ctx->accept_writes = true;
1080  ctx->write_xid = txn->xid;
1081  ctx->write_location = txn->end_lsn; /* points to the end of the record */
1082  ctx->end_xact = true;
1083 
1084  /*
1085  * If the plugin support two-phase commits then rollback prepared callback
1086  * is mandatory
1087  */
1088  if (ctx->callbacks.rollback_prepared_cb == NULL)
1089  ereport(ERROR,
1090  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
1091  errmsg("logical replication at prepare time requires a %s callback",
1092  "rollback_prepared_cb")));
1093 
1094  /* do the actual work: call callback */
1095  ctx->callbacks.rollback_prepared_cb(ctx, txn, prepare_end_lsn,
1096  prepare_time);
1097 
1098  /* Pop the error context stack */
1099  error_context_stack = errcallback.previous;
1100 }
1101 
1102 static void
1104  Relation relation, ReorderBufferChange *change)
1105 {
1106  LogicalDecodingContext *ctx = cache->private_data;
1108  ErrorContextCallback errcallback;
1109 
1110  Assert(!ctx->fast_forward);
1111 
1112  /* Push callback + info on the error context stack */
1113  state.ctx = ctx;
1114  state.callback_name = "change";
1115  state.report_location = change->lsn;
1116  errcallback.callback = output_plugin_error_callback;
1117  errcallback.arg = (void *) &state;
1118  errcallback.previous = error_context_stack;
1119  error_context_stack = &errcallback;
1120 
1121  /* set output state */
1122  ctx->accept_writes = true;
1123  ctx->write_xid = txn->xid;
1124 
1125  /*
1126  * Report this change's lsn so replies from clients can give an up-to-date
1127  * answer. This won't ever be enough (and shouldn't be!) to confirm
1128  * receipt of this transaction, but it might allow another transaction's
1129  * commit to be confirmed with one message.
1130  */
1131  ctx->write_location = change->lsn;
1132 
1133  ctx->end_xact = false;
1134 
1135  ctx->callbacks.change_cb(ctx, txn, relation, change);
1136 
1137  /* Pop the error context stack */
1138  error_context_stack = errcallback.previous;
1139 }
1140 
1141 static void
1143  int nrelations, Relation relations[], ReorderBufferChange *change)
1144 {
1145  LogicalDecodingContext *ctx = cache->private_data;
1147  ErrorContextCallback errcallback;
1148 
1149  Assert(!ctx->fast_forward);
1150 
1151  if (!ctx->callbacks.truncate_cb)
1152  return;
1153 
1154  /* Push callback + info on the error context stack */
1155  state.ctx = ctx;
1156  state.callback_name = "truncate";
1157  state.report_location = change->lsn;
1158  errcallback.callback = output_plugin_error_callback;
1159  errcallback.arg = (void *) &state;
1160  errcallback.previous = error_context_stack;
1161  error_context_stack = &errcallback;
1162 
1163  /* set output state */
1164  ctx->accept_writes = true;
1165  ctx->write_xid = txn->xid;
1166 
1167  /*
1168  * Report this change's lsn so replies from clients can give an up-to-date
1169  * answer. This won't ever be enough (and shouldn't be!) to confirm
1170  * receipt of this transaction, but it might allow another transaction's
1171  * commit to be confirmed with one message.
1172  */
1173  ctx->write_location = change->lsn;
1174 
1175  ctx->end_xact = false;
1176 
1177  ctx->callbacks.truncate_cb(ctx, txn, nrelations, relations, change);
1178 
1179  /* Pop the error context stack */
1180  error_context_stack = errcallback.previous;
1181 }
1182 
1183 bool
1185  const char *gid)
1186 {
1188  ErrorContextCallback errcallback;
1189  bool ret;
1190 
1191  Assert(!ctx->fast_forward);
1192 
1193  /* Push callback + info on the error context stack */
1194  state.ctx = ctx;
1195  state.callback_name = "filter_prepare";
1196  state.report_location = InvalidXLogRecPtr;
1197  errcallback.callback = output_plugin_error_callback;
1198  errcallback.arg = (void *) &state;
1199  errcallback.previous = error_context_stack;
1200  error_context_stack = &errcallback;
1201 
1202  /* set output state */
1203  ctx->accept_writes = false;
1204  ctx->end_xact = false;
1205 
1206  /* do the actual work: call callback */
1207  ret = ctx->callbacks.filter_prepare_cb(ctx, xid, gid);
1208 
1209  /* Pop the error context stack */
1210  error_context_stack = errcallback.previous;
1211 
1212  return ret;
1213 }
1214 
1215 bool
1217 {
1219  ErrorContextCallback errcallback;
1220  bool ret;
1221 
1222  Assert(!ctx->fast_forward);
1223 
1224  /* Push callback + info on the error context stack */
1225  state.ctx = ctx;
1226  state.callback_name = "filter_by_origin";
1227  state.report_location = InvalidXLogRecPtr;
1228  errcallback.callback = output_plugin_error_callback;
1229  errcallback.arg = (void *) &state;
1230  errcallback.previous = error_context_stack;
1231  error_context_stack = &errcallback;
1232 
1233  /* set output state */
1234  ctx->accept_writes = false;
1235  ctx->end_xact = false;
1236 
1237  /* do the actual work: call callback */
1238  ret = ctx->callbacks.filter_by_origin_cb(ctx, origin_id);
1239 
1240  /* Pop the error context stack */
1241  error_context_stack = errcallback.previous;
1242 
1243  return ret;
1244 }
1245 
1246 static void
1248  XLogRecPtr message_lsn, bool transactional,
1249  const char *prefix, Size message_size, const char *message)
1250 {
1251  LogicalDecodingContext *ctx = cache->private_data;
1253  ErrorContextCallback errcallback;
1254 
1255  Assert(!ctx->fast_forward);
1256 
1257  if (ctx->callbacks.message_cb == NULL)
1258  return;
1259 
1260  /* Push callback + info on the error context stack */
1261  state.ctx = ctx;
1262  state.callback_name = "message";
1263  state.report_location = message_lsn;
1264  errcallback.callback = output_plugin_error_callback;
1265  errcallback.arg = (void *) &state;
1266  errcallback.previous = error_context_stack;
1267  error_context_stack = &errcallback;
1268 
1269  /* set output state */
1270  ctx->accept_writes = true;
1271  ctx->write_xid = txn != NULL ? txn->xid : InvalidTransactionId;
1272  ctx->write_location = message_lsn;
1273  ctx->end_xact = false;
1274 
1275  /* do the actual work: call callback */
1276  ctx->callbacks.message_cb(ctx, txn, message_lsn, transactional, prefix,
1277  message_size, message);
1278 
1279  /* Pop the error context stack */
1280  error_context_stack = errcallback.previous;
1281 }
1282 
1283 static void
1285  XLogRecPtr first_lsn)
1286 {
1287  LogicalDecodingContext *ctx = cache->private_data;
1289  ErrorContextCallback errcallback;
1290 
1291  Assert(!ctx->fast_forward);
1292 
1293  /* We're only supposed to call this when streaming is supported. */
1294  Assert(ctx->streaming);
1295 
1296  /* Push callback + info on the error context stack */
1297  state.ctx = ctx;
1298  state.callback_name = "stream_start";
1299  state.report_location = first_lsn;
1300  errcallback.callback = output_plugin_error_callback;
1301  errcallback.arg = (void *) &state;
1302  errcallback.previous = error_context_stack;
1303  error_context_stack = &errcallback;
1304 
1305  /* set output state */
1306  ctx->accept_writes = true;
1307  ctx->write_xid = txn->xid;
1308 
1309  /*
1310  * Report this message's lsn so replies from clients can give an
1311  * up-to-date answer. This won't ever be enough (and shouldn't be!) to
1312  * confirm receipt of this transaction, but it might allow another
1313  * transaction's commit to be confirmed with one message.
1314  */
1315  ctx->write_location = first_lsn;
1316 
1317  ctx->end_xact = false;
1318 
1319  /* in streaming mode, stream_start_cb is required */
1320  if (ctx->callbacks.stream_start_cb == NULL)
1321  ereport(ERROR,
1322  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
1323  errmsg("logical streaming requires a %s callback",
1324  "stream_start_cb")));
1325 
1326  ctx->callbacks.stream_start_cb(ctx, txn);
1327 
1328  /* Pop the error context stack */
1329  error_context_stack = errcallback.previous;
1330 }
1331 
1332 static void
1334  XLogRecPtr last_lsn)
1335 {
1336  LogicalDecodingContext *ctx = cache->private_data;
1338  ErrorContextCallback errcallback;
1339 
1340  Assert(!ctx->fast_forward);
1341 
1342  /* We're only supposed to call this when streaming is supported. */
1343  Assert(ctx->streaming);
1344 
1345  /* Push callback + info on the error context stack */
1346  state.ctx = ctx;
1347  state.callback_name = "stream_stop";
1348  state.report_location = last_lsn;
1349  errcallback.callback = output_plugin_error_callback;
1350  errcallback.arg = (void *) &state;
1351  errcallback.previous = error_context_stack;
1352  error_context_stack = &errcallback;
1353 
1354  /* set output state */
1355  ctx->accept_writes = true;
1356  ctx->write_xid = txn->xid;
1357 
1358  /*
1359  * Report this message's lsn so replies from clients can give an
1360  * up-to-date answer. This won't ever be enough (and shouldn't be!) to
1361  * confirm receipt of this transaction, but it might allow another
1362  * transaction's commit to be confirmed with one message.
1363  */
1364  ctx->write_location = last_lsn;
1365 
1366  ctx->end_xact = false;
1367 
1368  /* in streaming mode, stream_stop_cb is required */
1369  if (ctx->callbacks.stream_stop_cb == NULL)
1370  ereport(ERROR,
1371  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
1372  errmsg("logical streaming requires a %s callback",
1373  "stream_stop_cb")));
1374 
1375  ctx->callbacks.stream_stop_cb(ctx, txn);
1376 
1377  /* Pop the error context stack */
1378  error_context_stack = errcallback.previous;
1379 }
1380 
1381 static void
1383  XLogRecPtr abort_lsn)
1384 {
1385  LogicalDecodingContext *ctx = cache->private_data;
1387  ErrorContextCallback errcallback;
1388 
1389  Assert(!ctx->fast_forward);
1390 
1391  /* We're only supposed to call this when streaming is supported. */
1392  Assert(ctx->streaming);
1393 
1394  /* Push callback + info on the error context stack */
1395  state.ctx = ctx;
1396  state.callback_name = "stream_abort";
1397  state.report_location = abort_lsn;
1398  errcallback.callback = output_plugin_error_callback;
1399  errcallback.arg = (void *) &state;
1400  errcallback.previous = error_context_stack;
1401  error_context_stack = &errcallback;
1402 
1403  /* set output state */
1404  ctx->accept_writes = true;
1405  ctx->write_xid = txn->xid;
1406  ctx->write_location = abort_lsn;
1407  ctx->end_xact = true;
1408 
1409  /* in streaming mode, stream_abort_cb is required */
1410  if (ctx->callbacks.stream_abort_cb == NULL)
1411  ereport(ERROR,
1412  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
1413  errmsg("logical streaming requires a %s callback",
1414  "stream_abort_cb")));
1415 
1416  ctx->callbacks.stream_abort_cb(ctx, txn, abort_lsn);
1417 
1418  /* Pop the error context stack */
1419  error_context_stack = errcallback.previous;
1420 }
1421 
1422 static void
1424  XLogRecPtr prepare_lsn)
1425 {
1426  LogicalDecodingContext *ctx = cache->private_data;
1428  ErrorContextCallback errcallback;
1429 
1430  Assert(!ctx->fast_forward);
1431 
1432  /*
1433  * We're only supposed to call this when streaming and two-phase commits
1434  * are supported.
1435  */
1436  Assert(ctx->streaming);
1437  Assert(ctx->twophase);
1438 
1439  /* Push callback + info on the error context stack */
1440  state.ctx = ctx;
1441  state.callback_name = "stream_prepare";
1442  state.report_location = txn->final_lsn;
1443  errcallback.callback = output_plugin_error_callback;
1444  errcallback.arg = (void *) &state;
1445  errcallback.previous = error_context_stack;
1446  error_context_stack = &errcallback;
1447 
1448  /* set output state */
1449  ctx->accept_writes = true;
1450  ctx->write_xid = txn->xid;
1451  ctx->write_location = txn->end_lsn;
1452  ctx->end_xact = true;
1453 
1454  /* in streaming mode with two-phase commits, stream_prepare_cb is required */
1455  if (ctx->callbacks.stream_prepare_cb == NULL)
1456  ereport(ERROR,
1457  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
1458  errmsg("logical streaming at prepare time requires a %s callback",
1459  "stream_prepare_cb")));
1460 
1461  ctx->callbacks.stream_prepare_cb(ctx, txn, prepare_lsn);
1462 
1463  /* Pop the error context stack */
1464  error_context_stack = errcallback.previous;
1465 }
1466 
1467 static void
1469  XLogRecPtr commit_lsn)
1470 {
1471  LogicalDecodingContext *ctx = cache->private_data;
1473  ErrorContextCallback errcallback;
1474 
1475  Assert(!ctx->fast_forward);
1476 
1477  /* We're only supposed to call this when streaming is supported. */
1478  Assert(ctx->streaming);
1479 
1480  /* Push callback + info on the error context stack */
1481  state.ctx = ctx;
1482  state.callback_name = "stream_commit";
1483  state.report_location = txn->final_lsn;
1484  errcallback.callback = output_plugin_error_callback;
1485  errcallback.arg = (void *) &state;
1486  errcallback.previous = error_context_stack;
1487  error_context_stack = &errcallback;
1488 
1489  /* set output state */
1490  ctx->accept_writes = true;
1491  ctx->write_xid = txn->xid;
1492  ctx->write_location = txn->end_lsn;
1493  ctx->end_xact = true;
1494 
1495  /* in streaming mode, stream_commit_cb is required */
1496  if (ctx->callbacks.stream_commit_cb == NULL)
1497  ereport(ERROR,
1498  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
1499  errmsg("logical streaming requires a %s callback",
1500  "stream_commit_cb")));
1501 
1502  ctx->callbacks.stream_commit_cb(ctx, txn, commit_lsn);
1503 
1504  /* Pop the error context stack */
1505  error_context_stack = errcallback.previous;
1506 }
1507 
1508 static void
1510  Relation relation, ReorderBufferChange *change)
1511 {
1512  LogicalDecodingContext *ctx = cache->private_data;
1514  ErrorContextCallback errcallback;
1515 
1516  Assert(!ctx->fast_forward);
1517 
1518  /* We're only supposed to call this when streaming is supported. */
1519  Assert(ctx->streaming);
1520 
1521  /* Push callback + info on the error context stack */
1522  state.ctx = ctx;
1523  state.callback_name = "stream_change";
1524  state.report_location = change->lsn;
1525  errcallback.callback = output_plugin_error_callback;
1526  errcallback.arg = (void *) &state;
1527  errcallback.previous = error_context_stack;
1528  error_context_stack = &errcallback;
1529 
1530  /* set output state */
1531  ctx->accept_writes = true;
1532  ctx->write_xid = txn->xid;
1533 
1534  /*
1535  * Report this change's lsn so replies from clients can give an up-to-date
1536  * answer. This won't ever be enough (and shouldn't be!) to confirm
1537  * receipt of this transaction, but it might allow another transaction's
1538  * commit to be confirmed with one message.
1539  */
1540  ctx->write_location = change->lsn;
1541 
1542  ctx->end_xact = false;
1543 
1544  /* in streaming mode, stream_change_cb is required */
1545  if (ctx->callbacks.stream_change_cb == NULL)
1546  ereport(ERROR,
1547  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
1548  errmsg("logical streaming requires a %s callback",
1549  "stream_change_cb")));
1550 
1551  ctx->callbacks.stream_change_cb(ctx, txn, relation, change);
1552 
1553  /* Pop the error context stack */
1554  error_context_stack = errcallback.previous;
1555 }
1556 
1557 static void
1559  XLogRecPtr message_lsn, bool transactional,
1560  const char *prefix, Size message_size, const char *message)
1561 {
1562  LogicalDecodingContext *ctx = cache->private_data;
1564  ErrorContextCallback errcallback;
1565 
1566  Assert(!ctx->fast_forward);
1567 
1568  /* We're only supposed to call this when streaming is supported. */
1569  Assert(ctx->streaming);
1570 
1571  /* this callback is optional */
1572  if (ctx->callbacks.stream_message_cb == NULL)
1573  return;
1574 
1575  /* Push callback + info on the error context stack */
1576  state.ctx = ctx;
1577  state.callback_name = "stream_message";
1578  state.report_location = message_lsn;
1579  errcallback.callback = output_plugin_error_callback;
1580  errcallback.arg = (void *) &state;
1581  errcallback.previous = error_context_stack;
1582  error_context_stack = &errcallback;
1583 
1584  /* set output state */
1585  ctx->accept_writes = true;
1586  ctx->write_xid = txn != NULL ? txn->xid : InvalidTransactionId;
1587  ctx->write_location = message_lsn;
1588  ctx->end_xact = false;
1589 
1590  /* do the actual work: call callback */
1591  ctx->callbacks.stream_message_cb(ctx, txn, message_lsn, transactional, prefix,
1592  message_size, message);
1593 
1594  /* Pop the error context stack */
1595  error_context_stack = errcallback.previous;
1596 }
1597 
1598 static void
1600  int nrelations, Relation relations[],
1601  ReorderBufferChange *change)
1602 {
1603  LogicalDecodingContext *ctx = cache->private_data;
1605  ErrorContextCallback errcallback;
1606 
1607  Assert(!ctx->fast_forward);
1608 
1609  /* We're only supposed to call this when streaming is supported. */
1610  Assert(ctx->streaming);
1611 
1612  /* this callback is optional */
1613  if (!ctx->callbacks.stream_truncate_cb)
1614  return;
1615 
1616  /* Push callback + info on the error context stack */
1617  state.ctx = ctx;
1618  state.callback_name = "stream_truncate";
1619  state.report_location = change->lsn;
1620  errcallback.callback = output_plugin_error_callback;
1621  errcallback.arg = (void *) &state;
1622  errcallback.previous = error_context_stack;
1623  error_context_stack = &errcallback;
1624 
1625  /* set output state */
1626  ctx->accept_writes = true;
1627  ctx->write_xid = txn->xid;
1628 
1629  /*
1630  * Report this change's lsn so replies from clients can give an up-to-date
1631  * answer. This won't ever be enough (and shouldn't be!) to confirm
1632  * receipt of this transaction, but it might allow another transaction's
1633  * commit to be confirmed with one message.
1634  */
1635  ctx->write_location = change->lsn;
1636 
1637  ctx->end_xact = false;
1638 
1639  ctx->callbacks.stream_truncate_cb(ctx, txn, nrelations, relations, change);
1640 
1641  /* Pop the error context stack */
1642  error_context_stack = errcallback.previous;
1643 }
1644 
1645 static void
1647  XLogRecPtr lsn)
1648 {
1649  LogicalDecodingContext *ctx = cache->private_data;
1651  ErrorContextCallback errcallback;
1652 
1653  Assert(!ctx->fast_forward);
1654 
1655  /* Push callback + info on the error context stack */
1656  state.ctx = ctx;
1657  state.callback_name = "update_progress_txn";
1658  state.report_location = lsn;
1659  errcallback.callback = output_plugin_error_callback;
1660  errcallback.arg = (void *) &state;
1661  errcallback.previous = error_context_stack;
1662  error_context_stack = &errcallback;
1663 
1664  /* set output state */
1665  ctx->accept_writes = false;
1666  ctx->write_xid = txn->xid;
1667 
1668  /*
1669  * Report this change's lsn so replies from clients can give an up-to-date
1670  * answer. This won't ever be enough (and shouldn't be!) to confirm
1671  * receipt of this transaction, but it might allow another transaction's
1672  * commit to be confirmed with one message.
1673  */
1674  ctx->write_location = lsn;
1675 
1676  ctx->end_xact = false;
1677 
1678  OutputPluginUpdateProgress(ctx, false);
1679 
1680  /* Pop the error context stack */
1681  error_context_stack = errcallback.previous;
1682 }
1683 
1684 /*
1685  * Set the required catalog xmin horizon for historic snapshots in the current
1686  * replication slot.
1687  *
1688  * Note that in the most cases, we won't be able to immediately use the xmin
1689  * to increase the xmin horizon: we need to wait till the client has confirmed
1690  * receiving current_lsn with LogicalConfirmReceivedLocation().
1691  */
1692 void
1694 {
1695  bool updated_xmin = false;
1696  ReplicationSlot *slot;
1697  bool got_new_xmin = false;
1698 
1699  slot = MyReplicationSlot;
1700 
1701  Assert(slot != NULL);
1702 
1703  SpinLockAcquire(&slot->mutex);
1704 
1705  /*
1706  * don't overwrite if we already have a newer xmin. This can happen if we
1707  * restart decoding in a slot.
1708  */
1710  {
1711  }
1712 
1713  /*
1714  * If the client has already confirmed up to this lsn, we directly can
1715  * mark this as accepted. This can happen if we restart decoding in a
1716  * slot.
1717  */
1718  else if (current_lsn <= slot->data.confirmed_flush)
1719  {
1720  slot->candidate_catalog_xmin = xmin;
1721  slot->candidate_xmin_lsn = current_lsn;
1722 
1723  /* our candidate can directly be used */
1724  updated_xmin = true;
1725  }
1726 
1727  /*
1728  * Only increase if the previous values have been applied, otherwise we
1729  * might never end up updating if the receiver acks too slowly.
1730  */
1731  else if (slot->candidate_xmin_lsn == InvalidXLogRecPtr)
1732  {
1733  slot->candidate_catalog_xmin = xmin;
1734  slot->candidate_xmin_lsn = current_lsn;
1735 
1736  /*
1737  * Log new xmin at an appropriate log level after releasing the
1738  * spinlock.
1739  */
1740  got_new_xmin = true;
1741  }
1742  SpinLockRelease(&slot->mutex);
1743 
1744  if (got_new_xmin)
1745  elog(DEBUG1, "got new catalog xmin %u at %X/%X", xmin,
1746  LSN_FORMAT_ARGS(current_lsn));
1747 
1748  /* candidate already valid with the current flush position, apply */
1749  if (updated_xmin)
1751 }
1752 
1753 /*
1754  * Mark the minimal LSN (restart_lsn) we need to read to replay all
1755  * transactions that have not yet committed at current_lsn.
1756  *
1757  * Just like LogicalIncreaseXminForSlot this only takes effect when the
1758  * client has confirmed to have received current_lsn.
1759  */
1760 void
1762 {
1763  bool updated_lsn = false;
1764  ReplicationSlot *slot;
1765 
1766  slot = MyReplicationSlot;
1767 
1768  Assert(slot != NULL);
1769  Assert(restart_lsn != InvalidXLogRecPtr);
1770  Assert(current_lsn != InvalidXLogRecPtr);
1771 
1772  SpinLockAcquire(&slot->mutex);
1773 
1774  /* don't overwrite if have a newer restart lsn */
1775  if (restart_lsn <= slot->data.restart_lsn)
1776  {
1777  }
1778 
1779  /*
1780  * We might have already flushed far enough to directly accept this lsn,
1781  * in this case there is no need to check for existing candidate LSNs
1782  */
1783  else if (current_lsn <= slot->data.confirmed_flush)
1784  {
1785  slot->candidate_restart_valid = current_lsn;
1786  slot->candidate_restart_lsn = restart_lsn;
1787 
1788  /* our candidate can directly be used */
1789  updated_lsn = true;
1790  }
1791 
1792  /*
1793  * Only increase if the previous values have been applied, otherwise we
1794  * might never end up updating if the receiver acks too slowly. A missed
1795  * value here will just cause some extra effort after reconnecting.
1796  */
1798  {
1799  slot->candidate_restart_valid = current_lsn;
1800  slot->candidate_restart_lsn = restart_lsn;
1801  SpinLockRelease(&slot->mutex);
1802 
1803  elog(DEBUG1, "got new restart lsn %X/%X at %X/%X",
1804  LSN_FORMAT_ARGS(restart_lsn),
1805  LSN_FORMAT_ARGS(current_lsn));
1806  }
1807  else
1808  {
1809  XLogRecPtr candidate_restart_lsn;
1810  XLogRecPtr candidate_restart_valid;
1811  XLogRecPtr confirmed_flush;
1812 
1813  candidate_restart_lsn = slot->candidate_restart_lsn;
1814  candidate_restart_valid = slot->candidate_restart_valid;
1815  confirmed_flush = slot->data.confirmed_flush;
1816  SpinLockRelease(&slot->mutex);
1817 
1818  elog(DEBUG1, "failed to increase restart lsn: proposed %X/%X, after %X/%X, current candidate %X/%X, current after %X/%X, flushed up to %X/%X",
1819  LSN_FORMAT_ARGS(restart_lsn),
1820  LSN_FORMAT_ARGS(current_lsn),
1821  LSN_FORMAT_ARGS(candidate_restart_lsn),
1822  LSN_FORMAT_ARGS(candidate_restart_valid),
1823  LSN_FORMAT_ARGS(confirmed_flush));
1824  }
1825 
1826  /* candidates are already valid with the current flush position, apply */
1827  if (updated_lsn)
1829 }
1830 
1831 /*
1832  * Handle a consumer's confirmation having received all changes up to lsn.
1833  */
1834 void
1836 {
1837  Assert(lsn != InvalidXLogRecPtr);
1838 
1839  /* Do an unlocked check for candidate_lsn first. */
1842  {
1843  bool updated_xmin = false;
1844  bool updated_restart = false;
1845 
1847 
1849 
1850  /* if we're past the location required for bumping xmin, do so */
1853  {
1854  /*
1855  * We have to write the changed xmin to disk *before* we change
1856  * the in-memory value, otherwise after a crash we wouldn't know
1857  * that some catalog tuples might have been removed already.
1858  *
1859  * Ensure that by first writing to ->xmin and only update
1860  * ->effective_xmin once the new state is synced to disk. After a
1861  * crash ->effective_xmin is set to ->xmin.
1862  */
1865  {
1869  updated_xmin = true;
1870  }
1871  }
1872 
1875  {
1877 
1881  updated_restart = true;
1882  }
1883 
1885 
1886  /* first write new xmin to disk, so we know what's up after a crash */
1887  if (updated_xmin || updated_restart)
1888  {
1891  elog(DEBUG1, "updated xmin: %u restart: %u", updated_xmin, updated_restart);
1892  }
1893 
1894  /*
1895  * Now the new xmin is safely on disk, we can let the global value
1896  * advance. We do not take ProcArrayLock or similar since we only
1897  * advance xmin here and there's not much harm done by a concurrent
1898  * computation missing that.
1899  */
1900  if (updated_xmin)
1901  {
1905 
1908  }
1909  }
1910  else
1911  {
1915  }
1916 }
1917 
1918 /*
1919  * Clear logical streaming state during (sub)transaction abort.
1920  */
1921 void
1923 {
1925  bsysscan = false;
1926 }
1927 
1928 /*
1929  * Report stats for a slot.
1930  */
1931 void
1933 {
1934  ReorderBuffer *rb = ctx->reorder;
1935  PgStat_StatReplSlotEntry repSlotStat;
1936 
1937  /* Nothing to do if we don't have any replication stats to be sent. */
1938  if (rb->spillBytes <= 0 && rb->streamBytes <= 0 && rb->totalBytes <= 0)
1939  return;
1940 
1941  elog(DEBUG2, "UpdateDecodingStats: updating stats %p %lld %lld %lld %lld %lld %lld %lld %lld",
1942  rb,
1943  (long long) rb->spillTxns,
1944  (long long) rb->spillCount,
1945  (long long) rb->spillBytes,
1946  (long long) rb->streamTxns,
1947  (long long) rb->streamCount,
1948  (long long) rb->streamBytes,
1949  (long long) rb->totalTxns,
1950  (long long) rb->totalBytes);
1951 
1952  repSlotStat.spill_txns = rb->spillTxns;
1953  repSlotStat.spill_count = rb->spillCount;
1954  repSlotStat.spill_bytes = rb->spillBytes;
1955  repSlotStat.stream_txns = rb->streamTxns;
1956  repSlotStat.stream_count = rb->streamCount;
1957  repSlotStat.stream_bytes = rb->streamBytes;
1958  repSlotStat.total_txns = rb->totalTxns;
1959  repSlotStat.total_bytes = rb->totalBytes;
1960 
1961  pgstat_report_replslot(ctx->slot, &repSlotStat);
1962 
1963  rb->spillTxns = 0;
1964  rb->spillCount = 0;
1965  rb->spillBytes = 0;
1966  rb->streamTxns = 0;
1967  rb->streamCount = 0;
1968  rb->streamBytes = 0;
1969  rb->totalTxns = 0;
1970  rb->totalBytes = 0;
1971 }
1972 
1973 /*
1974  * Read up to the end of WAL starting from the decoding slot's restart_lsn.
1975  * Return true if any meaningful/decodable WAL records are encountered,
1976  * otherwise false.
1977  */
1978 bool
1980 {
1981  bool has_pending_wal = false;
1982 
1984 
1985  PG_TRY();
1986  {
1988 
1989  /*
1990  * Create our decoding context in fast_forward mode, passing start_lsn
1991  * as InvalidXLogRecPtr, so that we start processing from the slot's
1992  * confirmed_flush.
1993  */
1995  NIL,
1996  true, /* fast_forward */
1997  XL_ROUTINE(.page_read = read_local_xlog_page,
1998  .segment_open = wal_segment_open,
1999  .segment_close = wal_segment_close),
2000  NULL, NULL, NULL);
2001 
2002  /*
2003  * Start reading at the slot's restart_lsn, which we know points to a
2004  * valid record.
2005  */
2007 
2008  /* Invalidate non-timetravel entries */
2010 
2011  /* Loop until the end of WAL or some changes are processed */
2012  while (!has_pending_wal && ctx->reader->EndRecPtr < end_of_wal)
2013  {
2014  XLogRecord *record;
2015  char *errm = NULL;
2016 
2017  record = XLogReadRecord(ctx->reader, &errm);
2018 
2019  if (errm)
2020  elog(ERROR, "could not find record for logical decoding: %s", errm);
2021 
2022  if (record != NULL)
2024 
2025  has_pending_wal = ctx->processing_required;
2026 
2028  }
2029 
2030  /* Clean up */
2031  FreeDecodingContext(ctx);
2033  }
2034  PG_CATCH();
2035  {
2036  /* clear all timetravel entries */
2038 
2039  PG_RE_THROW();
2040  }
2041  PG_END_TRY();
2042 
2043  return has_pending_wal;
2044 }
2045 
2046 /*
2047  * Helper function for advancing our logical replication slot forward.
2048  *
2049  * The slot's restart_lsn is used as start point for reading records, while
2050  * confirmed_flush is used as base point for the decoding context.
2051  *
2052  * We cannot just do LogicalConfirmReceivedLocation to update confirmed_flush,
2053  * because we need to digest WAL to advance restart_lsn allowing to recycle
2054  * WAL and removal of old catalog tuples. As decoding is done in fast_forward
2055  * mode, no changes are generated anyway.
2056  *
2057  * *found_consistent_snapshot will be true if the initial decoding snapshot has
2058  * been built; Otherwise, it will be false.
2059  */
2060 XLogRecPtr
2062  bool *found_consistent_snapshot)
2063 {
2065  ResourceOwner old_resowner = CurrentResourceOwner;
2066  XLogRecPtr retlsn;
2067 
2068  Assert(moveto != InvalidXLogRecPtr);
2069 
2070  if (found_consistent_snapshot)
2071  *found_consistent_snapshot = false;
2072 
2073  PG_TRY();
2074  {
2075  /*
2076  * Create our decoding context in fast_forward mode, passing start_lsn
2077  * as InvalidXLogRecPtr, so that we start processing from my slot's
2078  * confirmed_flush.
2079  */
2081  NIL,
2082  true, /* fast_forward */
2083  XL_ROUTINE(.page_read = read_local_xlog_page,
2084  .segment_open = wal_segment_open,
2085  .segment_close = wal_segment_close),
2086  NULL, NULL, NULL);
2087 
2088  /*
2089  * Wait for specified streaming replication standby servers (if any)
2090  * to confirm receipt of WAL up to moveto lsn.
2091  */
2093 
2094  /*
2095  * Start reading at the slot's restart_lsn, which we know to point to
2096  * a valid record.
2097  */
2099 
2100  /* invalidate non-timetravel entries */
2102 
2103  /* Decode records until we reach the requested target */
2104  while (ctx->reader->EndRecPtr < moveto)
2105  {
2106  char *errm = NULL;
2107  XLogRecord *record;
2108 
2109  /*
2110  * Read records. No changes are generated in fast_forward mode,
2111  * but snapbuilder/slot statuses are updated properly.
2112  */
2113  record = XLogReadRecord(ctx->reader, &errm);
2114  if (errm)
2115  elog(ERROR, "could not find record while advancing replication slot: %s",
2116  errm);
2117 
2118  /*
2119  * Process the record. Storage-level changes are ignored in
2120  * fast_forward mode, but other modules (such as snapbuilder)
2121  * might still have critical updates to do.
2122  */
2123  if (record)
2125 
2127  }
2128 
2129  if (found_consistent_snapshot && DecodingContextReady(ctx))
2130  *found_consistent_snapshot = true;
2131 
2132  /*
2133  * Logical decoding could have clobbered CurrentResourceOwner during
2134  * transaction management, so restore the executor's value. (This is
2135  * a kluge, but it's not worth cleaning up right now.)
2136  */
2137  CurrentResourceOwner = old_resowner;
2138 
2139  if (ctx->reader->EndRecPtr != InvalidXLogRecPtr)
2140  {
2142 
2143  /*
2144  * If only the confirmed_flush LSN has changed the slot won't get
2145  * marked as dirty by the above. Callers on the walsender
2146  * interface are expected to keep track of their own progress and
2147  * don't need it written out. But SQL-interface users cannot
2148  * specify their own start positions and it's harder for them to
2149  * keep track of their progress, so we should make more of an
2150  * effort to save it for them.
2151  *
2152  * Dirty the slot so it is written out at the next checkpoint. The
2153  * LSN position advanced to may still be lost on a crash but this
2154  * makes the data consistent after a clean shutdown.
2155  */
2157  }
2158 
2160 
2161  /* free context, call shutdown callback */
2162  FreeDecodingContext(ctx);
2163 
2165  }
2166  PG_CATCH();
2167  {
2168  /* clear all timetravel entries */
2170 
2171  PG_RE_THROW();
2172  }
2173  PG_END_TRY();
2174 
2175  return retlsn;
2176 }
#define NameStr(name)
Definition: c.h:746
#define Assert(condition)
Definition: c.h:858
uint32 TransactionId
Definition: c.h:652
size_t Size
Definition: c.h:605
int64 TimestampTz
Definition: timestamp.h:39
void LogicalDecodingProcessRecord(LogicalDecodingContext *ctx, XLogReaderState *record)
Definition: decode.c:88
void * load_external_function(const char *filename, const char *funcname, bool signalNotFound, void **filehandle)
Definition: dfmgr.c:105
int errdetail(const char *fmt,...)
Definition: elog.c:1203
ErrorContextCallback * error_context_stack
Definition: elog.c:94
int errhint(const char *fmt,...)
Definition: elog.c:1317
int errcode(int sqlerrcode)
Definition: elog.c:853
int errmsg(const char *fmt,...)
Definition: elog.c:1070
#define LOG
Definition: elog.h:31
#define PG_RE_THROW()
Definition: elog.h:411
#define errcontext
Definition: elog.h:196
#define PG_TRY(...)
Definition: elog.h:370
#define DEBUG2
Definition: elog.h:29
#define PG_END_TRY(...)
Definition: elog.h:395
#define DEBUG1
Definition: elog.h:30
#define ERROR
Definition: elog.h:39
#define PG_CATCH(...)
Definition: elog.h:380
#define elog(elevel,...)
Definition: elog.h:224
#define ereport(elevel,...)
Definition: elog.h:149
void err(int eval, const char *fmt,...)
Definition: err.c:43
Oid MyDatabaseId
Definition: globals.c:92
void InvalidateSystemCaches(void)
Definition: inval.c:792
static void change_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn, Relation relation, ReorderBufferChange *change)
Definition: logical.c:1103
static void commit_prepared_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn, XLogRecPtr commit_lsn)
Definition: logical.c:1011
static void update_progress_txn_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn, XLogRecPtr lsn)
Definition: logical.c:1646
XLogRecPtr LogicalSlotAdvanceAndCheckSnapState(XLogRecPtr moveto, bool *found_consistent_snapshot)
Definition: logical.c:2061
void LogicalConfirmReceivedLocation(XLogRecPtr lsn)
Definition: logical.c:1835
void FreeDecodingContext(LogicalDecodingContext *ctx)
Definition: logical.c:694
bool LogicalReplicationSlotHasPendingWal(XLogRecPtr end_of_wal)
Definition: logical.c:1979
static void stream_start_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn, XLogRecPtr first_lsn)
Definition: logical.c:1284
static void commit_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn, XLogRecPtr commit_lsn)
Definition: logical.c:883
static void output_plugin_error_callback(void *arg)
Definition: logical.c:772
static void begin_prepare_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn)
Definition: logical.c:922
static void stream_prepare_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn, XLogRecPtr prepare_lsn)
Definition: logical.c:1423
static LogicalDecodingContext * StartupDecodingContext(List *output_plugin_options, XLogRecPtr start_lsn, TransactionId xmin_horizon, bool need_full_snapshot, bool fast_forward, bool in_create, XLogReaderRoutine *xl_routine, LogicalOutputPluginWriterPrepareWrite prepare_write, LogicalOutputPluginWriterWrite do_write, LogicalOutputPluginWriterUpdateProgress update_progress)
Definition: logical.c:150
static void prepare_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn, XLogRecPtr prepare_lsn)
Definition: logical.c:966
void OutputPluginWrite(struct LogicalDecodingContext *ctx, bool last_write)
Definition: logical.c:722
static void stream_truncate_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn, int nrelations, Relation relations[], ReorderBufferChange *change)
Definition: logical.c:1599
static void truncate_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn, int nrelations, Relation relations[], ReorderBufferChange *change)
Definition: logical.c:1142
void DecodingContextFindStartpoint(LogicalDecodingContext *ctx)
Definition: logical.c:650
static void begin_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn)
Definition: logical.c:852
static void rollback_prepared_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn, XLogRecPtr prepare_end_lsn, TimestampTz prepare_time)
Definition: logical.c:1056
bool DecodingContextReady(LogicalDecodingContext *ctx)
Definition: logical.c:641
void OutputPluginUpdateProgress(struct LogicalDecodingContext *ctx, bool skipped_xact)
Definition: logical.c:735
static void startup_cb_wrapper(LogicalDecodingContext *ctx, OutputPluginOptions *opt, bool is_init)
Definition: logical.c:791
void UpdateDecodingStats(LogicalDecodingContext *ctx)
Definition: logical.c:1932
void LogicalIncreaseRestartDecodingForSlot(XLogRecPtr current_lsn, XLogRecPtr restart_lsn)
Definition: logical.c:1761
static void stream_change_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn, Relation relation, ReorderBufferChange *change)
Definition: logical.c:1509
static void stream_abort_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn, XLogRecPtr abort_lsn)
Definition: logical.c:1382
void ResetLogicalStreamingState(void)
Definition: logical.c:1922
void LogicalIncreaseXminForSlot(XLogRecPtr current_lsn, TransactionId xmin)
Definition: logical.c:1693
struct LogicalErrorCallbackState LogicalErrorCallbackState
static void stream_message_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn, XLogRecPtr message_lsn, bool transactional, const char *prefix, Size message_size, const char *message)
Definition: logical.c:1558
static void stream_commit_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn, XLogRecPtr commit_lsn)
Definition: logical.c:1468
bool filter_prepare_cb_wrapper(LogicalDecodingContext *ctx, TransactionId xid, const char *gid)
Definition: logical.c:1184
static void shutdown_cb_wrapper(LogicalDecodingContext *ctx)
Definition: logical.c:819
void OutputPluginPrepareWrite(struct LogicalDecodingContext *ctx, bool last_write)
Definition: logical.c:709
void CheckLogicalDecodingRequirements(void)
Definition: logical.c:109
LogicalDecodingContext * CreateInitDecodingContext(const char *plugin, List *output_plugin_options, bool need_full_snapshot, XLogRecPtr restart_lsn, XLogReaderRoutine *xl_routine, LogicalOutputPluginWriterPrepareWrite prepare_write, LogicalOutputPluginWriterWrite do_write, LogicalOutputPluginWriterUpdateProgress update_progress)
Definition: logical.c:330
bool filter_by_origin_cb_wrapper(LogicalDecodingContext *ctx, RepOriginId origin_id)
Definition: logical.c:1216
static void LoadOutputPlugin(OutputPluginCallbacks *callbacks, const char *plugin)
Definition: logical.c:750
static void stream_stop_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn, XLogRecPtr last_lsn)
Definition: logical.c:1333
static void message_cb_wrapper(ReorderBuffer *cache, ReorderBufferTXN *txn, XLogRecPtr message_lsn, bool transactional, const char *prefix, Size message_size, const char *message)
Definition: logical.c:1247
LogicalDecodingContext * CreateDecodingContext(XLogRecPtr start_lsn, List *output_plugin_options, bool fast_forward, XLogReaderRoutine *xl_routine, LogicalOutputPluginWriterPrepareWrite prepare_write, LogicalOutputPluginWriterWrite do_write, LogicalOutputPluginWriterUpdateProgress update_progress)
Definition: logical.c:496
void(* LogicalOutputPluginWriterUpdateProgress)(struct LogicalDecodingContext *lr, XLogRecPtr Ptr, TransactionId xid, bool skipped_xact)
Definition: logical.h:27
void(* LogicalOutputPluginWriterWrite)(struct LogicalDecodingContext *lr, XLogRecPtr Ptr, TransactionId xid, bool last_write)
Definition: logical.h:19
LogicalOutputPluginWriterWrite LogicalOutputPluginWriterPrepareWrite
Definition: logical.h:25
bool LWLockAcquire(LWLock *lock, LWLockMode mode)
Definition: lwlock.c:1168
void LWLockRelease(LWLock *lock)
Definition: lwlock.c:1781
@ LW_EXCLUSIVE
Definition: lwlock.h:114
void * palloc0(Size size)
Definition: mcxt.c:1347
MemoryContext CurrentMemoryContext
Definition: mcxt.c:143
void MemoryContextDelete(MemoryContext context)
Definition: mcxt.c:454
#define AllocSetContextCreate
Definition: memutils.h:129
#define ALLOCSET_DEFAULT_SIZES
Definition: memutils.h:160
#define CHECK_FOR_INTERRUPTS()
Definition: miscadmin.h:122
void namestrcpy(Name name, const char *str)
Definition: name.c:233
void(* LogicalOutputPluginInit)(struct OutputPluginCallbacks *cb)
Definition: output_plugin.h:36
void * arg
const void * data
#define NIL
Definition: pg_list.h:68
static const char * plugin
void pgstat_report_replslot(ReplicationSlot *slot, const PgStat_StatReplSlotEntry *repSlotStat)
#define InvalidOid
Definition: postgres_ext.h:36
#define PROC_IN_LOGICAL_DECODING
Definition: proc.h:61
TransactionId GetOldestSafeDecodingTransactionId(bool catalogOnly)
Definition: procarray.c:2949
tree context
Definition: radixtree.h:1835
MemoryContextSwitchTo(old_ctx)
ReorderBuffer * ReorderBufferAllocate(void)
void ReorderBufferFree(ReorderBuffer *rb)
ResourceOwner CurrentResourceOwner
Definition: resowner.c:165
void ReplicationSlotMarkDirty(void)
Definition: slot.c:1031
void ReplicationSlotReserveWal(void)
Definition: slot.c:1422
void ReplicationSlotsComputeRequiredXmin(bool already_locked)
Definition: slot.c:1070
ReplicationSlot * MyReplicationSlot
Definition: slot.c:138
void ReplicationSlotSave(void)
Definition: slot.c:1013
void WaitForStandbyConfirmation(XLogRecPtr wait_for_lsn)
Definition: slot.c:2762
void ReplicationSlotsComputeRequiredLSN(void)
Definition: slot.c:1126
void CheckSlotRequirements(void)
Definition: slot.c:1383
#define SlotIsPhysical(slot)
Definition: slot.h:209
@ RS_INVAL_WAL_REMOVED
Definition: slot.h:51
@ RS_INVAL_NONE
Definition: slot.h:49
bool IsSyncingReplicationSlots(void)
Definition: slotsync.c:1651
void SnapBuildSetTwoPhaseAt(SnapBuild *builder, XLogRecPtr ptr)
Definition: snapbuild.c:434
SnapBuildState SnapBuildCurrentState(SnapBuild *builder)
Definition: snapbuild.c:416
void FreeSnapshotBuilder(SnapBuild *builder)
Definition: snapbuild.c:372
SnapBuild * AllocateSnapshotBuilder(ReorderBuffer *reorder, TransactionId xmin_horizon, XLogRecPtr start_lsn, bool need_full_snapshot, bool in_slot_creation, XLogRecPtr two_phase_at)
Definition: snapbuild.c:324
@ SNAPBUILD_CONSISTENT
Definition: snapbuild.h:46
#define SpinLockRelease(lock)
Definition: spin.h:64
#define SpinLockAcquire(lock)
Definition: spin.h:62
PGPROC * MyProc
Definition: proc.c:66
PROC_HDR * ProcGlobal
Definition: proc.c:78
StringInfo makeStringInfo(void)
Definition: stringinfo.c:41
struct ErrorContextCallback * previous
Definition: elog.h:295
void(* callback)(void *arg)
Definition: elog.h:296
Definition: pg_list.h:54
OutputPluginOptions options
Definition: logical.h:54
XLogReaderState * reader
Definition: logical.h:42
MemoryContext context
Definition: logical.h:36
struct SnapBuild * snapshot_builder
Definition: logical.h:44
StringInfo out
Definition: logical.h:71
XLogRecPtr write_location
Definition: logical.h:108
LogicalOutputPluginWriterPrepareWrite prepare_write
Definition: logical.h:64
OutputPluginCallbacks callbacks
Definition: logical.h:53
TransactionId write_xid
Definition: logical.h:109
List * output_plugin_options
Definition: logical.h:59
ReplicationSlot * slot
Definition: logical.h:39
LogicalOutputPluginWriterWrite write
Definition: logical.h:65
struct ReorderBuffer * reorder
Definition: logical.h:43
LogicalOutputPluginWriterUpdateProgress update_progress
Definition: logical.h:66
XLogRecPtr report_location
Definition: logical.c:52
LogicalDecodingContext * ctx
Definition: logical.c:50
const char * callback_name
Definition: logical.c:51
LogicalDecodeStreamChangeCB stream_change_cb
LogicalDecodeMessageCB message_cb
LogicalDecodeStreamTruncateCB stream_truncate_cb
LogicalDecodeStreamMessageCB stream_message_cb
LogicalDecodeFilterPrepareCB filter_prepare_cb
LogicalDecodeFilterByOriginCB filter_by_origin_cb
LogicalDecodeTruncateCB truncate_cb
LogicalDecodeStreamStopCB stream_stop_cb
LogicalDecodeStreamCommitCB stream_commit_cb
LogicalDecodeRollbackPreparedCB rollback_prepared_cb
LogicalDecodeStreamPrepareCB stream_prepare_cb
LogicalDecodeCommitPreparedCB commit_prepared_cb
LogicalDecodeStreamStartCB stream_start_cb
LogicalDecodePrepareCB prepare_cb
LogicalDecodeStartupCB startup_cb
LogicalDecodeCommitCB commit_cb
LogicalDecodeBeginCB begin_cb
LogicalDecodeStreamAbortCB stream_abort_cb
LogicalDecodeBeginPrepareCB begin_prepare_cb
LogicalDecodeChangeCB change_cb
LogicalDecodeShutdownCB shutdown_cb
uint8 statusFlags
Definition: proc.h:237
int pgxactoff
Definition: proc.h:179
uint8 * statusFlags
Definition: proc.h:394
PgStat_Counter stream_count
Definition: pgstat.h:373
PgStat_Counter total_txns
Definition: pgstat.h:375
PgStat_Counter total_bytes
Definition: pgstat.h:376
PgStat_Counter spill_txns
Definition: pgstat.h:369
PgStat_Counter stream_txns
Definition: pgstat.h:372
PgStat_Counter spill_count
Definition: pgstat.h:370
PgStat_Counter stream_bytes
Definition: pgstat.h:374
PgStat_Counter spill_bytes
Definition: pgstat.h:371
XLogRecPtr first_lsn
XLogRecPtr final_lsn
XLogRecPtr end_lsn
TransactionId xid
ReorderBufferStreamMessageCB stream_message
ReorderBufferStreamChangeCB stream_change
ReorderBufferBeginCB begin_prepare
ReorderBufferStreamTruncateCB stream_truncate
ReorderBufferCommitPreparedCB commit_prepared
ReorderBufferUpdateProgressTxnCB update_progress_txn
ReorderBufferMessageCB message
ReorderBufferRollbackPreparedCB rollback_prepared
ReorderBufferPrepareCB prepare
ReorderBufferStreamStopCB stream_stop
ReorderBufferApplyChangeCB apply_change
ReorderBufferStreamPrepareCB stream_prepare
ReorderBufferStreamAbortCB stream_abort
ReorderBufferCommitCB commit
ReorderBufferStreamStartCB stream_start
ReorderBufferStreamCommitCB stream_commit
ReorderBufferApplyTruncateCB apply_truncate
ReorderBufferBeginCB begin
void * private_data
TransactionId catalog_xmin
Definition: slot.h:90
XLogRecPtr restart_lsn
Definition: slot.h:93
XLogRecPtr confirmed_flush
Definition: slot.h:104
ReplicationSlotInvalidationCause invalidated
Definition: slot.h:96
XLogRecPtr candidate_xmin_lsn
Definition: slot.h:194
TransactionId effective_catalog_xmin
Definition: slot.h:175
slock_t mutex
Definition: slot.h:151
XLogRecPtr candidate_restart_valid
Definition: slot.h:195
TransactionId effective_xmin
Definition: slot.h:174
XLogRecPtr candidate_restart_lsn
Definition: slot.h:196
TransactionId candidate_catalog_xmin
Definition: slot.h:193
ReplicationSlotPersistentData data
Definition: slot.h:178
XLogRecPtr EndRecPtr
Definition: xlogreader.h:207
Definition: c.h:741
Definition: regguts.h:323
bool TransactionIdPrecedesOrEquals(TransactionId id1, TransactionId id2)
Definition: transam.c:299
#define InvalidTransactionId
Definition: transam.h:31
#define TransactionIdIsValid(xid)
Definition: transam.h:41
bool IsTransactionOrTransactionBlock(void)
Definition: xact.c:4976
bool bsysscan
Definition: xact.c:98
TransactionId CheckXidAlive
Definition: xact.c:97
bool IsTransactionState(void)
Definition: xact.c:385
TransactionId GetTopTransactionIdIfAny(void)
Definition: xact.c:439
bool RecoveryInProgress(void)
Definition: xlog.c:6304
int wal_level
Definition: xlog.c:129
int wal_segment_size
Definition: xlog.c:141
WalLevel GetActiveWalLevelOnStandby(void)
Definition: xlog.c:4829
@ WAL_LEVEL_LOGICAL
Definition: xlog.h:76
#define LSN_FORMAT_ARGS(lsn)
Definition: xlogdefs.h:43
#define XLogRecPtrIsInvalid(r)
Definition: xlogdefs.h:29
uint16 RepOriginId
Definition: xlogdefs.h:65
uint64 XLogRecPtr
Definition: xlogdefs.h:21
#define InvalidXLogRecPtr
Definition: xlogdefs.h:28
XLogRecord * XLogReadRecord(XLogReaderState *state, char **errormsg)
Definition: xlogreader.c:389
void XLogReaderFree(XLogReaderState *state)
Definition: xlogreader.c:161
XLogReaderState * XLogReaderAllocate(int wal_segment_size, const char *waldir, XLogReaderRoutine *routine, void *private_data)
Definition: xlogreader.c:106
void XLogBeginRead(XLogReaderState *state, XLogRecPtr RecPtr)
Definition: xlogreader.c:231
#define XL_ROUTINE(...)
Definition: xlogreader.h:117
void wal_segment_close(XLogReaderState *state)
Definition: xlogutils.c:842
void wal_segment_open(XLogReaderState *state, XLogSegNo nextSegNo, TimeLineID *tli_p)
Definition: xlogutils.c:817
int read_local_xlog_page(XLogReaderState *state, XLogRecPtr targetPagePtr, int reqLen, XLogRecPtr targetRecPtr, char *cur_page)
Definition: xlogutils.c:861