System Tables

IoTDB has a built-in system database called INFORMATION_SCHEMA, which contains a series of system tables for storing IoTDB runtime information (such as currently executing SQL statements, etc.). Currently, the INFORMATION_SCHEMA database only supports read operations.

1. System Database

  • Name​: INFORMATION_SCHEMA
  • Commands​: Read-only, only supports Show databases (DETAILS) / Show Tables (DETAILS) / Use. Other operations will result in an error: "The database 'information_schema' can only be queried."
  • Attributes​: TTL=INF, other attributes default to null
  • SQL Example​:
IoTDB> show databases
+------------------+-------+-----------------------+---------------------+---------------------+
|          Database|TTL(ms)|SchemaReplicationFactor|DataReplicationFactor|TimePartitionInterval|
+------------------+-------+-----------------------+---------------------+---------------------+
|information_schema|    INF|                   null|                 null|                 null|
+------------------+-------+-----------------------+---------------------+---------------------+

IoTDB> show tables from information_schema
+--------------+-------+
|     TableName|TTL(ms)|
+--------------+-------+
|       columns|    INF|
|  config_nodes|    INF|
|configurations|    INF|
|    data_nodes|    INF|
|     databases|    INF|
|     functions|    INF|
|      keywords|    INF|
|        models|    INF|
|         nodes|    INF|
|  pipe_plugins|    INF|
|         pipes|    INF|
|       queries|    INF|
|       regions|    INF|
| subscriptions|    INF|
|        tables|    INF|
|        topics|    INF|
|         views|    INF|
+--------------+-------+

2. System Tables

  • Names​: DATABASES, TABLES, REGIONS, QUERIES, COLUMNS, PIPES, PIPE_PLUGINS, SUBSCRIPTION, TOPICS, VIEWS, MODELS, FUNCTIONS, CONFIGURATIONS, KEYWORDS, NODES, CONFIG_NODES, DATA_NODES (detailed descriptions in later sections)
  • Operations​: Read-only, only supports SELECT, COUNT/SHOW DEVICES, DESC. Any modifications to table structure or content are not allowed and will result in an error: "The database 'information_schema' can only be queried."
  • Column Names​: System table column names are all lowercase by default and separated by underscores (_).

2.1 DATABASES

  • Contains information about all databases in the cluster.
  • Table structure is as follows:
Column NameData TypeColumn TypeDescription
databaseSTRINGTAGDatabase name
ttl(ms)STRINGATTRIBUTEData retention time
schema_replication_factorINT32ATTRIBUTESchema replica count
data_replication_factorINT32ATTRIBUTEData replica count
time_partition_intervalINT64ATTRIBUTETime partition interval
schema_region_group_numINT32ATTRIBUTENumber of schema region groups
data_region_group_numINT32ATTRIBUTENumber of data region groups
  • The query results only display the collection of databases for which you have any permission on the database itself or any table within the database.
  • Query Example:
IoTDB> select * from information_schema.databases
+------------------+-------+-------------------------+-----------------------+-----------------------+-----------------------+---------------------+
|          database|ttl(ms)|schema_replication_factor|data_replication_factor|time_partition_interval|schema_region_group_num|data_region_group_num|
+------------------+-------+-------------------------+-----------------------+-----------------------+-----------------------+---------------------+
|information_schema|    INF|                     null|                   null|                   null|                   null|                 null|
|         database1|    INF|                        1|                      1|              604800000|                      0|                    0|
+------------------+-------+-------------------------+-----------------------+-----------------------+-----------------------+---------------------+

2.2 TABLES

  • Contains information about all tables in the cluster.
  • Table structure is as follows:
Column NameData TypeColumn TypeDescription
databaseSTRINGTAGDatabase name
table_nameSTRINGTAGTable name
ttl(ms)STRINGATTRIBUTEData retention time
statusSTRINGATTRIBUTEStatus
commentSTRINGATTRIBUTEDescription/comment
  • Note: Possible values for status: USING, PRE_CREATE, PRE_DELETE. For details, refer to the View Tables in Table Management documentation
  • The query results only display the collection of tables for which you have any permission.
  • Query Example:
IoTDB> select * from information_schema.tables
+------------------+--------------+-----------+------+-------+-----------+
|          database|    table_name|    ttl(ms)|status|comment| table_type|
+------------------+--------------+-----------+------+-------+-----------+
|information_schema|     databases|        INF| USING|   null|SYSTEM VIEW|
|information_schema|        models|        INF| USING|   null|SYSTEM VIEW|
|information_schema| subscriptions|        INF| USING|   null|SYSTEM VIEW|
|information_schema|       regions|        INF| USING|   null|SYSTEM VIEW|
|information_schema|     functions|        INF| USING|   null|SYSTEM VIEW|
|information_schema|      keywords|        INF| USING|   null|SYSTEM VIEW|
|information_schema|       columns|        INF| USING|   null|SYSTEM VIEW|
|information_schema|        topics|        INF| USING|   null|SYSTEM VIEW|
|information_schema|configurations|        INF| USING|   null|SYSTEM VIEW|
|information_schema|       queries|        INF| USING|   null|SYSTEM VIEW|
|information_schema|        tables|        INF| USING|   null|SYSTEM VIEW|
|information_schema|  pipe_plugins|        INF| USING|   null|SYSTEM VIEW|
|information_schema|         nodes|        INF| USING|   null|SYSTEM VIEW|
|information_schema|    data_nodes|        INF| USING|   null|SYSTEM VIEW|
|information_schema|         pipes|        INF| USING|   null|SYSTEM VIEW|
|information_schema|         views|        INF| USING|   null|SYSTEM VIEW|
|information_schema|  config_nodes|        INF| USING|   null|SYSTEM VIEW|
|         database1|        table1|31536000000| USING|   null| BASE TABLE|
+------------------+--------------+-----------+------+-------+-----------+

2.3 REGIONS

  • Contains information about all regions in the cluster.
  • Table structure is as follows:
Column NameData TypeColumn TypeDescription
region_idINT32TAGRegion ID
datanode_idINT32TAGDataNode ID
typeSTRINGATTRIBUTEType (SchemaRegion/DataRegion)
statusSTRINGATTRIBUTEStatus (Running,Unknown, etc.)
databaseSTRINGATTRIBUTEDatabase name
series_slot_numINT32ATTRIBUTENumber of series slots
time_slot_numINT64ATTRIBUTENumber of time slots
rpc_addressSTRINGATTRIBUTERPC address
rpc_portINT32ATTRIBUTERPC port
internal_addressSTRINGATTRIBUTEInternal communication address
roleSTRINGATTRIBUTERole (Leader/Follower)
create_timeTIMESTAMPATTRIBUTECreation time
tsfile_size_bytesINT64ATTRIBUTE- For​DataRegion with statistics ​​: Total file size of TsFiles.
- ForDataRegion without statistics(Unknown):-1.
- For​SchemaRegion​:null.
  • Only administrators are allowed to perform query operations.
  • Query Example:
IoTDB> select * from information_schema.regions
+---------+-----------+------------+-------+---------+---------------+-------------+-----------+--------+----------------+------+-----------------------------+-----------------+
|region_id|datanode_id|        type| status| database|series_slot_num|time_slot_num|rpc_address|rpc_port|internal_address|  role|                  create_time|tsfile_size_bytes|
+---------+-----------+------------+-------+---------+---------------+-------------+-----------+--------+----------------+------+-----------------------------+-----------------+
|        0|          1|SchemaRegion|Running|database1|             12|            0|    0.0.0.0|    6667|       127.0.0.1|Leader|2025-03-31T11:19:08.485+08:00|             null|
|        1|          1|  DataRegion|Running|database1|              6|            6|    0.0.0.0|    6667|       127.0.0.1|Leader|2025-03-31T11:19:09.156+08:00|             3985|
|        2|          1|  DataRegion|Running|database1|              6|            6|    0.0.0.0|    6667|       127.0.0.1|Leader|2025-03-31T11:19:09.156+08:00|             3841|
+---------+-----------+------------+-------+---------+---------------+-------------+-----------+--------+----------------+------+-----------------------------+-----------------+

2.4 QUERIES

  • Contains information about all currently executing queries in the cluster. Can also be queried using the SHOW QUERIES syntax.
  • Table structure is as follows:
Column NameData TypeColumn TypeDescription
query_idSTRINGTAGQuery ID
start_timeTIMESTAMPATTRIBUTEQuery start timestamp (precision matches system precision)
datanode_idINT32ATTRIBUTEDataNode ID that initiated the query
elapsed_timeFLOATATTRIBUTEQuery execution duration (in seconds)
statementSTRINGATTRIBUTESQL statement of the query
userSTRINGATTRIBUTEUser who initiated the query
  • For regular users, the query results only display the queries executed by themselves; for administrators, all queries are displayed.
  • Query Example:
IoTDB> select * from information_schema.queries
+-----------------------+-----------------------------+-----------+------------+----------------------------------------+----+
|               query_id|                   start_time|datanode_id|elapsed_time|                               statement|user|
+-----------------------+-----------------------------+-----------+------------+----------------------------------------+----+
|20250331_023242_00011_1|2025-03-31T10:32:42.360+08:00|          1|       0.025|select * from information_schema.queries|root|
+-----------------------+-----------------------------+-----------+------------+----------------------------------------+----+

2.5 COLUMNS

  • Contains information about all columns in tables across the cluster
  • Table structure is as follows:
Column NameData TypeColumn TypeDescription
databaseSTRINGTAGDatabase name
table_nameSTRINGTAGTable name
column_nameSTRINGTAGColumn name
datatypeSTRINGATTRIBUTEColumn data type
categorySTRINGATTRIBUTEColumn category
statusSTRINGATTRIBUTEColumn status
commentSTRINGATTRIBUTEColumn description

Notes:

  • Possible values for status: USING, PRE_DELETE. For details, refer to Viewing Table Columns in Table Management documentation.

  • The query results only display the column information of tables for which you have any permission.

  • Query Example:

IoTDB> select * from information_schema.columns where database = 'database1'
+---------+----------+------------+---------+---------+------+-------+
| database|table_name| column_name| datatype| category|status|comment|
+---------+----------+------------+---------+---------+------+-------+
|database1|    table1|        time|TIMESTAMP|     TIME| USING|   null|
|database1|    table1|      region|   STRING|      TAG| USING|   null|
|database1|    table1|    plant_id|   STRING|      TAG| USING|   null|
|database1|    table1|   device_id|   STRING|      TAG| USING|   null|
|database1|    table1|    model_id|   STRING|ATTRIBUTE| USING|   null|
|database1|    table1| maintenance|   STRING|ATTRIBUTE| USING|   null|
|database1|    table1| temperature|    FLOAT|    FIELD| USING|   null|
|database1|    table1|    humidity|    FLOAT|    FIELD| USING|   null|
|database1|    table1|      status|  BOOLEAN|    FIELD| USING|   null|
|database1|    table1|arrival_time|TIMESTAMP|    FIELD| USING|   null|
+---------+----------+------------+---------+---------+------+-------+

2.6 PIPES

  • Contains information about all pipes in the cluster
  • Table structure is as follows:
Column NameData TypeColumn TypeDescription
idSTRINGTAGPipe name
creation_timeTIMESTAMPATTRIBUTECreation time
stateSTRINGATTRIBUTEPipe status (RUNNING/STOPPED)
pipe_sourceSTRINGATTRIBUTESource plugin parameters
pipe_processorSTRINGATTRIBUTEProcessor plugin parameters
pipe_sinkSTRINGATTRIBUTESink plugin parameters
exception_messageSTRINGATTRIBUTEException message
remaining_event_countINT64ATTRIBUTERemaining event count (-1if Unknown)
estimated_remaining_secondsDOUBLEATTRIBUTEEstimated remaining time in seconds (-1if Unknown)
  • Only administrators are allowed to perform operations.
  • Query Example:
select * from information_schema.pipes
+----------+-----------------------------+-------+--------------------------------------------------------------------------+--------------+-----------------------------------------------------------------------+-----------------+---------------------+---------------------------+
|        id|                creation_time|  state|                                                               pipe_source|pipe_processor|                                                              pipe_sink|exception_message|remaining_event_count|estimated_remaining_seconds|
+----------+-----------------------------+-------+--------------------------------------------------------------------------+--------------+-----------------------------------------------------------------------+-----------------+---------------------+---------------------------+
|tablepipe1|2025-03-31T12:25:24.040+08:00|RUNNING|{__system.sql-dialect=table, source.password=******, source.username=root}|            {}|{format=hybrid, node-urls=192.168.xxx.xxx:6667, sink=iotdb-thrift-sink}|                 |                    0|                        0.0|
+----------+-----------------------------+-------+--------------------------------------------------------------------------+--------------+-----------------------------------------------------------------------+-----------------+---------------------+---------------------------+

2.7 PIPE_PLUGINS

  • Contains information about all PIPE plugins in the cluster
  • Table structure is as follows:
Column NameData TypeColumn TypeDescription
plugin_nameSTRINGTAGPlugin name
plugin_typeSTRINGATTRIBUTEPlugin type (Builtin/External)
class_nameSTRINGATTRIBUTEPlugin's main class name
plugin_jarSTRINGATTRIBUTEPlugin's JAR file name (nullfor builtin type)
  • Query Example:
IoTDB> select * from information_schema.pipe_plugins
+---------------------+-----------+-------------------------------------------------------------------------------------------------+----------+
|          plugin_name|plugin_type|                                                                                       class_name|plugin_jar|
+---------------------+-----------+-------------------------------------------------------------------------------------------------+----------+
|IOTDB-THRIFT-SSL-SINK|    Builtin|org.apache.iotdb.commons.pipe.agent.plugin.builtin.connector.iotdb.thrift.IoTDBThriftSslConnector|      null|
|   IOTDB-AIR-GAP-SINK|    Builtin|   org.apache.iotdb.commons.pipe.agent.plugin.builtin.connector.iotdb.airgap.IoTDBAirGapConnector|      null|
|      DO-NOTHING-SINK|    Builtin|        org.apache.iotdb.commons.pipe.agent.plugin.builtin.connector.donothing.DoNothingConnector|      null|
| DO-NOTHING-PROCESSOR|    Builtin|        org.apache.iotdb.commons.pipe.agent.plugin.builtin.processor.donothing.DoNothingProcessor|      null|
|    IOTDB-THRIFT-SINK|    Builtin|   org.apache.iotdb.commons.pipe.agent.plugin.builtin.connector.iotdb.thrift.IoTDBThriftConnector|      null|
|         IOTDB-SOURCE|    Builtin|                org.apache.iotdb.commons.pipe.agent.plugin.builtin.extractor.iotdb.IoTDBExtractor|      null|
+---------------------+-----------+-------------------------------------------------------------------------------------------------+----------+

2.8 SUBSCRIPTIONS

  • Contains information about all data subscriptions in the cluster
  • Table structure is as follows:
Column NameData TypeColumn TypeDescription
topic_nameSTRINGTAGSubscription topic name
consumer_group_nameSTRINGTAGConsumer group name
subscribed_consumersSTRINGATTRIBUTESubscribed consumers
  • Only administrators are allowed to perform operations.
  • Query Example:
IoTDB> select * from information_schema.subscriptions where topic_name = 'topic_1'
+----------+-------------------+--------------------------------+
|topic_name|consumer_group_name|            subscribed_consumers|
+----------+-------------------+--------------------------------+
|   topic_1|                cg1|[c3, c4, c5, c6, c7, c0, c1, c2]|
+----------+-------------------+--------------------------------+

2.9 TOPICS

  • Contains information about all data subscription topics in the cluster
  • Table structure is as follows:
Column NameData TypeColumn TypeDescription
topic_nameSTRINGTAGSubscription topic name
topic_configsSTRINGATTRIBUTETopic configuration parameters
  • Only administrators are allowed to perform operations.
  • Query Example:
IoTDB> select * from information_schema.topics
+----------+----------------------------------------------------------------+
|topic_name|                                                   topic_configs|
+----------+----------------------------------------------------------------+
|     topic|{__system.sql-dialect=table, start-time=2025-01-10T17:05:38.282}|
+----------+----------------------------------------------------------------+

2.10 VIEWS Table

This system table is available starting from version V2.0.5.

  • Contains information about all table views in the database.
  • The table structure is as follows:
Column NameData TypeColumn CategoryDescription
databaseSTRINGTAGDatabase name
table_nameSTRINGTAGView name
view_definitionSTRINGATTRIBUTESQL statement for view creation
  • The query results only display the collection of views for which you have any permission.
  • Query example:
IoTDB> select * from information_schema.views
+---------+----------+---------------------------------------------------------------------------------------------------------------------------------------+
| database|table_name|                                                                                                                        view_definition|
+---------+----------+---------------------------------------------------------------------------------------------------------------------------------------+
|database1|        ln|CREATE VIEW "ln" ("device" STRING TAG,"model" STRING TAG,"status" BOOLEAN FIELD,"hardware" STRING FIELD) WITH (ttl='INF') AS root.ln.**|
+---------+----------+---------------------------------------------------------------------------------------------------------------------------------------+

2.11 MODELS Table

This system table is available starting from version V2.0.5.

  • Contains information about all models in the database.
  • The table structure is as follows:
Column NameData TypeColumn CategoryDescription
model_idSTRINGTAGModel name
model_typeSTRINGATTRIBUTEModel type (Forecast, Anomaly Detection, Custom)
stateSTRINGATTRIBUTEModel status (Available/Unavailable)
configsSTRINGATTRIBUTEString format of model hyperparameters, consistent with the output of the show command
notesSTRINGATTRIBUTEModel description* Built-in model: Built-in model in IoTDB* User-defined model: Custom model
  • Query example:
-- Find all built-in forecast models
IoTDB> select * from information_schema.models where model_type = 'BUILT_IN_FORECAST'
+---------------------+-----------------+------+-------+-----------------------+
|             model_id|       model_type| state|configs|                  notes|
+---------------------+-----------------+------+-------+-----------------------+
|       _STLForecaster|BUILT_IN_FORECAST|ACTIVE|   null|Built-in model in IoTDB|
|     _NaiveForecaster|BUILT_IN_FORECAST|ACTIVE|   null|Built-in model in IoTDB|
|               _ARIMA|BUILT_IN_FORECAST|ACTIVE|   null|Built-in model in IoTDB|
|_ExponentialSmoothing|BUILT_IN_FORECAST|ACTIVE|   null|Built-in model in IoTDB|
|         _HoltWinters|BUILT_IN_FORECAST|ACTIVE|   null|Built-in model in IoTDB|
|             _sundial|BUILT_IN_FORECAST|ACTIVE|   null|Built-in model in IoTDB|
+---------------------+-----------------+------+-------+-----------------------+

2.12 FUNCTIONS Table

This system table is available starting from version V2.0.5.

  • Contains information about all functions in the database.
  • The table structure is as follows:
Column NameData TypeColumn CategoryDescription
function_nameSTRINGTAGFunction name
function_typeSTRINGATTRIBUTEFunction type (Built-in/User-defined, Scalar/Aggregation/Table Function)
class_name(udf)STRINGATTRIBUTEClass name if it is a UDF, otherwise null (tentative)
stateSTRINGATTRIBUTEAvailability status
  • Query example:
IoTDB> select * from information_schema.functions where function_type='built-in table function'
+--------------+-----------------------+---------------+---------+
|function_name |          function_type|class_name(udf)|    state|
+--------------+-----------------------+---------------+---------+
|      CUMULATE|built-in table function|           null|AVAILABLE|
|       SESSION|built-in table function|           null|AVAILABLE|
|           HOP|built-in table function|           null|AVAILABLE|
|        TUMBLE|built-in table function|           null|AVAILABLE|
|      FORECAST|built-in table function|           null|AVAILABLE|
|     VARIATION|built-in table function|           null|AVAILABLE|
|      CAPACITY|built-in table function|           null|AVAILABLE|
+--------------+-----------------------+---------------+---------+

2.13 CONFIGURATIONS Table

This system table is available starting from version V2.0.5.

  • Contains all configuration properties of the database.
  • The table structure is as follows:
Column NameData TypeColumn CategoryDescription
variableSTRINGTAGConfiguration property name
valueSTRINGATTRIBUTEConfiguration property value
  • Only administrators are allowed to perform operations on this table.
  • Query example:
IoTDB> select * from information_schema.configurations
+----------------------------------+-----------------------------------------------------------------+
|                          variable|                                                            value|
+----------------------------------+-----------------------------------------------------------------+
|                       ClusterName|                                                   defaultCluster|
|             DataReplicationFactor|                                                                1|
|           SchemaReplicationFactor|                                                                1|
|  DataRegionConsensusProtocolClass|                      org.apache.iotdb.consensus.iot.IoTConsensus|
|SchemaRegionConsensusProtocolClass|                  org.apache.iotdb.consensus.ratis.RatisConsensus|
|  ConfigNodeConsensusProtocolClass|                  org.apache.iotdb.consensus.ratis.RatisConsensus|
|               TimePartitionOrigin|                                                                0|
|             TimePartitionInterval|                                                        604800000|
|              ReadConsistencyLevel|                                                           strong|
|           SchemaRegionPerDataNode|                                                                1|
|             DataRegionPerDataNode|                                                                0|
|                     SeriesSlotNum|                                                             1000|
|           SeriesSlotExecutorClass|org.apache.iotdb.commons.partition.executor.hash.BKDRHashExecutor|
|         DiskSpaceWarningThreshold|                                                             0.05|
|                TimestampPrecision|                                                               ms|
+----------------------------------+-----------------------------------------------------------------+

2.14 KEYWORDS Table

This system table is available starting from version V2.0.5.

  • Contains all keywords in the database.
  • The table structure is as follows:
Column NameData TypeColumn CategoryDescription
wordSTRINGTAGKeyword
reservedINT32ATTRIBUTEWhether it is a reserved word (1 = Yes, 0 = No)
  • Query example:
IoTDB> select * from information_schema.keywords limit 10
+----------+--------+
|      word|reserved|
+----------+--------+
|    ABSENT|       0|
|ACTIVATION|       1|
|  ACTIVATE|       1|
|       ADD|       0|
|     ADMIN|       0|
|     AFTER|       0|
|   AINODES|       1|
|       ALL|       0|
|     ALTER|       1|
|   ANALYZE|       0|
+----------+--------+

2.15 NODES Table

This system table is available starting from version V2.0.5.

  • Contains information about all nodes in the database cluster.
  • The table structure is as follows:
Column NameData TypeColumn CategoryDescription
node_idINT32TAGNode ID
node_typeSTRINGATTRIBUTENode type
statusSTRINGATTRIBUTENode status
internal_addressSTRINGATTRIBUTEInternal RPC address
internal_portINT32ATTRIBUTEInternal port
versionSTRINGATTRIBUTEVersion number
build_infoSTRINGATTRIBUTECommit ID
activate_status (Enterprise Edition only)STRINGATTRIBUTEActivation status
  • Only administrators are allowed to perform operations on this table.
  • Query example:
IoTDB> select * from information_schema.nodes 
+-------+----------+-------+----------------+-------------+-------+----------+
|node_id| node_type| status|internal_address|internal_port|version|build_info|
+-------+----------+-------+----------------+-------------+-------+----------+
|      0|ConfigNode|Running|       127.0.0.1|        10710|2.0.5.1|   58d685e|
|      1|  DataNode|Running|       127.0.0.1|        10730|2.0.5.1|   58d685e|
+-------+----------+-------+----------------+-------------+-------+----------+

2.16 CONFIG_NODES Table

This system table is available starting from version V2.0.5.

  • Contains information about all ConfigNodes in the cluster.
  • The table structure is as follows:
Column NameData TypeColumn CategoryDescription
node_idINT32TAGNode ID
config_consensus_portINT32ATTRIBUTEConfigNode consensus port
roleSTRINGATTRIBUTEConfigNode role
  • Only administrators are allowed to perform operations on this table.
  • Query example:
IoTDB> select * from information_schema.config_nodes 
+-------+---------------------+------+
|node_id|config_consensus_port|  role|
+-------+---------------------+------+
|      0|                10720|Leader|
+-------+---------------------+------+

2.17 DATA_NODES Table

This system table is available starting from version V2.0.5.

  • Contains information about all DataNodes in the cluster.
  • The table structure is as follows:
Column NameData TypeColumn CategoryDescription
node_idINT32TAGNode ID
data_region_numINT32ATTRIBUTENumber of DataRegions
schema_region_numINT32ATTRIBUTENumber of SchemaRegions
rpc_addressSTRINGATTRIBUTERPC address
rpc_portINT32ATTRIBUTERPC port
mpp_portINT32ATTRIBUTEMPP communication port
data_consensus_portINT32ATTRIBUTEDataRegion consensus port
schema_consensus_portINT32ATTRIBUTESchemaRegion consensus port
  • Only administrators are allowed to perform operations on this table.
  • Query example:
IoTDB> select * from information_schema.data_nodes 
+-------+---------------+-----------------+-----------+--------+--------+-------------------+---------------------+
|node_id|data_region_num|schema_region_num|rpc_address|rpc_port|mpp_port|data_consensus_port|schema_consensus_port|
+-------+---------------+-----------------+-----------+--------+--------+-------------------+---------------------+
|      1|              4|                4|    0.0.0.0|    6667|   10740|              10760|                10750|
+-------+---------------+-----------------+-----------+--------+--------+-------------------+---------------------+

3. Permission Description

  • GRANT/REVOKE operations are not supported for the information_schema database or any of its tables.
  • All users can view information_schema database details via the SHOW DATABASES statement.
  • All users can list system tables via SHOW TABLES FROM information_schema.
  • All users can inspect system table structures using the DESC statement.