Kinetica Virtual Catalog

Overview

The Kinetica Virtual Catalog tables contain metadata about the database's objects, relationships, & permissions.

The tables are implemented commensurate with their usage and storage requirements. As such, a variety of distribution and partitioning schemes will be used across the tables. These tables will be automatically updated to reflect changes in the database structure and processing state.

The information returned when querying the virtual catalogs is automatically filtered by the permissions of the querying user. For instance, regular users will only see the tables & views to which they have access when querying a virtual catalog table that lists all of the tables in the database, while system administrators will see all tables & views.

For queries that can be run against the catalog tables to return useful information about the structure and processing state of the database, see Useful Catalog Queries.

The Kinetica Virtual Catalog tables reside in the ki_catalog schema.

Catalog Table List

Virtual Catalog TableDescription
ki_columnsColumns of tables & views and their respective types & statistics.
ki_contextsSQL-GPT context entries and their configuration. For each context, there will be one record per section--one for each table entry, one for global rules, and one for global samples.
ki_datasource_subscriptionsKafka data subscriptions, associating Kafka data sources with their target load tables.
ki_datasourcesExternal data sources, their containing schemas and types.
ki_datatypesSupported column data types.
ki_dependObject dependencies for views, procedures, and result tables.
ki_fk_constraintsForeign keys, one record per column specified in each foreign key.
ki_functionsScalar, aggregate, window, and user-defined functions.
ki_ingest_file_infoName & date of data files loaded into the database.
ki_load_historyRecord & statistics of each data load or export, subscription event, and data refresh.
ki_obj_statRow & byte counts for each object in the database.
ki_object_permissionsPrivileges granted, including the grantee, privilege type, and object to which access was granted.
ki_objectsTables & views and their respective types & statistics.
ki_query_active_allActively running SQL statements per worker rank, including DML & DDL.
ki_query_historyHistory of SQL statements run within the database, including DML & DDL; will not include multi-head ingest/egress.
ki_query_span_metrics_allProcessing metrics captured during the execution of commands on worker ranks.
ki_query_workersWorker ranks' status and their actively running tasks.
ki_rag_embeddingsSQL-GPT context definitions and their associated embeddings, one record for each sample or table definition.
ki_role_membersUsers & roles and their granted roles, one record per user/role or role/role pair.
ki_schemasSchemas, containing all database objects.
ki_tiered_objects

Tiered objects and their size within those tiers.

Tip

To retrieve the tiering information for a particular object, the object must be queried by fully-qualified name using the pseudo-column outer_object.

ki_users_and_rolesUsers & user roles.

Catalog Column List


ki_columns

Each record in ki_columns represents a single column in a table or view for all tables & views in the database, including those in virtual catalog tables.

Column NameColumn TypeDescription
oidBIGINTUnique identifier associated with this column, database-wide.
schema_oidBIGINTUnique identifier associated with the schema containing this column's table. See ki_schemas.
schema_nameVARCHAR(256)Name of the schema containing this column's table.
table_oidBIGINTUnique identifier associated with the table containing this column. See ki_objects.
table_nameVARCHAR(256)Name of the table containing this column.
column_nameVARCHAR(256)Name of this column.
column_positionINTEGERPosition of this column in its table, using a 0-based index.
column_type_oidBIGINTUnique identifier associated with the data type of this column. See ki_datatypes.
is_nullableINTEGERWhether this column can be set to null.
is_shard_keyINTEGERWhether this column is a shard key or part of a composite shard key.
is_primary_keyINTEGERWhether this column is a primary key or part of a composite primary key.
is_dist_encodedINTEGERWhether this column is dictionary-encoded.
default_valueVARCHAR(256)Not used.
default_value_exprVARCHAR(256)The default value expression applied to this column. See Data Replacement for options.
propertiesVARCHAR(256)Space-separated list of all column properties applied to this column.
commentsVARCHAR(256)User comments associated with this column.

ki_contexts

Each record in ki_contexts represents a top-level object within a SQL-GPT context. Objects can be one of the following:

  • Table Definition - Rules, samples & comments that apply to the use of the given table specifically
  • Rules Definition - Rules that apply globally when using the context
  • Samples Definition - Samples that apply globally when using the context
Column NameColumn TypeDescription
oidBIGINTUnique identifier associated with this SQL-GPT context object.
context_nameVARCHAR(256)Name of the SQL-GPT context containing this context object.
schema_oidBIGINTUnique identifier associated with the schema containing the parent SQL-GPT context. See ki_schemas.
schema_nameVARCHAR(256)Name of the schema containing the parent SQL-GPT context.
object_nameVARCHAR(256)

Name of this SQL-GPT context object, denoting the type of context object it is.

NameDescription
rulesRules Definition
samplesSamples Definition
<schema_name.table_name>Table Definition for the given table name
object_descriptionVARCHARThe COMMENT associated with the table, if context object is a table definition.
object_rulesVARCHAR[]The RULES associated with the table, if context object is a table definition; or the global rules associated with the overall context, if a rules definition.
object_commentsJSONThe COMMENTS associated with the table, if context object is a table definition--essentially, the column definitions for the table.
object_samplesJSONThe SAMPLES associated with the table, if context object is a table definition; or the global samples associated with the overall context, if a samples definition.
is_temp_contextBOOLEANWhether this context is temporary and will be removed when either its time-to-live expires or the database is restarted, whichever comes first.
ttlINTEGERTime-to-live, in seconds, for this context; if this context is not used for the associated TTL time span, it will be automatically removed.

ki_datasource_subscriptions

Each record in ki_datasource_subscriptions represents a subscription a single target table has through a single data source.

Column NameColumn TypeDescription
datasource_oidBIGINTUnique identifier associated with the data source used by this subscription. See ki_datasources.
table_oidBIGINTUnique identifier associated with the table to which subscribed data is written. See ki_objects.

ki_datasources

Each record in ki_datasources represents a single data source.

Column NameColumn TypeDescription
datasource_oidBIGINTUnique identifier associated with this data source.
datasource_schemaVARCHAR(256)Name of the schema containing this data source.
datasource_nameVARCHAR(256)Name of this data source.
datasource_kindVARCHAR(8)Provider associated with this data source.

ki_datatypes

Each record in ki_datatypes represents a standard data type into which a supported data type can be translated. Not all supported data types will have a unique 1-to-1 mapping with the standard set, and not all data types listed in this table will have supported analogs in Kinetica.

Column NameColumn TypeDescription
oidBIGINTUnique identifier associated with this data type.
nameVARCHAR(256)Name of the data type.
schema_oidBIGINTUnique identifier associated with the schema containing this data type. See ki_schemas.
creatorVARCHAR(256)Not used.
kindVARCHAR(1)Category of this data type; always B for Base type.
sizeINTEGERSize, in bytes, of this data type; -1 indicates variable length. Note that fixed-width (charN) string columns will list their actual data type size in ki_columns.
is_varyingINTEGERWhether the data type is variable length.
precINTEGERNot used.
scaleINTEGERNot used.
pg_typenameVARCHAR(32)Name of the equivalent PostgreSQL type.
sql_typenameVARCHAR(32)Name of the equivalent ANSI SQL type.

ki_depend

Each record in ki_depend represents a dependent relationship between a "source" object and an object that depends on it; for example, a view will depend on all of the tables & views referenced in its corresponding query.

Column NameColumn TypeDescription
src_obj_oidBIGINTUnique identifier associated with the source object depended on.
src_obj_kindVARCHAR(1)

Type of the source object depended on.

CodeDescription
EExternal table
HPartitioned table
IMaterialized view intermediate table
MMaterialized view
PSQL procedure
RRegular (local) table
VLogical view
dep_obj_oidBIGINTUnique identifier associated with the dependent object.
dep_obj_kindVARCHAR(1)

Type of the dependent object.

CodeDescription
IMaterialized view intermediate table
MMaterialized view
PSQL procedure
RRegular (local) table
VLogical view
mv_oidBIGINTUnique identifier of the associated materialized view (for materialized view components).
dep_kindVARCHAR(1)Not used.

ki_fk_constraints

Each record in ki_fk_constraints represents one column in either a primary key or foreign key relationship. For example, a table with a single primary key column will have one record in this table, while a composite foreign key linking two columns of one table to two columns of another will have four records in this table--one for each of the columns on the source side of the relation and one for each of the columns on the target side of the relation. Primary keys will be listed once for themselves, and then once for each instance of their participation in a foreign key relationship.

Column NameColumn TypeDescription
schema_oidBIGINTUnique identifier associated with the schema containing this constrained table. See ki_schemas.
schema_nameVARCHAR(256)Name of the schema containing this constrained table.
table_oidBIGINTUnique identifier associated with the table containing this constraint. See ki_objects.
table_nameVARCHAR(256)Name of the table containing this constraint.
parent_schema_oidBIGINTUnique identifier associated with the schema containing the foreign table referenced by this constraint (for foreign key constraints). See ki_schemas.
parent_schema_nameVARCHAR(256)Name of the schema containing the foreign table referenced by this constraint (for foreign key constraints).
parent_table_oidBIGINTUnique identifier associated with the foreign table referenced by this constraint (for foreign key constraints). See ki_objects.
parent_table_nameVARCHAR(256)Name of the foreign table referenced by this constraint (for foreign key constraints).
constraint_nameVARCHAR(256)Name of this constraint, if specified by the user (for foreign key constraints).
unique_constraint_nameVARCHAR(256)Name of this constraint, auto-generated by the system.
created_byVARCHAR(256)Username of user who created the constraint.
creation_timeTIMESTAMPTimestamp of constraint creation.
last_alter_timeTIMESTAMPTimestamp of most recent constraint update (initially, time of creation).
is_enforcedINTEGER

Whether the constraint is enforced.

CodeDescription
0Ignored (all foreign key constraints are ignored)
1Enforced (all primary key constraints are enforced)
fk_column_countINTEGERNumber of columns in the associated key.
fk_column_nameVARCHAR(256)Name of this constrained column referencing the primary key column of the foreign table.
fk_column_posINTEGER0-based index of the position of this constrained column within the set of foreign key columns (for foreign key constraints). If the foreign key is composed of only one column (non-composite foreign key), the index will be 0.
pk_column_nameVARCHAR(256)Name of the primary key column in the foreign table referenced by this constrained column (for foreign key constraints).
pk_column_posINTEGER0-based index of the position of the primary key column in the foreign table referenced by this constrained column within the set of referenced primary key columns (for foreign key constraints). If the primary key in the foreign table is composed of only one column (non-composite primary key), the index will be 0.
fk_column_positionsINTEGER[]0-based indexes of all foreign key columns associated with this constraint within the set of all columns in the constrained table (for foreign key constraints).
pk_column_positionsINTEGER[]0-based indexes of all primary key columns associated with this constraint within the set of all columns in the constrained table. For primary key constraints, this will be the list of column indexes among all columns in the constrained table; for foreign key constraints, this will be the list of column indexes among all columns in the foreign table referenced by the constraint.
fk_defVARCHAR(256)Definition of the foreign key constraint (for foreign key constraints).
pk_defVARCHAR(256)Definition of the primary key constraint. For primary key constraints, this will be the definition of the primary key on the constrained table; for foreign key constraints, this will be the definition of the primary key on the foreign table referenced by the constraint.
commentsVARCHAR(256)Not used.

ki_functions

Each record in ki_functions represents a native scalar or aggregate function, a UDF/UDTF, or a SQL procedure.

Column NameColumn TypeDescription
oidBIGINTUnique identifier associated with this function.
schema_oidBIGINTUnique identifier associated with the schema containing this function. See ki_schemas.
schema_nameVARCHAR(256)Name of the schema containing this constrained table. Native functions and UDFs are located in the pg_catalog schema, while SQL procedures are located in the schema specified by the user during creation.
nameVARCHAR(256)Name of this function.
langVARCHAR(256)Language in which this SQL procedure was written (for SQL procedures; always SQL).
variadicINTEGERNot used.
kindVARCHAR(256)

Function type.

CodeDescription
AAggregate function
CCast function
PSQL procedure
SScalar function
UUser-defined function
volatileVARCHAR(256)Not used.
nargsINTEGERNumber of parameters accepted by this function.
default_arg_countINTEGERNumber of parameters accepted by this function with default values.
return_type_oidBIGINTUnique identifier associated with the data type of this function's return value. See ki_datatypes.
arg_type_oidBIGINT[]Unique identifiers associated with the data types of this function's parameters. See ki_datatypes.
arg_typesVARCHAR[]Names of the data types of this function's parameters. See ki_datatypes.
arg_namesVARCHARNot used.
creation_timeTIMESTAMPTimestamp of function creation.
last_alter_timeTIMESTAMPTimestamp of most recent function update (initially, time of creation).
created_byVARCHAR(256)Username of user who created this function.
propertiesVARCHAR(256)Not used.
infoVARCHAR(256)Not used.

ki_ingest_file_info

Each record in ki_ingest_file_info represents the import from a single data file into the database or the export into a single data file from the database.

Column NameColumn TypeDescription
file_oidBIGINTUnique identifier associated with the data file imported from or exported into.
jobidBIGINTUnique identifier of the system job responsible for processing the import/export request.
start_timeTIMESTAMPTimestamp of import/export start.
file_short_nameVARCHAR(64)Name of data file.
file_full_nameVARCHARFull path of data file.

ki_load_history

Each record in ki_load_history represents a process that was invoked during either the import into or export from the database. Multiple processes may be invoked for a single data processing task.

Column NameColumn TypeDescription
table_oidBIGINTUnique identifier associated with the table into which loaded data is inserted. See ki_objects.
datasource_oidBIGINTUnique identifier associated with the data source or data sink used for this load (for loads that make use of either). See ki_datasources for loads that use a data source.
user_nameVARCHAR(256)Name of the user who initiated the load.
jobidBIGINTUnique identifier of the system job responsible for the load.
rank_numINTEGERIndex of the rank responsible for processing this segment of the load.
tomINTEGERIndex of the TOM responsible for processing this segment of the load.
load_kindVARCHAR(1)

Type of load.

CodeDescription
EExport local table to remote table via data sink.
IIngest from KiFS file or remote data via data source.
XExport local table to remote file via data sink.
start_timeTIMESTAMPTimestamp of loading process start.
end_timeTIMESTAMPTimestamp of loading process end.
file_oidBIGINTUnique identifier associated with the file imported from or exported into (for loads that make use of files). See ki_ingest_file_info.
line_numBIGINTNot used.
offset_valBIGINTNot used.
rows_processedBIGINTNumber of records processed for this import/export.
rows_insertedBIGINTNumber of records processed for this load that were either successfully imported into Kinetica or exported into a remote database (for imports of any kind and exports to tables).
rows_skippedBIGINTNumber of records processed for this import that were skipped due to errors in the data (for imports).
event_messageVARCHAR

System messages relevant to the load process, including:

  • error message relating to skipped records or other, if applicable (for imports)
  • Cancelled, denoting a data load process was terminated
  • pause, denoting a data load subscription was stopped temporarily
  • resume, denoting a data load subscription was resumed after being paused
  • subscribe, denoting subscription-based data loads
  • unsubscribe, denoting a data load subscription was cancelled
num_errorsBIGINTNumber of errors encountered during processing.
additional_infoVARCHAR

Extra information about the load, depending on load type.

Load TypeAdditional Info
Import from fileIndicator of which import load process this was.
Import from queryRemote query used to pull data from remote database.
Export to tableHow the export query was split across the local table.

ki_obj_stat

Each record in ki_obj_stat represents a single table or view in the database and its associated sizing statistics, including those in virtual catalog tables.

Column NameColumn TypeDescription
oidBIGINTUnique identifier associated with this object.
object_nameVARCHAR(256)Name of this object.
schema_nameVARCHAR(256)Name of the schema containing this object.
row_countBIGINTNumber of records contained in this object.
bytes_per_rowBIGINTCalculated average number of bytes per record for this object.
total_bytesBIGINTTotal number of raw bytes used by the table; this will not account for the extra RAM occupied by the unused portion of data chunks containing this table or the blocks used on disk to store the table.

ki_object_permissions

Each record in ki_object_permissions represents the mapping of a user or role to a system-level or object-level permission they have.

Column NameColumn TypeDescription
grantorBIGINTNot used.
role_oidBIGINTUnique identifier of the user or role associated with this mapping. See ki_users_and_roles.
role_nameVARCHAR(256)Name of the user or role associated with this mapping.
permission_typeVARCHAR(256)Type of permission grant this mapping represents.
object_typeVARCHAR(256)

Type of object grant this mapping represents (for object-level permissions).

TypeDescription
procSQL procedure or UDF/UDTF
datasinkData sink
datasourceData source
credentialCredential
directoryKiFS directory
schemaSchema
graphGraph
contextSQL-GPT context
tableTable or view
table_monitorTable monitor
object_schema_oidBIGINTUnique identifier of the schema containing the granted object associated with this mapping. See ki_schemas.
object_schema_nameVARCHAR(256)Name of the schema containing the granted object associated with this mapping.
object_oidBIGINTUnique identifier of the granted object associated with this mapping. See ki_objects.
object_nameVARCHAR(256)Name of the granted object associated with this mapping.
rlsVARCHAR(256)Row-level security expression granted in this mapping (for table & view object grants).
clsVARCHAR(256)Column-level security list of columns granted in this mapping (for table & view object grants).

ki_objects

Each record in ki_objects represents a single table, view, or SQL procedure within the database, including those in the virtual catalog tables.

Column NameColumn TypeDescription
oidBIGINTUnique identifier associated with this object.
object_nameVARCHAR(256)Name of this object.
schema_oidBIGINTUnique identifier associated with the schema containing this object. See ki_schemas.
schema_nameVARCHAR(256)Name of the schema containing this object.
type_idVARCHAR(128)Unique identifier associated with this table's definition (for tables & views).
shard_kindVARCHAR(1)

Distribution scheme (for regular tables, materialized external tables, and materialized views).

CodeDescription
NRandomly sharded
RReplicated
SSharded, by shard key
persistenceVARCHAR(1)

Whether the object will persist after a database restart.

CodeDescription
PPersisted
TTemporary
obj_kindVARCHAR(1)

Object type.

CodeDescription
EExternal table
HPartitioned table
IMaterialized view intermediate table
MMaterialized view
PSQL procedure
RRegular (local) table
VLogical view
virtualVARCHAR(1)

Virtual object type (for virtual objects).

CodeDescription
NNot virtual
FFiltered view
JJoin view
UVirtual union
ext_obj_kindVARCHAR(1)

External object type (for external tables).

CodeDescription
NNot external
LLogical
MMaterialized
refresh_kindVARCHAR(1)

Refresh scheme (for refreshable objects).

CodeDescription
NNot refreshable
COn-change
MManual
PPeriodic
QOn-query
SOn-start
refresh_periodDOUBLENumber of seconds between refreshes (for refreshable objects).
column_countINTEGERNumber of columns in this table (for tables & views).
has_indexINTEGERWhether this object has an index of any kind on any of its columns.
creation_timeTIMESTAMPTimestamp of object creation.
last_alter_timeTIMESTAMPTimestamp of most recent table definition update (initially, time of creation).
last_update_timeTIMESTAMPTimestamp of most recent data update (initially, time of creation).
last_refresh_timeTIMESTAMPTimestamp of last data refresh (for refreshable objects; initially, time of creation).
created_byVARCHAR(256)Username of user who created this object.
execute_asVARCHAR(256)Username of user assigned as the execution user of this object (for executable objects).
ttlINTEGERTime-to-live of this object (for objects that can expire).
definitionVARCHAR(256)Query that backs this view (for views).
commentsVARCHAR(256)User comments associated with this object.

ki_query_active_all

Each record in ki_query_active_all represents the portion of a given query or REST endpoint call being run on a given worker rank at the time this catalog table was queried. It returns general information about the query portion running on the given worker rank. See ki_query_workers for worker-specific details.

Column NameColumn TypeDescription
job_idBIGINTUnique identifier of the system job responsible for the query.
query_idUUIDUnique identifier of the query being run.
user_nameVARCHAR(64)Name of the user who initiated the query.
resource_groupVARCHAR(64)Name of resource group governing this query's resource management.
source_ipVARCHAR(64)IP address of user who initiated the query.
endpointVARCHAR(64)REST endpoint called to initiate the request (for SQL-based requests).
execution_statusVARCHAR(32)

Status of the query processing.

StatusDescription
noneJob not yet queued for processing.
async job doneAsynchronous job completed successfully.
cancelledJob cancelled.
cancellingJob in the process of being cancelled.
dispatchedJob sent to worker ranks for processing.
done at TOMPortion of job completed on worker rank.
doneJob completed successfully.
errorJob completed with errors.
initializedPersistent job (e.g., PostgreSQL wireline connection) established.
local cleanupJob artifacts being removed before completion.
runningJob being processed on worker ranks.
error_messageVARCHARError message associated with failed query.
start_timeTIMESTAMPTimestamp of query processing start.
query_textVARCHARSQL command issued (for SQL-based requests).
user_dataVARCHARSupplemental information about the request.
sql_step_countINTEGERStep number in processing this SQL command (for SQL-based requests).
refresh_idBIGINTUnique identifier of the materialized view refresh being performed (for materialized view refreshes).
is_mhBOOLEANWhether the job is a multi-head ingest request.
is_perpetualBOOLEAN

Whether the job has no fixed end time (e.g., Kafka streaming data feed).

CodeDescription
falseJob has a deterministic end time (fixed-size load).
trueJob has no deterministic end time (Kafka feed).
is_cancellableBOOLEANWhether the job can be cancelled by a user.
is_using_timeoutBOOLEANWhether the job can time out or not.
source_rankINTEGERNumber of the rank associated with this job.

ki_query_history

Each record in ki_query_history represents a single query or REST endpoint call made to the database. It will include all SQL queries, but not direct calls to DML-related endpoints, like:

Column NameColumn TypeDescription
job_idBIGINTUnique identifier of the system job responsible for the query.
query_idUUIDUnique identifier of the query.
user_nameVARCHAR(64)Name of the user who initiated the query.
endpointVARCHAR(64)REST endpoint called to initiate the request (for SQL-based requests).
execution_statusVARCHAR(32)

Final status of the query processing.

StatusDescription
async job doneAsynchronous job completed successfully.
cancelledJob cancelled.
doneJob completed successfully.
errorJob completed with errors.
error_messageVARCHARError message associated with failed query.
query_textVARCHARSQL command issued (for SQL-based requests).
user_dataVARCHARSupplemental information about the request.
start_timeTIMESTAMPTimestamp of query processing start.
stop_timeTIMESTAMPTimestamp of query processing stop.
sql_step_countINTEGERStep number in processing this SQL command (for SQL-based requests).
refresh_idBIGINTUnique identifier of the materialized view refresh performed (for materialized view refreshes).
resource_groupVARCHAR(64)Name of resource group that governed this query's resource management.
source_ipVARCHAR(64)IP address of user who initiated the query.

ki_query_span_metrics_all

Each record in ki_query_span_metrics_all represents an independent operation that was processed on a given rank in order to fulfill a given query request, along with the statistics collected for that operation. This table will have one entry for each rank involved in processing a given operation and the statistics collected for that rank.

Column NameColumn TypeDescription
query_idUUIDUnique identifier of the query request. See ki_query_active_all & ki_query_history.
span_idUNSIGNED BIGINTUnique identifier of the metric span for this query.
parent_span_idUNSIGNED BIGINTNot used.
operatorVARCHAR(32)Internal name for operation performed. Many operators will roughly match the name of the REST endpoints they serve.
sql_stepINTEGERStep number in processing this SQL command (for SQL-based requests).
metric_dataJSONJSON block of collected metrics.
start_timeTIMESTAMPTimestamp of operation start on the associated rank.
stop_timeTIMESTAMPTimestamp of operation stop on the associtated rank.
source_rankINTEGERNumber of the rank on which this portion of the operation was processed and metrics collected.

ki_query_workers

Each record in ki_query_workers represents the portion of a given query or REST endpoint call being run on a given worker rank at the time this catalog table was queried. It returns worker-specific information about the query portion running on the given worker rank. See ki_query_active_all for general query processing details.

Column NameColumn TypeDescription
job_idBIGINTUnique identifier of the system job responsible for the query.
worker_idBIGINTUnique identifier of the worker job responsible for its portion of the query.
typeVARCHAR(64)Type of worker process handling this portion of the query.
internal_nameVARCHAR(64)Internal name of worker process handling this portion of the query, if present.
task_infoVARCHAR(64)Worker task-specific information.
thread_poolVARCHAR(16)Type of thread pool being used to service this portion of the query.
statusVARCHAR(16)

Status of the processing of this portion of the query--one of:

  • cancelled
  • completed
  • failed
  • paused
  • running
blockersVARCHAR(128)Any dependencies that may be blocking the execution of this portion of the query.
sql_stepINTEGERStep number in processing this SQL command (for SQL-based requests).
final_msg_setBOOLEANWhether the final status has been recorded for this portion of the query.
running_task_countINTEGERNumber of running tasks relating to this portion of the query.
queued_task_countINTEGERNumber of queued tasks relating to this portion of the query.
pending_async_tasksINTEGERNumber of asynchronous tasks not yet complete for this portion of the query.
elapsed_time_msBIGINTNumber of milliseconds that have passed since processing began on this portion of the query.
exceptionVARCHAR(256)Any exception thrown during processing this portion of the query.
source_rankINTEGERNumber of the rank on which this portion of the query is being processed.

ki_rag_embeddings

Each record in ki_rag_embeddings represents a table or sample definition of a SQL-GPT context and its associated embeddings.

Column NameColumn TypeDescription
obj_idVARCHARUnique identifier associated with this SQL-GPT context table or sample definition.
context_nameVARCHAR(256)Name of the SQL-GPT context containing this definition.
obj_typeVARCHAR(8)

Type of SQL-GPT context definition this is.

TypeDescription
SAMPLESample definition
TABLETable definition
embed_textVARCHARSemicolon-separated compaction of the context definition fields.
n_tokensINTEGERNumber of tokens used in generating the embedding for this context definition.
embeddingVECTOR(2048)Embedding generated for this context definition.
embed_modelVARCHAR(256)Name of the model used to generate the embedding.

ki_role_members

Each record in ki_role_members represents the mapping of a role to a user or role that is a member of that role.

Column NameColumn TypeDescription
role_oidBIGINTUnique identifier of the parent role associated with this mapping. See ki_users_and_roles.
role_nameVARCHAR(256)Name of the parent role associated with this mapping.
member_oidBIGINTUnique identifier of the user or role that has (is a member of) the parent role. See ki_users_and_roles.
member_nameVARCHAR(256)Name of the user or role that has (is a member of) the parent role.
grantor_oidBIGINTNot used.
admin_optionINTEGERWhether the member user/role can grant membership to the parent role to other users/roles; effectively, whether the member user/role has system_admin or system_user_admin permission.

ki_schemas

Each record in ki_schemas represents a schema in the database.

Column NameColumn TypeDescription
oidBIGINTUnique identifier associated with this schema.
schema_nameVARCHAR(256)Name of this schema.
created_byVARCHAR(256)Username of user who created this schema.
creation_timeTIMESTAMPTimestamp of schema creation.
last_alter_timeTIMESTAMPTimestamp of most recent schema modification (initially, time of creation).
commentsVARCHAR(256)Not used.

ki_tiered_objects

Each record in ki_tiered_objects represents a column of data from a given table, located within a given rank & tier. For instance, the oid column of the ki_objects table will likely have one entry for each combination of rank and tier in the database; on a database with two worker ranks, the column will have one entry for the RAM tier and one for the PERSIST tier on each of the two ranks, for a total of four entries for that single table column of data.

Column NameColumn TypeDescription
sizeBIGINTTotal number of bytes used by this object in this tier.
idVARCHAR(256)Unique identifier of this tiered object; for tables, containing the tiered column & table name.
priorityINTEGEREviction priority for this object in this tier.
tierINTEGERName of the tier associated with this object.
evictableBOOLEANWhether this tiered object is evictable from this tier.
lockedBOOLEANWhether this tiered object is being processed by the tier management system.
pin_countINTEGERNumber of operations currently using this tiered object.
owner_resource_groupVARCHAR(128)Name of resource group governing this tiered object's tier position and eviction strategy.
source_rankINTEGERNumber of the rank associated with this tiered object.
outer_objectVARCHAR(256)Not used.

ki_users_and_roles

Each record in ki_users_and_roles represents either a user or role.

Column NameColumn TypeDescription
oidBIGINTUnique identifier associated with this user or role.
nameVARCHAR(256)Name of this user or role.
can_loginINTEGER

Whether this user/role can log in to the database; effectively, whether this is a user or role.

CodeDescription
0Can't log in (role)
1Can log in (user)
is_externalINTEGER

Whether this user is externally authenticated or not.

CodeDescription
0Internal user
1External user
is_superuserINTEGER

Whether this user/role has system_admin permission.

CodeDescription
0Doesn't have system admin
1Has system admin
can_create_roleINTEGER

Whether this user/role can create other users/roles; effectively, whether this user/role has system_admin or system_user_admin permission.

CodeDescription
0Can't create roles
1Can create roles
can_create_schemaINTEGER

Whether this user/role can create schemas; effectively, whether this user/role has system_admin or system_write permission.

CodeDescription
0Can't create schemas
1Can create schemas
can_bypass_rlsINTEGER

Whether this user/role can bypass row-level security; effectively, whether this user/role has system_admin permission.

CodeDescription
0Can't bypass row-level security
1Can bypass row-level security
resource_groupINTEGERresource group assigned to this user/role.
commentsVARCHAR(256)Not used.