PostgreSQL Source Code  git master
copyfrom.c
Go to the documentation of this file.
1 /*-------------------------------------------------------------------------
2  *
3  * copyfrom.c
4  * COPY <table> FROM file/program/client
5  *
6  * This file contains routines needed to efficiently load tuples into a
7  * table. That includes looking up the correct partition, firing triggers,
8  * calling the table AM function to insert the data, and updating indexes.
9  * Reading data from the input file or client and parsing it into Datums
10  * is handled in copyfromparse.c.
11  *
12  * Portions Copyright (c) 1996-2023, PostgreSQL Global Development Group
13  * Portions Copyright (c) 1994, Regents of the University of California
14  *
15  *
16  * IDENTIFICATION
17  * src/backend/commands/copyfrom.c
18  *
19  *-------------------------------------------------------------------------
20  */
21 #include "postgres.h"
22 
23 #include <ctype.h>
24 #include <unistd.h>
25 #include <sys/stat.h>
26 
27 #include "access/heapam.h"
28 #include "access/htup_details.h"
29 #include "access/tableam.h"
30 #include "access/xact.h"
31 #include "access/xlog.h"
32 #include "catalog/namespace.h"
33 #include "commands/copy.h"
35 #include "commands/progress.h"
36 #include "commands/trigger.h"
37 #include "executor/execPartition.h"
38 #include "executor/executor.h"
40 #include "executor/tuptable.h"
41 #include "foreign/fdwapi.h"
42 #include "libpq/libpq.h"
43 #include "libpq/pqformat.h"
44 #include "miscadmin.h"
45 #include "optimizer/optimizer.h"
46 #include "pgstat.h"
47 #include "rewrite/rewriteHandler.h"
48 #include "storage/fd.h"
49 #include "tcop/tcopprot.h"
50 #include "utils/lsyscache.h"
51 #include "utils/memutils.h"
52 #include "utils/portal.h"
53 #include "utils/rel.h"
54 #include "utils/snapmgr.h"
55 
56 /*
57  * No more than this many tuples per CopyMultiInsertBuffer
58  *
59  * Caution: Don't make this too big, as we could end up with this many
60  * CopyMultiInsertBuffer items stored in CopyMultiInsertInfo's
61  * multiInsertBuffers list. Increasing this can cause quadratic growth in
62  * memory requirements during copies into partitioned tables with a large
63  * number of partitions.
64  */
65 #define MAX_BUFFERED_TUPLES 1000
66 
67 /*
68  * Flush buffers if there are >= this many bytes, as counted by the input
69  * size, of tuples stored.
70  */
71 #define MAX_BUFFERED_BYTES 65535
72 
73 /* Trim the list of buffers back down to this number after flushing */
74 #define MAX_PARTITION_BUFFERS 32
75 
76 /* Stores multi-insert data related to a single relation in CopyFrom. */
77 typedef struct CopyMultiInsertBuffer
78 {
79  TupleTableSlot *slots[MAX_BUFFERED_TUPLES]; /* Array to store tuples */
80  ResultRelInfo *resultRelInfo; /* ResultRelInfo for 'relid' */
81  BulkInsertState bistate; /* BulkInsertState for this rel if plain
82  * table; NULL if foreign table */
83  int nused; /* number of 'slots' containing tuples */
84  uint64 linenos[MAX_BUFFERED_TUPLES]; /* Line # of tuple in copy
85  * stream */
87 
88 /*
89  * Stores one or many CopyMultiInsertBuffers and details about the size and
90  * number of tuples which are stored in them. This allows multiple buffers to
91  * exist at once when COPYing into a partitioned table.
92  */
93 typedef struct CopyMultiInsertInfo
94 {
95  List *multiInsertBuffers; /* List of tracked CopyMultiInsertBuffers */
96  int bufferedTuples; /* number of tuples buffered over all buffers */
97  int bufferedBytes; /* number of bytes from all buffered tuples */
98  CopyFromState cstate; /* Copy state for this CopyMultiInsertInfo */
99  EState *estate; /* Executor state used for COPY */
100  CommandId mycid; /* Command Id used for COPY */
101  int ti_options; /* table insert options */
103 
104 
105 /* non-export function prototypes */
106 static char *limit_printout_length(const char *str);
107 
108 static void ClosePipeFromProgram(CopyFromState cstate);
109 
110 /*
111  * error context callback for COPY FROM
112  *
113  * The argument for the error context must be CopyFromState.
114  */
115 void
117 {
118  CopyFromState cstate = (CopyFromState) arg;
119 
120  if (cstate->relname_only)
121  {
122  errcontext("COPY %s",
123  cstate->cur_relname);
124  return;
125  }
126  if (cstate->opts.binary)
127  {
128  /* can't usefully display the data */
129  if (cstate->cur_attname)
130  errcontext("COPY %s, line %llu, column %s",
131  cstate->cur_relname,
132  (unsigned long long) cstate->cur_lineno,
133  cstate->cur_attname);
134  else
135  errcontext("COPY %s, line %llu",
136  cstate->cur_relname,
137  (unsigned long long) cstate->cur_lineno);
138  }
139  else
140  {
141  if (cstate->cur_attname && cstate->cur_attval)
142  {
143  /* error is relevant to a particular column */
144  char *attval;
145 
146  attval = limit_printout_length(cstate->cur_attval);
147  errcontext("COPY %s, line %llu, column %s: \"%s\"",
148  cstate->cur_relname,
149  (unsigned long long) cstate->cur_lineno,
150  cstate->cur_attname,
151  attval);
152  pfree(attval);
153  }
154  else if (cstate->cur_attname)
155  {
156  /* error is relevant to a particular column, value is NULL */
157  errcontext("COPY %s, line %llu, column %s: null input",
158  cstate->cur_relname,
159  (unsigned long long) cstate->cur_lineno,
160  cstate->cur_attname);
161  }
162  else
163  {
164  /*
165  * Error is relevant to a particular line.
166  *
167  * If line_buf still contains the correct line, print it.
168  */
169  if (cstate->line_buf_valid)
170  {
171  char *lineval;
172 
173  lineval = limit_printout_length(cstate->line_buf.data);
174  errcontext("COPY %s, line %llu: \"%s\"",
175  cstate->cur_relname,
176  (unsigned long long) cstate->cur_lineno, lineval);
177  pfree(lineval);
178  }
179  else
180  {
181  errcontext("COPY %s, line %llu",
182  cstate->cur_relname,
183  (unsigned long long) cstate->cur_lineno);
184  }
185  }
186  }
187 }
188 
189 /*
190  * Make sure we don't print an unreasonable amount of COPY data in a message.
191  *
192  * Returns a pstrdup'd copy of the input.
193  */
194 static char *
196 {
197 #define MAX_COPY_DATA_DISPLAY 100
198 
199  int slen = strlen(str);
200  int len;
201  char *res;
202 
203  /* Fast path if definitely okay */
204  if (slen <= MAX_COPY_DATA_DISPLAY)
205  return pstrdup(str);
206 
207  /* Apply encoding-dependent truncation */
209 
210  /*
211  * Truncate, and add "..." to show we truncated the input.
212  */
213  res = (char *) palloc(len + 4);
214  memcpy(res, str, len);
215  strcpy(res + len, "...");
216 
217  return res;
218 }
219 
220 /*
221  * Allocate memory and initialize a new CopyMultiInsertBuffer for this
222  * ResultRelInfo.
223  */
224 static CopyMultiInsertBuffer *
226 {
227  CopyMultiInsertBuffer *buffer;
228 
229  buffer = (CopyMultiInsertBuffer *) palloc(sizeof(CopyMultiInsertBuffer));
230  memset(buffer->slots, 0, sizeof(TupleTableSlot *) * MAX_BUFFERED_TUPLES);
231  buffer->resultRelInfo = rri;
232  buffer->bistate = (rri->ri_FdwRoutine == NULL) ? GetBulkInsertState() : NULL;
233  buffer->nused = 0;
234 
235  return buffer;
236 }
237 
238 /*
239  * Make a new buffer for this ResultRelInfo.
240  */
241 static inline void
243  ResultRelInfo *rri)
244 {
245  CopyMultiInsertBuffer *buffer;
246 
247  buffer = CopyMultiInsertBufferInit(rri);
248 
249  /* Setup back-link so we can easily find this buffer again */
250  rri->ri_CopyMultiInsertBuffer = buffer;
251  /* Record that we're tracking this buffer */
252  miinfo->multiInsertBuffers = lappend(miinfo->multiInsertBuffers, buffer);
253 }
254 
255 /*
256  * Initialize an already allocated CopyMultiInsertInfo.
257  *
258  * If rri is a non-partitioned table then a CopyMultiInsertBuffer is set up
259  * for that table.
260  */
261 static void
263  CopyFromState cstate, EState *estate, CommandId mycid,
264  int ti_options)
265 {
266  miinfo->multiInsertBuffers = NIL;
267  miinfo->bufferedTuples = 0;
268  miinfo->bufferedBytes = 0;
269  miinfo->cstate = cstate;
270  miinfo->estate = estate;
271  miinfo->mycid = mycid;
272  miinfo->ti_options = ti_options;
273 
274  /*
275  * Only setup the buffer when not dealing with a partitioned table.
276  * Buffers for partitioned tables will just be setup when we need to send
277  * tuples their way for the first time.
278  */
279  if (rri->ri_RelationDesc->rd_rel->relkind != RELKIND_PARTITIONED_TABLE)
280  CopyMultiInsertInfoSetupBuffer(miinfo, rri);
281 }
282 
283 /*
284  * Returns true if the buffers are full
285  */
286 static inline bool
288 {
289  if (miinfo->bufferedTuples >= MAX_BUFFERED_TUPLES ||
291  return true;
292  return false;
293 }
294 
295 /*
296  * Returns true if we have no buffered tuples
297  */
298 static inline bool
300 {
301  return miinfo->bufferedTuples == 0;
302 }
303 
304 /*
305  * Write the tuples stored in 'buffer' out to the table.
306  */
307 static inline void
309  CopyMultiInsertBuffer *buffer,
310  int64 *processed)
311 {
312  CopyFromState cstate = miinfo->cstate;
313  EState *estate = miinfo->estate;
314  int nused = buffer->nused;
315  ResultRelInfo *resultRelInfo = buffer->resultRelInfo;
316  TupleTableSlot **slots = buffer->slots;
317  int i;
318 
319  if (resultRelInfo->ri_FdwRoutine)
320  {
321  int batch_size = resultRelInfo->ri_BatchSize;
322  int sent = 0;
323 
324  Assert(buffer->bistate == NULL);
325 
326  /* Ensure that the FDW supports batching and it's enabled */
328  Assert(batch_size > 1);
329 
330  /*
331  * We suppress error context information other than the relation name,
332  * if one of the operations below fails.
333  */
334  Assert(!cstate->relname_only);
335  cstate->relname_only = true;
336 
337  while (sent < nused)
338  {
339  int size = (batch_size < nused - sent) ? batch_size : (nused - sent);
340  int inserted = size;
341  TupleTableSlot **rslots;
342 
343  /* insert into foreign table: let the FDW do it */
344  rslots =
345  resultRelInfo->ri_FdwRoutine->ExecForeignBatchInsert(estate,
346  resultRelInfo,
347  &slots[sent],
348  NULL,
349  &inserted);
350 
351  sent += size;
352 
353  /* No need to do anything if there are no inserted rows */
354  if (inserted <= 0)
355  continue;
356 
357  /* Triggers on foreign tables should not have transition tables */
358  Assert(resultRelInfo->ri_TrigDesc == NULL ||
359  resultRelInfo->ri_TrigDesc->trig_insert_new_table == false);
360 
361  /* Run AFTER ROW INSERT triggers */
362  if (resultRelInfo->ri_TrigDesc != NULL &&
363  resultRelInfo->ri_TrigDesc->trig_insert_after_row)
364  {
365  Oid relid = RelationGetRelid(resultRelInfo->ri_RelationDesc);
366 
367  for (i = 0; i < inserted; i++)
368  {
369  TupleTableSlot *slot = rslots[i];
370 
371  /*
372  * AFTER ROW Triggers might reference the tableoid column,
373  * so (re-)initialize tts_tableOid before evaluating them.
374  */
375  slot->tts_tableOid = relid;
376 
377  ExecARInsertTriggers(estate, resultRelInfo,
378  slot, NIL,
379  cstate->transition_capture);
380  }
381  }
382 
383  /* Update the row counter and progress of the COPY command */
384  *processed += inserted;
386  *processed);
387  }
388 
389  for (i = 0; i < nused; i++)
390  ExecClearTuple(slots[i]);
391 
392  /* reset relname_only */
393  cstate->relname_only = false;
394  }
395  else
396  {
397  CommandId mycid = miinfo->mycid;
398  int ti_options = miinfo->ti_options;
399  bool line_buf_valid = cstate->line_buf_valid;
400  uint64 save_cur_lineno = cstate->cur_lineno;
401  MemoryContext oldcontext;
402 
403  Assert(buffer->bistate != NULL);
404 
405  /*
406  * Print error context information correctly, if one of the operations
407  * below fails.
408  */
409  cstate->line_buf_valid = false;
410 
411  /*
412  * table_multi_insert may leak memory, so switch to short-lived memory
413  * context before calling it.
414  */
415  oldcontext = MemoryContextSwitchTo(GetPerTupleMemoryContext(estate));
416  table_multi_insert(resultRelInfo->ri_RelationDesc,
417  slots,
418  nused,
419  mycid,
420  ti_options,
421  buffer->bistate);
422  MemoryContextSwitchTo(oldcontext);
423 
424  for (i = 0; i < nused; i++)
425  {
426  /*
427  * If there are any indexes, update them for all the inserted
428  * tuples, and run AFTER ROW INSERT triggers.
429  */
430  if (resultRelInfo->ri_NumIndices > 0)
431  {
432  List *recheckIndexes;
433 
434  cstate->cur_lineno = buffer->linenos[i];
435  recheckIndexes =
436  ExecInsertIndexTuples(resultRelInfo,
437  buffer->slots[i], estate, false,
438  false, NULL, NIL, false);
439  ExecARInsertTriggers(estate, resultRelInfo,
440  slots[i], recheckIndexes,
441  cstate->transition_capture);
442  list_free(recheckIndexes);
443  }
444 
445  /*
446  * There's no indexes, but see if we need to run AFTER ROW INSERT
447  * triggers anyway.
448  */
449  else if (resultRelInfo->ri_TrigDesc != NULL &&
450  (resultRelInfo->ri_TrigDesc->trig_insert_after_row ||
451  resultRelInfo->ri_TrigDesc->trig_insert_new_table))
452  {
453  cstate->cur_lineno = buffer->linenos[i];
454  ExecARInsertTriggers(estate, resultRelInfo,
455  slots[i], NIL,
456  cstate->transition_capture);
457  }
458 
459  ExecClearTuple(slots[i]);
460  }
461 
462  /* Update the row counter and progress of the COPY command */
463  *processed += nused;
465  *processed);
466 
467  /* reset cur_lineno and line_buf_valid to what they were */
468  cstate->line_buf_valid = line_buf_valid;
469  cstate->cur_lineno = save_cur_lineno;
470  }
471 
472  /* Mark that all slots are free */
473  buffer->nused = 0;
474 }
475 
476 /*
477  * Drop used slots and free member for this buffer.
478  *
479  * The buffer must be flushed before cleanup.
480  */
481 static inline void
483  CopyMultiInsertBuffer *buffer)
484 {
485  ResultRelInfo *resultRelInfo = buffer->resultRelInfo;
486  int i;
487 
488  /* Ensure buffer was flushed */
489  Assert(buffer->nused == 0);
490 
491  /* Remove back-link to ourself */
492  resultRelInfo->ri_CopyMultiInsertBuffer = NULL;
493 
494  if (resultRelInfo->ri_FdwRoutine == NULL)
495  {
496  Assert(buffer->bistate != NULL);
497  FreeBulkInsertState(buffer->bistate);
498  }
499  else
500  Assert(buffer->bistate == NULL);
501 
502  /* Since we only create slots on demand, just drop the non-null ones. */
503  for (i = 0; i < MAX_BUFFERED_TUPLES && buffer->slots[i] != NULL; i++)
505 
506  if (resultRelInfo->ri_FdwRoutine == NULL)
508  miinfo->ti_options);
509 
510  pfree(buffer);
511 }
512 
513 /*
514  * Write out all stored tuples in all buffers out to the tables.
515  *
516  * Once flushed we also trim the tracked buffers list down to size by removing
517  * the buffers created earliest first.
518  *
519  * Callers should pass 'curr_rri' as the ResultRelInfo that's currently being
520  * used. When cleaning up old buffers we'll never remove the one for
521  * 'curr_rri'.
522  */
523 static inline void
525  int64 *processed)
526 {
527  ListCell *lc;
528 
529  foreach(lc, miinfo->multiInsertBuffers)
530  {
532 
533  CopyMultiInsertBufferFlush(miinfo, buffer, processed);
534  }
535 
536  miinfo->bufferedTuples = 0;
537  miinfo->bufferedBytes = 0;
538 
539  /*
540  * Trim the list of tracked buffers down if it exceeds the limit. Here we
541  * remove buffers starting with the ones we created first. It seems less
542  * likely that these older ones will be needed than the ones that were
543  * just created.
544  */
546  {
547  CopyMultiInsertBuffer *buffer;
548 
549  buffer = (CopyMultiInsertBuffer *) linitial(miinfo->multiInsertBuffers);
550 
551  /*
552  * We never want to remove the buffer that's currently being used, so
553  * if we happen to find that then move it to the end of the list.
554  */
555  if (buffer->resultRelInfo == curr_rri)
556  {
558  miinfo->multiInsertBuffers = lappend(miinfo->multiInsertBuffers, buffer);
559  buffer = (CopyMultiInsertBuffer *) linitial(miinfo->multiInsertBuffers);
560  }
561 
562  CopyMultiInsertBufferCleanup(miinfo, buffer);
564  }
565 }
566 
567 /*
568  * Cleanup allocated buffers and free memory
569  */
570 static inline void
572 {
573  ListCell *lc;
574 
575  foreach(lc, miinfo->multiInsertBuffers)
577 
578  list_free(miinfo->multiInsertBuffers);
579 }
580 
581 /*
582  * Get the next TupleTableSlot that the next tuple should be stored in.
583  *
584  * Callers must ensure that the buffer is not full.
585  *
586  * Note: 'miinfo' is unused but has been included for consistency with the
587  * other functions in this area.
588  */
589 static inline TupleTableSlot *
591  ResultRelInfo *rri)
592 {
594  int nused = buffer->nused;
595 
596  Assert(buffer != NULL);
597  Assert(nused < MAX_BUFFERED_TUPLES);
598 
599  if (buffer->slots[nused] == NULL)
600  buffer->slots[nused] = table_slot_create(rri->ri_RelationDesc, NULL);
601  return buffer->slots[nused];
602 }
603 
604 /*
605  * Record the previously reserved TupleTableSlot that was reserved by
606  * CopyMultiInsertInfoNextFreeSlot as being consumed.
607  */
608 static inline void
610  TupleTableSlot *slot, int tuplen, uint64 lineno)
611 {
613 
614  Assert(buffer != NULL);
615  Assert(slot == buffer->slots[buffer->nused]);
616 
617  /* Store the line number so we can properly report any errors later */
618  buffer->linenos[buffer->nused] = lineno;
619 
620  /* Record this slot as being used */
621  buffer->nused++;
622 
623  /* Update how many tuples are stored and their size */
624  miinfo->bufferedTuples++;
625  miinfo->bufferedBytes += tuplen;
626 }
627 
628 /*
629  * Copy FROM file to relation.
630  */
631 uint64
633 {
634  ResultRelInfo *resultRelInfo;
635  ResultRelInfo *target_resultRelInfo;
636  ResultRelInfo *prevResultRelInfo = NULL;
637  EState *estate = CreateExecutorState(); /* for ExecConstraints() */
638  ModifyTableState *mtstate;
639  ExprContext *econtext;
640  TupleTableSlot *singleslot = NULL;
641  MemoryContext oldcontext = CurrentMemoryContext;
642 
643  PartitionTupleRouting *proute = NULL;
644  ErrorContextCallback errcallback;
645  CommandId mycid = GetCurrentCommandId(true);
646  int ti_options = 0; /* start with default options for insert */
647  BulkInsertState bistate = NULL;
648  CopyInsertMethod insertMethod;
649  CopyMultiInsertInfo multiInsertInfo = {0}; /* pacify compiler */
650  int64 processed = 0;
651  int64 excluded = 0;
652  bool has_before_insert_row_trig;
653  bool has_instead_insert_row_trig;
654  bool leafpart_use_multi_insert = false;
655 
656  Assert(cstate->rel);
657  Assert(list_length(cstate->range_table) == 1);
658 
659  /*
660  * The target must be a plain, foreign, or partitioned relation, or have
661  * an INSTEAD OF INSERT row trigger. (Currently, such triggers are only
662  * allowed on views, so we only hint about them in the view case.)
663  */
664  if (cstate->rel->rd_rel->relkind != RELKIND_RELATION &&
665  cstate->rel->rd_rel->relkind != RELKIND_FOREIGN_TABLE &&
666  cstate->rel->rd_rel->relkind != RELKIND_PARTITIONED_TABLE &&
667  !(cstate->rel->trigdesc &&
669  {
670  if (cstate->rel->rd_rel->relkind == RELKIND_VIEW)
671  ereport(ERROR,
672  (errcode(ERRCODE_WRONG_OBJECT_TYPE),
673  errmsg("cannot copy to view \"%s\"",
674  RelationGetRelationName(cstate->rel)),
675  errhint("To enable copying to a view, provide an INSTEAD OF INSERT trigger.")));
676  else if (cstate->rel->rd_rel->relkind == RELKIND_MATVIEW)
677  ereport(ERROR,
678  (errcode(ERRCODE_WRONG_OBJECT_TYPE),
679  errmsg("cannot copy to materialized view \"%s\"",
680  RelationGetRelationName(cstate->rel))));
681  else if (cstate->rel->rd_rel->relkind == RELKIND_SEQUENCE)
682  ereport(ERROR,
683  (errcode(ERRCODE_WRONG_OBJECT_TYPE),
684  errmsg("cannot copy to sequence \"%s\"",
685  RelationGetRelationName(cstate->rel))));
686  else
687  ereport(ERROR,
688  (errcode(ERRCODE_WRONG_OBJECT_TYPE),
689  errmsg("cannot copy to non-table relation \"%s\"",
690  RelationGetRelationName(cstate->rel))));
691  }
692 
693  /*
694  * If the target file is new-in-transaction, we assume that checking FSM
695  * for free space is a waste of time. This could possibly be wrong, but
696  * it's unlikely.
697  */
698  if (RELKIND_HAS_STORAGE(cstate->rel->rd_rel->relkind) &&
701  ti_options |= TABLE_INSERT_SKIP_FSM;
702 
703  /*
704  * Optimize if new relation storage was created in this subxact or one of
705  * its committed children and we won't see those rows later as part of an
706  * earlier scan or command. The subxact test ensures that if this subxact
707  * aborts then the frozen rows won't be visible after xact cleanup. Note
708  * that the stronger test of exactly which subtransaction created it is
709  * crucial for correctness of this optimization. The test for an earlier
710  * scan or command tolerates false negatives. FREEZE causes other sessions
711  * to see rows they would not see under MVCC, and a false negative merely
712  * spreads that anomaly to the current session.
713  */
714  if (cstate->opts.freeze)
715  {
716  /*
717  * We currently disallow COPY FREEZE on partitioned tables. The
718  * reason for this is that we've simply not yet opened the partitions
719  * to determine if the optimization can be applied to them. We could
720  * go and open them all here, but doing so may be quite a costly
721  * overhead for small copies. In any case, we may just end up routing
722  * tuples to a small number of partitions. It seems better just to
723  * raise an ERROR for partitioned tables.
724  */
725  if (cstate->rel->rd_rel->relkind == RELKIND_PARTITIONED_TABLE)
726  {
727  ereport(ERROR,
728  (errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
729  errmsg("cannot perform COPY FREEZE on a partitioned table")));
730  }
731 
732  /*
733  * Tolerate one registration for the benefit of FirstXactSnapshot.
734  * Scan-bearing queries generally create at least two registrations,
735  * though relying on that is fragile, as is ignoring ActiveSnapshot.
736  * Clear CatalogSnapshot to avoid counting its registration. We'll
737  * still detect ongoing catalog scans, each of which separately
738  * registers the snapshot it uses.
739  */
742  ereport(ERROR,
743  (errcode(ERRCODE_INVALID_TRANSACTION_STATE),
744  errmsg("cannot perform COPY FREEZE because of prior transaction activity")));
745 
746  if (cstate->rel->rd_createSubid != GetCurrentSubTransactionId() &&
748  ereport(ERROR,
749  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
750  errmsg("cannot perform COPY FREEZE because the table was not created or truncated in the current subtransaction")));
751 
752  ti_options |= TABLE_INSERT_FROZEN;
753  }
754 
755  /*
756  * We need a ResultRelInfo so we can use the regular executor's
757  * index-entry-making machinery. (There used to be a huge amount of code
758  * here that basically duplicated execUtils.c ...)
759  */
760  ExecInitRangeTable(estate, cstate->range_table, cstate->rteperminfos);
761  resultRelInfo = target_resultRelInfo = makeNode(ResultRelInfo);
762  ExecInitResultRelation(estate, resultRelInfo, 1);
763 
764  /* Verify the named relation is a valid target for INSERT */
765  CheckValidResultRel(resultRelInfo, CMD_INSERT);
766 
767  ExecOpenIndices(resultRelInfo, false);
768 
769  /*
770  * Set up a ModifyTableState so we can let FDW(s) init themselves for
771  * foreign-table result relation(s).
772  */
773  mtstate = makeNode(ModifyTableState);
774  mtstate->ps.plan = NULL;
775  mtstate->ps.state = estate;
776  mtstate->operation = CMD_INSERT;
777  mtstate->mt_nrels = 1;
778  mtstate->resultRelInfo = resultRelInfo;
779  mtstate->rootResultRelInfo = resultRelInfo;
780 
781  if (resultRelInfo->ri_FdwRoutine != NULL &&
782  resultRelInfo->ri_FdwRoutine->BeginForeignInsert != NULL)
783  resultRelInfo->ri_FdwRoutine->BeginForeignInsert(mtstate,
784  resultRelInfo);
785 
786  /*
787  * Also, if the named relation is a foreign table, determine if the FDW
788  * supports batch insert and determine the batch size (a FDW may support
789  * batching, but it may be disabled for the server/table).
790  *
791  * If the FDW does not support batching, we set the batch size to 1.
792  */
793  if (resultRelInfo->ri_FdwRoutine != NULL &&
794  resultRelInfo->ri_FdwRoutine->GetForeignModifyBatchSize &&
795  resultRelInfo->ri_FdwRoutine->ExecForeignBatchInsert)
796  resultRelInfo->ri_BatchSize =
797  resultRelInfo->ri_FdwRoutine->GetForeignModifyBatchSize(resultRelInfo);
798  else
799  resultRelInfo->ri_BatchSize = 1;
800 
801  Assert(resultRelInfo->ri_BatchSize >= 1);
802 
803  /* Prepare to catch AFTER triggers. */
805 
806  /*
807  * If there are any triggers with transition tables on the named relation,
808  * we need to be prepared to capture transition tuples.
809  *
810  * Because partition tuple routing would like to know about whether
811  * transition capture is active, we also set it in mtstate, which is
812  * passed to ExecFindPartition() below.
813  */
814  cstate->transition_capture = mtstate->mt_transition_capture =
816  RelationGetRelid(cstate->rel),
817  CMD_INSERT);
818 
819  /*
820  * If the named relation is a partitioned table, initialize state for
821  * CopyFrom tuple routing.
822  */
823  if (cstate->rel->rd_rel->relkind == RELKIND_PARTITIONED_TABLE)
824  proute = ExecSetupPartitionTupleRouting(estate, cstate->rel);
825 
826  if (cstate->whereClause)
827  cstate->qualexpr = ExecInitQual(castNode(List, cstate->whereClause),
828  &mtstate->ps);
829 
830  /*
831  * It's generally more efficient to prepare a bunch of tuples for
832  * insertion, and insert them in one
833  * table_multi_insert()/ExecForeignBatchInsert() call, than call
834  * table_tuple_insert()/ExecForeignInsert() separately for every tuple.
835  * However, there are a number of reasons why we might not be able to do
836  * this. These are explained below.
837  */
838  if (resultRelInfo->ri_TrigDesc != NULL &&
839  (resultRelInfo->ri_TrigDesc->trig_insert_before_row ||
840  resultRelInfo->ri_TrigDesc->trig_insert_instead_row))
841  {
842  /*
843  * Can't support multi-inserts when there are any BEFORE/INSTEAD OF
844  * triggers on the table. Such triggers might query the table we're
845  * inserting into and act differently if the tuples that have already
846  * been processed and prepared for insertion are not there.
847  */
848  insertMethod = CIM_SINGLE;
849  }
850  else if (resultRelInfo->ri_FdwRoutine != NULL &&
851  resultRelInfo->ri_BatchSize == 1)
852  {
853  /*
854  * Can't support multi-inserts to a foreign table if the FDW does not
855  * support batching, or it's disabled for the server or foreign table.
856  */
857  insertMethod = CIM_SINGLE;
858  }
859  else if (proute != NULL && resultRelInfo->ri_TrigDesc != NULL &&
860  resultRelInfo->ri_TrigDesc->trig_insert_new_table)
861  {
862  /*
863  * For partitioned tables we can't support multi-inserts when there
864  * are any statement level insert triggers. It might be possible to
865  * allow partitioned tables with such triggers in the future, but for
866  * now, CopyMultiInsertInfoFlush expects that any after row insert and
867  * statement level insert triggers are on the same relation.
868  */
869  insertMethod = CIM_SINGLE;
870  }
871  else if (cstate->volatile_defexprs)
872  {
873  /*
874  * Can't support multi-inserts if there are any volatile default
875  * expressions in the table. Similarly to the trigger case above,
876  * such expressions may query the table we're inserting into.
877  *
878  * Note: It does not matter if any partitions have any volatile
879  * default expressions as we use the defaults from the target of the
880  * COPY command.
881  */
882  insertMethod = CIM_SINGLE;
883  }
884  else if (contain_volatile_functions(cstate->whereClause))
885  {
886  /*
887  * Can't support multi-inserts if there are any volatile function
888  * expressions in WHERE clause. Similarly to the trigger case above,
889  * such expressions may query the table we're inserting into.
890  */
891  insertMethod = CIM_SINGLE;
892  }
893  else
894  {
895  /*
896  * For partitioned tables, we may still be able to perform bulk
897  * inserts. However, the possibility of this depends on which types
898  * of triggers exist on the partition. We must disable bulk inserts
899  * if the partition is a foreign table that can't use batching or it
900  * has any before row insert or insert instead triggers (same as we
901  * checked above for the parent table). Since the partition's
902  * resultRelInfos are initialized only when we actually need to insert
903  * the first tuple into them, we must have the intermediate insert
904  * method of CIM_MULTI_CONDITIONAL to flag that we must later
905  * determine if we can use bulk-inserts for the partition being
906  * inserted into.
907  */
908  if (proute)
909  insertMethod = CIM_MULTI_CONDITIONAL;
910  else
911  insertMethod = CIM_MULTI;
912 
913  CopyMultiInsertInfoInit(&multiInsertInfo, resultRelInfo, cstate,
914  estate, mycid, ti_options);
915  }
916 
917  /*
918  * If not using batch mode (which allocates slots as needed) set up a
919  * tuple slot too. When inserting into a partitioned table, we also need
920  * one, even if we might batch insert, to read the tuple in the root
921  * partition's form.
922  */
923  if (insertMethod == CIM_SINGLE || insertMethod == CIM_MULTI_CONDITIONAL)
924  {
925  singleslot = table_slot_create(resultRelInfo->ri_RelationDesc,
926  &estate->es_tupleTable);
927  bistate = GetBulkInsertState();
928  }
929 
930  has_before_insert_row_trig = (resultRelInfo->ri_TrigDesc &&
931  resultRelInfo->ri_TrigDesc->trig_insert_before_row);
932 
933  has_instead_insert_row_trig = (resultRelInfo->ri_TrigDesc &&
934  resultRelInfo->ri_TrigDesc->trig_insert_instead_row);
935 
936  /*
937  * Check BEFORE STATEMENT insertion triggers. It's debatable whether we
938  * should do this for COPY, since it's not really an "INSERT" statement as
939  * such. However, executing these triggers maintains consistency with the
940  * EACH ROW triggers that we already fire on COPY.
941  */
942  ExecBSInsertTriggers(estate, resultRelInfo);
943 
944  econtext = GetPerTupleExprContext(estate);
945 
946  /* Set up callback to identify error line number */
947  errcallback.callback = CopyFromErrorCallback;
948  errcallback.arg = (void *) cstate;
949  errcallback.previous = error_context_stack;
950  error_context_stack = &errcallback;
951 
952  for (;;)
953  {
954  TupleTableSlot *myslot;
955  bool skip_tuple;
956 
958 
959  /*
960  * Reset the per-tuple exprcontext. We do this after every tuple, to
961  * clean-up after expression evaluations etc.
962  */
963  ResetPerTupleExprContext(estate);
964 
965  /* select slot to (initially) load row into */
966  if (insertMethod == CIM_SINGLE || proute)
967  {
968  myslot = singleslot;
969  Assert(myslot != NULL);
970  }
971  else
972  {
973  Assert(resultRelInfo == target_resultRelInfo);
974  Assert(insertMethod == CIM_MULTI);
975 
976  myslot = CopyMultiInsertInfoNextFreeSlot(&multiInsertInfo,
977  resultRelInfo);
978  }
979 
980  /*
981  * Switch to per-tuple context before calling NextCopyFrom, which does
982  * evaluate default expressions etc. and requires per-tuple context.
983  */
985 
986  ExecClearTuple(myslot);
987 
988  /* Directly store the values/nulls array in the slot */
989  if (!NextCopyFrom(cstate, econtext, myslot->tts_values, myslot->tts_isnull))
990  break;
991 
992  ExecStoreVirtualTuple(myslot);
993 
994  /*
995  * Constraints and where clause might reference the tableoid column,
996  * so (re-)initialize tts_tableOid before evaluating them.
997  */
998  myslot->tts_tableOid = RelationGetRelid(target_resultRelInfo->ri_RelationDesc);
999 
1000  /* Triggers and stuff need to be invoked in query context. */
1001  MemoryContextSwitchTo(oldcontext);
1002 
1003  if (cstate->whereClause)
1004  {
1005  econtext->ecxt_scantuple = myslot;
1006  /* Skip items that don't match COPY's WHERE clause */
1007  if (!ExecQual(cstate->qualexpr, econtext))
1008  {
1009  /*
1010  * Report that this tuple was filtered out by the WHERE
1011  * clause.
1012  */
1014  ++excluded);
1015  continue;
1016  }
1017  }
1018 
1019  /* Determine the partition to insert the tuple into */
1020  if (proute)
1021  {
1022  TupleConversionMap *map;
1023 
1024  /*
1025  * Attempt to find a partition suitable for this tuple.
1026  * ExecFindPartition() will raise an error if none can be found or
1027  * if the found partition is not suitable for INSERTs.
1028  */
1029  resultRelInfo = ExecFindPartition(mtstate, target_resultRelInfo,
1030  proute, myslot, estate);
1031 
1032  if (prevResultRelInfo != resultRelInfo)
1033  {
1034  /* Determine which triggers exist on this partition */
1035  has_before_insert_row_trig = (resultRelInfo->ri_TrigDesc &&
1036  resultRelInfo->ri_TrigDesc->trig_insert_before_row);
1037 
1038  has_instead_insert_row_trig = (resultRelInfo->ri_TrigDesc &&
1039  resultRelInfo->ri_TrigDesc->trig_insert_instead_row);
1040 
1041  /*
1042  * Disable multi-inserts when the partition has BEFORE/INSTEAD
1043  * OF triggers, or if the partition is a foreign table that
1044  * can't use batching.
1045  */
1046  leafpart_use_multi_insert = insertMethod == CIM_MULTI_CONDITIONAL &&
1047  !has_before_insert_row_trig &&
1048  !has_instead_insert_row_trig &&
1049  (resultRelInfo->ri_FdwRoutine == NULL ||
1050  resultRelInfo->ri_BatchSize > 1);
1051 
1052  /* Set the multi-insert buffer to use for this partition. */
1053  if (leafpart_use_multi_insert)
1054  {
1055  if (resultRelInfo->ri_CopyMultiInsertBuffer == NULL)
1056  CopyMultiInsertInfoSetupBuffer(&multiInsertInfo,
1057  resultRelInfo);
1058  }
1059  else if (insertMethod == CIM_MULTI_CONDITIONAL &&
1060  !CopyMultiInsertInfoIsEmpty(&multiInsertInfo))
1061  {
1062  /*
1063  * Flush pending inserts if this partition can't use
1064  * batching, so rows are visible to triggers etc.
1065  */
1066  CopyMultiInsertInfoFlush(&multiInsertInfo,
1067  resultRelInfo,
1068  &processed);
1069  }
1070 
1071  if (bistate != NULL)
1072  ReleaseBulkInsertStatePin(bistate);
1073  prevResultRelInfo = resultRelInfo;
1074  }
1075 
1076  /*
1077  * If we're capturing transition tuples, we might need to convert
1078  * from the partition rowtype to root rowtype. But if there are no
1079  * BEFORE triggers on the partition that could change the tuple,
1080  * we can just remember the original unconverted tuple to avoid a
1081  * needless round trip conversion.
1082  */
1083  if (cstate->transition_capture != NULL)
1085  !has_before_insert_row_trig ? myslot : NULL;
1086 
1087  /*
1088  * We might need to convert from the root rowtype to the partition
1089  * rowtype.
1090  */
1091  map = ExecGetRootToChildMap(resultRelInfo, estate);
1092  if (insertMethod == CIM_SINGLE || !leafpart_use_multi_insert)
1093  {
1094  /* non batch insert */
1095  if (map != NULL)
1096  {
1097  TupleTableSlot *new_slot;
1098 
1099  new_slot = resultRelInfo->ri_PartitionTupleSlot;
1100  myslot = execute_attr_map_slot(map->attrMap, myslot, new_slot);
1101  }
1102  }
1103  else
1104  {
1105  /*
1106  * Prepare to queue up tuple for later batch insert into
1107  * current partition.
1108  */
1109  TupleTableSlot *batchslot;
1110 
1111  /* no other path available for partitioned table */
1112  Assert(insertMethod == CIM_MULTI_CONDITIONAL);
1113 
1114  batchslot = CopyMultiInsertInfoNextFreeSlot(&multiInsertInfo,
1115  resultRelInfo);
1116 
1117  if (map != NULL)
1118  myslot = execute_attr_map_slot(map->attrMap, myslot,
1119  batchslot);
1120  else
1121  {
1122  /*
1123  * This looks more expensive than it is (Believe me, I
1124  * optimized it away. Twice.). The input is in virtual
1125  * form, and we'll materialize the slot below - for most
1126  * slot types the copy performs the work materialization
1127  * would later require anyway.
1128  */
1129  ExecCopySlot(batchslot, myslot);
1130  myslot = batchslot;
1131  }
1132  }
1133 
1134  /* ensure that triggers etc see the right relation */
1135  myslot->tts_tableOid = RelationGetRelid(resultRelInfo->ri_RelationDesc);
1136  }
1137 
1138  skip_tuple = false;
1139 
1140  /* BEFORE ROW INSERT Triggers */
1141  if (has_before_insert_row_trig)
1142  {
1143  if (!ExecBRInsertTriggers(estate, resultRelInfo, myslot))
1144  skip_tuple = true; /* "do nothing" */
1145  }
1146 
1147  if (!skip_tuple)
1148  {
1149  /*
1150  * If there is an INSTEAD OF INSERT ROW trigger, let it handle the
1151  * tuple. Otherwise, proceed with inserting the tuple into the
1152  * table or foreign table.
1153  */
1154  if (has_instead_insert_row_trig)
1155  {
1156  ExecIRInsertTriggers(estate, resultRelInfo, myslot);
1157  }
1158  else
1159  {
1160  /* Compute stored generated columns */
1161  if (resultRelInfo->ri_RelationDesc->rd_att->constr &&
1163  ExecComputeStoredGenerated(resultRelInfo, estate, myslot,
1164  CMD_INSERT);
1165 
1166  /*
1167  * If the target is a plain table, check the constraints of
1168  * the tuple.
1169  */
1170  if (resultRelInfo->ri_FdwRoutine == NULL &&
1171  resultRelInfo->ri_RelationDesc->rd_att->constr)
1172  ExecConstraints(resultRelInfo, myslot, estate);
1173 
1174  /*
1175  * Also check the tuple against the partition constraint, if
1176  * there is one; except that if we got here via tuple-routing,
1177  * we don't need to if there's no BR trigger defined on the
1178  * partition.
1179  */
1180  if (resultRelInfo->ri_RelationDesc->rd_rel->relispartition &&
1181  (proute == NULL || has_before_insert_row_trig))
1182  ExecPartitionCheck(resultRelInfo, myslot, estate, true);
1183 
1184  /* Store the slot in the multi-insert buffer, when enabled. */
1185  if (insertMethod == CIM_MULTI || leafpart_use_multi_insert)
1186  {
1187  /*
1188  * The slot previously might point into the per-tuple
1189  * context. For batching it needs to be longer lived.
1190  */
1191  ExecMaterializeSlot(myslot);
1192 
1193  /* Add this tuple to the tuple buffer */
1194  CopyMultiInsertInfoStore(&multiInsertInfo,
1195  resultRelInfo, myslot,
1196  cstate->line_buf.len,
1197  cstate->cur_lineno);
1198 
1199  /*
1200  * If enough inserts have queued up, then flush all
1201  * buffers out to their tables.
1202  */
1203  if (CopyMultiInsertInfoIsFull(&multiInsertInfo))
1204  CopyMultiInsertInfoFlush(&multiInsertInfo,
1205  resultRelInfo,
1206  &processed);
1207 
1208  /*
1209  * We delay updating the row counter and progress of the
1210  * COPY command until after writing the tuples stored in
1211  * the buffer out to the table, as in single insert mode.
1212  * See CopyMultiInsertBufferFlush().
1213  */
1214  continue; /* next tuple please */
1215  }
1216  else
1217  {
1218  List *recheckIndexes = NIL;
1219 
1220  /* OK, store the tuple */
1221  if (resultRelInfo->ri_FdwRoutine != NULL)
1222  {
1223  myslot = resultRelInfo->ri_FdwRoutine->ExecForeignInsert(estate,
1224  resultRelInfo,
1225  myslot,
1226  NULL);
1227 
1228  if (myslot == NULL) /* "do nothing" */
1229  continue; /* next tuple please */
1230 
1231  /*
1232  * AFTER ROW Triggers might reference the tableoid
1233  * column, so (re-)initialize tts_tableOid before
1234  * evaluating them.
1235  */
1236  myslot->tts_tableOid = RelationGetRelid(resultRelInfo->ri_RelationDesc);
1237  }
1238  else
1239  {
1240  /* OK, store the tuple and create index entries for it */
1241  table_tuple_insert(resultRelInfo->ri_RelationDesc,
1242  myslot, mycid, ti_options, bistate);
1243 
1244  if (resultRelInfo->ri_NumIndices > 0)
1245  recheckIndexes = ExecInsertIndexTuples(resultRelInfo,
1246  myslot,
1247  estate,
1248  false,
1249  false,
1250  NULL,
1251  NIL,
1252  false);
1253  }
1254 
1255  /* AFTER ROW INSERT Triggers */
1256  ExecARInsertTriggers(estate, resultRelInfo, myslot,
1257  recheckIndexes, cstate->transition_capture);
1258 
1259  list_free(recheckIndexes);
1260  }
1261  }
1262 
1263  /*
1264  * We count only tuples not suppressed by a BEFORE INSERT trigger
1265  * or FDW; this is the same definition used by nodeModifyTable.c
1266  * for counting tuples inserted by an INSERT command. Update
1267  * progress of the COPY command as well.
1268  */
1270  ++processed);
1271  }
1272  }
1273 
1274  /* Flush any remaining buffered tuples */
1275  if (insertMethod != CIM_SINGLE)
1276  {
1277  if (!CopyMultiInsertInfoIsEmpty(&multiInsertInfo))
1278  CopyMultiInsertInfoFlush(&multiInsertInfo, NULL, &processed);
1279  }
1280 
1281  /* Done, clean up */
1282  error_context_stack = errcallback.previous;
1283 
1284  if (bistate != NULL)
1285  FreeBulkInsertState(bistate);
1286 
1287  MemoryContextSwitchTo(oldcontext);
1288 
1289  /* Execute AFTER STATEMENT insertion triggers */
1290  ExecASInsertTriggers(estate, target_resultRelInfo, cstate->transition_capture);
1291 
1292  /* Handle queued AFTER triggers */
1293  AfterTriggerEndQuery(estate);
1294 
1295  ExecResetTupleTable(estate->es_tupleTable, false);
1296 
1297  /* Allow the FDW to shut down */
1298  if (target_resultRelInfo->ri_FdwRoutine != NULL &&
1299  target_resultRelInfo->ri_FdwRoutine->EndForeignInsert != NULL)
1300  target_resultRelInfo->ri_FdwRoutine->EndForeignInsert(estate,
1301  target_resultRelInfo);
1302 
1303  /* Tear down the multi-insert buffer data */
1304  if (insertMethod != CIM_SINGLE)
1305  CopyMultiInsertInfoCleanup(&multiInsertInfo);
1306 
1307  /* Close all the partitioned tables, leaf partitions, and their indices */
1308  if (proute)
1309  ExecCleanupTupleRouting(mtstate, proute);
1310 
1311  /* Close the result relations, including any trigger target relations */
1312  ExecCloseResultRelations(estate);
1314 
1315  FreeExecutorState(estate);
1316 
1317  return processed;
1318 }
1319 
1320 /*
1321  * Setup to read tuples from a file for COPY FROM.
1322  *
1323  * 'rel': Used as a template for the tuples
1324  * 'whereClause': WHERE clause from the COPY FROM command
1325  * 'filename': Name of server-local file to read, NULL for STDIN
1326  * 'is_program': true if 'filename' is program to execute
1327  * 'data_source_cb': callback that provides the input data
1328  * 'attnamelist': List of char *, columns to include. NIL selects all cols.
1329  * 'options': List of DefElem. See copy_opt_item in gram.y for selections.
1330  *
1331  * Returns a CopyFromState, to be passed to NextCopyFrom and related functions.
1332  */
1335  Relation rel,
1336  Node *whereClause,
1337  const char *filename,
1338  bool is_program,
1339  copy_data_source_cb data_source_cb,
1340  List *attnamelist,
1341  List *options)
1342 {
1343  CopyFromState cstate;
1344  bool pipe = (filename == NULL);
1345  TupleDesc tupDesc;
1346  AttrNumber num_phys_attrs,
1347  num_defaults;
1348  FmgrInfo *in_functions;
1349  Oid *typioparams;
1350  Oid in_func_oid;
1351  int *defmap;
1352  ExprState **defexprs;
1353  MemoryContext oldcontext;
1354  bool volatile_defexprs;
1355  const int progress_cols[] = {
1359  };
1360  int64 progress_vals[] = {
1362  0,
1363  0
1364  };
1365 
1366  /* Allocate workspace and zero all fields */
1367  cstate = (CopyFromStateData *) palloc0(sizeof(CopyFromStateData));
1368 
1369  /*
1370  * We allocate everything used by a cstate in a new memory context. This
1371  * avoids memory leaks during repeated use of COPY in a query.
1372  */
1374  "COPY",
1376 
1377  oldcontext = MemoryContextSwitchTo(cstate->copycontext);
1378 
1379  /* Extract options from the statement node tree */
1380  ProcessCopyOptions(pstate, &cstate->opts, true /* is_from */ , options);
1381 
1382  /* Process the target relation */
1383  cstate->rel = rel;
1384 
1385  tupDesc = RelationGetDescr(cstate->rel);
1386 
1387  /* process common options or initialization */
1388 
1389  /* Generate or convert list of attributes to process */
1390  cstate->attnumlist = CopyGetAttnums(tupDesc, cstate->rel, attnamelist);
1391 
1392  num_phys_attrs = tupDesc->natts;
1393 
1394  /* Convert FORCE_NOT_NULL name list to per-column flags, check validity */
1395  cstate->opts.force_notnull_flags = (bool *) palloc0(num_phys_attrs * sizeof(bool));
1396  if (cstate->opts.force_notnull)
1397  {
1398  List *attnums;
1399  ListCell *cur;
1400 
1401  attnums = CopyGetAttnums(tupDesc, cstate->rel, cstate->opts.force_notnull);
1402 
1403  foreach(cur, attnums)
1404  {
1405  int attnum = lfirst_int(cur);
1406  Form_pg_attribute attr = TupleDescAttr(tupDesc, attnum - 1);
1407 
1408  if (!list_member_int(cstate->attnumlist, attnum))
1409  ereport(ERROR,
1410  (errcode(ERRCODE_INVALID_COLUMN_REFERENCE),
1411  errmsg("FORCE_NOT_NULL column \"%s\" not referenced by COPY",
1412  NameStr(attr->attname))));
1413  cstate->opts.force_notnull_flags[attnum - 1] = true;
1414  }
1415  }
1416 
1417  /* Convert FORCE_NULL name list to per-column flags, check validity */
1418  cstate->opts.force_null_flags = (bool *) palloc0(num_phys_attrs * sizeof(bool));
1419  if (cstate->opts.force_null)
1420  {
1421  List *attnums;
1422  ListCell *cur;
1423 
1424  attnums = CopyGetAttnums(tupDesc, cstate->rel, cstate->opts.force_null);
1425 
1426  foreach(cur, attnums)
1427  {
1428  int attnum = lfirst_int(cur);
1429  Form_pg_attribute attr = TupleDescAttr(tupDesc, attnum - 1);
1430 
1431  if (!list_member_int(cstate->attnumlist, attnum))
1432  ereport(ERROR,
1433  (errcode(ERRCODE_INVALID_COLUMN_REFERENCE),
1434  errmsg("FORCE_NULL column \"%s\" not referenced by COPY",
1435  NameStr(attr->attname))));
1436  cstate->opts.force_null_flags[attnum - 1] = true;
1437  }
1438  }
1439 
1440  /* Convert convert_selectively name list to per-column flags */
1441  if (cstate->opts.convert_selectively)
1442  {
1443  List *attnums;
1444  ListCell *cur;
1445 
1446  cstate->convert_select_flags = (bool *) palloc0(num_phys_attrs * sizeof(bool));
1447 
1448  attnums = CopyGetAttnums(tupDesc, cstate->rel, cstate->opts.convert_select);
1449 
1450  foreach(cur, attnums)
1451  {
1452  int attnum = lfirst_int(cur);
1453  Form_pg_attribute attr = TupleDescAttr(tupDesc, attnum - 1);
1454 
1455  if (!list_member_int(cstate->attnumlist, attnum))
1456  ereport(ERROR,
1457  (errcode(ERRCODE_INVALID_COLUMN_REFERENCE),
1458  errmsg_internal("selected column \"%s\" not referenced by COPY",
1459  NameStr(attr->attname))));
1460  cstate->convert_select_flags[attnum - 1] = true;
1461  }
1462  }
1463 
1464  /* Use client encoding when ENCODING option is not specified. */
1465  if (cstate->opts.file_encoding < 0)
1467  else
1468  cstate->file_encoding = cstate->opts.file_encoding;
1469 
1470  /*
1471  * Look up encoding conversion function.
1472  */
1473  if (cstate->file_encoding == GetDatabaseEncoding() ||
1474  cstate->file_encoding == PG_SQL_ASCII ||
1476  {
1477  cstate->need_transcoding = false;
1478  }
1479  else
1480  {
1481  cstate->need_transcoding = true;
1484  }
1485 
1486  cstate->copy_src = COPY_FILE; /* default */
1487 
1488  cstate->whereClause = whereClause;
1489 
1490  /* Initialize state variables */
1491  cstate->eol_type = EOL_UNKNOWN;
1492  cstate->cur_relname = RelationGetRelationName(cstate->rel);
1493  cstate->cur_lineno = 0;
1494  cstate->cur_attname = NULL;
1495  cstate->cur_attval = NULL;
1496  cstate->relname_only = false;
1497 
1498  /*
1499  * Allocate buffers for the input pipeline.
1500  *
1501  * attribute_buf and raw_buf are used in both text and binary modes, but
1502  * input_buf and line_buf only in text mode.
1503  */
1504  cstate->raw_buf = palloc(RAW_BUF_SIZE + 1);
1505  cstate->raw_buf_index = cstate->raw_buf_len = 0;
1506  cstate->raw_reached_eof = false;
1507 
1508  if (!cstate->opts.binary)
1509  {
1510  /*
1511  * If encoding conversion is needed, we need another buffer to hold
1512  * the converted input data. Otherwise, we can just point input_buf
1513  * to the same buffer as raw_buf.
1514  */
1515  if (cstate->need_transcoding)
1516  {
1517  cstate->input_buf = (char *) palloc(INPUT_BUF_SIZE + 1);
1518  cstate->input_buf_index = cstate->input_buf_len = 0;
1519  }
1520  else
1521  cstate->input_buf = cstate->raw_buf;
1522  cstate->input_reached_eof = false;
1523 
1524  initStringInfo(&cstate->line_buf);
1525  }
1526 
1527  initStringInfo(&cstate->attribute_buf);
1528 
1529  /* Assign range table and rteperminfos, we'll need them in CopyFrom. */
1530  if (pstate)
1531  {
1532  cstate->range_table = pstate->p_rtable;
1533  cstate->rteperminfos = pstate->p_rteperminfos;
1534  }
1535 
1536  tupDesc = RelationGetDescr(cstate->rel);
1537  num_phys_attrs = tupDesc->natts;
1538  num_defaults = 0;
1539  volatile_defexprs = false;
1540 
1541  /*
1542  * Pick up the required catalog information for each attribute in the
1543  * relation, including the input function, the element type (to pass to
1544  * the input function), and info about defaults and constraints. (Which
1545  * input function we use depends on text/binary format choice.)
1546  */
1547  in_functions = (FmgrInfo *) palloc(num_phys_attrs * sizeof(FmgrInfo));
1548  typioparams = (Oid *) palloc(num_phys_attrs * sizeof(Oid));
1549  defmap = (int *) palloc(num_phys_attrs * sizeof(int));
1550  defexprs = (ExprState **) palloc(num_phys_attrs * sizeof(ExprState *));
1551 
1552  for (int attnum = 1; attnum <= num_phys_attrs; attnum++)
1553  {
1554  Form_pg_attribute att = TupleDescAttr(tupDesc, attnum - 1);
1555 
1556  /* We don't need info for dropped attributes */
1557  if (att->attisdropped)
1558  continue;
1559 
1560  /* Fetch the input function and typioparam info */
1561  if (cstate->opts.binary)
1562  getTypeBinaryInputInfo(att->atttypid,
1563  &in_func_oid, &typioparams[attnum - 1]);
1564  else
1565  getTypeInputInfo(att->atttypid,
1566  &in_func_oid, &typioparams[attnum - 1]);
1567  fmgr_info(in_func_oid, &in_functions[attnum - 1]);
1568 
1569  /* Get default info if available */
1570  defexprs[attnum - 1] = NULL;
1571 
1572  if (!att->attgenerated)
1573  {
1574  Expr *defexpr = (Expr *) build_column_default(cstate->rel,
1575  attnum);
1576 
1577  if (defexpr != NULL)
1578  {
1579  /* Run the expression through planner */
1580  defexpr = expression_planner(defexpr);
1581 
1582  /* Initialize executable expression in copycontext */
1583  defexprs[attnum - 1] = ExecInitExpr(defexpr, NULL);
1584 
1585  /* if NOT copied from input */
1586  /* use default value if one exists */
1587  if (!list_member_int(cstate->attnumlist, attnum))
1588  {
1589  defmap[num_defaults] = attnum - 1;
1590  num_defaults++;
1591  }
1592 
1593  /*
1594  * If a default expression looks at the table being loaded,
1595  * then it could give the wrong answer when using
1596  * multi-insert. Since database access can be dynamic this is
1597  * hard to test for exactly, so we use the much wider test of
1598  * whether the default expression is volatile. We allow for
1599  * the special case of when the default expression is the
1600  * nextval() of a sequence which in this specific case is
1601  * known to be safe for use with the multi-insert
1602  * optimization. Hence we use this special case function
1603  * checker rather than the standard check for
1604  * contain_volatile_functions().
1605  */
1606  if (!volatile_defexprs)
1607  volatile_defexprs = contain_volatile_functions_not_nextval((Node *) defexpr);
1608  }
1609  }
1610  }
1611 
1612 
1613  /* initialize progress */
1615  cstate->rel ? RelationGetRelid(cstate->rel) : InvalidOid);
1616  cstate->bytes_processed = 0;
1617 
1618  /* We keep those variables in cstate. */
1619  cstate->in_functions = in_functions;
1620  cstate->typioparams = typioparams;
1621  cstate->defmap = defmap;
1622  cstate->defexprs = defexprs;
1623  cstate->volatile_defexprs = volatile_defexprs;
1624  cstate->num_defaults = num_defaults;
1625  cstate->is_program = is_program;
1626 
1627  if (data_source_cb)
1628  {
1629  progress_vals[1] = PROGRESS_COPY_TYPE_CALLBACK;
1630  cstate->copy_src = COPY_CALLBACK;
1631  cstate->data_source_cb = data_source_cb;
1632  }
1633  else if (pipe)
1634  {
1635  progress_vals[1] = PROGRESS_COPY_TYPE_PIPE;
1636  Assert(!is_program); /* the grammar does not allow this */
1638  ReceiveCopyBegin(cstate);
1639  else
1640  cstate->copy_file = stdin;
1641  }
1642  else
1643  {
1644  cstate->filename = pstrdup(filename);
1645 
1646  if (cstate->is_program)
1647  {
1648  progress_vals[1] = PROGRESS_COPY_TYPE_PROGRAM;
1649  cstate->copy_file = OpenPipeStream(cstate->filename, PG_BINARY_R);
1650  if (cstate->copy_file == NULL)
1651  ereport(ERROR,
1653  errmsg("could not execute command \"%s\": %m",
1654  cstate->filename)));
1655  }
1656  else
1657  {
1658  struct stat st;
1659 
1660  progress_vals[1] = PROGRESS_COPY_TYPE_FILE;
1661  cstate->copy_file = AllocateFile(cstate->filename, PG_BINARY_R);
1662  if (cstate->copy_file == NULL)
1663  {
1664  /* copy errno because ereport subfunctions might change it */
1665  int save_errno = errno;
1666 
1667  ereport(ERROR,
1669  errmsg("could not open file \"%s\" for reading: %m",
1670  cstate->filename),
1671  (save_errno == ENOENT || save_errno == EACCES) ?
1672  errhint("COPY FROM instructs the PostgreSQL server process to read a file. "
1673  "You may want a client-side facility such as psql's \\copy.") : 0));
1674  }
1675 
1676  if (fstat(fileno(cstate->copy_file), &st))
1677  ereport(ERROR,
1679  errmsg("could not stat file \"%s\": %m",
1680  cstate->filename)));
1681 
1682  if (S_ISDIR(st.st_mode))
1683  ereport(ERROR,
1684  (errcode(ERRCODE_WRONG_OBJECT_TYPE),
1685  errmsg("\"%s\" is a directory", cstate->filename)));
1686 
1687  progress_vals[2] = st.st_size;
1688  }
1689  }
1690 
1691  pgstat_progress_update_multi_param(3, progress_cols, progress_vals);
1692 
1693  if (cstate->opts.binary)
1694  {
1695  /* Read and verify binary header */
1696  ReceiveCopyBinaryHeader(cstate);
1697  }
1698 
1699  /* create workspace for CopyReadAttributes results */
1700  if (!cstate->opts.binary)
1701  {
1702  AttrNumber attr_count = list_length(cstate->attnumlist);
1703 
1704  cstate->max_fields = attr_count;
1705  cstate->raw_fields = (char **) palloc(attr_count * sizeof(char *));
1706  }
1707 
1708  MemoryContextSwitchTo(oldcontext);
1709 
1710  return cstate;
1711 }
1712 
1713 /*
1714  * Clean up storage and release resources for COPY FROM.
1715  */
1716 void
1718 {
1719  /* No COPY FROM related resources except memory. */
1720  if (cstate->is_program)
1721  {
1722  ClosePipeFromProgram(cstate);
1723  }
1724  else
1725  {
1726  if (cstate->filename != NULL && FreeFile(cstate->copy_file))
1727  ereport(ERROR,
1729  errmsg("could not close file \"%s\": %m",
1730  cstate->filename)));
1731  }
1732 
1734 
1736  pfree(cstate);
1737 }
1738 
1739 /*
1740  * Closes the pipe from an external program, checking the pclose() return code.
1741  */
1742 static void
1744 {
1745  int pclose_rc;
1746 
1747  Assert(cstate->is_program);
1748 
1749  pclose_rc = ClosePipeStream(cstate->copy_file);
1750  if (pclose_rc == -1)
1751  ereport(ERROR,
1753  errmsg("could not close pipe to external command: %m")));
1754  else if (pclose_rc != 0)
1755  {
1756  /*
1757  * If we ended a COPY FROM PROGRAM before reaching EOF, then it's
1758  * expectable for the called program to fail with SIGPIPE, and we
1759  * should not report that as an error. Otherwise, SIGPIPE indicates a
1760  * problem.
1761  */
1762  if (!cstate->raw_reached_eof &&
1763  wait_result_is_signal(pclose_rc, SIGPIPE))
1764  return;
1765 
1766  ereport(ERROR,
1767  (errcode(ERRCODE_EXTERNAL_ROUTINE_EXCEPTION),
1768  errmsg("program \"%s\" failed",
1769  cstate->filename),
1770  errdetail_internal("%s", wait_result_to_str(pclose_rc))));
1771  }
1772 }
int16 AttrNumber
Definition: attnum.h:21
List * CopyGetAttnums(TupleDesc tupDesc, Relation rel, List *attnamelist)
Definition: copy.c:782
void ProcessCopyOptions(ParseState *pstate, CopyFormatOptions *opts_out, bool is_from, List *options)
Definition: copy.c:414
void pgstat_progress_start_command(ProgressCommandType cmdtype, Oid relid)
void pgstat_progress_update_param(int index, int64 val)
void pgstat_progress_update_multi_param(int nparam, const int *index, const int64 *val)
void pgstat_progress_end_command(void)
@ PROGRESS_COMMAND_COPY
#define NameStr(name)
Definition: c.h:730
#define PG_BINARY_R
Definition: c.h:1280
#define InvalidSubTransactionId
Definition: c.h:642
uint32 CommandId
Definition: c.h:650
bool contain_volatile_functions_not_nextval(Node *clause)
Definition: clauses.c:590
bool contain_volatile_functions(Node *clause)
Definition: clauses.c:483
static void CopyMultiInsertInfoSetupBuffer(CopyMultiInsertInfo *miinfo, ResultRelInfo *rri)
Definition: copyfrom.c:242
static CopyMultiInsertBuffer * CopyMultiInsertBufferInit(ResultRelInfo *rri)
Definition: copyfrom.c:225
static void CopyMultiInsertInfoInit(CopyMultiInsertInfo *miinfo, ResultRelInfo *rri, CopyFromState cstate, EState *estate, CommandId mycid, int ti_options)
Definition: copyfrom.c:262
static void CopyMultiInsertInfoFlush(CopyMultiInsertInfo *miinfo, ResultRelInfo *curr_rri, int64 *processed)
Definition: copyfrom.c:524
static void CopyMultiInsertInfoStore(CopyMultiInsertInfo *miinfo, ResultRelInfo *rri, TupleTableSlot *slot, int tuplen, uint64 lineno)
Definition: copyfrom.c:609
static void CopyMultiInsertInfoCleanup(CopyMultiInsertInfo *miinfo)
Definition: copyfrom.c:571
#define MAX_PARTITION_BUFFERS
Definition: copyfrom.c:74
struct CopyMultiInsertInfo CopyMultiInsertInfo
#define MAX_BUFFERED_TUPLES
Definition: copyfrom.c:65
static bool CopyMultiInsertInfoIsFull(CopyMultiInsertInfo *miinfo)
Definition: copyfrom.c:287
CopyFromState BeginCopyFrom(ParseState *pstate, Relation rel, Node *whereClause, const char *filename, bool is_program, copy_data_source_cb data_source_cb, List *attnamelist, List *options)
Definition: copyfrom.c:1334
static void CopyMultiInsertBufferFlush(CopyMultiInsertInfo *miinfo, CopyMultiInsertBuffer *buffer, int64 *processed)
Definition: copyfrom.c:308
static TupleTableSlot * CopyMultiInsertInfoNextFreeSlot(CopyMultiInsertInfo *miinfo, ResultRelInfo *rri)
Definition: copyfrom.c:590
static void ClosePipeFromProgram(CopyFromState cstate)
Definition: copyfrom.c:1743
#define MAX_BUFFERED_BYTES
Definition: copyfrom.c:71
static void CopyMultiInsertBufferCleanup(CopyMultiInsertInfo *miinfo, CopyMultiInsertBuffer *buffer)
Definition: copyfrom.c:482
uint64 CopyFrom(CopyFromState cstate)
Definition: copyfrom.c:632
void EndCopyFrom(CopyFromState cstate)
Definition: copyfrom.c:1717
static char * limit_printout_length(const char *str)
Definition: copyfrom.c:195
static bool CopyMultiInsertInfoIsEmpty(CopyMultiInsertInfo *miinfo)
Definition: copyfrom.c:299
struct CopyMultiInsertBuffer CopyMultiInsertBuffer
#define MAX_COPY_DATA_DISPLAY
void CopyFromErrorCallback(void *arg)
Definition: copyfrom.c:116
CopyInsertMethod
@ CIM_SINGLE
@ CIM_MULTI_CONDITIONAL
@ CIM_MULTI
#define INPUT_BUF_SIZE
@ EOL_UNKNOWN
#define RAW_BUF_SIZE
void ReceiveCopyBinaryHeader(CopyFromState cstate)
void ReceiveCopyBegin(CopyFromState cstate)
bool NextCopyFrom(CopyFromState cstate, ExprContext *econtext, Datum *values, bool *nulls)
@ COPY_FILE
Definition: copyto.c:52
@ COPY_CALLBACK
Definition: copyto.c:54
@ DestRemote
Definition: dest.h:89
struct cursor * cur
Definition: ecpg.c:28
int errmsg_internal(const char *fmt,...)
Definition: elog.c:1156
int errdetail_internal(const char *fmt,...)
Definition: elog.c:1229
int errcode_for_file_access(void)
Definition: elog.c:881
ErrorContextCallback * error_context_stack
Definition: elog.c:95
int errhint(const char *fmt,...)
Definition: elog.c:1316
int errcode(int sqlerrcode)
Definition: elog.c:858
int errmsg(const char *fmt,...)
Definition: elog.c:1069
#define errcontext
Definition: elog.h:196
#define ERROR
Definition: elog.h:39
#define ereport(elevel,...)
Definition: elog.h:149
ExprState * ExecInitQual(List *qual, PlanState *parent)
Definition: execExpr.c:213
ExprState * ExecInitExpr(Expr *node, PlanState *parent)
Definition: execExpr.c:127
List * ExecInsertIndexTuples(ResultRelInfo *resultRelInfo, TupleTableSlot *slot, EState *estate, bool update, bool noDupErr, bool *specConflict, List *arbiterIndexes, bool onlySummarizing)
Definition: execIndexing.c:293
void ExecOpenIndices(ResultRelInfo *resultRelInfo, bool speculative)
Definition: execIndexing.c:156
bool ExecPartitionCheck(ResultRelInfo *resultRelInfo, TupleTableSlot *slot, EState *estate, bool emitError)
Definition: execMain.c:1807
void ExecCloseResultRelations(EState *estate)
Definition: execMain.c:1532
void ExecCloseRangeTableRelations(EState *estate)
Definition: execMain.c:1592
void ExecConstraints(ResultRelInfo *resultRelInfo, TupleTableSlot *slot, EState *estate)
Definition: execMain.c:1931
void CheckValidResultRel(ResultRelInfo *resultRelInfo, CmdType operation)
Definition: execMain.c:1015
ResultRelInfo * ExecFindPartition(ModifyTableState *mtstate, ResultRelInfo *rootResultRelInfo, PartitionTupleRouting *proute, TupleTableSlot *slot, EState *estate)
PartitionTupleRouting * ExecSetupPartitionTupleRouting(EState *estate, Relation rel)
void ExecCleanupTupleRouting(ModifyTableState *mtstate, PartitionTupleRouting *proute)
void ExecResetTupleTable(List *tupleTable, bool shouldFree)
Definition: execTuples.c:1192
TupleTableSlot * ExecStoreVirtualTuple(TupleTableSlot *slot)
Definition: execTuples.c:1553
void ExecDropSingleTupleTableSlot(TupleTableSlot *slot)
Definition: execTuples.c:1255
void ExecInitRangeTable(EState *estate, List *rangeTable, List *permInfos)
Definition: execUtils.c:759
void ExecInitResultRelation(EState *estate, ResultRelInfo *resultRelInfo, Index rti)
Definition: execUtils.c:845
EState * CreateExecutorState(void)
Definition: execUtils.c:93
TupleConversionMap * ExecGetRootToChildMap(ResultRelInfo *resultRelInfo, EState *estate)
Definition: execUtils.c:1263
void FreeExecutorState(EState *estate)
Definition: execUtils.c:194
#define ResetPerTupleExprContext(estate)
Definition: executor.h:558
#define GetPerTupleExprContext(estate)
Definition: executor.h:549
#define GetPerTupleMemoryContext(estate)
Definition: executor.h:554
static bool ExecQual(ExprState *state, ExprContext *econtext)
Definition: executor.h:412
FILE * AllocateFile(const char *name, const char *mode)
Definition: fd.c:2480
int ClosePipeStream(FILE *file)
Definition: fd.c:2888
int FreeFile(FILE *file)
Definition: fd.c:2678
FILE * OpenPipeStream(const char *command, const char *mode)
Definition: fd.c:2583
void fmgr_info(Oid functionId, FmgrInfo *finfo)
Definition: fmgr.c:127
void ReleaseBulkInsertStatePin(BulkInsertState bistate)
Definition: heapam.c:1798
BulkInsertState GetBulkInsertState(void)
Definition: heapam.c:1770
void FreeBulkInsertState(BulkInsertState bistate)
Definition: heapam.c:1786
struct CopyFromStateData * CopyFromState
Definition: copy.h:67
int(* copy_data_source_cb)(void *outbuf, int minread, int maxread)
Definition: copy.h:70
int i
Definition: isn.c:73
Assert(fmt[strlen(fmt) - 1] !='\n')
List * lappend(List *list, void *datum)
Definition: list.c:338
List * list_delete_first(List *list)
Definition: list.c:942
void list_free(List *list)
Definition: list.c:1545
bool list_member_int(const List *list, int datum)
Definition: list.c:701
void getTypeInputInfo(Oid type, Oid *typInput, Oid *typIOParam)
Definition: lsyscache.c:2832
void getTypeBinaryInputInfo(Oid type, Oid *typReceive, Oid *typIOParam)
Definition: lsyscache.c:2898
int GetDatabaseEncoding(void)
Definition: mbutils.c:1268
int pg_mbcliplen(const char *mbstr, int len, int limit)
Definition: mbutils.c:1084
int pg_get_client_encoding(void)
Definition: mbutils.c:337
char * pstrdup(const char *in)
Definition: mcxt.c:1644
void pfree(void *pointer)
Definition: mcxt.c:1456
void * palloc0(Size size)
Definition: mcxt.c:1257
MemoryContext CurrentMemoryContext
Definition: mcxt.c:135
void MemoryContextDelete(MemoryContext context)
Definition: mcxt.c:403
void * palloc(Size size)
Definition: mcxt.c:1226
#define AllocSetContextCreate
Definition: memutils.h:129
#define ALLOCSET_DEFAULT_SIZES
Definition: memutils.h:153
#define CHECK_FOR_INTERRUPTS()
Definition: miscadmin.h:121
Oid FindDefaultConversionProc(int32 for_encoding, int32 to_encoding)
Definition: namespace.c:3757
void ExecComputeStoredGenerated(ResultRelInfo *resultRelInfo, EState *estate, TupleTableSlot *slot, CmdType cmdtype)
@ CMD_INSERT
Definition: nodes.h:278
#define makeNode(_type_)
Definition: nodes.h:176
#define castNode(_type_, nodeptr)
Definition: nodes.h:197
static MemoryContext MemoryContextSwitchTo(MemoryContext context)
Definition: palloc.h:138
int16 attnum
Definition: pg_attribute.h:74
FormData_pg_attribute * Form_pg_attribute
Definition: pg_attribute.h:209
void * arg
const void size_t len
static char * filename
Definition: pg_dumpall.c:119
#define lfirst(lc)
Definition: pg_list.h:172
static int list_length(const List *l)
Definition: pg_list.h:152
#define NIL
Definition: pg_list.h:68
#define lfirst_int(lc)
Definition: pg_list.h:173
#define linitial(l)
Definition: pg_list.h:178
@ PG_SQL_ASCII
Definition: pg_wchar.h:226
Expr * expression_planner(Expr *expr)
Definition: planner.c:6431
bool ThereAreNoReadyPortals(void)
Definition: portalmem.c:1169
CommandDest whereToSendOutput
Definition: postgres.c:88
#define InvalidOid
Definition: postgres_ext.h:36
unsigned int Oid
Definition: postgres_ext.h:31
#define PROGRESS_COPY_COMMAND
Definition: progress.h:141
#define PROGRESS_COPY_TYPE_FILE
Definition: progress.h:149
#define PROGRESS_COPY_COMMAND_FROM
Definition: progress.h:145
#define PROGRESS_COPY_TUPLES_PROCESSED
Definition: progress.h:139
#define PROGRESS_COPY_TUPLES_EXCLUDED
Definition: progress.h:140
#define PROGRESS_COPY_TYPE
Definition: progress.h:142
#define PROGRESS_COPY_TYPE_PROGRAM
Definition: progress.h:150
#define PROGRESS_COPY_BYTES_TOTAL
Definition: progress.h:138
#define PROGRESS_COPY_TYPE_CALLBACK
Definition: progress.h:152
#define PROGRESS_COPY_TYPE_PIPE
Definition: progress.h:151
#define RelationGetRelid(relation)
Definition: rel.h:504
#define RelationGetDescr(relation)
Definition: rel.h:530
#define RelationGetRelationName(relation)
Definition: rel.h:538
Node * build_column_default(Relation rel, int attrno)
bool ThereAreNoPriorRegisteredSnapshots(void)
Definition: snapmgr.c:1623
void InvalidateCatalogSnapshot(void)
Definition: snapmgr.c:457
void initStringInfo(StringInfo str)
Definition: stringinfo.c:59
bool freeze
Definition: copy.h:44
bool binary
Definition: copy.h:43
bool convert_selectively
Definition: copy.h:62
List * force_null
Definition: copy.h:60
List * convert_select
Definition: copy.h:63
bool * force_notnull_flags
Definition: copy.h:59
int file_encoding
Definition: copy.h:41
bool * force_null_flags
Definition: copy.h:61
List * force_notnull
Definition: copy.h:58
ExprState ** defexprs
copy_data_source_cb data_source_cb
StringInfoData line_buf
CopyFormatOptions opts
StringInfoData attribute_buf
TransitionCaptureState * transition_capture
MemoryContext copycontext
const char * cur_attval
const char * cur_attname
const char * cur_relname
TupleTableSlot * slots[MAX_BUFFERED_TUPLES]
Definition: copyfrom.c:79
ResultRelInfo * resultRelInfo
Definition: copyfrom.c:80
uint64 linenos[MAX_BUFFERED_TUPLES]
Definition: copyfrom.c:84
BulkInsertState bistate
Definition: copyfrom.c:81
EState * estate
Definition: copyfrom.c:99
CommandId mycid
Definition: copyfrom.c:100
List * multiInsertBuffers
Definition: copyfrom.c:95
CopyFromState cstate
Definition: copyfrom.c:98
List * es_tupleTable
Definition: execnodes.h:661
struct ErrorContextCallback * previous
Definition: elog.h:295
void(* callback)(void *arg)
Definition: elog.h:296
TupleTableSlot * ecxt_scantuple
Definition: execnodes.h:249
EndForeignInsert_function EndForeignInsert
Definition: fdwapi.h:239
BeginForeignInsert_function BeginForeignInsert
Definition: fdwapi.h:238
ExecForeignInsert_function ExecForeignInsert
Definition: fdwapi.h:232
ExecForeignBatchInsert_function ExecForeignBatchInsert
Definition: fdwapi.h:233
GetForeignModifyBatchSize_function GetForeignModifyBatchSize
Definition: fdwapi.h:234
Definition: fmgr.h:57
Definition: pg_list.h:54
CmdType operation
Definition: execnodes.h:1276
ResultRelInfo * resultRelInfo
Definition: execnodes.h:1280
PlanState ps
Definition: execnodes.h:1275
ResultRelInfo * rootResultRelInfo
Definition: execnodes.h:1288
struct TransitionCaptureState * mt_transition_capture
Definition: execnodes.h:1314
Definition: nodes.h:129
List * p_rteperminfos
Definition: parse_node.h:194
List * p_rtable
Definition: parse_node.h:193
Plan * plan
Definition: execnodes.h:1037
EState * state
Definition: execnodes.h:1039
SubTransactionId rd_firstRelfilelocatorSubid
Definition: rel.h:106
TriggerDesc * trigdesc
Definition: rel.h:117
TupleDesc rd_att
Definition: rel.h:112
SubTransactionId rd_newRelfilelocatorSubid
Definition: rel.h:104
SubTransactionId rd_createSubid
Definition: rel.h:103
Form_pg_class rd_rel
Definition: rel.h:111
TupleTableSlot * ri_PartitionTupleSlot
Definition: execnodes.h:575
int ri_NumIndices
Definition: execnodes.h:453
Relation ri_RelationDesc
Definition: execnodes.h:450
struct CopyMultiInsertBuffer * ri_CopyMultiInsertBuffer
Definition: execnodes.h:578
TriggerDesc * ri_TrigDesc
Definition: execnodes.h:480
struct FdwRoutine * ri_FdwRoutine
Definition: execnodes.h:497
int ri_BatchSize
Definition: execnodes.h:508
TupleTableSlot * tcs_original_insert_tuple
Definition: trigger.h:76
bool trig_insert_instead_row
Definition: reltrigger.h:58
bool trig_insert_after_row
Definition: reltrigger.h:57
bool trig_insert_new_table
Definition: reltrigger.h:75
bool trig_insert_before_row
Definition: reltrigger.h:56
bool has_generated_stored
Definition: tupdesc.h:45
AttrMap * attrMap
Definition: tupconvert.h:28
TupleConstr * constr
Definition: tupdesc.h:85
Oid tts_tableOid
Definition: tuptable.h:131
bool * tts_isnull
Definition: tuptable.h:128
Datum * tts_values
Definition: tuptable.h:126
__int64 st_size
Definition: win32_port.h:281
unsigned short st_mode
Definition: win32_port.h:276
TupleTableSlot * table_slot_create(Relation relation, List **reglist)
Definition: tableam.c:91
#define TABLE_INSERT_FROZEN
Definition: tableam.h:253
#define TABLE_INSERT_SKIP_FSM
Definition: tableam.h:252
static void table_finish_bulk_insert(Relation rel, int options)
Definition: tableam.h:1590
static void table_multi_insert(Relation rel, TupleTableSlot **slots, int nslots, CommandId cid, int options, struct BulkInsertStateData *bistate)
Definition: tableam.h:1452
static void table_tuple_insert(Relation rel, TupleTableSlot *slot, CommandId cid, int options, struct BulkInsertStateData *bistate)
Definition: tableam.h:1397
void ExecBSInsertTriggers(EState *estate, ResultRelInfo *relinfo)
Definition: trigger.c:2400
bool ExecBRInsertTriggers(EState *estate, ResultRelInfo *relinfo, TupleTableSlot *slot)
Definition: trigger.c:2464
bool ExecIRInsertTriggers(EState *estate, ResultRelInfo *relinfo, TupleTableSlot *slot)
Definition: trigger.c:2557
void ExecARInsertTriggers(EState *estate, ResultRelInfo *relinfo, TupleTableSlot *slot, List *recheckIndexes, TransitionCaptureState *transition_capture)
Definition: trigger.c:2540
TransitionCaptureState * MakeTransitionCaptureState(TriggerDesc *trigdesc, Oid relid, CmdType cmdType)
Definition: trigger.c:4839
void ExecASInsertTriggers(EState *estate, ResultRelInfo *relinfo, TransitionCaptureState *transition_capture)
Definition: trigger.c:2451
void AfterTriggerEndQuery(EState *estate)
Definition: trigger.c:4995
void AfterTriggerBeginQuery(void)
Definition: trigger.c:4975
TupleTableSlot * execute_attr_map_slot(AttrMap *attrMap, TupleTableSlot *in_slot, TupleTableSlot *out_slot)
Definition: tupconvert.c:192
#define TupleDescAttr(tupdesc, i)
Definition: tupdesc.h:92
static TupleTableSlot * ExecClearTuple(TupleTableSlot *slot)
Definition: tuptable.h:433
static TupleTableSlot * ExecCopySlot(TupleTableSlot *dstslot, TupleTableSlot *srcslot)
Definition: tuptable.h:483
static void ExecMaterializeSlot(TupleTableSlot *slot)
Definition: tuptable.h:451
char * wait_result_to_str(int exitstatus)
Definition: wait_error.c:33
bool wait_result_is_signal(int exit_status, int signum)
Definition: wait_error.c:102
#define SIGPIPE
Definition: win32_port.h:181
#define S_ISDIR(m)
Definition: win32_port.h:333
#define fstat
Definition: win32_port.h:291
SubTransactionId GetCurrentSubTransactionId(void)
Definition: xact.c:780
CommandId GetCurrentCommandId(bool used)
Definition: xact.c:818