LCOV - code coverage report
Current view: top level - src/backend/commands - matview.c (source / functions) Hit Total Coverage
Test: PostgreSQL 18devel Lines: 245 269 91.1 %
Date: 2025-01-18 04:15:08 Functions: 15 16 93.8 %
Legend: Lines: hit not hit

          Line data    Source code
       1             : /*-------------------------------------------------------------------------
       2             :  *
       3             :  * matview.c
       4             :  *    materialized view support
       5             :  *
       6             :  * Portions Copyright (c) 1996-2025, PostgreSQL Global Development Group
       7             :  * Portions Copyright (c) 1994, Regents of the University of California
       8             :  *
       9             :  *
      10             :  * IDENTIFICATION
      11             :  *    src/backend/commands/matview.c
      12             :  *
      13             :  *-------------------------------------------------------------------------
      14             :  */
      15             : #include "postgres.h"
      16             : 
      17             : #include "access/genam.h"
      18             : #include "access/heapam.h"
      19             : #include "access/htup_details.h"
      20             : #include "access/multixact.h"
      21             : #include "access/tableam.h"
      22             : #include "access/xact.h"
      23             : #include "catalog/indexing.h"
      24             : #include "catalog/namespace.h"
      25             : #include "catalog/pg_am.h"
      26             : #include "catalog/pg_opclass.h"
      27             : #include "commands/cluster.h"
      28             : #include "commands/matview.h"
      29             : #include "commands/tablecmds.h"
      30             : #include "commands/tablespace.h"
      31             : #include "executor/executor.h"
      32             : #include "executor/spi.h"
      33             : #include "miscadmin.h"
      34             : #include "pgstat.h"
      35             : #include "rewrite/rewriteHandler.h"
      36             : #include "storage/lmgr.h"
      37             : #include "tcop/tcopprot.h"
      38             : #include "utils/builtins.h"
      39             : #include "utils/lsyscache.h"
      40             : #include "utils/rel.h"
      41             : #include "utils/snapmgr.h"
      42             : #include "utils/syscache.h"
      43             : 
      44             : 
      45             : typedef struct
      46             : {
      47             :     DestReceiver pub;           /* publicly-known function pointers */
      48             :     Oid         transientoid;   /* OID of new heap into which to store */
      49             :     /* These fields are filled by transientrel_startup: */
      50             :     Relation    transientrel;   /* relation to write to */
      51             :     CommandId   output_cid;     /* cmin to insert in output tuples */
      52             :     int         ti_options;     /* table_tuple_insert performance options */
      53             :     BulkInsertState bistate;    /* bulk insert state */
      54             : } DR_transientrel;
      55             : 
      56             : static int  matview_maintenance_depth = 0;
      57             : 
      58             : static void transientrel_startup(DestReceiver *self, int operation, TupleDesc typeinfo);
      59             : static bool transientrel_receive(TupleTableSlot *slot, DestReceiver *self);
      60             : static void transientrel_shutdown(DestReceiver *self);
      61             : static void transientrel_destroy(DestReceiver *self);
      62             : static uint64 refresh_matview_datafill(DestReceiver *dest, Query *query,
      63             :                                        const char *queryString, bool is_create);
      64             : static char *make_temptable_name_n(char *tempname, int n);
      65             : static void refresh_by_match_merge(Oid matviewOid, Oid tempOid, Oid relowner,
      66             :                                    int save_sec_context);
      67             : static void refresh_by_heap_swap(Oid matviewOid, Oid OIDNewHeap, char relpersistence);
      68             : static bool is_usable_unique_index(Relation indexRel);
      69             : static void OpenMatViewIncrementalMaintenance(void);
      70             : static void CloseMatViewIncrementalMaintenance(void);
      71             : 
      72             : /*
      73             :  * SetMatViewPopulatedState
      74             :  *      Mark a materialized view as populated, or not.
      75             :  *
      76             :  * NOTE: caller must be holding an appropriate lock on the relation.
      77             :  */
      78             : void
      79         610 : SetMatViewPopulatedState(Relation relation, bool newstate)
      80             : {
      81             :     Relation    pgrel;
      82             :     HeapTuple   tuple;
      83             : 
      84             :     Assert(relation->rd_rel->relkind == RELKIND_MATVIEW);
      85             : 
      86             :     /*
      87             :      * Update relation's pg_class entry.  Crucial side-effect: other backends
      88             :      * (and this one too!) are sent SI message to make them rebuild relcache
      89             :      * entries.
      90             :      */
      91         610 :     pgrel = table_open(RelationRelationId, RowExclusiveLock);
      92         610 :     tuple = SearchSysCacheCopy1(RELOID,
      93             :                                 ObjectIdGetDatum(RelationGetRelid(relation)));
      94         610 :     if (!HeapTupleIsValid(tuple))
      95           0 :         elog(ERROR, "cache lookup failed for relation %u",
      96             :              RelationGetRelid(relation));
      97             : 
      98         610 :     ((Form_pg_class) GETSTRUCT(tuple))->relispopulated = newstate;
      99             : 
     100         610 :     CatalogTupleUpdate(pgrel, &tuple->t_self, tuple);
     101             : 
     102         610 :     heap_freetuple(tuple);
     103         610 :     table_close(pgrel, RowExclusiveLock);
     104             : 
     105             :     /*
     106             :      * Advance command counter to make the updated pg_class row locally
     107             :      * visible.
     108             :      */
     109         610 :     CommandCounterIncrement();
     110         610 : }
     111             : 
     112             : /*
     113             :  * ExecRefreshMatView -- execute a REFRESH MATERIALIZED VIEW command
     114             :  *
     115             :  * If WITH NO DATA was specified, this is effectively like a TRUNCATE;
     116             :  * otherwise it is like a TRUNCATE followed by an INSERT using the SELECT
     117             :  * statement associated with the materialized view.  The statement node's
     118             :  * skipData field shows whether the clause was used.
     119             :  */
     120             : ObjectAddress
     121         262 : ExecRefreshMatView(RefreshMatViewStmt *stmt, const char *queryString,
     122             :                    QueryCompletion *qc)
     123             : {
     124             :     Oid         matviewOid;
     125             :     LOCKMODE    lockmode;
     126             : 
     127             :     /* Determine strength of lock needed. */
     128         262 :     lockmode = stmt->concurrent ? ExclusiveLock : AccessExclusiveLock;
     129             : 
     130             :     /*
     131             :      * Get a lock until end of transaction.
     132             :      */
     133         262 :     matviewOid = RangeVarGetRelidExtended(stmt->relation,
     134             :                                           lockmode, 0,
     135             :                                           RangeVarCallbackMaintainsTable,
     136             :                                           NULL);
     137             : 
     138         446 :     return RefreshMatViewByOid(matviewOid, false, stmt->skipData,
     139         256 :                                stmt->concurrent, queryString, qc);
     140             : }
     141             : 
     142             : /*
     143             :  * RefreshMatViewByOid -- refresh materialized view by OID
     144             :  *
     145             :  * This refreshes the materialized view by creating a new table and swapping
     146             :  * the relfilenumbers of the new table and the old materialized view, so the OID
     147             :  * of the original materialized view is preserved. Thus we do not lose GRANT
     148             :  * nor references to this materialized view.
     149             :  *
     150             :  * If skipData is true, this is effectively like a TRUNCATE; otherwise it is
     151             :  * like a TRUNCATE followed by an INSERT using the SELECT statement associated
     152             :  * with the materialized view.
     153             :  *
     154             :  * Indexes are rebuilt too, via REINDEX. Since we are effectively bulk-loading
     155             :  * the new heap, it's better to create the indexes afterwards than to fill them
     156             :  * incrementally while we load.
     157             :  *
     158             :  * The matview's "populated" state is changed based on whether the contents
     159             :  * reflect the result set of the materialized view's query.
     160             :  *
     161             :  * This is also used to populate the materialized view created by CREATE
     162             :  * MATERIALIZED VIEW command.
     163             :  */
     164             : ObjectAddress
     165         616 : RefreshMatViewByOid(Oid matviewOid, bool is_create, bool skipData,
     166             :                     bool concurrent, const char *queryString,
     167             :                     QueryCompletion *qc)
     168             : {
     169             :     Relation    matviewRel;
     170             :     RewriteRule *rule;
     171             :     List       *actions;
     172             :     Query      *dataQuery;
     173             :     Oid         tableSpace;
     174             :     Oid         relowner;
     175             :     Oid         OIDNewHeap;
     176         616 :     uint64      processed = 0;
     177             :     char        relpersistence;
     178             :     Oid         save_userid;
     179             :     int         save_sec_context;
     180             :     int         save_nestlevel;
     181             :     ObjectAddress address;
     182             : 
     183         616 :     matviewRel = table_open(matviewOid, NoLock);
     184         616 :     relowner = matviewRel->rd_rel->relowner;
     185             : 
     186             :     /*
     187             :      * Switch to the owner's userid, so that any functions are run as that
     188             :      * user.  Also lock down security-restricted operations and arrange to
     189             :      * make GUC variable changes local to this command.
     190             :      */
     191         616 :     GetUserIdAndSecContext(&save_userid, &save_sec_context);
     192         616 :     SetUserIdAndSecContext(relowner,
     193             :                            save_sec_context | SECURITY_RESTRICTED_OPERATION);
     194         616 :     save_nestlevel = NewGUCNestLevel();
     195         616 :     RestrictSearchPath();
     196             : 
     197             :     /* Make sure it is a materialized view. */
     198         616 :     if (matviewRel->rd_rel->relkind != RELKIND_MATVIEW)
     199           0 :         ereport(ERROR,
     200             :                 (errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
     201             :                  errmsg("\"%s\" is not a materialized view",
     202             :                         RelationGetRelationName(matviewRel))));
     203             : 
     204             :     /* Check that CONCURRENTLY is not specified if not populated. */
     205         616 :     if (concurrent && !RelationIsPopulated(matviewRel))
     206           0 :         ereport(ERROR,
     207             :                 (errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
     208             :                  errmsg("CONCURRENTLY cannot be used when the materialized view is not populated")));
     209             : 
     210             :     /* Check that conflicting options have not been specified. */
     211         616 :     if (concurrent && skipData)
     212           6 :         ereport(ERROR,
     213             :                 (errcode(ERRCODE_SYNTAX_ERROR),
     214             :                  errmsg("%s and %s options cannot be used together",
     215             :                         "CONCURRENTLY", "WITH NO DATA")));
     216             : 
     217             :     /*
     218             :      * Check that everything is correct for a refresh. Problems at this point
     219             :      * are internal errors, so elog is sufficient.
     220             :      */
     221         610 :     if (matviewRel->rd_rel->relhasrules == false ||
     222         610 :         matviewRel->rd_rules->numLocks < 1)
     223           0 :         elog(ERROR,
     224             :              "materialized view \"%s\" is missing rewrite information",
     225             :              RelationGetRelationName(matviewRel));
     226             : 
     227         610 :     if (matviewRel->rd_rules->numLocks > 1)
     228           0 :         elog(ERROR,
     229             :              "materialized view \"%s\" has too many rules",
     230             :              RelationGetRelationName(matviewRel));
     231             : 
     232         610 :     rule = matviewRel->rd_rules->rules[0];
     233         610 :     if (rule->event != CMD_SELECT || !(rule->isInstead))
     234           0 :         elog(ERROR,
     235             :              "the rule for materialized view \"%s\" is not a SELECT INSTEAD OF rule",
     236             :              RelationGetRelationName(matviewRel));
     237             : 
     238         610 :     actions = rule->actions;
     239         610 :     if (list_length(actions) != 1)
     240           0 :         elog(ERROR,
     241             :              "the rule for materialized view \"%s\" is not a single action",
     242             :              RelationGetRelationName(matviewRel));
     243             : 
     244             :     /*
     245             :      * Check that there is a unique index with no WHERE clause on one or more
     246             :      * columns of the materialized view if CONCURRENTLY is specified.
     247             :      */
     248         610 :     if (concurrent)
     249             :     {
     250          78 :         List       *indexoidlist = RelationGetIndexList(matviewRel);
     251             :         ListCell   *indexoidscan;
     252          78 :         bool        hasUniqueIndex = false;
     253             : 
     254             :         Assert(!is_create);
     255             : 
     256          90 :         foreach(indexoidscan, indexoidlist)
     257             :         {
     258          84 :             Oid         indexoid = lfirst_oid(indexoidscan);
     259             :             Relation    indexRel;
     260             : 
     261          84 :             indexRel = index_open(indexoid, AccessShareLock);
     262          84 :             hasUniqueIndex = is_usable_unique_index(indexRel);
     263          84 :             index_close(indexRel, AccessShareLock);
     264          84 :             if (hasUniqueIndex)
     265          72 :                 break;
     266             :         }
     267             : 
     268          78 :         list_free(indexoidlist);
     269             : 
     270          78 :         if (!hasUniqueIndex)
     271           6 :             ereport(ERROR,
     272             :                     (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
     273             :                      errmsg("cannot refresh materialized view \"%s\" concurrently",
     274             :                             quote_qualified_identifier(get_namespace_name(RelationGetNamespace(matviewRel)),
     275             :                                                        RelationGetRelationName(matviewRel))),
     276             :                      errhint("Create a unique index with no WHERE clause on one or more columns of the materialized view.")));
     277             :     }
     278             : 
     279             :     /*
     280             :      * The stored query was rewritten at the time of the MV definition, but
     281             :      * has not been scribbled on by the planner.
     282             :      */
     283         604 :     dataQuery = linitial_node(Query, actions);
     284             : 
     285             :     /*
     286             :      * Check for active uses of the relation in the current transaction, such
     287             :      * as open scans.
     288             :      *
     289             :      * NB: We count on this to protect us against problems with refreshing the
     290             :      * data using TABLE_INSERT_FROZEN.
     291             :      */
     292         604 :     CheckTableNotInUse(matviewRel,
     293             :                        is_create ? "CREATE MATERIALIZED VIEW" :
     294             :                        "REFRESH MATERIALIZED VIEW");
     295             : 
     296             :     /*
     297             :      * Tentatively mark the matview as populated or not (this will roll back
     298             :      * if we fail later).
     299             :      */
     300         604 :     SetMatViewPopulatedState(matviewRel, !skipData);
     301             : 
     302             :     /* Concurrent refresh builds new data in temp tablespace, and does diff. */
     303         604 :     if (concurrent)
     304             :     {
     305          72 :         tableSpace = GetDefaultTablespace(RELPERSISTENCE_TEMP, false);
     306          72 :         relpersistence = RELPERSISTENCE_TEMP;
     307             :     }
     308             :     else
     309             :     {
     310         532 :         tableSpace = matviewRel->rd_rel->reltablespace;
     311         532 :         relpersistence = matviewRel->rd_rel->relpersistence;
     312             :     }
     313             : 
     314             :     /*
     315             :      * Create the transient table that will receive the regenerated data. Lock
     316             :      * it against access by any other process until commit (by which time it
     317             :      * will be gone).
     318             :      */
     319        1208 :     OIDNewHeap = make_new_heap(matviewOid, tableSpace,
     320         604 :                                matviewRel->rd_rel->relam,
     321             :                                relpersistence, ExclusiveLock);
     322             :     Assert(CheckRelationOidLockedByMe(OIDNewHeap, AccessExclusiveLock, false));
     323             : 
     324             :     /* Generate the data, if wanted. */
     325         604 :     if (!skipData)
     326             :     {
     327             :         DestReceiver *dest;
     328             : 
     329         604 :         dest = CreateTransientRelDestReceiver(OIDNewHeap);
     330         604 :         processed = refresh_matview_datafill(dest, dataQuery, queryString,
     331             :                                              is_create);
     332             :     }
     333             : 
     334             :     /* Make the matview match the newly generated data. */
     335         562 :     if (concurrent)
     336             :     {
     337          72 :         int         old_depth = matview_maintenance_depth;
     338             : 
     339          72 :         PG_TRY();
     340             :         {
     341          72 :             refresh_by_match_merge(matviewOid, OIDNewHeap, relowner,
     342             :                                    save_sec_context);
     343             :         }
     344          12 :         PG_CATCH();
     345             :         {
     346          12 :             matview_maintenance_depth = old_depth;
     347          12 :             PG_RE_THROW();
     348             :         }
     349          60 :         PG_END_TRY();
     350             :         Assert(matview_maintenance_depth == old_depth);
     351             :     }
     352             :     else
     353             :     {
     354         490 :         refresh_by_heap_swap(matviewOid, OIDNewHeap, relpersistence);
     355             : 
     356             :         /*
     357             :          * Inform cumulative stats system about our activity: basically, we
     358             :          * truncated the matview and inserted some new data.  (The concurrent
     359             :          * code path above doesn't need to worry about this because the
     360             :          * inserts and deletes it issues get counted by lower-level code.)
     361             :          */
     362         484 :         pgstat_count_truncate(matviewRel);
     363         484 :         if (!skipData)
     364         484 :             pgstat_count_heap_insert(matviewRel, processed);
     365             :     }
     366             : 
     367         544 :     table_close(matviewRel, NoLock);
     368             : 
     369             :     /* Roll back any GUC changes */
     370         544 :     AtEOXact_GUC(false, save_nestlevel);
     371             : 
     372             :     /* Restore userid and security context */
     373         544 :     SetUserIdAndSecContext(save_userid, save_sec_context);
     374             : 
     375         544 :     ObjectAddressSet(address, RelationRelationId, matviewOid);
     376             : 
     377             :     /*
     378             :      * Save the rowcount so that pg_stat_statements can track the total number
     379             :      * of rows processed by REFRESH MATERIALIZED VIEW command. Note that we
     380             :      * still don't display the rowcount in the command completion tag output,
     381             :      * i.e., the display_rowcount flag of CMDTAG_REFRESH_MATERIALIZED_VIEW
     382             :      * command tag is left false in cmdtaglist.h. Otherwise, the change of
     383             :      * completion tag output might break applications using it.
     384             :      *
     385             :      * When called from CREATE MATERIALIZED VIEW command, the rowcount is
     386             :      * displayed with the command tag CMDTAG_SELECT.
     387             :      */
     388         544 :     if (qc)
     389         532 :         SetQueryCompletion(qc,
     390             :                            is_create ? CMDTAG_SELECT : CMDTAG_REFRESH_MATERIALIZED_VIEW,
     391             :                            processed);
     392             : 
     393         544 :     return address;
     394             : }
     395             : 
     396             : /*
     397             :  * refresh_matview_datafill
     398             :  *
     399             :  * Execute the given query, sending result rows to "dest" (which will
     400             :  * insert them into the target matview).
     401             :  *
     402             :  * Returns number of rows inserted.
     403             :  */
     404             : static uint64
     405         604 : refresh_matview_datafill(DestReceiver *dest, Query *query,
     406             :                          const char *queryString, bool is_create)
     407             : {
     408             :     List       *rewritten;
     409             :     PlannedStmt *plan;
     410             :     QueryDesc  *queryDesc;
     411             :     Query      *copied_query;
     412             :     uint64      processed;
     413             : 
     414             :     /* Lock and rewrite, using a copy to preserve the original query. */
     415         604 :     copied_query = copyObject(query);
     416         604 :     AcquireRewriteLocks(copied_query, true, false);
     417         604 :     rewritten = QueryRewrite(copied_query);
     418             : 
     419             :     /* SELECT should never rewrite to more or less than one SELECT query */
     420         604 :     if (list_length(rewritten) != 1)
     421           0 :         elog(ERROR, "unexpected rewrite result for %s",
     422             :              is_create ? "CREATE MATERIALIZED VIEW " : "REFRESH MATERIALIZED VIEW");
     423         604 :     query = (Query *) linitial(rewritten);
     424             : 
     425             :     /* Check for user-requested abort. */
     426         604 :     CHECK_FOR_INTERRUPTS();
     427             : 
     428             :     /* Plan the query which will generate data for the refresh. */
     429         604 :     plan = pg_plan_query(query, queryString, CURSOR_OPT_PARALLEL_OK, NULL);
     430             : 
     431             :     /*
     432             :      * Use a snapshot with an updated command ID to ensure this query sees
     433             :      * results of any previously executed queries.  (This could only matter if
     434             :      * the planner executed an allegedly-stable function that changed the
     435             :      * database contents, but let's do it anyway to be safe.)
     436             :      */
     437         592 :     PushCopiedSnapshot(GetActiveSnapshot());
     438         592 :     UpdateActiveSnapshotCommandId();
     439             : 
     440             :     /* Create a QueryDesc, redirecting output to our tuple receiver */
     441         592 :     queryDesc = CreateQueryDesc(plan, queryString,
     442             :                                 GetActiveSnapshot(), InvalidSnapshot,
     443             :                                 dest, NULL, NULL, 0);
     444             : 
     445             :     /* call ExecutorStart to prepare the plan for execution */
     446         592 :     ExecutorStart(queryDesc, 0);
     447             : 
     448             :     /* run the plan */
     449         592 :     ExecutorRun(queryDesc, ForwardScanDirection, 0);
     450             : 
     451         562 :     processed = queryDesc->estate->es_processed;
     452             : 
     453             :     /* and clean up */
     454         562 :     ExecutorFinish(queryDesc);
     455         562 :     ExecutorEnd(queryDesc);
     456             : 
     457         562 :     FreeQueryDesc(queryDesc);
     458             : 
     459         562 :     PopActiveSnapshot();
     460             : 
     461         562 :     return processed;
     462             : }
     463             : 
     464             : DestReceiver *
     465         604 : CreateTransientRelDestReceiver(Oid transientoid)
     466             : {
     467         604 :     DR_transientrel *self = (DR_transientrel *) palloc0(sizeof(DR_transientrel));
     468             : 
     469         604 :     self->pub.receiveSlot = transientrel_receive;
     470         604 :     self->pub.rStartup = transientrel_startup;
     471         604 :     self->pub.rShutdown = transientrel_shutdown;
     472         604 :     self->pub.rDestroy = transientrel_destroy;
     473         604 :     self->pub.mydest = DestTransientRel;
     474         604 :     self->transientoid = transientoid;
     475             : 
     476         604 :     return (DestReceiver *) self;
     477             : }
     478             : 
     479             : /*
     480             :  * transientrel_startup --- executor startup
     481             :  */
     482             : static void
     483         592 : transientrel_startup(DestReceiver *self, int operation, TupleDesc typeinfo)
     484             : {
     485         592 :     DR_transientrel *myState = (DR_transientrel *) self;
     486             :     Relation    transientrel;
     487             : 
     488         592 :     transientrel = table_open(myState->transientoid, NoLock);
     489             : 
     490             :     /*
     491             :      * Fill private fields of myState for use by later routines
     492             :      */
     493         592 :     myState->transientrel = transientrel;
     494         592 :     myState->output_cid = GetCurrentCommandId(true);
     495         592 :     myState->ti_options = TABLE_INSERT_SKIP_FSM | TABLE_INSERT_FROZEN;
     496         592 :     myState->bistate = GetBulkInsertState();
     497             : 
     498             :     /*
     499             :      * Valid smgr_targblock implies something already wrote to the relation.
     500             :      * This may be harmless, but this function hasn't planned for it.
     501             :      */
     502             :     Assert(RelationGetTargetBlock(transientrel) == InvalidBlockNumber);
     503         592 : }
     504             : 
     505             : /*
     506             :  * transientrel_receive --- receive one tuple
     507             :  */
     508             : static bool
     509        3854 : transientrel_receive(TupleTableSlot *slot, DestReceiver *self)
     510             : {
     511        3854 :     DR_transientrel *myState = (DR_transientrel *) self;
     512             : 
     513             :     /*
     514             :      * Note that the input slot might not be of the type of the target
     515             :      * relation. That's supported by table_tuple_insert(), but slightly less
     516             :      * efficient than inserting with the right slot - but the alternative
     517             :      * would be to copy into a slot of the right type, which would not be
     518             :      * cheap either. This also doesn't allow accessing per-AM data (say a
     519             :      * tuple's xmin), but since we don't do that here...
     520             :      */
     521             : 
     522        3854 :     table_tuple_insert(myState->transientrel,
     523             :                        slot,
     524             :                        myState->output_cid,
     525             :                        myState->ti_options,
     526             :                        myState->bistate);
     527             : 
     528             :     /* We know this is a newly created relation, so there are no indexes */
     529             : 
     530        3854 :     return true;
     531             : }
     532             : 
     533             : /*
     534             :  * transientrel_shutdown --- executor end
     535             :  */
     536             : static void
     537         562 : transientrel_shutdown(DestReceiver *self)
     538             : {
     539         562 :     DR_transientrel *myState = (DR_transientrel *) self;
     540             : 
     541         562 :     FreeBulkInsertState(myState->bistate);
     542             : 
     543         562 :     table_finish_bulk_insert(myState->transientrel, myState->ti_options);
     544             : 
     545             :     /* close transientrel, but keep lock until commit */
     546         562 :     table_close(myState->transientrel, NoLock);
     547         562 :     myState->transientrel = NULL;
     548         562 : }
     549             : 
     550             : /*
     551             :  * transientrel_destroy --- release DestReceiver object
     552             :  */
     553             : static void
     554           0 : transientrel_destroy(DestReceiver *self)
     555             : {
     556           0 :     pfree(self);
     557           0 : }
     558             : 
     559             : 
     560             : /*
     561             :  * Given a qualified temporary table name, append an underscore followed by
     562             :  * the given integer, to make a new table name based on the old one.
     563             :  * The result is a palloc'd string.
     564             :  *
     565             :  * As coded, this would fail to make a valid SQL name if the given name were,
     566             :  * say, "FOO"."BAR".  Currently, the table name portion of the input will
     567             :  * never be double-quoted because it's of the form "pg_temp_NNN", cf
     568             :  * make_new_heap().  But we might have to work harder someday.
     569             :  */
     570             : static char *
     571          72 : make_temptable_name_n(char *tempname, int n)
     572             : {
     573             :     StringInfoData namebuf;
     574             : 
     575          72 :     initStringInfo(&namebuf);
     576          72 :     appendStringInfoString(&namebuf, tempname);
     577          72 :     appendStringInfo(&namebuf, "_%d", n);
     578          72 :     return namebuf.data;
     579             : }
     580             : 
     581             : /*
     582             :  * refresh_by_match_merge
     583             :  *
     584             :  * Refresh a materialized view with transactional semantics, while allowing
     585             :  * concurrent reads.
     586             :  *
     587             :  * This is called after a new version of the data has been created in a
     588             :  * temporary table.  It performs a full outer join against the old version of
     589             :  * the data, producing "diff" results.  This join cannot work if there are any
     590             :  * duplicated rows in either the old or new versions, in the sense that every
     591             :  * column would compare as equal between the two rows.  It does work correctly
     592             :  * in the face of rows which have at least one NULL value, with all non-NULL
     593             :  * columns equal.  The behavior of NULLs on equality tests and on UNIQUE
     594             :  * indexes turns out to be quite convenient here; the tests we need to make
     595             :  * are consistent with default behavior.  If there is at least one UNIQUE
     596             :  * index on the materialized view, we have exactly the guarantee we need.
     597             :  *
     598             :  * The temporary table used to hold the diff results contains just the TID of
     599             :  * the old record (if matched) and the ROW from the new table as a single
     600             :  * column of complex record type (if matched).
     601             :  *
     602             :  * Once we have the diff table, we perform set-based DELETE and INSERT
     603             :  * operations against the materialized view, and discard both temporary
     604             :  * tables.
     605             :  *
     606             :  * Everything from the generation of the new data to applying the differences
     607             :  * takes place under cover of an ExclusiveLock, since it seems as though we
     608             :  * would want to prohibit not only concurrent REFRESH operations, but also
     609             :  * incremental maintenance.  It also doesn't seem reasonable or safe to allow
     610             :  * SELECT FOR UPDATE or SELECT FOR SHARE on rows being updated or deleted by
     611             :  * this command.
     612             :  */
     613             : static void
     614          72 : refresh_by_match_merge(Oid matviewOid, Oid tempOid, Oid relowner,
     615             :                        int save_sec_context)
     616             : {
     617             :     StringInfoData querybuf;
     618             :     Relation    matviewRel;
     619             :     Relation    tempRel;
     620             :     char       *matviewname;
     621             :     char       *tempname;
     622             :     char       *diffname;
     623             :     TupleDesc   tupdesc;
     624             :     bool        foundUniqueIndex;
     625             :     List       *indexoidlist;
     626             :     ListCell   *indexoidscan;
     627             :     int16       relnatts;
     628             :     Oid        *opUsedForQual;
     629             : 
     630          72 :     initStringInfo(&querybuf);
     631          72 :     matviewRel = table_open(matviewOid, NoLock);
     632          72 :     matviewname = quote_qualified_identifier(get_namespace_name(RelationGetNamespace(matviewRel)),
     633          72 :                                              RelationGetRelationName(matviewRel));
     634          72 :     tempRel = table_open(tempOid, NoLock);
     635          72 :     tempname = quote_qualified_identifier(get_namespace_name(RelationGetNamespace(tempRel)),
     636          72 :                                           RelationGetRelationName(tempRel));
     637          72 :     diffname = make_temptable_name_n(tempname, 2);
     638             : 
     639          72 :     relnatts = RelationGetNumberOfAttributes(matviewRel);
     640             : 
     641             :     /* Open SPI context. */
     642          72 :     SPI_connect();
     643             : 
     644             :     /* Analyze the temp table with the new contents. */
     645          72 :     appendStringInfo(&querybuf, "ANALYZE %s", tempname);
     646          72 :     if (SPI_exec(querybuf.data, 0) != SPI_OK_UTILITY)
     647           0 :         elog(ERROR, "SPI_exec failed: %s", querybuf.data);
     648             : 
     649             :     /*
     650             :      * We need to ensure that there are not duplicate rows without NULLs in
     651             :      * the new data set before we can count on the "diff" results.  Check for
     652             :      * that in a way that allows showing the first duplicated row found.  Even
     653             :      * after we pass this test, a unique index on the materialized view may
     654             :      * find a duplicate key problem.
     655             :      *
     656             :      * Note: here and below, we use "tablename.*::tablerowtype" as a hack to
     657             :      * keep ".*" from being expanded into multiple columns in a SELECT list.
     658             :      * Compare ruleutils.c's get_variable().
     659             :      */
     660          72 :     resetStringInfo(&querybuf);
     661          72 :     appendStringInfo(&querybuf,
     662             :                      "SELECT newdata.*::%s FROM %s newdata "
     663             :                      "WHERE newdata.* IS NOT NULL AND EXISTS "
     664             :                      "(SELECT 1 FROM %s newdata2 WHERE newdata2.* IS NOT NULL "
     665             :                      "AND newdata2.* OPERATOR(pg_catalog.*=) newdata.* "
     666             :                      "AND newdata2.ctid OPERATOR(pg_catalog.<>) "
     667             :                      "newdata.ctid)",
     668             :                      tempname, tempname, tempname);
     669          72 :     if (SPI_execute(querybuf.data, false, 1) != SPI_OK_SELECT)
     670           0 :         elog(ERROR, "SPI_exec failed: %s", querybuf.data);
     671          72 :     if (SPI_processed > 0)
     672             :     {
     673             :         /*
     674             :          * Note that this ereport() is returning data to the user.  Generally,
     675             :          * we would want to make sure that the user has been granted access to
     676             :          * this data.  However, REFRESH MAT VIEW is only able to be run by the
     677             :          * owner of the mat view (or a superuser) and therefore there is no
     678             :          * need to check for access to data in the mat view.
     679             :          */
     680           6 :         ereport(ERROR,
     681             :                 (errcode(ERRCODE_CARDINALITY_VIOLATION),
     682             :                  errmsg("new data for materialized view \"%s\" contains duplicate rows without any null columns",
     683             :                         RelationGetRelationName(matviewRel)),
     684             :                  errdetail("Row: %s",
     685             :                            SPI_getvalue(SPI_tuptable->vals[0], SPI_tuptable->tupdesc, 1))));
     686             :     }
     687             : 
     688             :     /*
     689             :      * Create the temporary "diff" table.
     690             :      *
     691             :      * Temporarily switch out of the SECURITY_RESTRICTED_OPERATION context,
     692             :      * because you cannot create temp tables in SRO context.  For extra
     693             :      * paranoia, add the composite type column only after switching back to
     694             :      * SRO context.
     695             :      */
     696          66 :     SetUserIdAndSecContext(relowner,
     697             :                            save_sec_context | SECURITY_LOCAL_USERID_CHANGE);
     698          66 :     resetStringInfo(&querybuf);
     699          66 :     appendStringInfo(&querybuf,
     700             :                      "CREATE TEMP TABLE %s (tid pg_catalog.tid)",
     701             :                      diffname);
     702          66 :     if (SPI_exec(querybuf.data, 0) != SPI_OK_UTILITY)
     703           0 :         elog(ERROR, "SPI_exec failed: %s", querybuf.data);
     704          66 :     SetUserIdAndSecContext(relowner,
     705             :                            save_sec_context | SECURITY_RESTRICTED_OPERATION);
     706          66 :     resetStringInfo(&querybuf);
     707          66 :     appendStringInfo(&querybuf,
     708             :                      "ALTER TABLE %s ADD COLUMN newdata %s",
     709             :                      diffname, tempname);
     710          66 :     if (SPI_exec(querybuf.data, 0) != SPI_OK_UTILITY)
     711           0 :         elog(ERROR, "SPI_exec failed: %s", querybuf.data);
     712             : 
     713             :     /* Start building the query for populating the diff table. */
     714          66 :     resetStringInfo(&querybuf);
     715          66 :     appendStringInfo(&querybuf,
     716             :                      "INSERT INTO %s "
     717             :                      "SELECT mv.ctid AS tid, newdata.*::%s AS newdata "
     718             :                      "FROM %s mv FULL JOIN %s newdata ON (",
     719             :                      diffname, tempname, matviewname, tempname);
     720             : 
     721             :     /*
     722             :      * Get the list of index OIDs for the table from the relcache, and look up
     723             :      * each one in the pg_index syscache.  We will test for equality on all
     724             :      * columns present in all unique indexes which only reference columns and
     725             :      * include all rows.
     726             :      */
     727          66 :     tupdesc = matviewRel->rd_att;
     728          66 :     opUsedForQual = (Oid *) palloc0(sizeof(Oid) * relnatts);
     729          66 :     foundUniqueIndex = false;
     730             : 
     731          66 :     indexoidlist = RelationGetIndexList(matviewRel);
     732             : 
     733         138 :     foreach(indexoidscan, indexoidlist)
     734             :     {
     735          72 :         Oid         indexoid = lfirst_oid(indexoidscan);
     736             :         Relation    indexRel;
     737             : 
     738          72 :         indexRel = index_open(indexoid, RowExclusiveLock);
     739          72 :         if (is_usable_unique_index(indexRel))
     740             :         {
     741          72 :             Form_pg_index indexStruct = indexRel->rd_index;
     742          72 :             int         indnkeyatts = indexStruct->indnkeyatts;
     743             :             oidvector  *indclass;
     744             :             Datum       indclassDatum;
     745             :             int         i;
     746             : 
     747             :             /* Must get indclass the hard way. */
     748          72 :             indclassDatum = SysCacheGetAttrNotNull(INDEXRELID,
     749          72 :                                                    indexRel->rd_indextuple,
     750             :                                                    Anum_pg_index_indclass);
     751          72 :             indclass = (oidvector *) DatumGetPointer(indclassDatum);
     752             : 
     753             :             /* Add quals for all columns from this index. */
     754         160 :             for (i = 0; i < indnkeyatts; i++)
     755             :             {
     756          88 :                 int         attnum = indexStruct->indkey.values[i];
     757          88 :                 Oid         opclass = indclass->values[i];
     758          88 :                 Form_pg_attribute attr = TupleDescAttr(tupdesc, attnum - 1);
     759          88 :                 Oid         attrtype = attr->atttypid;
     760             :                 HeapTuple   cla_ht;
     761             :                 Form_pg_opclass cla_tup;
     762             :                 Oid         opfamily;
     763             :                 Oid         opcintype;
     764             :                 Oid         op;
     765             :                 const char *leftop;
     766             :                 const char *rightop;
     767             : 
     768             :                 /*
     769             :                  * Identify the equality operator associated with this index
     770             :                  * column.  First we need to look up the column's opclass.
     771             :                  */
     772          88 :                 cla_ht = SearchSysCache1(CLAOID, ObjectIdGetDatum(opclass));
     773          88 :                 if (!HeapTupleIsValid(cla_ht))
     774           0 :                     elog(ERROR, "cache lookup failed for opclass %u", opclass);
     775          88 :                 cla_tup = (Form_pg_opclass) GETSTRUCT(cla_ht);
     776             :                 Assert(cla_tup->opcmethod == BTREE_AM_OID);
     777          88 :                 opfamily = cla_tup->opcfamily;
     778          88 :                 opcintype = cla_tup->opcintype;
     779          88 :                 ReleaseSysCache(cla_ht);
     780             : 
     781          88 :                 op = get_opfamily_member(opfamily, opcintype, opcintype,
     782             :                                          BTEqualStrategyNumber);
     783          88 :                 if (!OidIsValid(op))
     784           0 :                     elog(ERROR, "missing operator %d(%u,%u) in opfamily %u",
     785             :                          BTEqualStrategyNumber, opcintype, opcintype, opfamily);
     786             : 
     787             :                 /*
     788             :                  * If we find the same column with the same equality semantics
     789             :                  * in more than one index, we only need to emit the equality
     790             :                  * clause once.
     791             :                  *
     792             :                  * Since we only remember the last equality operator, this
     793             :                  * code could be fooled into emitting duplicate clauses given
     794             :                  * multiple indexes with several different opclasses ... but
     795             :                  * that's so unlikely it doesn't seem worth spending extra
     796             :                  * code to avoid.
     797             :                  */
     798          88 :                 if (opUsedForQual[attnum - 1] == op)
     799           0 :                     continue;
     800          88 :                 opUsedForQual[attnum - 1] = op;
     801             : 
     802             :                 /*
     803             :                  * Actually add the qual, ANDed with any others.
     804             :                  */
     805          88 :                 if (foundUniqueIndex)
     806          28 :                     appendStringInfoString(&querybuf, " AND ");
     807             : 
     808          88 :                 leftop = quote_qualified_identifier("newdata",
     809          88 :                                                     NameStr(attr->attname));
     810          88 :                 rightop = quote_qualified_identifier("mv",
     811          88 :                                                      NameStr(attr->attname));
     812             : 
     813          88 :                 generate_operator_clause(&querybuf,
     814             :                                          leftop, attrtype,
     815             :                                          op,
     816             :                                          rightop, attrtype);
     817             : 
     818          88 :                 foundUniqueIndex = true;
     819             :             }
     820             :         }
     821             : 
     822             :         /* Keep the locks, since we're about to run DML which needs them. */
     823          72 :         index_close(indexRel, NoLock);
     824             :     }
     825             : 
     826          66 :     list_free(indexoidlist);
     827             : 
     828             :     /*
     829             :      * There must be at least one usable unique index on the matview.
     830             :      *
     831             :      * ExecRefreshMatView() checks that after taking the exclusive lock on the
     832             :      * matview. So at least one unique index is guaranteed to exist here
     833             :      * because the lock is still being held.  (One known exception is if a
     834             :      * function called as part of refreshing the matview drops the index.
     835             :      * That's a pretty silly thing to do.)
     836             :      */
     837          66 :     if (!foundUniqueIndex)
     838           6 :         ereport(ERROR,
     839             :                 errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
     840             :                 errmsg("could not find suitable unique index on materialized view"));
     841             : 
     842          60 :     appendStringInfoString(&querybuf,
     843             :                            " AND newdata.* OPERATOR(pg_catalog.*=) mv.*) "
     844             :                            "WHERE newdata.* IS NULL OR mv.* IS NULL "
     845             :                            "ORDER BY tid");
     846             : 
     847             :     /* Populate the temporary "diff" table. */
     848          60 :     if (SPI_exec(querybuf.data, 0) != SPI_OK_INSERT)
     849           0 :         elog(ERROR, "SPI_exec failed: %s", querybuf.data);
     850             : 
     851             :     /*
     852             :      * We have no further use for data from the "full-data" temp table, but we
     853             :      * must keep it around because its type is referenced from the diff table.
     854             :      */
     855             : 
     856             :     /* Analyze the diff table. */
     857          60 :     resetStringInfo(&querybuf);
     858          60 :     appendStringInfo(&querybuf, "ANALYZE %s", diffname);
     859          60 :     if (SPI_exec(querybuf.data, 0) != SPI_OK_UTILITY)
     860           0 :         elog(ERROR, "SPI_exec failed: %s", querybuf.data);
     861             : 
     862          60 :     OpenMatViewIncrementalMaintenance();
     863             : 
     864             :     /* Deletes must come before inserts; do them first. */
     865          60 :     resetStringInfo(&querybuf);
     866          60 :     appendStringInfo(&querybuf,
     867             :                      "DELETE FROM %s mv WHERE ctid OPERATOR(pg_catalog.=) ANY "
     868             :                      "(SELECT diff.tid FROM %s diff "
     869             :                      "WHERE diff.tid IS NOT NULL "
     870             :                      "AND diff.newdata IS NULL)",
     871             :                      matviewname, diffname);
     872          60 :     if (SPI_exec(querybuf.data, 0) != SPI_OK_DELETE)
     873           0 :         elog(ERROR, "SPI_exec failed: %s", querybuf.data);
     874             : 
     875             :     /* Inserts go last. */
     876          60 :     resetStringInfo(&querybuf);
     877          60 :     appendStringInfo(&querybuf,
     878             :                      "INSERT INTO %s SELECT (diff.newdata).* "
     879             :                      "FROM %s diff WHERE tid IS NULL",
     880             :                      matviewname, diffname);
     881          60 :     if (SPI_exec(querybuf.data, 0) != SPI_OK_INSERT)
     882           0 :         elog(ERROR, "SPI_exec failed: %s", querybuf.data);
     883             : 
     884             :     /* We're done maintaining the materialized view. */
     885          60 :     CloseMatViewIncrementalMaintenance();
     886          60 :     table_close(tempRel, NoLock);
     887          60 :     table_close(matviewRel, NoLock);
     888             : 
     889             :     /* Clean up temp tables. */
     890          60 :     resetStringInfo(&querybuf);
     891          60 :     appendStringInfo(&querybuf, "DROP TABLE %s, %s", diffname, tempname);
     892          60 :     if (SPI_exec(querybuf.data, 0) != SPI_OK_UTILITY)
     893           0 :         elog(ERROR, "SPI_exec failed: %s", querybuf.data);
     894             : 
     895             :     /* Close SPI context. */
     896          60 :     if (SPI_finish() != SPI_OK_FINISH)
     897           0 :         elog(ERROR, "SPI_finish failed");
     898          60 : }
     899             : 
     900             : /*
     901             :  * Swap the physical files of the target and transient tables, then rebuild
     902             :  * the target's indexes and throw away the transient table.  Security context
     903             :  * swapping is handled by the called function, so it is not needed here.
     904             :  */
     905             : static void
     906         490 : refresh_by_heap_swap(Oid matviewOid, Oid OIDNewHeap, char relpersistence)
     907             : {
     908         490 :     finish_heap_swap(matviewOid, OIDNewHeap, false, false, true, true,
     909             :                      RecentXmin, ReadNextMultiXactId(), relpersistence);
     910         484 : }
     911             : 
     912             : /*
     913             :  * Check whether specified index is usable for match merge.
     914             :  */
     915             : static bool
     916         156 : is_usable_unique_index(Relation indexRel)
     917             : {
     918         156 :     Form_pg_index indexStruct = indexRel->rd_index;
     919             : 
     920             :     /*
     921             :      * Must be unique, valid, immediate, non-partial, and be defined over
     922             :      * plain user columns (not expressions).  We also require it to be a
     923             :      * btree.  Even if we had any other unique index kinds, we'd not know how
     924             :      * to identify the corresponding equality operator, nor could we be sure
     925             :      * that the planner could implement the required FULL JOIN with non-btree
     926             :      * operators.
     927             :      */
     928         156 :     if (indexStruct->indisunique &&
     929         156 :         indexStruct->indimmediate &&
     930         156 :         indexRel->rd_rel->relam == BTREE_AM_OID &&
     931         312 :         indexStruct->indisvalid &&
     932         156 :         RelationGetIndexPredicate(indexRel) == NIL &&
     933         150 :         indexStruct->indnatts > 0)
     934             :     {
     935             :         /*
     936             :          * The point of groveling through the index columns individually is to
     937             :          * reject both index expressions and system columns.  Currently,
     938             :          * matviews couldn't have OID columns so there's no way to create an
     939             :          * index on a system column; but maybe someday that wouldn't be true,
     940             :          * so let's be safe.
     941             :          */
     942         150 :         int         numatts = indexStruct->indnatts;
     943             :         int         i;
     944             : 
     945         326 :         for (i = 0; i < numatts; i++)
     946             :         {
     947         182 :             int         attnum = indexStruct->indkey.values[i];
     948             : 
     949         182 :             if (attnum <= 0)
     950           6 :                 return false;
     951             :         }
     952         144 :         return true;
     953             :     }
     954           6 :     return false;
     955             : }
     956             : 
     957             : 
     958             : /*
     959             :  * This should be used to test whether the backend is in a context where it is
     960             :  * OK to allow DML statements to modify materialized views.  We only want to
     961             :  * allow that for internal code driven by the materialized view definition,
     962             :  * not for arbitrary user-supplied code.
     963             :  *
     964             :  * While the function names reflect the fact that their main intended use is
     965             :  * incremental maintenance of materialized views (in response to changes to
     966             :  * the data in referenced relations), they are initially used to allow REFRESH
     967             :  * without blocking concurrent reads.
     968             :  */
     969             : bool
     970         120 : MatViewIncrementalMaintenanceIsEnabled(void)
     971             : {
     972         120 :     return matview_maintenance_depth > 0;
     973             : }
     974             : 
     975             : static void
     976          60 : OpenMatViewIncrementalMaintenance(void)
     977             : {
     978          60 :     matview_maintenance_depth++;
     979          60 : }
     980             : 
     981             : static void
     982          60 : CloseMatViewIncrementalMaintenance(void)
     983             : {
     984          60 :     matview_maintenance_depth--;
     985             :     Assert(matview_maintenance_depth >= 0);
     986          60 : }

Generated by: LCOV version 1.14