blob: 71ef7cef7555330af34d442cc886fa6f23742ebe [file] [log] [blame]
/*-------------------------------------------------------------------------
*
* appendonlyam_handler.c
* appendonly table access method code
*
* Portions Copyright (c) 2008, Greenplum Inc
* Portions Copyright (c) 2020-Present VMware, Inc. or its affiliates.
* Portions Copyright (c) 1996-2019, PostgreSQL Global Development Group
* Portions Copyright (c) 1994, Regents of the University of California
*
*
* IDENTIFICATION
* src/backend/access/appendonly/appendonlyam_handler.c
*
*-------------------------------------------------------------------------
*/
#include "postgres.h"
#include "access/aomd.h"
#include "access/appendonlywriter.h"
#include "access/heapam.h"
#include "access/heaptoast.h"
#include "access/multixact.h"
#include "access/reloptions.h"
#include "access/tableam.h"
#include "access/tsmapi.h"
#include "access/xact.h"
#include "catalog/aoseg.h"
#include "catalog/catalog.h"
#include "catalog/heap.h"
#include "catalog/index.h"
#include "catalog/pg_am.h"
#include "catalog/pg_appendonly.h"
#include "catalog/storage.h"
#include "catalog/storage_xlog.h"
#include "cdb/cdbappendonlyam.h"
#include "cdb/cdbvars.h"
#include "commands/progress.h"
#include "commands/vacuum.h"
#include "commands/progress.h"
#include "executor/executor.h"
#include "pgstat.h"
#include "storage/procarray.h"
#include "utils/builtins.h"
#include "utils/faultinjector.h"
#include "utils/lsyscache.h"
#include "utils/pg_rusage.h"
#include "utils/guc.h"
#define IS_BTREE(r) ((r)->rd_rel->relam == BTREE_AM_OID)
extern void finishWriteBlock(AppendOnlyInsertDesc aoInsertDesc);
extern void setupNextWriteBlock(AppendOnlyInsertDesc aoInsertDesc);
extern BlockNumber system_nextsampleblock(SampleScanState *node, BlockNumber nblocks);
static void reset_state_cb(void *arg);
static const TableAmRoutine ao_row_methods;
/*
* Per-relation backend-local DML state for DML or DML-like operations.
*/
typedef struct AppendOnlyDMLState
{
Oid relationOid;
AppendOnlyInsertDesc insertDesc;
AppendOnlyDeleteDesc deleteDesc;
AppendOnlyUniqueCheckDesc uniqueCheckDesc;
/*
* CBDB_PARALLEL
* head: the Head of multiple segment files insertion list.
* insertMultiFiles: number of seg files to be inserted into.
* used_segment_files: used to avoid used files when asking
* for a new segment file.
*/
dlist_head head;
int insertMultiFiles;
List* used_segment_files;
} AppendOnlyDMLState;
/*
* A repository for per-relation backend-local DML states. Contains:
* a quick look up member for the common case (only 1 relation)
* a hash table which keeps per relation information
* a memory context that should be long lived enough and is
* responsible for reseting the state via its reset cb
*/
typedef struct AppendOnlyDMLStates
{
AppendOnlyDMLState *last_used_state;
HTAB *state_table;
MemoryContext stateCxt;
MemoryContextCallback cb;
} AppendOnlyDMLStates;
static AppendOnlyDMLStates appendOnlyDMLStates;
/* ------------------------------------------------------------------------
* DML state related functions
* ------------------------------------------------------------------------
*/
/*
* Initialize the backend local AppendOnlyDMLStates object for this backend for
* the current DML or DML-like command (if not already initialized).
*
* This function should be called with a current memory context whose life
* span is enough to last until the end of this command execution.
*/
static void
init_appendonly_dml_states()
{
HASHCTL hash_ctl;
if (!appendOnlyDMLStates.state_table)
{
Assert(appendOnlyDMLStates.stateCxt == NULL);
appendOnlyDMLStates.stateCxt = AllocSetContextCreate(
CurrentMemoryContext,
"AppendOnly DML State Context",
ALLOCSET_SMALL_SIZES);
appendOnlyDMLStates.cb.func = reset_state_cb;
appendOnlyDMLStates.cb.arg = NULL;
MemoryContextRegisterResetCallback(appendOnlyDMLStates.stateCxt,
&appendOnlyDMLStates.cb);
memset(&hash_ctl, 0, sizeof(hash_ctl));
hash_ctl.keysize = sizeof(Oid);
hash_ctl.entrysize = sizeof(AppendOnlyDMLState);
hash_ctl.hcxt = appendOnlyDMLStates.stateCxt;
appendOnlyDMLStates.state_table =
hash_create("AppendOnly DML state", 128, &hash_ctl,
HASH_CONTEXT | HASH_ELEM | HASH_BLOBS);
}
}
/*
* Create and insert a state entry for a relation. The actual descriptors will
* be created lazily when/if needed.
*
* Should be called exactly once per relation.
*/
static inline void
init_dml_state(const Oid relationOid)
{
AppendOnlyDMLState *state;
bool found;
Assert(appendOnlyDMLStates.state_table);
state = (AppendOnlyDMLState *) hash_search(appendOnlyDMLStates.state_table,
&relationOid,
HASH_ENTER,
&found);
state->insertDesc = NULL;
state->deleteDesc = NULL;
state->uniqueCheckDesc = NULL;
state->insertMultiFiles = 0;
state->used_segment_files = NIL;
dlist_init(&state->head);
Assert(!found);
appendOnlyDMLStates.last_used_state = state;
}
/*
* Retrieve the state information for a relation.
* It is required that the state has been created before hand.
*/
static inline AppendOnlyDMLState *
find_dml_state(const Oid relationOid)
{
AppendOnlyDMLState *state;
Assert(appendOnlyDMLStates.state_table);
if (appendOnlyDMLStates.last_used_state &&
appendOnlyDMLStates.last_used_state->relationOid == relationOid)
return appendOnlyDMLStates.last_used_state;
state = (AppendOnlyDMLState *) hash_search(appendOnlyDMLStates.state_table,
&relationOid,
HASH_FIND,
NULL);
Assert(state);
appendOnlyDMLStates.last_used_state = state;
return state;
}
/*
* Remove the state information for a relation.
* It is required that the state has been created before hand.
*
* Should be called exactly once per relation.
*/
static inline void
remove_dml_state(const Oid relationOid)
{
AppendOnlyDMLState *state;
Assert(appendOnlyDMLStates.state_table);
state = (AppendOnlyDMLState *) hash_search(appendOnlyDMLStates.state_table,
&relationOid,
HASH_REMOVE,
NULL);
if (!state)
return;
if (appendOnlyDMLStates.last_used_state &&
appendOnlyDMLStates.last_used_state->relationOid == relationOid)
appendOnlyDMLStates.last_used_state = NULL;
return;
}
/*
* Although the operation param is superfluous at the momment, the signature of
* the function is such for balance between the init and finish.
*
* This function should be called exactly once per relation.
*/
void
appendonly_dml_init(Relation relation, CmdType operation)
{
init_appendonly_dml_states();
init_dml_state(RelationGetRelid(relation));
}
/*
* This function should be called exactly once per relation.
*/
void
appendonly_dml_finish(Relation relation, CmdType operation)
{
AppendOnlyDMLState *state;
bool had_delete_desc = false;
Oid relationOid = RelationGetRelid(relation);
Assert(appendOnlyDMLStates.state_table);
state = (AppendOnlyDMLState *)hash_search(appendOnlyDMLStates.state_table,
&relationOid,
HASH_FIND,
NULL);
if (!state)
return;
if (state->deleteDesc)
{
appendonly_delete_finish(state->deleteDesc);
state->deleteDesc = NULL;
/*
* Bump up the modcount. If we inserted something (meaning that
* this was an UPDATE), we can skip this, as the insertion bumped
* up the modcount already.
*/
if (!state->insertDesc)
AORelIncrementModCount(relation);
had_delete_desc = true;
}
if (state->insertDesc)
{
Assert(state->insertDesc->aoi_rel == relation);
appendonly_insert_finish(state->insertDesc, &state->head);
state->insertDesc = NULL;
state->insertMultiFiles = 0;
pfree(state->used_segment_files);
state->used_segment_files = NIL;
}
if (state->uniqueCheckDesc)
{
/* clean up the block directory */
AppendOnlyBlockDirectory_End_forUniqueChecks(state->uniqueCheckDesc->blockDirectory);
pfree(state->uniqueCheckDesc->blockDirectory);
state->uniqueCheckDesc->blockDirectory = NULL;
/*
* If this fetch is a part of an update, then we have been reusing the
* visimapDelete used by the delete half of the update, which would have
* already been cleaned up above. Clean up otherwise.
*/
if (!had_delete_desc)
{
AppendOnlyVisimap_Finish_forUniquenessChecks(state->uniqueCheckDesc->visimap);
pfree(state->uniqueCheckDesc->visimap);
}
else
{
/*
* Github issue: https://github.com/apache/cloudberry/issues/557
*
* For partition tables, it's possible to update across partitions.
* And it does have deleteDesc and uniqueCheckDesc if there were.
* Some partitions have visimap but some not, clean them if possible.
*/
if (state->uniqueCheckDesc->visimap)
{
AppendOnlyVisimapStore_Finish(&state->uniqueCheckDesc->visimap->visimapStore, AccessShareLock);
}
}
state->uniqueCheckDesc->visimap = NULL;
state->uniqueCheckDesc->visiMapDelete = NULL;
pfree(state->uniqueCheckDesc);
state->uniqueCheckDesc = NULL;
}
remove_dml_state(relationOid);
}
/*
* There are two cases that we are called from, during context destruction
* after a successful completion and after a transaction abort. Only in the
* second case we should not have cleaned up the DML state and the entries in
* the hash table. We need to reset our global state. The actual clean up is
* taken care elsewhere.
*/
static void
reset_state_cb(void *arg)
{
appendOnlyDMLStates.state_table = NULL;
appendOnlyDMLStates.last_used_state = NULL;
appendOnlyDMLStates.stateCxt = NULL;
}
/*
* Retrieve the insertDescriptor for a relation. Initialize it if needed.
*/
static AppendOnlyInsertDesc
get_insert_descriptor(const Relation relation)
{
AppendOnlyDMLState *state;
AppendOnlyInsertDesc next = NULL;
MemoryContext oldcxt;
state = find_dml_state(RelationGetRelid(relation));
oldcxt = MemoryContextSwitchTo(appendOnlyDMLStates.stateCxt);
if (state->insertDesc == NULL)
{
/*
* CBDB_PARALLEL:
* Should not enable insertMultiFiles if the table is created by own transaction
* or in utility mode.
*/
if (Gp_role != GP_ROLE_UTILITY &&
gp_appendonly_insert_files > 1 &&
!ShouldUseReservedSegno(relation, CHOOSE_MODE_WRITE))
state->insertMultiFiles = gp_appendonly_insert_files;
state->insertDesc= appendonly_insert_init(relation,
ChooseSegnoForWrite(relation));
state->used_segment_files = list_make1_int(state->insertDesc->cur_segno);
dlist_init(&state->head);
dlist_push_tail(&state->head, &state->insertDesc->node);
}
/* switch insertDesc */
if (state->insertMultiFiles && state->insertDesc->range == gp_appendonly_insert_files_tuples_range)
{
state->insertDesc->range = 0;
if (list_length(state->used_segment_files) < state->insertMultiFiles)
{
next = appendonly_insert_init(relation, ChooseSegnoForWriteMultiFile(relation, state->used_segment_files));
dlist_push_tail(&state->head, &next->node);
state->used_segment_files = lappend_int(state->used_segment_files, next->cur_segno);
}
if (!dlist_has_next(&state->head, &state->insertDesc->node))
next = (AppendOnlyInsertDesc)dlist_container(AppendOnlyInsertDescData, node, dlist_head_node(&state->head));
else
next = (AppendOnlyInsertDesc)dlist_container(AppendOnlyInsertDescData, node, dlist_next_node(&state->head, &state->insertDesc->node));
state->insertDesc = next;
}
/*
* If we have a unique index, insert a placeholder block directory row
* to entertain uniqueness checks from concurrent inserts. See
* AppendOnlyBlockDirectory_InsertPlaceholder() for details.
*/
if (relationHasUniqueIndex(relation) && !state->insertDesc->placeholderInserted)
{
AppendOnlyInsertDesc insertDesc = state->insertDesc;
int64 firstRowNum = insertDesc->lastSequence + 1;
BufferedAppend *bufferedAppend = &insertDesc->storageWrite.bufferedAppend;
int64 fileOffset = BufferedAppendNextBufferPosition(bufferedAppend);
AppendOnlyBlockDirectory_InsertPlaceholder(&insertDesc->blockDirectory,
firstRowNum,
fileOffset,
0);
insertDesc->placeholderInserted = true;
}
MemoryContextSwitchTo(oldcxt);
return state->insertDesc;
}
/*
* Retrieve the deleteDescriptor for a relation. Initialize it if needed.
*/
static AppendOnlyDeleteDesc
get_delete_descriptor(const Relation relation, bool forUpdate)
{
AppendOnlyDMLState *state;
state = find_dml_state(RelationGetRelid(relation));
if (state->deleteDesc == NULL)
{
MemoryContext oldcxt;
oldcxt = MemoryContextSwitchTo(appendOnlyDMLStates.stateCxt);
state->deleteDesc = appendonly_delete_init(relation);
MemoryContextSwitchTo(oldcxt);
}
return state->deleteDesc;
}
static AppendOnlyUniqueCheckDesc
get_or_create_unique_check_desc(Relation relation, Snapshot snapshot)
{
AppendOnlyDMLState *state = find_dml_state(RelationGetRelid(relation));
if (!state->uniqueCheckDesc)
{
MemoryContext oldcxt;
AppendOnlyUniqueCheckDesc uniqueCheckDesc;
oldcxt = MemoryContextSwitchTo(appendOnlyDMLStates.stateCxt);
uniqueCheckDesc = palloc0(sizeof(AppendOnlyUniqueCheckDescData));
/* Initialize the block directory */
uniqueCheckDesc->blockDirectory = palloc0(sizeof(AppendOnlyBlockDirectory));
AppendOnlyBlockDirectory_Init_forUniqueChecks(uniqueCheckDesc->blockDirectory,
relation,
1, /* numColGroups */
snapshot);
/*
* If this is part of an UPDATE, we need to reuse the visimapDelete
* support structure from the delete half of the update. This is to
* avoid spurious conflicts when the key's previous and new value are
* identical. Using it ensures that we can recognize any tuples deleted
* by us prior to this insert, within this command.
*
* Note: It is important that we reuse the visimapDelete structure and
* not the visimap structure. This is because, when a uniqueness check
* is performed as part of an UPDATE, visimap changes aren't persisted
* yet (they are persisted at dml_finish() time, see
* AppendOnlyVisimapDelete_Finish()). So, if we use the visimap
* structure, we would not necessarily see all the changes.
*/
if (state->deleteDesc)
{
uniqueCheckDesc->visiMapDelete = &state->deleteDesc->visiMapDelete;
uniqueCheckDesc->visimap = NULL;
}
else
{
/* COPY/INSERT: Initialize the visimap */
uniqueCheckDesc->visimap = palloc0(sizeof(AppendOnlyVisimap));
AppendOnlyVisimap_Init_forUniqueCheck(uniqueCheckDesc->visimap,
relation,
snapshot);
}
state->uniqueCheckDesc = uniqueCheckDesc;
MemoryContextSwitchTo(oldcxt);
}
return state->uniqueCheckDesc;
}
/* ------------------------------------------------------------------------
* Slot related callbacks for appendonly AM
* ------------------------------------------------------------------------
*/
/*
* Appendonly access method uses virtual tuples
*/
static const TupleTableSlotOps *
appendonly_slot_callbacks(Relation relation)
{
return &TTSOpsVirtual;
}
MemTuple
appendonly_form_memtuple(TupleTableSlot *slot, MemTupleBinding *mt_bind)
{
MemTuple result;
MemoryContext oldContext;
/*
* In case of a non virtal tuple, make certain that the slot's values are
* populated, for example during a CTAS.
*/
if (!TTS_IS_VIRTUAL(slot))
slot_getsomeattrs(slot, slot->tts_tupleDescriptor->natts);
oldContext = MemoryContextSwitchTo(slot->tts_mcxt);
result = memtuple_form(mt_bind,
slot->tts_values,
slot->tts_isnull);
MemoryContextSwitchTo(oldContext);
return result;
}
/*
* appendonly_free_memtuple
*/
void
appendonly_free_memtuple(MemTuple tuple)
{
pfree(tuple);
}
/* ------------------------------------------------------------------------
* Parallel aware Seq Scan callbacks for ao_row AM
* ------------------------------------------------------------------------
*/
static Size
appendonly_parallelscan_estimate(Relation rel)
{
return sizeof(ParallelBlockTableScanDescData);
}
/*
* AO only uses part fields of ParallelBlockTableScanDesc.
*/
static Size
appendonly_parallelscan_initialize(Relation rel, ParallelTableScanDesc pscan)
{
ParallelBlockTableScanDesc bpscan = (ParallelBlockTableScanDesc) pscan;
bpscan->base.phs_relid = RelationGetRelid(rel);
bpscan->phs_nblocks = 0; /* init, will be updated later by table_parallelscan_initialize */
pg_atomic_init_u64(&bpscan->phs_nallocated, 0);
/* we don't need phs_mutex and phs_startblock in ao, though, init them. */
SpinLockInit(&bpscan->phs_mutex);
bpscan->phs_startblock = InvalidBlockNumber;
return sizeof(ParallelBlockTableScanDescData);
}
static void
appendonly_parallelscan_reinitialize(Relation rel, ParallelTableScanDesc pscan)
{
ParallelBlockTableScanDesc bpscan = (ParallelBlockTableScanDesc) pscan;
pg_atomic_write_u64(&bpscan->phs_nallocated, 0);
}
/* ------------------------------------------------------------------------
* Seq Scan callbacks for appendonly AM
*
* These are in appendonlyam.c
* ------------------------------------------------------------------------
*/
/* ------------------------------------------------------------------------
* Index Scan Callbacks for appendonly AM
* ------------------------------------------------------------------------
*/
static IndexFetchTableData *
appendonly_index_fetch_begin(Relation rel)
{
IndexFetchAppendOnlyData *aoscan = palloc0(sizeof(IndexFetchAppendOnlyData));
aoscan->xs_base.rel = rel;
/* aoscan->aofetch is initialized lazily on first fetch */
return &aoscan->xs_base;
}
static void
appendonly_index_fetch_reset(IndexFetchTableData *scan)
{
/*
* Unlike Heap, we don't release the resources (fetch descriptor and its
* members) here because it is more like a global data structure shared
* across scans, rather than an iterator to yield a granularity of data.
*
* Additionally, should be aware of that no matter whether allocation or
* release on fetch descriptor, it is considerably expensive.
*/
return;
}
static void
appendonly_index_fetch_end(IndexFetchTableData *scan)
{
IndexFetchAppendOnlyData *aoscan = (IndexFetchAppendOnlyData *) scan;
if (aoscan->aofetch)
{
appendonly_fetch_finish(aoscan->aofetch);
pfree(aoscan->aofetch);
aoscan->aofetch = NULL;
}
pfree(aoscan);
}
static bool
appendonly_index_fetch_tuple(struct IndexFetchTableData *scan,
ItemPointer tid,
Snapshot snapshot,
TupleTableSlot *slot,
bool *call_again, bool *all_dead)
{
IndexFetchAppendOnlyData *aoscan = (IndexFetchAppendOnlyData *) scan;
if (!aoscan->aofetch)
{
Snapshot appendOnlyMetaDataSnapshot;
appendOnlyMetaDataSnapshot = snapshot;
if (appendOnlyMetaDataSnapshot == SnapshotAny)
{
/*
* the append-only meta data should never be fetched with
* SnapshotAny as bogus results are returned.
*/
appendOnlyMetaDataSnapshot = GetTransactionSnapshot();
}
aoscan->aofetch =
appendonly_fetch_init(aoscan->xs_base.rel,
snapshot,
appendOnlyMetaDataSnapshot);
}
/*
* There is no reason to expect changes on snapshot between tuple
* fetching calls after fech_init is called, treat it as a
* programming error in case of occurrence.
*/
Assert(aoscan->aofetch->snapshot == snapshot);
appendonly_fetch(aoscan->aofetch, (AOTupleId *) tid, slot);
/*
* Currently, we don't determine this parameter. By contract, it is to be
* set to true iff we can determine that this row is dead to all
* transactions. Failure to set this will lead to use of a garbage value
* in certain code, such as that for unique index checks.
* This is typically used for HOT chains, which we don't support.
*/
if (all_dead)
*all_dead = false;
/* Currently, we don't determine this parameter. By contract, it is to be
* set to true iff there is another tuple for the tid, so that we can prompt
* the caller to call index_fetch_tuple() again for the same tid.
* This is typically used for HOT chains, which we don't support.
*/
if (call_again)
*call_again = false;
return !TupIsNull(slot);
}
/*
* Check if a visible tuple exists given the tid and a snapshot. This is
* currently used to determine uniqueness checks.
*
* We determine existence simply by checking if a *visible* block directory
* entry covers the given tid.
*
* There is no need to fetch the tuple (we actually can't reliably do so as
* we might encounter a placeholder row in the block directory)
*
* If no visible block directory entry exists, we are done. If it does, we need
* to further check the visibility of the tuple itself by consulting the visimap.
* Now, the visimap check can be skipped if the tuple was found to have been
* inserted by a concurrent in-progress transaction, in which case we return
* true and have the xwait machinery kick in.
*/
static bool
appendonly_index_unique_check(Relation rel,
ItemPointer tid,
Snapshot snapshot,
bool *all_dead)
{
AppendOnlyUniqueCheckDesc uniqueCheckDesc;
AOTupleId *aoTupleId = (AOTupleId *) tid;
bool visible;
#ifdef USE_ASSERT_CHECKING
int segmentFileNum = AOTupleIdGet_segmentFileNum(aoTupleId);
int64 rowNum = AOTupleIdGet_rowNum(aoTupleId);
Assert(segmentFileNum != InvalidFileSegNumber);
Assert(rowNum != InvalidAORowNum);
/*
* Since this can only be called in the context of a unique index check, the
* snapshots that are supplied can only be non-MVCC snapshots: SELF and DIRTY.
*/
Assert(snapshot->snapshot_type == SNAPSHOT_SELF ||
snapshot->snapshot_type == SNAPSHOT_DIRTY);
#endif
/*
* Currently, we don't determine this parameter. By contract, it is to be
* set to true iff we can determine that this row is dead to all
* transactions. Failure to set this will lead to use of a garbage value
* in certain code, such as that for unique index checks.
* This is typically used for HOT chains, which we don't support.
*/
if (all_dead)
*all_dead = false;
/*
* FIXME: for when we want CREATE UNIQUE INDEX CONCURRENTLY to work
* Unique constraint violation checks with SNAPSHOT_SELF are currently
* required to support CREATE UNIQUE INDEX CONCURRENTLY. Currently, the
* sole placeholder row inserted at first insert might not be visible to
* the snapshot, if it was already updated by its actual first row. So,
* we would need to flush a placeholder row at the beginning of each new
* in-memory minipage. Currently, CREATE INDEX CONCURRENTLY isn't
* supported, so we assume such a check satisfies SNAPSHOT_SELF.
*/
if (snapshot->snapshot_type == SNAPSHOT_SELF)
return true;
uniqueCheckDesc = get_or_create_unique_check_desc(rel, snapshot);
/* First, scan the block directory */
if (!AppendOnlyBlockDirectory_UniqueCheck(uniqueCheckDesc->blockDirectory,
aoTupleId,
snapshot))
return false;
/*
* If the xmin or xmax are set for the dirty snapshot, after the block
* directory is scanned with the snapshot, it means that there is a
* concurrent in-progress transaction inserting the tuple. So, return true
* and have the xwait machinery kick in.
*/
Assert(snapshot->snapshot_type == SNAPSHOT_DIRTY);
if (TransactionIdIsValid(snapshot->xmin) || TransactionIdIsValid(snapshot->xmax))
return true;
/* Now, perform a visibility check against the visimap infrastructure */
visible = AppendOnlyVisimap_UniqueCheck(uniqueCheckDesc->visiMapDelete,
uniqueCheckDesc->visimap,
aoTupleId,
snapshot);
/*
* Since we disallow deletes and updates running in parallel with inserts,
* there is no way that the dirty snapshot has it's xmin and xmax populated
* after the visimap has been scanned with it.
*
* Note: we disallow it by grabbing an ExclusiveLock on the QD (See
* CdbTryOpenTable()). So if we are running in utility mode, there is no
* such restriction.
*/
AssertImply(Gp_role != GP_ROLE_UTILITY,
(!TransactionIdIsValid(snapshot->xmin) && !TransactionIdIsValid(snapshot->xmax)));
return visible;
}
/* ------------------------------------------------------------------------
* Callbacks for non-modifying operations on individual tuples for
* appendonly AM
* ------------------------------------------------------------------------
*/
static bool
appendonly_fetch_row_version(Relation relation,
ItemPointer tid,
Snapshot snapshot,
TupleTableSlot *slot)
{
/*
* This is a generic interface. It is currently used in three distinct
* cases, only one of which is currently invoking it for AO tables.
* This is DELETE RETURNING. In order to return the slot via the tid for
* AO tables one would have to scan the block directory and the visibility
* map. A block directory is not guarranteed to exist. Even if it exists, a
* state would have to be created and dropped for every tuple look up since
* this interface does not allow for the state to be passed around. This is
* a very costly operation to be performed per tuple lookup. Furthermore, if
* a DELETE operation is currently on the fly, the corresponding visibility
* map entries will not have been finalized into a visibility map tuple.
*
* Error out with feature not supported. Given that this is a generic
* interface, we can not really say which feature is that, although we do
* know that is DELETE RETURNING.
*/
ereport(ERROR,
(errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
errmsg("feature not supported on appendoptimized relations")));
}
static void
appendonly_get_latest_tid(TableScanDesc sscan,
ItemPointer tid)
{
/*
* Tid scans are not supported for appendoptimized relation. This function
* should not have been called in the first place, but if it is called,
* better to error out.
*/
ereport(ERROR,
(errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
errmsg("feature not supported on appendoptimized relations")));
}
static bool
appendonly_tuple_tid_valid(TableScanDesc scan, ItemPointer tid)
{
/*
* Tid scans are not supported for appendoptimized relation. This function
* should not have been called in the first place, but if it is called,
* better to error out.
*/
ereport(ERROR,
(errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
errmsg("feature not supported on appendoptimized relations")));
}
static bool
appendonly_tuple_satisfies_snapshot(Relation rel, TupleTableSlot *slot,
Snapshot snapshot)
{
/*
* AO table dose not support unique and tidscan yet.
*/
ereport(ERROR,
(errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
errmsg("feature not supported on appendoptimized relations")));
}
static TransactionId
appendonly_index_delete_tuples(Relation rel,
TM_IndexDeleteOp *delstate)
{
/*
* This API is only useful for hot standby snapshot conflict resolution
* (for eg. see btree_xlog_delete()), in the context of index page-level
* vacuums (aka page-level cleanups). This operation is only done when
* IndexScanDesc->kill_prior_tuple is true, which is never for AO/CO tables
* (we always return all_dead = false in the index_fetch_tuple() callback
* as we don't support HOT)
*/
ereport(ERROR,
(errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
errmsg("feature not supported on appendoptimized relations")));
}
/* ----------------------------------------------------------------------------
* Functions for manipulations of physical tuples for appendonly AM.
* ----------------------------------------------------------------------------
*/
static void
appendonly_tuple_insert(Relation relation, TupleTableSlot *slot, CommandId cid,
int options, BulkInsertState bistate)
{
AppendOnlyInsertDesc insertDesc;
MemTuple mtuple;
insertDesc = get_insert_descriptor(relation);
mtuple = appendonly_form_memtuple(slot, insertDesc->mt_bind);
/* Update the tuple with table oid */
slot->tts_tableOid = RelationGetRelid(relation);
/* Perform the insertion, and copy the resulting ItemPointer */
appendonly_insert(insertDesc, mtuple, (AOTupleId *) &slot->tts_tid);
pgstat_count_heap_insert(relation, 1);
appendonly_free_memtuple(mtuple);
}
/*
* We don't support speculative inserts on appendoptimized tables, i.e. we don't
* support INSERT ON CONFLICT DO NOTHING or INSERT ON CONFLICT DO UPDATE. Thus,
* the following functions are left unimplemented.
*/
static void
appendonly_tuple_insert_speculative(Relation relation, TupleTableSlot *slot,
CommandId cid, int options,
BulkInsertState bistate, uint32 specToken)
{
ereport(ERROR,
(errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
errmsg("speculative insert is not supported on appendoptimized relations")));
}
static void
appendonly_tuple_complete_speculative(Relation relation, TupleTableSlot *slot,
uint32 specToken, bool succeeded)
{
ereport(ERROR,
(errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
errmsg("speculative insert is not supported on appendoptimized relations")));
}
/*
* appendonly_multi_insert - insert multiple tuples into an ao relation
*
* This is like appendonly_tuple_insert(), but inserts multiple tuples in one
* operation. Typicaly used by COPY. This is preferrable than calling
* appendonly_tuple_insert() in a loop because ... WAL??
*/
static void
appendonly_multi_insert(Relation relation, TupleTableSlot **slots, int ntuples,
CommandId cid, int options, BulkInsertState bistate)
{
AppendOnlyInsertDesc insertDesc;
AppendOnlyDMLState *state;
MemTuple *mtuple;
int ndone = 0;
int nthisBlock = 0;
insertDesc = get_insert_descriptor(relation);
state = find_dml_state(RelationGetRelid(relation));
Oid tableOid = RelationGetRelid(relation);
mtuple = palloc(ntuples * sizeof(MemTuple));
for (int i = 0; i < ntuples; i++)
{
mtuple[i] = appendonly_form_memtuple(slots[i], insertDesc->mt_bind);
slots[i]->tts_tableOid = tableOid;
}
while (ndone < ntuples)
{
/*
* For bulk insert, we may switch insertDesc
* on the fly.
*/
if (state->insertMultiFiles && state->insertDesc->range == gp_appendonly_insert_files_tuples_range)
{
insertDesc = get_insert_descriptor(relation);
}
appendonly_insert(insertDesc, mtuple[ndone], (AOTupleId *) &slots[ndone]->tts_tid);
for (nthisBlock = 1; ndone + nthisBlock < ntuples; nthisBlock++)
{
if (insertDesc->useNoToast)
{
/*
* This is a hack way to insert into AO of CBDB.
* Check switch insertDesc again.
*/
if (state->insertMultiFiles && state->insertDesc->range == gp_appendonly_insert_files_tuples_range)
{
insertDesc = get_insert_descriptor(relation);
}
MemTuple tup = mtuple[ndone + nthisBlock] ;
uint8 *itemPtr = NULL;
VarBlockByteLen itemLen;
itemLen = memtuple_get_size(tup);
if (VarBlockMakerItemCount(&insertDesc->varBlockMaker) >= AOSmallContentHeader_MaxRowCount)
{
// Need Write out the current VarBlock to make room.
finishWriteBlock(insertDesc);
Assert(insertDesc->nonCompressedData == NULL);
Assert(!AppendOnlyStorageWrite_IsBufferAllocated(&insertDesc->storageWrite));
setupNextWriteBlock(insertDesc);
itemPtr = VarBlockMakerGetNextItemPtr(&insertDesc->varBlockMaker, itemLen);
break;
}
else
itemPtr = VarBlockMakerGetNextItemPtr(&insertDesc->varBlockMaker, itemLen);
if (itemLen > 0 && itemPtr != NULL )
{
memcpy(itemPtr, tup, itemLen);
insertDesc->insertCount++;
insertDesc->range++;
insertDesc->lastSequence++;
if (insertDesc->numSequences > 0)
(insertDesc->numSequences)--;
Assert(insertDesc->numSequences >= 0);
AOTupleId *aoTupleId = (AOTupleId *)&slots[ndone + nthisBlock]->tts_tid;
AOTupleIdInit(aoTupleId, insertDesc->cur_segno, insertDesc->lastSequence);
if (insertDesc->numSequences == 0)
{
int64 firstSequence;
Oid segrelid;
GetAppendOnlyEntryAuxOids(insertDesc->aoi_rel, &segrelid, NULL, NULL, NULL, NULL);
firstSequence = GetFastSequences(segrelid, insertDesc->cur_segno, insertDesc->lastSequence + 1, NUM_FAST_SEQUENCES);
Assert(firstSequence == insertDesc->lastSequence + 1);
insertDesc->numSequences = NUM_FAST_SEQUENCES;
}
elogif(Debug_appendonly_print_insert_tuple, LOG,
"Append-only insert tuple for table '%s' "
"(AOTupleId %s, memtuple length %d, isLargeRow %s, block count " INT64_FORMAT ")",
NameStr(insertDesc->aoi_rel->rd_rel->relname),
AOTupleIdToString(aoTupleId),
itemLen,
"false",
insertDesc->bufferCount);
}
else
{
break;
}
}
else
{
break;
}
}
ndone += nthisBlock;
}
pgstat_count_heap_insert(relation, ntuples);
for (int i = 0; i < ntuples; i++)
appendonly_free_memtuple(mtuple[i]);
pfree(mtuple);
}
static TM_Result
appendonly_tuple_delete(Relation relation, ItemPointer tid, CommandId cid,
Snapshot snapshot, Snapshot crosscheck, bool wait,
TM_FailureData *tmfd, bool changingPart)
{
AppendOnlyDeleteDesc deleteDesc;
TM_Result result;
deleteDesc = get_delete_descriptor(relation, false);
result = appendonly_delete(deleteDesc, (AOTupleId *) tid);
if (result == TM_Ok)
pgstat_count_heap_delete(relation);
else if (result == TM_SelfModified)
{
/*
* The visibility map entry has been set and it was in this command.
*
* Our caller might want to investigate tmfd to decide on appropriate
* action. Set it here to match expectations. The uglyness here is
* preferrable to having to inspect the relation's am in the caller.
*/
tmfd->cmax = cid;
}
return result;
}
static TM_Result
appendonly_tuple_update(Relation relation, ItemPointer otid, TupleTableSlot *slot,
CommandId cid, Snapshot snapshot, Snapshot crosscheck,
bool wait, TM_FailureData *tmfd,
LockTupleMode *lockmode, TU_UpdateIndexes *update_indexes)
{
AppendOnlyInsertDesc insertDesc;
AppendOnlyDeleteDesc deleteDesc;
MemTuple mtuple;
TM_Result result;
/* should disable insert multilfiles for update? */
insertDesc = get_insert_descriptor(relation);
deleteDesc = get_delete_descriptor(relation, true);
/* Update the tuple with table oid */
slot->tts_tableOid = RelationGetRelid(relation);
mtuple = appendonly_form_memtuple(slot, insertDesc->mt_bind);
#ifdef FAULT_INJECTOR
FaultInjector_InjectFaultIfSet(
"appendonly_update",
DDLNotSpecified,
"", //databaseName
RelationGetRelationName(insertDesc->aoi_rel));
/* tableName */
#endif
result = appendonly_delete(deleteDesc, (AOTupleId *) otid);
if (result != TM_Ok)
return result;
appendonly_insert(insertDesc, mtuple, (AOTupleId *) &slot->tts_tid);
pgstat_count_heap_update(relation, false, false);
/* No HOT updates with AO tables. */
*update_indexes = TU_All;
appendonly_free_memtuple(mtuple);
return result;
}
/*
* This API is called for a variety of purposes, which are either not supported
* for AO/CO tables or not supported for GPDB in general:
*
* (1) UPSERT: ExecOnConflictUpdate() calls this, but clearly upsert is not
* supported for AO/CO tables.
*
* (2) DELETE and UPDATE triggers: GetTupleForTrigger() calls this, but clearly
* these trigger types are not supported for AO/CO tables.
*
* (3) Logical replication: RelationFindReplTupleByIndex() and
* RelationFindReplTupleSeq() calls this, but clearly we don't support logical
* replication yet for GPDB.
*
* (4) For DELETEs/UPDATEs, when a state of TM_Updated is returned from
* table_tuple_delete() and table_tuple_update() respectively, this API is invoked.
* However, that is impossible for AO/CO tables as an AO/CO tuple cannot be
* deleted/updated while another transaction is updating it (see CdbTryOpenTable()).
*
* (5) Row-level locking (SELECT FOR ..): ExecLockRows() calls this but a plan
* containing the LockRows plan node is never generated for AO/CO tables. In fact,
* we lock at the table level instead.
*/
static TM_Result
appendonly_tuple_lock(Relation relation, ItemPointer tid, Snapshot snapshot,
TupleTableSlot *slot, CommandId cid, LockTupleMode mode,
LockWaitPolicy wait_policy, uint8 flags,
TM_FailureData *tmfd)
{
ereport(ERROR,
(errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
errmsg("tuple locking is not supported on appendoptimized tables")));
}
static void
appendonly_finish_bulk_insert(Relation relation, int options)
{
appendonly_dml_finish(relation, CMD_INSERT);
}
/* helper routine to call open a rel and call heap_truncate_one_rel() on it */
static void
heap_truncate_one_relid(Oid relid)
{
if (OidIsValid(relid))
{
Relation rel = relation_open(relid, AccessExclusiveLock);
heap_truncate_one_rel(rel);
relation_close(rel, NoLock);
}
}
/* ------------------------------------------------------------------------
* DDL related callbacks for appendonly AM.
* ------------------------------------------------------------------------
*/
static void
appendonly_relation_set_new_filenode(Relation rel,
const RelFileLocator *newrnode,
char persistence,
TransactionId *freezeXid,
MultiXactId *minmulti)
{
SMgrRelation srel;
/*
* Append-optimized tables do not contain transaction information in
* tuples.
*/
*freezeXid = *minmulti = InvalidTransactionId;
/*
* No special treatment is needed for new AO_ROW/COLUMN relation. Create
* the underlying disk file storage for the relation. No clean up is
* needed, RelationCreateStorage() is transactional.
*
* Segment files will be created when / if needed.
*/
srel = RelationCreateStorage(*newrnode, persistence, true, SMGR_AO, rel);
/*
* If required, set up an init fork for an unlogged table so that it can
* be correctly reinitialized on restart. An immediate sync is required
* even if the page has been logged, because the write did not go through
* shared_buffers and therefore a concurrent checkpoint may have moved the
* redo pointer past our xlog record. Recovery may as well remove it
* while replaying, for example, XLOG_DBASE_CREATE or XLOG_TBLSPC_CREATE
* record. Therefore, logging is necessary even if wal_level=minimal.
*/
if (persistence == RELPERSISTENCE_UNLOGGED)
{
Assert(rel->rd_rel->relkind == RELKIND_RELATION ||
rel->rd_rel->relkind == RELKIND_MATVIEW ||
rel->rd_rel->relkind == RELKIND_DIRECTORY_TABLE ||
rel->rd_rel->relkind == RELKIND_TOASTVALUE);
smgrcreate(srel, INIT_FORKNUM, false);
log_smgrcreate(newrnode, INIT_FORKNUM, SMGR_AO);
smgrimmedsync(srel, INIT_FORKNUM);
}
smgrclose(srel);
}
static void
appendonly_relation_nontransactional_truncate(Relation rel)
{
Oid aoseg_relid = InvalidOid;
Oid aoblkdir_relid = InvalidOid;
Oid aovisimap_relid = InvalidOid;
ao_truncate_one_rel(rel);
/* Also truncate the aux tables */
GetAppendOnlyEntryAuxOids(rel,
&aoseg_relid,
&aoblkdir_relid, NULL,
&aovisimap_relid, NULL);
heap_truncate_one_relid(aoseg_relid);
heap_truncate_one_relid(aoblkdir_relid);
heap_truncate_one_relid(aovisimap_relid);
}
static void
appendonly_relation_copy_data(Relation rel, const RelFileLocator *newrnode)
{
SMgrRelation dstrel;
/*
* Use the "AO-specific" (non-shared buffers backed storage) SMGR
* implementation
*/
dstrel = smgropen(*newrnode, rel->rd_backend, SMGR_AO, rel);
/*
* Create and copy all forks of the relation, and schedule unlinking of
* old physical files.
*
* NOTE: any conflict in relfilenode value will be caught in
* RelationCreateStorage().
*/
RelationCreateStorage(*newrnode, rel->rd_rel->relpersistence, SMGR_AO, true, rel);
copy_append_only_data(rel->rd_locator, *newrnode, RelationGetSmgr(rel), dstrel,
rel->rd_backend, rel->rd_rel->relpersistence);
/*
* For append-optimized tables, no forks other than the main fork should
* exist with the exception of unlogged tables. For unlogged AO tables,
* INIT_FORK must exist.
*/
if (rel->rd_rel->relpersistence == RELPERSISTENCE_UNLOGGED)
{
Assert (smgrexists(rel->rd_smgr, INIT_FORKNUM));
/*
* INIT_FORK is empty, creating it is sufficient, no need to copy
* contents from source to destination.
*/
smgrcreate(dstrel, INIT_FORKNUM, false);
log_smgrcreate(newrnode, INIT_FORKNUM, SMGR_AO);
}
/* drop old relation, and close new one */
RelationDropStorage(rel);
smgrclose(dstrel);
}
static void
appendonly_vacuum_rel(Relation onerel, VacuumParams *params,
BufferAccessStrategy bstrategy)
{
/*
* We VACUUM an AO_ROW table through multiple phases. vacuum_rel()
* orchestrates the phases and calls itself again for each phase, so we
* get here for every phase. ao_vacuum_rel() is a wrapper of dedicated
* ao_vacuum_rel_*() functions for the specific phases.
*/
ao_vacuum_rel(onerel, params, bstrategy);
return;
}
static void
appendonly_relation_copy_for_cluster(Relation OldHeap, Relation NewHeap,
Relation OldIndex, bool use_sort,
TransactionId OldestXmin,
TransactionId *xid_cutoff,
MultiXactId *multi_cutoff,
double *num_tuples,
double *tups_vacuumed,
double *tups_recently_dead)
{
TupleDesc oldTupDesc;
TupleDesc newTupDesc;
int natts;
Datum *values;
bool *isnull;
TransactionId FreezeXid;
MultiXactId MultiXactCutoff;
Tuplesortstate *tuplesort;
PGRUsage ru0;
AOTupleId aoTupleId;
AppendOnlyInsertDesc aoInsertDesc = NULL;
MemTupleBinding* mt_bind = NULL;
int write_seg_no;
MemTuple mtuple = NULL;
TupleTableSlot *slot;
TableScanDesc aoscandesc;
pg_rusage_init(&ru0);
/*
* Curently AO storage lacks cost model for IndexScan, thus IndexScan
* is not functional. In future, probably, this will be fixed and CLUSTER
* command will support this. Though, random IO over AO on TID stream
* can be impractical anyway.
* Here we are sorting data on on the lines of heap tables, build a tuple
* sort state and sort the entire AO table using the index key, rewrite
* the table, one tuple at a time, in order as returned by tuple sort state.
*/
if (OldIndex == NULL || !IS_BTREE(OldIndex))
ereport(ERROR,
(errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
errmsg("cannot cluster append-optimized table \"%s\"", RelationGetRelationName(OldHeap)),
errdetail("Append-optimized tables can only be clustered against a B-tree index")));
/*
* Their tuple descriptors should be exactly alike, but here we only need
* assume that they have the same number of columns.
*/
oldTupDesc = RelationGetDescr(OldHeap);
newTupDesc = RelationGetDescr(NewHeap);
Assert(newTupDesc->natts == oldTupDesc->natts);
/* Preallocate values/isnull arrays to deform heap tuples after sort */
natts = newTupDesc->natts;
values = (Datum *) palloc(natts * sizeof(Datum));
isnull = (bool *) palloc(natts * sizeof(bool));
/*
* If the OldHeap has a toast table, get lock on the toast table to keep
* it from being vacuumed. This is needed because autovacuum processes
* toast tables independently of their main tables, with no lock on the
* latter. If an autovacuum were to start on the toast table after we
* compute our OldestXmin below, it would use a later OldestXmin, and then
* possibly remove as DEAD toast tuples belonging to main tuples we think
* are only RECENTLY_DEAD. Then we'd fail while trying to copy those
* tuples.
*
* We don't need to open the toast relation here, just lock it. The lock
* will be held till end of transaction.
*/
if (OldHeap->rd_rel->reltoastrelid)
LockRelationOid(OldHeap->rd_rel->reltoastrelid, AccessExclusiveLock);
/* use_wal off requires smgr_targblock be initially invalid */
Assert(RelationGetTargetBlock(NewHeap) == InvalidBlockNumber);
/*
* Compute sane values for FreezeXid and CutoffMulti with regular
* VACUUM machinery to avoidconfising existing CLUSTER code.
*/
vacuum_set_xid_limits(OldHeap, 0, 0, 0, 0,
&OldestXmin, &FreezeXid, NULL, &MultiXactCutoff,
NULL);
/*
* FreezeXid will become the table's new relfrozenxid, and that mustn't go
* backwards, so take the max.
*/
if (TransactionIdPrecedes(FreezeXid, OldHeap->rd_rel->relfrozenxid))
FreezeXid = OldHeap->rd_rel->relfrozenxid;
/*
* MultiXactCutoff, similarly, shouldn't go backwards either.
*/
if (MultiXactIdPrecedes(MultiXactCutoff, OldHeap->rd_rel->relminmxid))
MultiXactCutoff = OldHeap->rd_rel->relminmxid;
/* return selected values to caller */
*xid_cutoff = FreezeXid;
*multi_cutoff = MultiXactCutoff;
tuplesort = tuplesort_begin_cluster(oldTupDesc, OldIndex,
maintenance_work_mem, NULL, false);
/* Log what we're doing */
ereport(DEBUG2,
(errmsg("clustering \"%s.%s\" using sequential scan and sort",
get_namespace_name(RelationGetNamespace(OldHeap)),
RelationGetRelationName(OldHeap))));
/* Scan through old table to convert data into tuples for sorting */
slot = table_slot_create(OldHeap, NULL);
aoscandesc = appendonly_beginscan(OldHeap, GetActiveSnapshot(), 0, NULL,
NULL, 0);
mt_bind = create_memtuple_binding(oldTupDesc);
while (appendonly_getnextslot(aoscandesc, ForwardScanDirection, slot))
{
Datum *slot_values;
bool *slot_isnull;
HeapTuple tuple;
CHECK_FOR_INTERRUPTS();
/* Extract all the values of the tuple */
slot_getallattrs(slot);
slot_values = slot->tts_values;
slot_isnull = slot->tts_isnull;
tuple = heap_form_tuple(oldTupDesc, slot_values, slot_isnull);
*num_tuples += 1;
tuplesort_putheaptuple(tuplesort, tuple);
heap_freetuple(tuple);
}
ExecDropSingleTupleTableSlot(slot);
appendonly_endscan(aoscandesc);
/*
* Сomplete the sort, then read out all tuples
* from the tuplestore and write them to the new relation.
*/
tuplesort_performsort(tuplesort);
write_seg_no = ChooseSegnoForWrite(NewHeap);
aoInsertDesc = appendonly_insert_init(NewHeap, write_seg_no);
/* Insert sorted heap tuples into new storage */
for (;;)
{
HeapTuple tuple;
uint32 len;
uint32 null_save_len;
bool has_nulls;
CHECK_FOR_INTERRUPTS();
tuple = tuplesort_getheaptuple(tuplesort, true);
if (tuple == NULL)
break;
heap_deform_tuple(tuple, oldTupDesc, values, isnull);
len = compute_memtuple_size(mt_bind, values, isnull, &null_save_len, &has_nulls);
if (len > 0)
{
if (mtuple != NULL)
pfree(mtuple);
mtuple = NULL;
}
mtuple = memtuple_form_to(mt_bind, values, isnull, len, null_save_len, has_nulls, mtuple);
appendonly_insert(aoInsertDesc, mtuple, &aoTupleId);
}
tuplesort_end(tuplesort);
/* Finish and deallocate insertion */
appendonly_insert_finish(aoInsertDesc, NULL);
}
static bool
appendonly_scan_analyze_next_block(TableScanDesc scan, BlockNumber blockno,
BufferAccessStrategy bstrategy)
{
AppendOnlyScanDesc aoscan = (AppendOnlyScanDesc) scan;
aoscan->targetTupleId = blockno;
return true;
}
static bool
appendonly_scan_analyze_next_tuple(TableScanDesc scan, TransactionId OldestXmin,
double *liverows, double *deadrows,
TupleTableSlot *slot)
{
AppendOnlyScanDesc aoscan = (AppendOnlyScanDesc) scan;
bool ret = false;
/* skip several tuples if they are not sampling target */
while (!aoscan->aos_done_all_segfiles
&& aoscan->targetTupleId > aoscan->nextTupleId)
{
appendonly_getnextslot(scan, ForwardScanDirection, slot);
aoscan->nextTupleId++;
}
if (!aoscan->aos_done_all_segfiles
&& aoscan->targetTupleId == aoscan->nextTupleId)
{
ret = appendonly_getnextslot(scan, ForwardScanDirection, slot);
aoscan->nextTupleId++;
if (ret)
*liverows += 1;
else
*deadrows += 1; /* if return an invisible tuple */
}
return ret;
}
static double
appendonly_index_build_range_scan(Relation heapRelation,
Relation indexRelation,
IndexInfo *indexInfo,
bool allow_sync,
bool anyvisible,
bool progress,
BlockNumber start_blockno,
BlockNumber numblocks,
IndexBuildCallback callback,
void *callback_state,
TableScanDesc scan)
{
AppendOnlyScanDesc aoscan;
bool is_system_catalog;
bool checking_uniqueness;
Datum values[INDEX_MAX_KEYS];
bool isnull[INDEX_MAX_KEYS];
double reltuples;
ExprState *predicate;
TupleTableSlot *slot;
EState *estate;
ExprContext *econtext;
Snapshot snapshot;
FileSegInfo **seginfo = NULL;
int segfile_count = 0;
int64 total_blockcount = 0;
int64 previous_blkno = -1;
/*
* sanity checks
*/
Assert(OidIsValid(indexRelation->rd_rel->relam));
/* Remember if it's a system catalog */
is_system_catalog = IsSystemRelation(heapRelation);
/* Appendoptimized catalog tables are not supported. */
Assert(!is_system_catalog);
/* Appendoptimized tables have no data on master unless we are in singlenode mode. */
if (IS_QUERY_DISPATCHER() && !IS_SINGLENODE())
return 0;
/* See whether we're verifying uniqueness/exclusion properties */
checking_uniqueness = (indexInfo->ii_Unique ||
indexInfo->ii_ExclusionOps != NULL);
/*
* "Any visible" mode is not compatible with uniqueness checks; make sure
* only one of those is requested.
*/
Assert(!(anyvisible && checking_uniqueness));
/*
* Need an EState for evaluation of index expressions and partial-index
* predicates. Also a slot to hold the current tuple.
*/
estate = CreateExecutorState();
econtext = GetPerTupleExprContext(estate);
slot = table_slot_create(heapRelation, NULL);
/* Arrange for econtext's scan tuple to be the tuple under test */
econtext->ecxt_scantuple = slot;
/* Set up execution state for predicate, if any. */
predicate = ExecPrepareQual(indexInfo->ii_Predicate, estate);
if (!scan)
{
/*
* Serial index build.
*
* XXX: We always use SnapshotAny here. An MVCC snapshot and oldest xmin
* calculation is necessary to support indexes built CONCURRENTLY.
*/
snapshot = SnapshotAny;
scan = table_beginscan_strat(heapRelation, /* relation */
snapshot, /* snapshot */
0, /* number of keys */
NULL, /* scan key */
true, /* buffer access strategy OK */
allow_sync); /* syncscan OK? */
}
else
{
/*
* Parallel index build.
*
* Parallel case never registers/unregisters own snapshot. Snapshot
* is taken from parallel heap scan, and is SnapshotAny or an MVCC
* snapshot, based on same criteria as serial case.
*/
Assert(!IsBootstrapProcessingMode());
Assert(allow_sync);
snapshot = scan->rs_snapshot;
}
aoscan = (AppendOnlyScanDesc) scan;
/*
* If block directory is empty, it must also be built along with the index.
*/
Oid blkdirrelid;
Oid blkidxrelid;
GetAppendOnlyEntryAuxOids(aoscan->aos_rd, NULL,
&blkdirrelid, &blkidxrelid, NULL, NULL);
/*
* Note that block directory is created during creation of the first
* index. If it is found empty, it means the block directory was created
* by this create index transaction. The caller (DefineIndex) must have
* acquired sufficiently strong lock on the appendoptimized table such
* that index creation as well as insert from concurrent transactions are
* blocked. We can rest assured of exclusive access to the block
* directory relation.
*/
Relation blkdir = relation_open(blkdirrelid, AccessShareLock);
if (RelationGetNumberOfBlocks(blkdir) == 0)
{
/*
* Allocate blockDirectory in scan descriptor to let the access method
* know that it needs to also build the block directory while
* scanning.
*/
Assert(aoscan->blockDirectory == NULL);
aoscan->blockDirectory = palloc0(sizeof(AppendOnlyBlockDirectory));
}
relation_close(blkdir, NoLock);
/*
* When Parallel index build,there is no additional operation to update the number of tuples
* that supports this logic. Uniform processing is used here.
*/
if (progress)
{
FileSegTotals *fileSegTotals;
BlockNumber totalBlocks;
fileSegTotals = GetSegFilesTotals(heapRelation, aoscan->appendOnlyMetaDataSnapshot);
Assert(fileSegTotals->totalbytes >= 0);
totalBlocks =
RelationGuessNumberOfBlocksFromSize((uint64) fileSegTotals->totalbytes);
pgstat_progress_update_param(PROGRESS_SCAN_BLOCKS_TOTAL,
totalBlocks);
}
/* set our scan endpoints */
if (!allow_sync)
{
}
else
{
/* syncscan can only be requested on whole relation */
Assert(start_blockno == 0);
Assert(numblocks == InvalidBlockNumber);
}
reltuples = 0;
/*
* Scan all tuples in the base relation.
*/
while (appendonly_getnextslot(&aoscan->rs_base, ForwardScanDirection, slot))
{
bool tupleIsAlive;
AOTupleId *aoTupleId;
BlockNumber currblockno = ItemPointerGetBlockNumber(&slot->tts_tid);
CHECK_FOR_INTERRUPTS();
/*
* GPDB_12_MERGE_FIXME: How to properly do a partial scan? Currently,
* we scan the whole table, and throw away tuples that are not in the
* range. That's clearly very inefficient.
*/
if (currblockno < start_blockno ||
(numblocks != InvalidBlockNumber && currblockno >= (start_blockno + numblocks)))
continue;
/* Report scan progress, if asked to. */
if (progress)
{
int64 current_blkno =
RelationGuessNumberOfBlocksFromSize(aoscan->totalBytesRead);
/* XXX: How can we report for builds with parallel scans? */
Assert(!aoscan->rs_base.rs_parallel);
/* As soon as a new block starts, report it as scanned */
if (current_blkno != previous_blkno)
{
pgstat_progress_update_param(PROGRESS_SCAN_BLOCKS_DONE,
current_blkno);
previous_blkno = current_blkno;
}
}
aoTupleId = (AOTupleId *) &slot->tts_tid;
/*
* We didn't perform the check to see if the tuple was deleted in
* appendonlygettup(), since we passed it SnapshotAny. See
* appendonlygettup() for details. We need to do this to avoid spurious
* conflicts with deleted tuples for unique index builds.
*/
if (AppendOnlyVisimap_IsVisible(&aoscan->visibilityMap, aoTupleId))
{
tupleIsAlive = true;
reltuples += 1;
}
else
tupleIsAlive = false; /* excluded from unique-checking */
MemoryContextReset(econtext->ecxt_per_tuple_memory);
/*
* In a partial index, discard tuples that don't satisfy the
* predicate.
*/
if (predicate != NULL)
{
if (!ExecQual(predicate, econtext))
continue;
}
/*
* For the current heap tuple, extract all the attributes we use in
* this index, and note which are null. This also performs evaluation
* of any expressions needed.
*/
FormIndexDatum(indexInfo,
slot,
estate,
values,
isnull);
/*
* You'd think we should go ahead and build the index tuple here, but
* some index AMs want to do further processing on the data first. So
* pass the values[] and isnull[] arrays, instead.
*/
/* Call the AM's callback routine to process the tuple */
/*
* GPDB: the callback is modified to accept ItemPointer as argument
* instead of HeapTuple. That allows the callback to be reused for
* appendoptimized tables.
*/
callback(indexRelation, &slot->tts_tid, values, isnull, tupleIsAlive,
callback_state);
}
if (progress)
{
if (seginfo)
{
FreeAllSegFileInfo(seginfo, segfile_count);
pfree(seginfo);
}
pgstat_progress_update_param(PROGRESS_SCAN_BLOCKS_DONE, total_blockcount);
}
table_endscan(scan);
ExecDropSingleTupleTableSlot(slot);
FreeExecutorState(estate);
/* These may have been pointing to the now-gone estate */
indexInfo->ii_ExpressionsState = NIL;
indexInfo->ii_PredicateState = NULL;
return reltuples;
}
static void
appendonly_index_validate_scan(Relation heapRelation,
Relation indexRelation,
IndexInfo *indexInfo,
Snapshot snapshot,
ValidateIndexState *state)
{
/*
* This interface is used during CONCURRENT INDEX builds. Currently,
* CONCURRENT INDEX builds are not supported in GPDB. This function should
* not have been called in the first place, but if it is called, better to
* error out.
*/
ereport(ERROR,
(errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
errmsg("index validate scan - feature not supported on appendoptimized relations")));
}
/* ------------------------------------------------------------------------
* Miscellaneous callbacks for the appendonly AM
* ------------------------------------------------------------------------
*/
/*
* This pretends that the all the space is taken by the main fork.
*/
static uint64
appendonly_relation_size(Relation rel, ForkNumber forkNumber)
{
Relation pg_aoseg_rel;
TupleDesc pg_aoseg_dsc;
HeapTuple tuple;
SysScanDesc aoscan;
int64 result;
Datum eof;
bool isNull;
Oid segrelid = InvalidOid;
if (forkNumber != MAIN_FORKNUM)
return 0;
result = 0;
GetAppendOnlyEntryAuxOids(rel, &segrelid, NULL,
NULL, NULL, NULL);
if (segrelid == InvalidOid)
elog(ERROR, "could not find pg_aoseg aux table for AO table \"%s\"",
RelationGetRelationName(rel));
pg_aoseg_rel = table_open(segrelid, AccessShareLock);
pg_aoseg_dsc = RelationGetDescr(pg_aoseg_rel);
aoscan = systable_beginscan(pg_aoseg_rel, InvalidOid, false, NULL, 0, NULL);
while ((tuple = systable_getnext(aoscan)) != NULL)
{
eof = fastgetattr(tuple, Anum_pg_aoseg_eof, pg_aoseg_dsc, &isNull);
Assert(!isNull);
result += DatumGetInt64(eof);
CHECK_FOR_INTERRUPTS();
}
systable_endscan(aoscan);
table_close(pg_aoseg_rel, AccessShareLock);
return result;
}
/*
* For each AO segment, get the starting heap block number and the number of
* heap blocks (together termed as a BlockSequence). The starting heap block
* number is always deterministic given a segment number. See AOtupleId.
*
* The number of heap blocks can be determined from the last row number present
* in the segment. See appendonlytid.h for details.
*/
static BlockSequence *
appendonly_relation_get_block_sequences(Relation rel,
int *numSequences)
{
Snapshot snapshot;
Oid segrelid;
int nsegs;
BlockSequence *sequences;
FileSegInfo **seginfos;
Assert(RelationIsValid(rel));
Assert(numSequences);
snapshot = RegisterSnapshot(GetCatalogSnapshot(InvalidOid));
seginfos = GetAllFileSegInfo(rel, snapshot, &nsegs, &segrelid);
sequences = (BlockSequence *) palloc(sizeof(BlockSequence) * nsegs);
*numSequences = nsegs;
/*
* For each aoseg, the sequence starts at a fixed heap block number and
* contains up to the highest numbered heap block corresponding to the
* lastSequence value of that segment.
*/
for (int i = 0; i < nsegs; i++)
AOSegment_PopulateBlockSequence(&sequences[i], segrelid, seginfos[i]->segno);
UnregisterSnapshot(snapshot);
if (seginfos != NULL)
{
FreeAllSegFileInfo(seginfos, nsegs);
pfree(seginfos);
}
return sequences;
}
/*
* Return the BlockSequence corresponding to the AO segment in which the logical
* heap block 'blkNum' falls.
*/
static void
appendonly_relation_get_block_sequence(Relation rel,
BlockNumber blkNum,
BlockSequence *sequence)
{
Oid segrelid;
GetAppendOnlyEntryAuxOids(rel, &segrelid, NULL, NULL, NULL, NULL);
AOSegment_PopulateBlockSequence(sequence, segrelid, AOSegmentGet_segno(blkNum));
}
/*
* Check to see whether the table needs a TOAST table. It does only if
* (1) there are any toastable attributes, and (2) the maximum length
* of a tuple could exceed TOAST_TUPLE_THRESHOLD. (We don't want to
* create a toast table for something like "f1 varchar(20)".)
*/
static bool
appendonly_relation_needs_toast_table(Relation rel)
{
int32 data_length = 0;
bool maxlength_unknown = false;
bool has_toastable_attrs = false;
TupleDesc tupdesc = rel->rd_att;
int32 tuple_length;
int i;
for (i = 0; i < tupdesc->natts; i++)
{
Form_pg_attribute att = TupleDescAttr(tupdesc, i);
if (att->attisdropped)
continue;
data_length = att_align_nominal(data_length, att->attalign);
if (att->attlen > 0)
{
/* Fixed-length types are never toastable */
data_length += att->attlen;
}
else
{
int32 maxlen = type_maximum_size(att->atttypid,
att->atttypmod);
if (maxlen < 0)
maxlength_unknown = true;
else
data_length += maxlen;
if (att->attstorage != 'p')
has_toastable_attrs = true;
}
}
if (!has_toastable_attrs)
return false; /* nothing to toast? */
if (maxlength_unknown)
return true; /* any unlimited-length attrs? */
tuple_length = MAXALIGN(SizeofHeapTupleHeader +
BITMAPLEN(tupdesc->natts)) +
MAXALIGN(data_length);
return (tuple_length > TOAST_TUPLE_THRESHOLD);
}
/*
* TOAST tables for heap relations are just heap relations.
*/
static Oid
appendonly_relation_toast_am(Relation rel)
{
return HEAP_TABLE_AM_OID;
}
/* ------------------------------------------------------------------------
* Planner related callbacks for the appendonly AM
* ------------------------------------------------------------------------
*/
static void
appendonly_estimate_rel_size(Relation rel, int32 *attr_widths,
BlockNumber *pages, double *tuples,
double *allvisfrac)
{
FileSegTotals *fileSegTotals;
Snapshot snapshot;
*pages = 1;
*tuples = 1;
*allvisfrac = 0;
if (Gp_role == GP_ROLE_DISPATCH)
return;
snapshot = RegisterSnapshot(GetLatestSnapshot());
fileSegTotals = GetSegFilesTotals(rel, snapshot);
*tuples = (double)fileSegTotals->totaltuples;
/* Quick exit if empty */
if (*tuples == 0)
{
UnregisterSnapshot(snapshot);
*pages = 0;
return;
}
Assert(fileSegTotals->totalbytesuncompressed > 0);
*pages = RelationGuessNumberOfBlocksFromSize(
(uint64)fileSegTotals->totalbytesuncompressed);
UnregisterSnapshot(snapshot);
/*
* Do not bother scanning the visimap aux table.
* Investigate if really needed.
*
* For Heap table, visibility map may help to estimate
* the number of page fetches can be avoided during an
* index-only scan. That is not the case for AO/AOCS table
* since index-only scan hasn't been used with AO/AOCS.
* So leave the comment here for future reference once
* we have a clear requirement to do that.
*/
return;
}
/* ------------------------------------------------------------------------
* Executor related callbacks for the appendonly AM
* ------------------------------------------------------------------------
*/
static bool
appendonly_scan_bitmap_next_block(TableScanDesc scan,
TBMIterateResult *tbmres)
{
AppendOnlyScanDesc aoscan = (AppendOnlyScanDesc) scan;
/*
* Start scanning from the beginning of the offsets array (or
* at first "offset number" if it's a lossy page).
* Have to set the init value before return fase. Since in
* nodeBitmapHeapscan.c's BitmapHeapNext. After call
* `table_scan_bitmap_next_block` and return false, it doesn't
* clean the tbmres. And then it'll read tuples from the page
* which should be skipped.
*/
aoscan->rs_cindex = 0;
/* If tbmres contains no tuples, continue. */
if (tbmres->ntuples == 0)
return false;
/* Make sure we never cross 15-bit offset number [MPP-24326] */
Assert(tbmres->ntuples <= INT16_MAX + 1);
return true;
}
static bool
appendonly_scan_bitmap_next_tuple(TableScanDesc scan,
TBMIterateResult *tbmres,
TupleTableSlot *slot)
{
AppendOnlyScanDesc aoscan = (AppendOnlyScanDesc) scan;
OffsetNumber pseudoHeapOffset;
ItemPointerData pseudoHeapTid;
AOTupleId aoTid;
int numTuples;
if (aoscan->aofetch == NULL)
{
aoscan->aofetch =
appendonly_fetch_init(aoscan->rs_base.rs_rd,
aoscan->snapshot,
aoscan->appendOnlyMetaDataSnapshot);
}
ExecClearTuple(slot);
/* ntuples == -1 indicates a lossy page */
numTuples = (tbmres->ntuples == -1) ? INT16_MAX + 1 : tbmres->ntuples;
while (aoscan->rs_cindex < numTuples)
{
/*
* If it's a lossy pase, iterate through all possible "offset numbers".
* Otherwise iterate through the array of "offset numbers".
*/
if (tbmres->ntuples == -1)
{
/*
* +1 to convert index to offset, since TID offsets are not zero
* based.
*/
pseudoHeapOffset = aoscan->rs_cindex + 1;
}
else
pseudoHeapOffset = tbmres->offsets[aoscan->rs_cindex];
aoscan->rs_cindex++;
/*
* Okay to fetch the tuple
*/
ItemPointerSet(&pseudoHeapTid, tbmres->blockno, pseudoHeapOffset);
tbm_convert_appendonly_tid_out(&pseudoHeapTid, &aoTid);
if(appendonly_fetch(aoscan->aofetch, &aoTid, slot))
{
/* OK to return this tuple */
pgstat_count_heap_fetch(aoscan->aos_rd);
return true;
}
}
/* Done with this block */
return false;
}
static bool
appendonly_scan_sample_next_block(TableScanDesc scan, SampleScanState *scanstate)
{
AppendOnlyScanDesc aoscan = (AppendOnlyScanDesc) scan;
TsmRoutine *tsm = scanstate->tsmroutine;
BlockNumber blockno = 0;
if (aoscan->totalTuples == 0)
{
FileSegInfo **seginfo;
int segfile_count;
int64 total_tupcount = 0;
seginfo = GetAllFileSegInfo(aoscan->aos_rd, aoscan->snapshot, &segfile_count, NULL);
for (int seginfo_no = 0; seginfo_no < segfile_count; seginfo_no++)
{
total_tupcount += seginfo[seginfo_no]->total_tupcount;
}
aoscan->totalTuples = total_tupcount;
if (seginfo)
{
FreeAllSegFileInfo(seginfo, segfile_count);
pfree(seginfo);
}
}
if (tsm->NextSampleBlock)
{
blockno = tsm->NextSampleBlock(scanstate, aoscan->totalTuples);
}
else
{
/*
* Tuple sampling is in advance implemented in next_block because
* next_tuple operates on a tuple, not on a block, and cannot be sampled.
* The reason the whole logic is implemented this way is because
* variable length blocks cannot be accessed randomly, and the tuple visibility
* needs to be determined by traversing the block. Therefore, the current implementation is adopted.
*/
blockno = system_nextsampleblock(scanstate, aoscan->totalTuples);
}
if (aoscan->aos_done_all_segfiles)
return false;
aoscan->fetchTupleId = blockno;
return true;
}
static bool
appendonly_scan_sample_next_tuple(TableScanDesc scan, SampleScanState *scanstate,
TupleTableSlot *slot)
{
bool ret = false;
AppendOnlyScanDesc aoscan = (AppendOnlyScanDesc) scan;
while (!aoscan->aos_done_all_segfiles
&& aoscan->fetchTupleId > aoscan->nextScanTupleId)
{
appendonly_getnextslot(scan, ForwardScanDirection, slot);
aoscan->nextScanTupleId++;
}
if (!aoscan->aos_done_all_segfiles
&& aoscan->fetchTupleId == aoscan->nextScanTupleId)
{
ret = appendonly_getnextslot(scan, ForwardScanDirection, slot);
aoscan->nextScanTupleId++;
}
return ret;
}
static void
appendonly_swap_relation_files(Oid relid1, Oid relid2,
TransactionId frozenXid pg_attribute_unused(),
MultiXactId cutoffMulti pg_attribute_unused())
{
SwapAppendonlyEntries(relid1, relid2);
}
/* ------------------------------------------------------------------------
* Definition of the appendonly table access method.
*
* NOTE: While there is a lot of functionality shared with the ao_column access
* method, is best for the handler methods to remain static in order to honour
* the contract of the access method interface.
* ------------------------------------------------------------------------
*/
static const TableAmRoutine ao_row_methods = {
.type = T_TableAmRoutine,
.slot_callbacks = appendonly_slot_callbacks,
/*
* appendonly row table doesn't extract columns, but handles
* predicate pushdown.
*/
.scan_begin_extractcolumns = appendonly_beginscan_extractcolumns,
.scan_begin = appendonly_beginscan,
.scan_end = appendonly_endscan,
.scan_rescan = appendonly_rescan,
.scan_getnextslot = appendonly_getnextslot,
.scan_flags = appendonly_scan_flags,
.parallelscan_estimate = appendonly_parallelscan_estimate,
.parallelscan_initialize = appendonly_parallelscan_initialize,
.parallelscan_reinitialize = appendonly_parallelscan_reinitialize,
.index_fetch_begin = appendonly_index_fetch_begin,
.index_fetch_reset = appendonly_index_fetch_reset,
.index_fetch_end = appendonly_index_fetch_end,
.index_fetch_tuple = appendonly_index_fetch_tuple,
.index_unique_check = appendonly_index_unique_check,
.tuple_insert = appendonly_tuple_insert,
.tuple_insert_speculative = appendonly_tuple_insert_speculative,
.tuple_complete_speculative = appendonly_tuple_complete_speculative,
.multi_insert = appendonly_multi_insert,
.tuple_delete = appendonly_tuple_delete,
.tuple_update = appendonly_tuple_update,
.tuple_lock = appendonly_tuple_lock,
.finish_bulk_insert = appendonly_finish_bulk_insert,
.tuple_fetch_row_version = appendonly_fetch_row_version,
.tuple_get_latest_tid = appendonly_get_latest_tid,
.tuple_tid_valid = appendonly_tuple_tid_valid,
.tuple_satisfies_snapshot = appendonly_tuple_satisfies_snapshot,
.index_delete_tuples = appendonly_index_delete_tuples,
.relation_set_new_filelocator = appendonly_relation_set_new_filenode,
.relation_nontransactional_truncate = appendonly_relation_nontransactional_truncate,
.relation_copy_data = appendonly_relation_copy_data,
.relation_copy_for_cluster = appendonly_relation_copy_for_cluster,
.relation_vacuum = appendonly_vacuum_rel,
.scan_analyze_next_block = appendonly_scan_analyze_next_block,
.scan_analyze_next_tuple = appendonly_scan_analyze_next_tuple,
.index_build_range_scan = appendonly_index_build_range_scan,
.index_validate_scan = appendonly_index_validate_scan,
.relation_size = appendonly_relation_size,
.relation_get_block_sequences = appendonly_relation_get_block_sequences,
.relation_get_block_sequence = appendonly_relation_get_block_sequence,
.relation_needs_toast_table = appendonly_relation_needs_toast_table,
.relation_toast_am = appendonly_relation_toast_am,
.relation_estimate_size = appendonly_estimate_rel_size,
.scan_bitmap_next_block = appendonly_scan_bitmap_next_block,
.scan_bitmap_next_tuple = appendonly_scan_bitmap_next_tuple,
.scan_sample_next_block = appendonly_scan_sample_next_block,
.scan_sample_next_tuple = appendonly_scan_sample_next_tuple,
.acquire_sample_rows = acquire_sample_rows,
.amoptions = ao_amoptions,
.swap_relation_files = appendonly_swap_relation_files,
};
Datum
ao_row_tableam_handler(PG_FUNCTION_ARGS)
{
PG_RETURN_POINTER(&ao_row_methods);
}