Maintenance Release Changelog v8. 7
On this page
2025-10-23 Version 8. 7. 44
-
Enhancement: Improved phonehome security by adding remote endpoint verification.
-
Enhancement: Added
source_to thetype config_shown in thejson information_.schema. PIPELINES view -
Enhancement: Upgraded the Almalinux version to Almalinux 10.
-
Enhancement: Updated the zookeeper version.
-
Bugfix: Fixed an issue where the
ALTER TABLEcommand could hang and become unkillable due to a type conversion error occurring during the alter operation. -
Bugfix: Fixed an issue that caused a stalled cluster in the presence of many concurrent
DROP TEMPORARY TABLEcommands. -
Bugfix: Fixed an issue where
memsql_would not work with specific values of theexporter ssl_engine variable.cipher
2025-10-01 Version 8. 7. 43
-
Enhancement: Added a new
blob_column forcompute_ id columnar_andsegments mv_information schema tables.columnstore_ files
2025-09-25 Version 8. 7. 42
-
Bugfix: Fixed a deadlock in result table creation during reshuffle with the always-false filter.
-
Enhancement: Manually register the path to the Java 11 library.
This path is set with the java_engine variable.pipelines_ java11_ path -
Bugfix: Enable full enclosure optimization for queries such as
SELECT COUNT(t.ifa) FROM t t.is a non-nullable column.a No longer performs segment scans.
2025-09-16 Version 8. 7. 41
-
Internal updates.
2025-08-27 Version 8. 7. 40
-
Bugfix: Fixed a crash when a
BM25function in a subselect referenced a table from the outer select. -
Bugfix: Disabled repartition on expressions for Materialized Common Table Expressions (MCTEs).
-
Bugfix: Fixed an issue where certain commands (e.
g. DROP TABLE) could hang due to aborted queries caused by stuck collocated services triggered by external functions.
2025-08-08 Version 8. 7. 39
-
Enhancement: Added knob to disable cardinality estimates on JSON/BSON columns during analyze.
-
Enhancement: Segment elimination is now only applied to
INclauses where the left-hand side is a table column field. -
Bugfix: Fixed query performance issue caused by heuristic estimate selectivity being overwritten.
-
Bugfix: Updated third party libraries to fix security vulnerabilities.
2025-07-02 Version 8. 7. 38
-
Bugfix: Bumped the _
bt timeout from 60 seconds to 180 seconds.
2025-06-24 Version 8. 7. 37
-
Enhancement: Users with database visibility can now query the
*_information schema views in the respective database.BOTTOMLESS_ * CLUSTERpermissions are no longer enforced for querying these views. -
Enhancement: Added Lucene logs to the cluster report.
-
Bugfix: Fixed a leak in a rare scenario.
-
Bugfix: Fixed the
ER_error onBAD_ TABLE_ ERROR UPDATEorDELETEqueries with a specific shape. -
Bugfix: Fixed a crash in a shallow copy of a table with a pending
ALTERoperation. -
Bugfix: Fixed an issue where periodic autostats was disabled when it should not have been.
-
Bugfix: Fixed crash in lockfree hashtable when engine is under high memory pressure.
Report out of memory error instead. -
Bugfix: Fixed an issue that led to undefined behavior if a node failed concurrently with the computation of the replication distribution tree.
2025-05-27 Version 8. 7. 36
-
Enhancement: Improved error message for parameter count mismatch during query parsing.
-
Bugfix: Fixed a bug that caused filter-aware optimizations to not be applied above MCTE when involved in hash joins.
2025-05-21 Version 8. 7. 35
-
Enhancement: Extended a rewrite to allow merging derived tables with json functions.
-
Enhancement: Prevented the destination table from being replaced by projection on update or delete.
2025-05-13 Version 8. 7. 34
-
Enhancement: Added more metrics to the views,
MV_andCLOUD_ PER_ COMPUTE_ REMOTE_ STATS MV_for tracking of retention log chunks and snapshots.CLOUD_ REMOTE_ STATS -
Enhancement: New variables (Note, these should only be set with guidance from SingleStore):
-
repl_: limits the number of page descriptors in the page map that a 'ReplLog' can use before stalling new txs.page_ desc_ limit_ before_ stall See 'ReplLog::StallForPageMap'. The default 256K page desciptor limit means the hash table will not have load greater than 4. -
repl_: limits the number of IO buffers that a 'ReplLog' can use before stalling new txs.io_ buffer_ limit See 'ReplLog::StallForPageMap'. 128 IO buffers is 16MB since each IO buffer is 128K. -
[dr_: replication tries to set both send and receive buffer sizes to reduce waits on TCP ack packets.]repl_ network_ buffer_ size 8MB is a sane battle-tested value. Can be set for both DR and non-DR replicas. -
[dr_: when sending logs or snapshots to a replica limits chunk size to this value.]repl_ max_ chunk_ size Too long of a chunk increases the chance of timeout waiting for the replica's response packet (since the replica must process the entire chunk before acking). This defaults to 8MB - a sane limit chunk size to this value. Maximum value is 1GB and it must be divisible by 128kb so it is a multiple of io buffer size. Can be set for both dr and non-DR replicas.
-
-
BugFix: Fixed an issue to use a full table scan instead of vector index scan if enough rows are not produced.
2025-05-02 Version 8. 7. 33
-
Internal updates.
2025-04-30 Version 8. 7. 32
-
Enhancement: Added estimates for query memory usage based on static row count and row size estimates to improve Workload Manager (WM) memory management.
-
Bugfix: Fixed a
NULLvalue inline bug by adding typecast operations above the referencing field. -
Bugfix: Fixed an issue where a node that had not been upgraded could trigger undefined behavior if the node's
processlistwas queried while the node was processing an internal RPC.
2025-04-22 Version 8. 7. 31
-
Enhancement: Improved optimization speed of parameterized
IN-lists by limiting traversal depth. -
Enhancement: Enabled auto
PROFILEforINSERT .and. . SELECT REPLACE .query shapes.. . SELECT -
Enhancement:
OPTIMIZE TABLE .is now more responsive to. . INDEX KILL QUERYstatements. -
Bugfix: Fixed an issue that caused a crash when a query referenced too many tables.
-
Bugfix: Fixed a crash while creating a shallow table copy due to a deleted column in the source table.
-
Bugfix: Disabled vector range search filter during
JOINs to avoid an engine crash.
2025-04-18 Version 8. 7. 30
-
Fixed a crash while creating a shallow table copy due to a deleted column in the source table.
2025-04-08 Version 8. 7. 29
-
Bugfix: Fixed a bug in
JSON_join pushdown optimization that occurred when the JSON value being extracted fromTO_ ARRAY() table_is a JSON array.col -
Bugfix: Fixed an issue to prevent LRU eviction from stalling when several table modules are stale.
-
Bugfix: Reduced contention on a global lock controlling modules, affecting code loading and unwinding of exceptions.
-
Bugfix: Fixed a memory corruption issue caused by a rare race condition involving
MV_information schema view.ACTIVE_ TRANSACTIONS
2025-03-31 Version 8. 7. 28
-
Enhancement: General improvements and optimizations for
CHECK BOTTOMLESS CHECKSUMcommand. -
Enhancement: Added support for updated Standard and Premium licenses.
-
Bugfix: Fixed
ALTER RESOURCE POOLto respect queue depth constraints. -
Bugfix: Fixed a bug that produced incorrect results when performing a hash join with a condition that compares mismatched types where one of the types is BSON.
-
Bugfix: Removed garbage collection from cleaning up arrangements when such garbage collection is already in process.
2025-03-26 Version 8. 7. 27
-
Enhancement: Added support for the
LIMITclause in prepared statements. -
Enhancement: Added an option to run queries that failed asynchronous compilation, allowing users to introspect the compilation results.
-
Enhancement: Added a feature to record Kafka properties of a message.
-
Bugfix: Fixed an issue impacting creating or altering a resource pool with a CPU percentage limitation after a MA failover.
-
Bugfix: Fixed a bug that occurred when a query used
I0as a column name. -
Bugfix: Reserved memory space for
segment_in the pseudo column's MemoryFile.id
2025-03-11 Version 8. 7. 26
-
Bugfix: Fixed a bug that caused a node to crash when the variable
ignore_is ON and theforeign_ keys ALTER TABLEcommand is used to add a foreign key. -
Bugfix: Changed the output projection DDL to
CREATE PROJECTIONinstead ofCREATE TABLE _in debug profile.$_ table_ name_ $ -
Bugfix: Fixed a bug to prevent a crash when using FTS v2 with CTE.
2025-03-05 Version 8. 7. 25
-
Enhancement: Added an engine variable
disk_that disables disk plan garbage collection on startup.plan_ gc_ pause_ seconds_ on_ startup This variable prevents hot plans from being unintentionally disk garbage collected. -
Bugfix: Fixed a crash that occurred when aggregator functions are used with
VECTORtype data inside other built-ins. -
Bugfix: Fixed a bug that caused incorrect results when running
INFER PIPELINE CSV.
2025-02-19 Version 8. 7. 24
-
Enhancement: The
DROPandALTER TABLEcommands no longer have to wait for the plan garbage collector. -
Enhancement: Computed column definitions now support the
SPLITfunction. -
Enhancement: Added a new engine variable
scheduler_that specifies the threshold for triggering the verbose logging of scheduler thread timing.slow_ loop_ seconds -
Enhancement: Added a new engine variable
scheduler_that specifies the threshold for triggering logging of slow ready queue draining.slow_ ready_ queue_ seconds -
Bugfix: Fixed a bug that caused CDC-in pipelines to fail while inferring the table schema, with the "Failed to allocate slot in the extractor pool" error.
-
Bugfix: Fixed a bug where a CDC pipeline gets stuck while waiting for data.
-
Bugfix: Fixed a bug where a compilation failure in a cross site query crashed a node.
-
Bugfix: Fixed a bug in
JSON_query rewrite for query shapes with theARRAY_ CONTAINS_ STRING LIMITclause.
2025-01-21 Version 8. 7. 23
-
Enhancement: Improved pipeline error clearing.
Additional errors are cleared when CLEAR PIPELINES ERRORSis run or when thepipelines_limit is reached.errors_ retention_ minutes -
Bugfix: Fixed a bug in lateral join; lateral join subselect's projection fields' aliases are now preserved.
2025-01-14 Version 8. 7. 22
-
New feature: Added support for the following parameter in the
CONFIGclause ofCREATE PIPELINE AS .statement:. . LOAD DATA S3 -
file_: Decompresses files with the specified extensions.compression
Refer to S3 Configurations for more information.
-
-
Enhancement: Improve behavior of garbage collection for plancache.
-
Enhancement: Introduced support for placeholders for partition ID and timestamp in the
SELECT INTO .command.. . file name -
Enhancement: Added logging for LRU compiled unit eviction.
-
Bugfix: Fixed an issue where the engine halted while deleting a user when there were multiple users with the same user name but different host names.
-
Bugfix: Fixed an issue that caused
DROP DATABASEand some other cluster management commands to wait indefinitely for resources.
-
Bugfix: Fixed a bug with updates and asserts using
JSON_predicates.ARRAY_ CONTAINS_ <type> -
Bugfix: Fixed bottomless upload throttling criteria.
-
Bugfix: Blocked creation of temporary table as a shallow copy.
2024-12-10 Version 8. 7. 21
-
Enhancement: Added the
TABLE_column to theNAME LOAD_information schema view.DATA_ ERRORS TABLE_is the name of the table associated with the error.NAME -
Bugfix: Fixed handling of heartbeat messages in the MongoDB® extractor in debug mode.
-
Bugfix: Fixed display of default BSON and string values with null-terminators in the information schema.
-
Bugfix: Removed trailing dot for decimal column types that have scale equal to 0.
-
Bugfix: Fixed
IN-list index matching for columnstore tables when a query has multipleIN-list predicates. -
Bugfix: Fixed a bug that caused an invalid optree error after the
JsonArrayContainsToTableBuiltinrewrite. -
Bugfix: Allowed cached table memory to be freed for empty tables in replica databases.
(8. 5. 37) -
Bugfix: Fixed a crash that occurred during spilling when executing a query with a large number of
GROUP BYcolumns.(8. 5. 37) -
Bugfix: Fixed an issue where attaching a leaf node to the Master Aggregator (MA) failed if the MA was still starting up.
-
Bugfix: Fixed an issue where some point-in-time-recovery (PITR) operations failed when started from a restored snapshot.
-
Bugfix: Fixed a rare issue where
ALTERoperation and two-phase commit (2PC) caused index corruption. -
Bugfix: Fixed an issue with lagging in binlogs offsets processing in MySQL CDC pipelines.
2024-11-19 Version 8. 7. 20
-
Bugfix: Fixed a lateral join parsing bug.
(8. 7. 20) -
New feature: Added a
SHOW CDC EXTRACTOR POOLcommand that displays information about the CDC-in pipelines.Refer to SHOW CDC EXTRACTOR POOL for more information. (8. 7. 20) -
Bugfix: Fixed an issue that caused a deadlock between the
DROP TABLEandAGGREGATOR SYNC AUTO_queries.INCREMENT -
Bugfix: Fixed an issue where the Master Aggregator could temporarily stop behaving like the Master Aggregator after being restarted.
(8. 7. 20) -
Enhancement: Allow rewrite for joining tables on the
JSON_function to support multiple predicates of that form on different columns.ARRAY_ CONTAINS_ <type> (8. 7. 20) -
Enhancement: Added the
MV_information schema view that contains a summary of remote API calls made from the engine.BOTTOMLESS_ API_ EVENTS_ SUMMARY Refer to MV_ BOTTOMLESS_ API_ EVENTS_ SUMMARY for more information. (8. 7. 20) -
Enhancement: Added information on remote API calls and bottle service reliability metrics to
MV_information schema view.BOTTOMLESS_ STATUS_ EXTENDED -
Enhancement: Added metrics to track the availability of unlimited storage and the bottle service to
MV_information schema view.BOTTOMLESS_ SUMMARY (8. 7. 20) -
Bugfix: Fixed an issue where repair operation gets stuck while converting milestones.
(8. 7. 20) -
Enhancement: Implemented heartbeats for bottle service.
Each node in the cluster now validates the availability of bottle service every minute and records any consecutive failures in the LMV_information schema view.EVENTS (8. 7. 20) -
Bugfix: Fixed an issue that caused dangling compute sessions after a failed
ALTER DATABASEcommand.(8. 7. 20) -
Bugfix: Fixed an edge case; common table expressions (CTEs) are now recognized in subselect to join rewrite.
(8. 7. 20) -
Bugfix: Fixed an error in
BSON_pushdown.MATCH_ ANY() (8. 7. 20) -
Bugfix: Fixed a bug that caused a query to fail in a specific situation when using
SEARCH OPTIONSwith vector index search.(8. 7. 20) -
Bugfix: Fixed an issue caused when multi-part names were used in common table expressions (CTEs) within
UNION.(8. 7. 20) -
Bugfix: Fixed issue that causes uneven time distribution in extractor pool.
(8. 7. 20) -
Bugfix: Fixed the result of
ORDER BY <sort_queries on tables with a sort key column defined inkey> LIMIT DESCorder.(8. 7. 20)
2024-11-05 Version 8. 7. 19
-
Enhancement: Improved out of memory (OOM) error message to make the message more accurate.
-
Bugfix: Fixed a crash that could occur when columns were dropped with
ALTER TABLE. -
Bugfix: Fixed an issue where left join sometimes returned an incorrect result when spilling occurred.
-
Bugfix: Fixed an issue that could lead to new connections hanging.
2024-10-21 Version 8. 7. 18
-
Enhancement: Improved the performance of regular expression (regex) operations.
2024-10-15 Version 8. 7. 17
-
Bugfix: Additional binlog position updates for CDC-in pipelines in the extractor pool queue.
-
Enhancement: Added a new filter derivation rewrite controlled by the
optimizer_engine variable.not_ null_ filter_ derivation -
Enhancement: Improved the performance of
REPLACEquery into a columnstore table when table-level locking is triggered. -
Enhancement: Added a variable,
max_, to tune the maximum number of background autostats update workers.autostats_ update_ workers -
Bugfix: Disable
JSON_rewrite in common table expressions (CTEs).ARRAY_ CONTAINS_ <type> -
Bugfix: Fixed an edge case certificate refresh issue for connections to remote storage in long running clusters.
-
Enhancement: Improved the Debezium DDL statements parser.
-
Bugfix: Improved the error message for CDC-in pipelines for insufficient permissions errors.
-
Bugfix: Fixed deadlock in database recovery due to evicting table module holding an open LOCK.
-
Bugfix: Fixed an issue where the garbage collection of a partition database's 2PC transaction table could unnecessarily delay the reprovisioning of the reference database.
-
Bugfix: Fixed an issue with alter repair where the repair job would be created before alter commits.
-
Bugfix: Fixed a race condition where node shutdown could get stuck if it happens concurrently with a partition failover.
-
Bugfix: Fixed a rare bug where
STOP PIPELINEcould write an old extractor cookie into pipeline metadata.
2024-09-30 Version 8. 7. 16
-
Enhancement: Added single-parameter
JSON_builtins.EXTRACT -
Bugfix: Fixed a crash when using a unique key to upsert into a table when JSON column optimization is enabled.
-
Bugfix: Fixed a certificate refresh issue for connections to remote storage in long-running clusters.
-
Bugfix: Fixed some cases of an incorrect transaction ID (txId) for snapshot records.
BeginSnapshot/CommitSnapshotcan now report nestedBeginTransaction/CommitTransactionwhen there are unresolved distributed transactions while the snapshot is taken. -
Enhancement: Added metrics to track the availability of unlimited storage and the bottle service.
-
Enhancement: Added support for query rewrite that enables hash joins when two tables are joined together using the
JSON_function.ARRAY_ CONTAINS_ <type> -
Enhancement: Added bottle service reliability metrics to
MV_.BOTTOMLESS_ STATUS_ EXTENDED -
Enhancement: Fixed the
KILLED_counter inQUERIES MV_.RESOURCE_ POOL_ STATUS -
Enhancement: Added support for query rewrite for certain query patterns with
EXISTSand subselects.
2024-09-24 Version 8. 7. 15
-
Enhancement: Added support for BM25 over multiple columns.
-
Enhancement: Added support for BM25 partition-scoped scoring for Boolean and boost queries.
-
Bugfix: Fixed a rare issue where a membership-related clustering operation could delay the re-provision or deletion of a cluster database.
-
Enhancement: Added the
json_engine variable to control JSON collation, the value of which can either becollation utf8_orbin utf8mb4_.bin -
Enhancement: Improved the logic for selecting vectors close to the distance threshold during vector range search.
2024-09-10 Version 8. 7. 14
-
Bugfix: Fixed an issue where
JSON_queries withMATCH_ ANY() MATCH_evaluated incorrectly on non-array values.ELEMENTS -
Enhancement: Updated
JSON_simplified syntax to allow specifyingMATCH_ ANY() MATCH_by appending a 'ELEMENTS *' to the end of the keypath. -
Enhancement: Added support for BM25 partition-scoped scoring for phrase and proximity search queries.
-
Bugfix: Fixed sporadic reading failures from
MV_.SYSINFO_ CPU
2024-09-06 Version 8. 7. 13
-
Bugfix: Clarified the error message produced in some cases where a snapshot gets aborted.
-
Bugfix: Fixed schema history in incremental snapshot mode for MySQL CDC.
2024-08-26 Version 8. 7. 12
-
New Feature: Added the new
FULLTEXT SERVICE STOPcommand.This command stops the full-text V2 service running on any node connected to the aggregator on which the command is run. Syntax:
FULLTEXT SERVICE STOPFULLTEXT SERVICE STOPrequires thePROCESSpermission.This command is useful when making configuration changes to the full-text service via engine variables that only take effect when the service (re)starts (
fts2_, for example).max_ connections Also can be used to force a reclaim of resources the service might be using before the idle-out time is reached. The service run state can be checked using
SHOW FULLTEXT SERVICE STATUS.(8. 7. 12) -
Enhancement: Significant overall performance improvements for the full-text V2 service.
-
Bugfix: Fixed an intermittent hang under load issue with the full-text V2 service.
-
Bugfix: Reduce
server_collision probability for MySQL CDC.id -
Enhancement: When
parametrize_is enabled, numeric keys will be parametrized as well.json_ keys Also fixed a crash in queries with json extracts within JSON MATCH ANY (when parametrize_is switched on).json_ keys
2024-08-21 Version 8. 7. 11
-
Enhancement: Update to certificate loading behavior.
Prior to this change, only the first certificate was loaded from a server's . pem file specified via the server configuration. Now all certificates are loaded, so if a . pem file contains a certificates chain, then intermediate CA certificates will be returned by the server. -
Enhancement: Updated the distributed OpenSSL license file to to 1.
0. 2zj
2024-08-14 Version 8. 7. 10
-
Bugfix: Fixed an issue that caused INFER of CDC-in pipelines to fail with "Failed to allocate slot in the extractor pool" error after increasing the limit.
-
Bugfix: Fixed an issue where concurrent
DROP TABLEs could block a snapshot from running indefinitely. -
Bugfix: Address an issue with rewriting of scalar subqueries with null-accepting projections.
-
Enhancement: Added
X-Content-Type-Options: nosniff,Strict-Transport-Security: max-age=31536000,Cache-control: no-storeheaders to Data API responses.
2024-08-06 Version 8. 7. 9
-
Enhancement: Added new engine variables for full-text search, used to fine-tune Lucene service connections:
fts2_andsocket_ timeout_ ms fts2_.socket_ ttl_ ms These variables control the service's socket timeout and time-to-live. -
Enhancement: The default value for the
fts2_engine variable has been increased to 100000.max_ connections -
Enhancement: Improved throughput for full-text v2 queries.
-
Enhancement: Optimized full-text queries that contain an
ORDER BY .over a full-text score and optionally filter on the same full-text clause.. . LIMIT . . . -
Bugfix: Fixed an issue in vector range search with
DOT PRODUCTas the distance metric. -
Bugfix: Fixed an issue with lateral join queries with identical aliases.
-
Bugfix: Fixed a possible race condition with DR connections that could cause repeated connection failures when attempting to replicate from the primary.
-
Bugfix: Fixed a rare race condition where PITR would incorrectly operate on an unrecoverable database.
2024-07-30 Version 8. 7. 8
-
Bugfix: Fixed a password validation error on
ADD AGGREGATOR. -
Enhancement: Added a new engine variable:
assume_.udfs_ deterministic This variable controls behavior where SingleStore will do extra work to avoid issues caused by UDFs that return different values when repeatedly invoked (e. g. , are non-deterministic). This variable defaults to false, preserving the existing behavior (since SingleStore version 8. 0), where SingleStore will ensure these computations take place once on an aggregator node. When set to true, SingleStore will avoid this extra layer of coordination (and bottleneck) allowing leaf nodes to independently coordinate. -
Enhancement: Added a new engine variable:
external_.functions_ service_ buffer_ mb Sets the maximum size (in mb) of the memory-mapped region used to communicate between the engine and collocated services. -
Bugfix: Fixed an issue that could occur when replacing JSON expressions with computed columns in
GROUP BYlists. -
Bugfix: Fixed potential deadlock in Lucene service under high load.
-
Bugfix: Fixed an issue where in a VM environment
SHOW LEAVEScould show corrupted latency values due to incorrect values from the system clock if the VM is stopped or migrated. -
Bugfix: Fixed a vector index issue in unlimited storage that could make a vector index blob file in accessible.
2024-07-23 Version 8. 7. 7
-
Enhancement: Added a new engine variable,
sampling_, used to configure sampling in columnstore tables.estimate_ approach See Statistics and Sampling Concepts for more information.
-
Enhancement: Added a method to throttle upload ingest when blob cache has low evictability and running out of disk space is imminent.
This is controlled via two new engine variables: bottomless_andupload_ throttle_ hard_ limit_ cache_ usability bottomless_.upload_ throttle_ soft_ limit_ cache_ usability bottomless_: The usability (free space + evictable space) of blob cache below which all columnstore ingest is throttled.upload_ throttle_ hard_ limit_ cache_ usability bottomless_: The usability (free space + evictable space) of blob cache below which some columnstore ingest is throttled.upload_ throttle_ soft_ limit_ cache_ usability -
Bugfix: Fixed an issue where indexes were not case-sensitive when performing full-text search against JSON keys.
-
Bugfix: Fixed an issue where
ALTER TABLEcould throw errors related to VECTOR-type columns, even if those columns were not part of theALTER. -
Bugfix: Fixed an issue in CDC-in pipelines causing delays between batches.
-
Enhancement: Added Feedback Reoptimization via the
REOPTIMIZESQL command.The command is used to reoptimize a query based on previous executions of it. You can reoptimize a query multiple times, pick execution plans from any iteration, and then choose the best iteration's plan to commit to use. Syntax: REOPTIMIZE [[EXPLAIN] | [COMMIT]] [<reoptimize_level>]For more information, see
REOPTIMIZE.(8. 7. 7) -
Enhancement: Added websocket_
proxy. log to the files managed via Trace Log Rotation. -
Enhancement: Added support for numeric range queries when doing full-text search against JSON fields.
Refer to numeric range queries for more information.
-
Enhancement: Enabled lateral join subselects to reference fields in grandparent
SELECT. -
Bugfix: Fixed an issue that could occur when replacing JSON expressions with computed columns in
GROUP BYlists. -
Enhancement: Enabled
log_andfile_ size_ partitions log_engine variables on SingleStore Helios.file_ size_ ref_ dbs
2024-07-18 Version 8. 7. 6
-
Bugfix: Fixed display of microseconds for default TIMESTAMP(6) column values in system information commands (such as
DESCRIBE TABLEorINFORMATION_).SCHEMA. COLUMNS. COLUMN_ DEFAULT -
Bugfix: Fixed an issue where user defined variables could read collation-related variables incorrectly during a
SET @var = .command.. . -
Bugfix: Fixed a table eviction issue that can crash a node when replaying straight-to-disk inserts on unique key tables during database recovery.
-
Bugfix: Fixed an issue in MongoDB® CDC-in pipelines which blocks data ingestion after
ALTER PIPELINE. -
Enhancement: Allow NULL values in JSON columns when used with Full-Text search.
-
Bugfix: Fixed several system warnings that occur when running a
SELECTfrom theMV_information schema view.VERSION_ HISTORY -
Enhancement: Improved performance of VECTOR-type User-Defined Variables(UDVs).
No longer require using extra typecast to BLOB datatype.
2024-07-09 Version 8. 7. 5
-
Bugfix: Fixed an issue to now avoid prematurely assigning column reference to namespace.
-
Enhancement: Added support for
INNER/LEFTlateral joins. -
Bugfix: Fixed issue that caused protocol errors in the pipelines.
2024-07-02 Version 8. 7. 4
-
Bugfix: Temporarily disallow shallow table copy for tables created on version 8.
0 or before. -
Enhancement: Enhance table pushdown to union rewrite to enable derived table pushdown based on row count estimation.
-
Enhancement: Added support for
ON NODEclause forSHOW PROFILE PROCESS|PLAN, which forwards the command to another aggregator. -
Enhancement: Improved performance of the
CREATE PROJECTIONcommand. -
Bugfix: Unneeded sort fields will no longer be projected to the aggregator.
-
Enhancement: Improved the performance of
CREATE TABLES AS INFER PIPELINE. -
Bugfix: Fixed an issue that could occur where a join with
TABLE(JSON_is performed with numeric keys in theTO_ ARRAY(JSON_ EXTRACT_ JSON())) JSON_statement could possibly lead to incorrect output or crashes.EXTRACT_ JSON() -
Bugfix: Identified an upgrade scenario that causes a blob leak and added a command to delete the leaked blobs.
As a result, temporarily disallowing shallow table copy for tables created on version 8. 0 or before. -
Enhancement: Set collation utf8_
bin for the JSON_builtin in cases where the input has utf8 charset, and set collation utf8mb4_TO_ ARRAY bin in cases where the input has utf8mb4 charset. -
Bugfix: An error is reported when inserting incorrect data into vector column for any
data_.conversion_ compatibility_ level -
Bugfix: Fixed a possible connectivity issue and eliminated delay when starting the Lucene service for the first time.
-
Enhancement: Updated the
MV_information schema table:BOTTOMLESS_ STATUS_ EXTENDED -
Removed the
LATEST_andAPI_ FAILURE_ RATE AVERAGE_columns.API_ LATENCY_ US -
Added the following columns:
SUCCESS_- Number of successful remote storage api calls per second over the last 30 seconds.API_ PER_ SECOND FAILED_- Number of failed remote storage api calls per second over the last 30 seconds.API_ PER_ SECOND AVERAGE_- Average latency to complete a remote storage api event over the past 30 seconds.API_ EVENT_ LATENCY_ US Includes time taken on retries or waiting for rate limiting. AVERAGE_- Average latency of receiving a response for a remote storage api request.API_ RESPONSE_ LATENCY_ US Excludes waiting for rate limiting or retries. NOTE: This is relevant only for S3. otherwise this field is identical to AVERAGE_.API_ EVENT_ LATENCY_ US
-
2024-06-25 Version 8. 7. 3
-
Bugfix: Fixed an edge case where unlimited storage garbage collection was causing the master aggregator to run out of connections.
-
Bugfix: Fixed a crash that occurred when dropping a database that contained tables with both very high and low column IDs.
2024-06-19 Version 8. 7. 2
-
Enhancement: Added the following monitoring metrics to the
information_view:schema. mv_ bottomless_ status_ extended NUM_,SUCCESS_ API_ REQUESTS NUM_,FAILED_ API_ REQUESTS LATEST_,API_ FAILURE_ RATE AVERAGE_,API_ LATENCY_ US IS_,GC_ RUNNING NUM_, andREMOTE_ FILES_ DELETED NUM_.SLOW_ DOWNS -
Bugfix: Fixed a crash that occurred when spilling a hash join operation with at least 3 tables.
-
Bugfix: Fixed a crash that occurred when running the
SHOW CREATE PROJECTIONScommand when using the database name in the syntax (SHOW CREATE PROJECTIONS database_).name. projection_ name. . . -
Bugfix: Fixed a bug where the full-text service controller would periodically restart the process when the started process hadn't fully completed.
-
Bugfix: Fixed an issue where
INSERT .into. . SELECT VECTORtype columns returned an error. -
Bugfix: Fixed issues with the
TO_function where results were truncated or reading communication packet errors were generated.CHAR() -
Bugfix: Fixed an integer overflow issue in unique integer columns by changing the storage type to a 32-bit unsigned integer.
-
Bugfix: Fixed incorrect results in an uncommon scenario where hash join operators with an optimization path need to spill.
-
Enhancement: The
memsql_now collects additional fields from theexporter mv_information schema view.activities_ extended_ cumulative -
Enhancement: Updated the default
client.for the Kafka configuration to the SingleStore partner ID.id -
Enhancement: Added support for Iceberg ingest via Snowflake, REST, and JDBC.
-
Enhancement: Added support for BM25 full-text search (FTS) as a built-in feature.
Last modified: October 24, 2025