comdb2_active_osqls
Information about OSQL requests in the database.
comdb2_active_osqls(type, origin, argv0, where, cnonce, request_id, nops,
start_time, commit_time, nretries)
type- “OSQL” for active osql streams and “BPLOG” for active block processors.origin- Where the request is fromargv0- Program that generates this requestwhere- Stack trace of this requestcnonce- cnonce (client nonce) of this requestrequest_id- UUID of this requestnops- Number of OSQL operationsstart_time- Time when this request is createdcommit_time- Commit time of this requestnretries- Number of retries
comdb2_api_history
Lists information about current and past api connections to the database
comdb2_api_history(host, task, api_driver_name, api_driver_version,
last_seen)
host- Client host nametask- Name of the client programapi_driver_name- Name of the api driver used to establish a connectionapi_driver_version- Version of the api driver used to establish a connectionlast_seen- Last time a connection was established using the api driver
comdb2_appsock_handlers
Lists all available APPSOCK handlers.
comdb2_appsock_handlers(name, usage, exec_count)
name- Name of the APPSOCK handlerusage- Usage informationexec_count- Execution count
comdb2_auto_analyze_tables
Lists auto analyze info about each table. NOTE: save_freq must be > 0 to use this table on a replicant. For most up to date info query on leader node.
comdb2_auto_analyze_tables(tablename, counter, saved, new, percent_of_tbl, last_run_time, needs_analyze_time)
tablename- Name of the tablecounter- Current number of operationssaved- Saved number of operationsnew- Difference betweencounterandsavedpercent_of_tbl- Percent of table that has been modified since last analyzelast_run_time- Last run time of analyze, or NULL if never ranneeds_analyze_time- The first time since it was last run that it was determined that a table needs to be analyzed (only in request mode), NULL if analyze not needed
comdb2_blkseq
Information about BLKSEQ stored in the database. (TODO: Explain BLKSEQ)
comdb2_blkseq(stripe, index, id, size, rcode, time, age)
stripe- Stripe of a BLKSEQ fileindex- Index of a BLKSEQ fileid- Identifier of the requestsize- Size of the BLKSEQ entryrcode- Return code of this requesttime- Epoch time when this BLKSEQ was addedage- Time in seconds since the BLKSEQ was added
comdb2_clientstats
Lists statistics about clients.
comdb2_clientstats(task, stack, host, ip, finds, rngexts, writes,
other_fstsnds, adds, upds, dels, bsql, recom,
snapisol, serial, sql_queries, sql_steps, sql_rows,
svc_time)
task- Name of the client programstack- Stack of the client programhost- Client host nameip- Client IP addressfinds-obsoleterngexts-obsoletewrites-obsoleteother_fstsnds-obsoleteadds-obsoleteupds-obsoletedels-obsoletebsql-obsoleterecom-obsoltesnapisol-obsoleteserial-obsoletesql_queries- Total number of SQL queries executedsql_steps- Total number of steps (basic internal operations) executedsql_rows- Total number of rows returnedsvc_time- Total time taken to execute queries (in milliseconds)
comdb2_cluster
Information about nodes in the cluster.
comdb2_cluster(host, port, is_master, coherent_state)
host- Host name of the nodeport- Port number of the nodeis_master- Is the node master?coherent_state- Is the node coherent?
comdb2_columns
Describes all the columns for all of the tables in the database.
comdb2_columns(tablename, columnnname, type, size, sqltype,
varinlinesize, defaultvalue, dbload, isnullable, lastsequence)
tablename- Name of the tablecolumnname- Name of the columnsize- The storage size of the columnsqltype- The type as recognized by SQLvarinlinesize- The size of the data stored in the column when inlineddefaultvalue- The default value for this columndbload-obsoleteisnullable-Yif this column can hold nullslastsequence- Largest value the column has held (for autoincrement)
comdb2_completion
This table lists all keywords & identifiers based on the current state of the database. cdb2sql uses it to provide auto-completion feature.
comdb2_completion(candidate)
candidate- keywords/identifiers
comdb2_constraints
Shows all foreign key constraints on tables in the database.
comdb2_constraints(tablename, keyname, foreigntablename,
foreignkeyname, iscascadingdelete, iscascadingupdate)
tablename- Name of the tablekeyname- Name of the keyforeigntablename- Name of the foreign tableforeignkeyname- Name of the foreign keyiscascadingdelete-Yif this is a cascading deleteiscascadingupdate-Yif this is a cascading update
comdb2_cron_events
Information about events queued in all the schedulers running.
comdb2_cron_events(name, type, epoch, arg1, arg2, arg3, sourceid)
name- Name of the eventtype- Type of the schedulerepoch- Unix time when the event is intended to runarg1- First argument for the event, usually the shard table name involvedarg2- Generic second argument for the eventarg3- Generic third argument for the eventsourceid- UUID identifying the client generating the event, if any
comdb2_cron_schedulers
Information about schedulers running.
comdb2_cron_schedulers(name, type, running, nevents, description)
name- Name of the schedulertype- Type of the scheduler, as “WALLTIME” for a time cronrunning- Set to1if the scheduler is running an event at this time,0otherwisenevents- How many events are queued in this scheduler?description- Details the purpose of the scheduler; for example, there is a time partition scheduler, or a memory modules stat scheduler
comdb2_fdb_info
The cached remote schemas used for distributed sql execution.
comdb2_fdb_info(dbname, location, tablename, indexname, rootpage, remoterootpage, version)
dbname- Name of the remote database that executes a subset of sqllocation- Name of the remote database class, ‘LOCAL’, ‘DEV’, ‘ALPHA’, ‘BETA’, ‘PROD’tablename- Name of the remote table (NOTE: we cache schemas only for accessed tables)indexname- Name of the index, if this is an index entry, NULL otherwise- `rootpage - Value of the local rootpage sqlite uses to refer to remote table/index
remoterootpage- Value of the remote rootpageversion- Schema version of the remote table; used to pull new schema on access
comdb2_functions
The functions available to call from sql.
comdb2_functions(name)
name- Name of the function
comdb2_keycomponents
Describes all the components of the keys.
comdb2_keycomponents(tablename, keyname, columnnumber, columnname,
isdescending)
tablename- Name of the tablekeyname- Name of the keycolumnnumber- Position ofcolumnnameinkeynamecolumnname- Name of a column inkeynameisdescending-Yif this column is descending
comdb2_keys
Describes all of the keys in the database.
comdb2_keys(tablename, keyname, keynumber, isunique, isdatacopy,
isrecnum, condition, ispartialdatacopy)
tablename- Name of the tablekeyname- Name of the keyisunique-Yif this key is uniqueisdatacopy-Yif the data is inlined with this keyisrecnum-Yif this key has recnumscondition- Where condition for this indexuniqnulls-Yif this key treats NULL values as uniqueispartialdatacopy-Yif some subset of the data is inlined with this key
comdb2_keywords
Describes all the keywords used in the database. A reserved keyword needs to be quoted when used as an identifier.
comdb2_keywords(name, reserved)
name- Name of the keywordreserved- ‘Y’ if the keyword is reserved, ‘N’ otherwise
comdb2_limits
Describes all the hard limits in the database.
comdb2_limits(name, description, value)
name- Name of the limitdescription- Description of the limitvalue- Value of the limit
comdb2_locks
Lists all active comdb2 locks.
comdb2_locks(thread, lockerid, mode, status, object, locktype, page)
thread- Thread Id of the owner threadlockerid- Locker Idmode- Lock mode (DIRTY_READ,IREAD,IWR,IWRITE,NG,READ,WRITE,WRITEADD,WRITEDEL,WAS_WRITE,WAIT)status- Status (ABORT,ERROR,FREE,HELD,WAIT,PENDING,EXPIRED)object- Locked objectlocktype- Lock type (PAGE,HANDLE,KEYHASH,ROWLOCK,MINMAX,TABLELOCK,STRIPELOCK,LSN,ENV)page- Page number
comdb2_logical_operations
Lists all logical operations
comdb2_logical_operations(commitlsn, opnum, operation, tablename, oldgenid,
oldrecord, genid, record)
commitlsn- Log sequence numberopnum- Index of operation within a transactionoperation- Type of logical operationtablename- Table nameoldgenid- Old record’s generation Idoldrecord- Old recordgenid- New record’s generation Idrecord- New record
comdb2_metrics
Shows various operational and performance metrics.
comdb2_metrics(name, description, type, value, collection_type)
name- Name of the metricsdescription- Descriptiontype- Type of the metricsvalue- Valuecollection_type- Is valuecumulativeorlatest? A cumulative metric is a cumulative sum over the time; A latest metric is a instantaneous measurement.
comdb2_net_userfuncs
Statistics about network packets sent across cluster nodes.
comdb2_net_userfuncs(service, userfunc, count, totalus)
service- Class of network packetuserfunc- Network packet type (handler/user function)count- Total number of invocations of this user functiontotalus- Total execution time of this user function (in microseconds)
comdb2_opcode_handlers
Lists all opcode handlers available in Comdb2.
comdb2_opcode_handlers(opcode, name)
opcode- Number assigned to the opcode handlername- Name of the opcode handler
comdb2_partial_datacopies
Lists all of the partial datacopy columns for each relevant key in the database.
comdb2_partial_datacopies(tablename, keyname, columnname)
tablename- Name of the table with partial datacopykeyname- Name of the key with partial datacopycolumnname- Name of the column included in partial datacopy forkeyname
comdb2_plugins
Lists all plugins currently available in Comdb2.
comdb2_plugins(name, description, type, version, is_static)
name- Name of the plugindescription- Descriptiontype- Type of pluginversion- Plugin versionis_static- Is plugin static or dynamic?
comdb2_procedures
List all stored procedures in the database.
comdb2_procedures(name, version, client_versioned, default, src)
name- Name of the stored procedureversion- Stored procedure versionclient_versioned- Is client versioned?default- Is default?src- Source
comdb2_query_plans
List all query plans for each fingerprint/query in the database.
comdb2_query_plans(fingerprint, plan_fingerprint, normalized_sql, plan, total_cost_per_row, num_executions, avg_cost_per_row)
fingerprint- Fingerprint of the queryplan_fingerprint- Fingerprint of the query plannormalized_sql- Query associated with the fingerprintplan- Query plan for this fingerprint that includes the tables and indices traversedtotal_cost_per_row- The sum of all of the cost per rows (in results set) each time this query plan is executed for this querynum_executions- The number of times this query plan is executed for this queryavg_cost_per_row- Average cost per row (in results set), calculated bytotal_cost_per_row/num_executions
comdb2_queues
List all queues in the database.
comdb2_queues(queuename, spname, head_age, depth, total_enqueued, total_dequeued)
queuename- Name of the queuespname- Stored procedure attached to the queuehead_age- Age of the head element in the queuedepth- Number of elements in the queuetotal_enqueued- Total number of elements added since process starttotal_dequeued- Total number of elements removed since process start
comdb2_repl_stats
Replication statistics.
comdb2_repl_stats(host, bytes_written, bytes_read, throttle_waits, reorders,
avg_wait_over_10secs, max_wait_over_10secs,
avg_wait_over_1min, max_wait_over_1min)
host- Host namebytes_written- Number of bytes writtenbytes_read- Number of bytes readthrottle_waits- Number of throttle waitsavg_wait_over_10secs- Average of waits over 10 secondsmax_wait_over_10secs- Maximum of waits over 10 secondsavg_wait_over_1min- Average of waits over a minutemax_wait_over_1min- Maximum of waits over a minute
comdb2_replication_netqueue
This table lists the current state of the replication network queue per node.
comdb2_replication_netqueue(machine, total, min_lsn, max_lsn, alive,
alive_req, all_req, dupmaster, file, file_req,
log, log_more, log_req, master_req, newclient,
newfile, newmaster, newsite, page, page_req,
plist, plist_req, verify, verify_fail,
verify_req, vote1, vote2, log_logput,
pgdump_req, gen_vote1, gen_vote2, log_fill,
uncategorized, unknown)
machine- Host name of the nodetotal- Number of total messagesmin_lsn- Minimum LSN in the queuemax_lsn- Maximum LSN in the queuealive- Number of ‘I am alive’ messagesalive_req- Number of requests for an alive messageall_req- Number of requests for all log records greater than LSNdupmaster- Number of ‘Duplicate master detected’ messagesfile- Number of ‘page of a database file’ messagesfile_req- Number of requests for a database filelog- Number of log record messageslog_more- Number of ‘more log records to request’ messageslog_req- Number of requests for a log recordmaster_req- Number of ‘Who is the master’ messagesnewclient- Number of ‘presence of new clients’ announcementsnewfile- Number of ‘log file change’ announcementsnewmaster- Number of ‘who the master is’ announcementsnewsite- Number of ‘heard from a new site’ announcementspage- Number of ‘database page’ messagespage_req- Number of requests for a database pageplist- Number of ‘database page list’ messagesplist_req- Number of requests for a page listverify- Number of ‘verification log record’ messagesverify_fail- Number of ‘client is outdated’ messagesverify_req- Number of requests for a log record to verifyvote1- Number of ‘basic information for election’ messagesvote2- Number of ‘you are master’ messageslog_logput- Master internal, same aslogpgdump_req- Number of requests to dump a page for a given file Id (for debugging)gen_vote1- Same as vote1 (also contains the generation number)gen_vote2- Same as vote2 (also contains the generation number)log_fill- Number of log_fill messagesuncategorized- Number of ‘uncategorized’ messagesunknown- Number of ‘unknown’ messages
comdb2_sample_queries
A collection of unnormalized queries run in the db. Only the earliest unnormalized query associated with a fingerprint, plan fingerprint combo will be present in the table.
comdb2_sample_queries(fingerprint, plan_fingerprint, query, query_plan, params, timestamp)
fingerprint- Fingerprint of the queryplan_fingerprint- Fingerprint of the query planquery- Unnormalized query associated with the fingerprintquery_plan- Query plan for this fingerprint that includes the tables and indices traversedparams- Parameters associated with querytimestamp- Timestamp that this query was run (time that it was added to this table)
comdb2_sqlpool_queue
Information about SQL query pool status.
comdb2_sqlpool_queue(time_in_queue_ms, sql)
time_in_queue_ms- Total time spent in queue (in milliseconds)sql- SQL query
comdb2_systables
List all available system tables in Comdb2.
comdb2_systables(name)
name- Name of the system table
comdb2_systablepermissions
Table of permissions for system tables in the database.
comdb2_systablepermissions(tablename, username, READ, WRITE, DDL)
tablename- Name of the system tableusername- Name of the userREAD-Yifusernamehas read access totablenameWRITE-Yifusernamehas write access totablenameDDL-Yifusernamecan modifytablenameschema
comdb2_tables
List of all tables in the database
comdb2_tables(tablename)
tablename- Name of the table
comdb2_tablepermissions
Permissions for tables in the database
comdb2_tablepermissions(tablename, username, READ, WRITE, DDL)
tablename- Name of the tableusername- Name of the userREAD-Yifusernamehas read access totablenameWRITE-Yifusernamehas write access totablenameDDL-Yifusernamecan modifytablenameschema
comdb2_tablesizes
Sizes on disk of tables in the database
comdb2_tablesizes(tablename, bytes)
tablename- Name of the tablebytes- Size of the table in bytes
comdb2_table_metrics
Lists real-time metrics for tables in the database
comdb2_table_metrics(table_name, num_queries, num_index_used, num_records_read,
num_records_inserted, num_records_updated, num_records_deleted)
table_name- Name of the tablenum_queries- Number of queries ran on the tablenum_index_used- Number of times a table index was usednum_records_read- Number of data records readnum_records_inserted- Number of data records insertednum_records_updated- Number of data records updatednum_records_deleted- Number of data records deleted
comdb2_table_properties
Lists miscellaneous table properties
comdb2_table_properties(table_name, odh, compress, blob_compress,
in_place_updates, instant_schema_change)
table_name- Name of the tableodh-Yif on disk headers are enabledcompress- Type of compression usedblob_compress- Type of blob compression usedin_place_updates-Yif in-place updates are enabledinstant_schema_change-Yif instant schema change is enabled
comdb2_tag_columns
Shows the columns for each schema tag
comdb2_tag_columns(tablename, tagname, name, indx, type, offset,
length, datalength, flags, expr, defaultvalue,
dbload, conversionflags, conversiondbpad,
conversionstep, blobindx)
tablename- Name of the tabletagname- Name of the tagname- Name of the columnindx- Index of the column in the tagtype- Type of the columnoffset- Offset of the column in the taglength- Bytes length of the column in the tagdatalength- For dyntags, length of the client supplied bufferflags- Flags for column INDEX_DESCENT = 1 set for index members, to reverse order NO_NULL = 2 do not allow nullsexpr- Set if the column is an expressiondefaultvalue- Dbstore default value for a columndbload- Dbload value for a columnconversionflags- Flags the alter the conversion FLD_CONV_DBPAD - special byte array handling FLD_CONV_TZONE - timezone is specifed FLD_CONV_LENDIAN - column is little endian FLD_CONV_TRUNCATE - special handling for out of range stringsconversiondbpad- For byte arrays. Converting from - if the destination is smaller, the lost bytes must match dbpad or it is a conversion failure. Converting to - if the destination is larger then the spare bytes will be padded with dbpad. If dbapd==-1 then the source and destination must match.conversionstep- Applies to out of range strings 0 for truncate only 1 for truncate and incrementblobindex- If the column is a blob, its index, otherwise -1
comdb2_tags
Shows the schema tags for tables
comdb2_tags(tablename, tagname, ixnum, size, columns, sqlitetag, csctag,
numblobs, numindexes)
tablename- Name of the tabletagname- Name of the tagixnum- If this is a schema index, its index in the list of indexessize- Length of the index (recsize)numcolumns- Number of columns in the tagsqlitekeyname- If this is a schema index, the name that sqlite uses for itkeyname- If this is an index, name of the indexnumblobs- Number of blob columns in the tagnumndexes- If this is a table tag schema, how many indexes
comdb2_temporary_file_sizes
Reports sizes of temporary files.
comdb2_temporary_file_sizes(type, bytes)
type- Temporary file type. Can be one oftemptables,sqlsorters,blkseqsandothersbytes- Size in bytes
comdb2_threadpools
Information about thread pools in the database.
comdb2_threadpools(name, status, num_thd, free_thd, peak_thd, num_creates,
num_exits, num_passed, num_enqueued, num_dequeued,
num_timeout, num_failed_dispatches, min_thds, max_thds,
peak_queue, max_queue, queue, long_wait_ms,
linger_secs, stack_size, max_queue_override,
max_queue_age_ms, exit_on_create_fail, dump_on_full)
name- Name of the thread poolstatus- Status of the thread poolnum_thd- Total number of threadsfree_thd- Number of free threadspeak_thd- Peak number of threadsnum_creates- Total number of thread creatednum_exits- Total number of threads exitednum_passed- Work items done immediatelynum_enqueued- Number of work items enqueuednum_dequeued- Number of work items dequeuednum_timeout- Number of work items timed-outnum_failed_dispatches- Number of failed dispatchesmin_thds- Desired number of threadsmax_thds- Maximum number of threadspeak_queue- Work queue peak sizemax_queue- Work queue maximum sizequeue- Work queue current sizelong_wait_ms- Long wait alarm thresholdlinger_secs- Thread linger timestack_size- Thread stack sizemax_queue_override- Maximum queue overridemax_queue_age_ms- Maximum queue ageexit_on_create_fail- If ‘Y’, exit on failure to create threaddump_on_full- If ‘Y’, dump on queue full
comdb2_timepartevents
Information about time partition events in the dedicated cron scheduler (alias for filtered comdb2_cron_events system table).
comdb2_timepartevents(name, type, arg1, arg2, arg3, sourceid)
-
name- Name of the event (AddShardRollShardDropShard) type- Type of the scheduler, here defaults to “timepart_sched”arg1- First argument for the event, usually the shard table name involvedarg2- Generic second argument for the eventarg3- Generic third argument for the eventsourceid- UUID identifying the partition generating the event, if any
comdb2_timepartitions
Information about time partitions.
comdb2_timepartitions(name, period, retention, nshards, version, shard0name, starttime, sourceid)
name- Name of the time partition-
period- How often this partition rolls out? (DAILYWEEKLYMONTHTLYYEARLY) retention- How many shards are preserved; older gets removed when retention is reachednshards- How many shards are already present, which is retention for fully grown time partitionsversion- Schema change version, matching the version of underlying tablesshard0name- Name of the initial table used to seed the time partitionstart- “epoch” seconds when the first rollout happens/happenedsourceid- UUID identifying the partition
comdb2_timepartpermissions
Table of permissions for time partitions in the database.
comdb2_timepartpermissions(tablename, username, READ, WRITE, DDL)
tablename- Name of the time partitionusername- Name of the userREAD-Yifusernamehas read access totablenameWRITE-Yifusernamehas write access totablenameDDL-Yifusernamecan modifytablenameschema
comdb2_timepartshards
Information about time partition shards.
comdb2_timepartshards(name, shardname, start, end)
name- Name of the time partitionshardname- Name of the underlying shard tablestart- Minimum “epoch” seconds for the shard; all rows in it were inserted after this timeend- Maximum “epoch” seconds for the shard; all rows in it were inserted before this time
comdb2_timeseries
This table lists various metrics.
comdb2_timeseries(metric, time, value)
metric- Name of the metrictime- Timestampvalue- Value
comdb2_transaction_logs
Lists all the transaction log records.
comdb2_transaction_logs(lsn, rectype, generation, timestamp, payload)
lsn- Log sequence numberrectype- Record typegeneration- Generation IDtimestamp- Timestamppayload- Paylod
comdb2_transaction_state
Lists the state of all threads processing transactions.
comdb2_transaction_state(state, time, machine, opcode, function)
state- Thread state (‘busy’ or ‘idle’)time- The amount of time (ms) that the thread has been processing this requestmachine- The ID of the machine that the thread is running onopcode- The opcode that the thread is processingfunction- The backend function that the thread is running
comdb2_triggers
Lists triggers in the database.
comdb2_triggers(name, type, tbl_name, event, col, seq)
name- Name of the triggertype- Type of the triggertbl_name- Name of the tableevent- Event to trigger oncol- Column to trigger onseq- ‘Y’ if sequences are enabled, ‘N’ otherwise
comdb2_tunables
Describes all the knobs in the database.
comdb2_tunables(name, description, type, value, read_only)
name- Name of the tunabledescription- Description of the tunabletype- Type of the tunablevalue- Current value of the tunableread_only- ‘Y’ if the tunable is READ-ONLY, ‘N’ otherwise
comdb2_type_samples
Describes the sample values of all the data types supported by Comdb2.
comdb2_type_samples(integer, real, cstring, blob, datetime, intervalym,
intervalds, datetimeus, intervaldsus)
integer- Sample value of ‘integer’ typereal- Sample value of ‘real’ typecstring- Sample value of ‘cstring’ typeblob- Sample value of ‘blob’ typedatetime- Sample value of ‘datetime’ typeintervalym- Sample value of ‘intervalym’ typeintervalds- Sample value of ‘intervalds’ typedatetimeus- Sample value of ‘datetimeus’ typeintervaldsus- Sample value of ‘intervaldsus’ type
comdb2_users
Table of users for the database that do or do not have operator access.
comdb2_users(username, isOP)
username- Name of the userisOP- ‘Y’ if ‘username’ has operator access
comdb2_sc_history
System table containing history of the schemachanges done in the database.
comdb2_sc_history(name, start, status, seed, last_updated,
converted, error)
name- Name of the table.start- Start time of the schema change.status- Last/Final status of the schema change.seed- Seed (ID) of schema changelast_updated- Time of the last status change.converted- Number of records converted.error- Error message of the schema change.
comdb2_sc_status
Information about current/most recent schema change per table.
comdb2_sc_status(name, type, newcsc2, start, status, seed, last_updated,
converted, error)
name- Name of the table.type- Type of the schema change.newcsc2- New schema in csc2 format.start- Start time of the schema change.status- Current status of the schema change.seed- Seed (ID) of schema change running for this table (NULL if not currently running).last_updated- Time of the last status change.converted- Number of records converted.error- Error message of the schema change.
comdb2_schemaversions
List of all versions of table schemas stored in llmeta.
comdb2_schemaversions(name, csc2, version)
tablename- Name of the table.csc2- Schema in csc2 format.version- Numeric version associated with this schema version in llmeta.
comdb2_views
List of views in the database.
comdb2_views(name, definition)
name- Name of the viewdefinition- View definition
comdb2_memstats
Heap memory usage
comdb2_memstats(name, scope, total, used, unused, peak)
name- name of the allocator.scope- thread type of the allocator.total- total number of bytes (used+unused) in the allocatorused- number of used bytes in the allocatorunused- number of unused bytes in the allocatorpeak- maximum number of bytes used by the allocator since it was created
comdb2_stacks
Generic stack collection
comdb2_stacks(id, hits, stack)
id- index of this stack.hits- number of times this stack has been collected.stack- flattened stack.
comdb2_stringrefs
Active string references
comdb2_stringrefs(string, func, line, refcnt, stack)
string- stringref string value.func- function which allocated the string.line- line number which allocates the string.refcnt- number of active references.stack- stack which allocated string.