Skip to content

Releases: taosdata/TDengine

3.3.6.0

25 Mar 11:58
Compare
Choose a tag to compare

Behavior change and compatibility

Features

  1. feat: supports Decimal data type
  2. feat: improve compatibility of taosc
  3. feat: support retrieving the values of other columns in the row returned by the single-row selection function through the cols keyword.
  4. feat: integrate with haixun database api
  5. feat: support constant as join primary key
  6. feat: change the max value of minFreeDiskSize to 2TB
  7. feat: supports control the retention period of time-series data in the supertable via the KEEP parameter.
  8. feat: support backup to s3 storage in taosX
  9. feat: effient data writing in JDBC
  10. feat: improve error handling of taosX
  11. feat: support persistent cache to guarantee data completement
  12. feat: interate with perspective BI library
  13. feat: support taos_validate_sql in websocket
  14. feat: integrate Tableau with ODBC driver
  15. feat: supports virtual table
  16. feat: taosbechmark can generate csv files
  17. feat: TDengine now integrate with FineBI
  18. feat: supports the use of virtual tables in stream computing
  19. feat: stream computing supports the continue_window_close trigger mode.
  20. feat: stream computing supports window event notification
  21. feat: stream computing support setting a minimum duration limit for event window and state window.
  22. feat: support for greatest and least Functions
  23. feat: provide an alias regexp for the operator match.
  24. feat: experimental decimal data types support in explorer
  25. feat: support decimal types in rust connector
  26. feat: taosX/agent support https connection
  27. feat: explorer add support for sql formatter
  28. feat: taosX support export/import data-in tasks
  29. feat: support request ts as primary key in opc-da

Enhancements

  1. enh: when the topic enables the "only meta" option, the data subscription interface will no longer transmit time-series data.
  2. enh: support compact TDB files.
  3. enh: execute stream creation asynchronously to reduce response time.
  4. enh: improve kafka performance in taosX
  5. enh: support index creation for tag fields of nchar and varchar types.
  6. enh: significantly enhance the data synchronization performance between clusters
  7. enh: optimize the distribution of data files across multiple disks within the same tier in multi-level storage
  8. enh: connectors support new subscription params
  9. enh: improve the write performance of automatic table creation
  10. enh: taosX should raise error when WAL retention period is 0
  11. enh: improve error messages in explorer
  12. enh: improve performance of mqtt fetching messages
  13. enh: c# connector add async receiver for websocket connection
  14. enh: filter timestamp by configuration for hebei power transform
  15. enh: suppport stmt via websocket in taosBenchmark
  16. enh: increase the error troubleshooting information for dual-replica databases
  17. enh: improve consumer polling strategy in ws(taosAdapter)
  18. enh: Interp function supports interpolation over a time range.
  19. enh: support for monitoring vnode recovery progress through SQL
  20. enh: tracking new database with replica cli
  21. enh: support the use of conditional expressions in the CAST function
  22. enh: supports using the LIKE keyword in the SHOW VARIABLES series commands to enable pattern matching for variable names.
  23. enh: root can view/edit all tasks in explorer
  24. enh: OPCDA datasource table template can use {/tagname}{id}{_id} extractor
  25. enh: introduce the "assign leader" command for dual-replica clusters to address the issue of cluster recovery when a dnode with a higher WAL version fails to start.
  26. enh: optimize the service recovery time of a dual-replica cluster after a single-node failure
  27. enh: refactor the STMT code to significantly enhance query and write performance.
  28. enh: improve benchmark writing robotics
  29. enh: extend the maximum password length to 255 characters.
  30. enh: when subscribe data, consumers can set the minimum rows and maximum waittime.
  31. enh: respect to log.* settings in configuration for opc logs
  32. enh: C taosws support session.timeout.ms
  33. enh: support long passwords with special characters in all components
  34. enh: support additional subscription parameters in JDBC
  35. enh: Python consumer can subscribe topic using newly added parameters
  36. enh: allow newly added subscription params without updating connectors
  37. enh: MQTT fallback to ssl when tcp failed
  38. enh: add a percentage sign (%) after the compression ratio value in the results displayed by show disk_info.
  39. enh: includes inspection tools in the Enterprise Edition.
  40. enh: stream computing supports sliding window in the force_window_close mode
  41. enh: supports silent uninstallation of the tar package using the -e parameter.
  42. enh: improve the efficiency of downsampling and group by tag queries
  43. enh: taosX does not allow start repeatedly
  44. enh: add DST(Daylight Saving Time) guideline
  45. enh: improve cpu/mem performance in OPC data-in
  46. enh: use fixed seconds format in explorer table view
  47. enh: support deletion of topics with active consumers.

Fixes

  1. fix: OOM may occur when dropping a super table containing a large number of child-tables.
  2. fix: taosX util to read archived data
  3. fix: explorer should raise error when password is not valid
  4. fix: In stmt2 interlace mode, asynchronous execution returns incorrect affectrow count.
  5. fix: explorer display error reason for backup tasks
  6. fix: vnode may go offline when dnode is overloaded
  7. fix: stream computing experiences a significant backlog of transactions during vgroup leader switch, resulting in computational delays.
  8. fix: fix explorer oss --version error
  9. fix: support special characters of password in Node.js
  10. fix: random value out of range in taosBenchmark
  11. fix: fix os error 10053 on windows for OPCUA
  12. fix: taosX panic when adapter/nginx restarted in some cases
  13. fix: the results of the show disk_info command are incorrect when configuring multi-level storage.
  14. fix: typo in the execution result of show .disk_info
  15. fix: when querying super table, using ORDER BY and LIMIT together may return an unexpected record.
  16. fix: allow health params in 2.x data-in
  17. fix: backup next execution time does allow past time
  18. fix: fix compatibility of backup task upgrading to latest
  19. fix: query error when performing a UNION operation on multiple nested queries.
  20. fix: in state window queries, if the same expression exists in both the PARTITION BY and SELECT clauses, it will cause taosd to crash.
  21. fix: when the subquery does not return any results but contains the LIMIT 1 clause, it may cause the result of the parent query to be abnormal or inaccurate.
  22. fix: taosc crash when table names contain *
  23. fix: on windows, closing a JDBC PreparedStatement while writing data may cause the JVM to crash.#30106
  24. fix: when using Websocket parameter binding to batch write data, Chinese characters in subtable names will cause garbled text #29998

What's Changed

Read more

3.3.5.8

28 Feb 14:18
Compare
Choose a tag to compare

Behavior change and compatibility

Features

  1. feat: suppport tmq subscription with ONLY META in JDBC
  2. feat: support multiple-line SQL editor in Grafana
  3. feat: add support for VARBINARY/GEOMETRY in ODBC
  4. feat: support TDengine with ODBC dirver in Excel
  5. feat: taosX agent use specific port range in local connection

Enhancements

  1. enh: websocket handle consumer error when tmq polled nothing
  2. enh: JDBC add support for unsigned integers
  3. enh: expose global.written_concurrent configuration for kafka/mqtt/csv in Explorer
  4. enh: support integration with TDgpt in community version
  5. enh: support BinaryRowData type in flink
  6. enh: in stmt2 SQL statements, the LIMIT clause supports the use of ? as a parameter placeholder
  7. enh: enable compression via websocket in taosX backup
  8. enh: ODBC support SQL_ROWSET_SIZE in SQLSetStmtAttr
  9. enh: expose num.of.consumers/writters configurations in Explorer
  10. enh: Add connector files to the macOS installation package.
  11. enh: handle errors when poll result is null in rust connector
  12. enh: tsbs support csv output format
  13. enh: add Classified Connections Counts table in TDinsight
  14. enh: use consist float precision in explorer and tao shell
  15. enh: flink table support update/delete
  16. enh: taosX agent will resume connection when taosX server disconnected for long time

Fixes

  1. fix: explorer support signup email with dot .
  2. fix: flock syscall error on aws cloud storage in taosAdapter
  3. fix: modify boolean tag values in sub-tables results in erroneous metadata from data subscriptions.
  4. fix: allow spaces in columns of csv in explorer datain
  5. fix: resolved the issue of high CPU usage by the stmtbind thread when the system is in an idle state
  6. fix: health state tick to idle when no data consumed
  7. fix: fix security issues in JDBC sample code
  8. fix: fix upgrade compaibility issue of taosX
  9. fix: ODBC core when set SQL_ATTR_TXN_ISOLATION with SQLSetConnectAttr
  10. fix: received/processed_messages should be reset when task rerun
  11. fix: when restoring data using taosX, it may crash if the database is not specified
  12. fix: when creating a database, the keep_time_offset options supports suffixes h (hours) and d (days) for time values
  13. fix: potential deadlocks while drop stream
  14. fix: failed to write data in a dual-replica database when a single dnode is disconnected from the network
  15. fix: when querying the information_schema.ins_tables table, a "Sync leader is unreachable" error may be triggered if the Leader of the mnode changes.
  16. fix: the time-filtering query results involving composite primary keys were incorrect after data compact
  17. fix: when the join condition of the primary key column is not a simple equality condition, it may lead to incorrect JOIN results
  18. fix: error caused by cursor.fetchmany with custom length in python taosws
  19. fix: the issue where the "show grants" command returned an incorrect number of columns
  20. fix: unexpected backup points before schedule executing
  21. fix: taosX task does not restart after interrupted
  22. fix: jdbc select server_version() caused mem high-usage
  23. fix: when using the WHERE tbname IN () statement, executing LAST query may cause taosd crash if the subtables filtered out do not belong to the same super table
  24. fix: after taosd exits abnormally and is restarted, if the WAL that has not been written to the data file is too large, it may cause an OOM error during startup
  25. fix: when using interp interpolation, if the select list contains string constants or string tags, the returned string content may be incomplete.#29353
  26. fix: when performing a JOIN query on a super table, using a subquery as the right table may lead to missing results
  27. fix: syntax error while use DISTINCT and ORDER BY together.#29263
  28. fix: when using the CAST function to convert a floating-point number to a binary and then performing a comparison, the result may be inaccurate due to loss of precision#29382
  29. fix: after upgrading from version 3.3.4 to 3.3.5, the taosd service fails to start properly if the configured charset does not exist in the system
  30. fix: websocket api timing field should not be negtive
  31. fix: duplicates backup points in taosX
  32. fix: configuration item s3BucketName was incorrectly set as a global variable, leading to failures while file uploads to S3.

What's Changed

Read more

3.3.5.2

20 Jan 07:07
Compare
Choose a tag to compare

Behavior change and compatibility

Features

  1. feat: taosX now support multiple stables with template for MQTT

Enhancements

  1. enh: improve taosX error message if database is invalid
  2. enh: use poetry group depencencies and reduce dep when install taosdata/taos-connector-python#251
  3. enh: improve backup restore using taosX
  4. enh: during the multi-level storage data migration, if the migration time is too long, it may cause the Vnode to switch leader
  5. enh: adjust the systemctl strategy for managing the taosd process, if three consecutive restarts fail within 60 seconds, the next restart will be delayed until 900 seconds later

Fixes

  1. fix: the maxRetryWaitTime parameter is used to control the maximum reconnection timeout time for the client when the cluster is unable to provide services, but it does not take effect when encountering a Sync timeout error
  2. fix: supports immediate subscription to the new tag value after modifying the tag value of the sub-table
  3. fix: the tmq_consumer_poll function for data subscription does not return an error code when the call fails
  4. fix: taosd may crash when more than 100 views are created and the show views command is executed
  5. fix: when using stmt2 to insert data, if not all data columns are bound, the insertion operation will fail
  6. fix: when using stmt2 to insert data, if the database name or table name is enclosed in backticks, the insertion operation will fail
  7. fix: when closing a vnode, if there are ongoing file merge tasks, taosd may crash
  8. fix: frequent execution of the “drop table with tb_uid” statement may lead to a deadlock in taosd
  9. fix: the potential deadlock during the switching of log files
  10. fix: prohibit the creation of databases with the same names as system databases (information_schema, performance_schema)
  11. fix: when the inner query of a nested query come from a super table, the sorting information cannot be pushed up
  12. fix: incorrect error reporting when attempting to write Geometry data types that do not conform to topological specifications through the STMT interface
  13. fix: when using the percentile function and session window in a query statement, if an error occurs, taosd may crash
  14. fix: the issue of being unable to dynamically modify system parameters
  15. fix: random error of tranlict transaction in replication
  16. fix: the same consumer executes the unsubscribe operation and immediately attempts to subscribe to other different topics, the subscription API will return an error
  17. fix: fix CVE-2022-28948 security issue in go connector
  18. fix: when a subquery in a view contains an ORDER BY clause with an alias, and the query function itself also has an alias, querying the view will result in an error
  19. fix: when changing the database from a single replica to a mulit replica, if there are some metadata generated by earlier versions that are no longer used in the new version, the modification operation will fail
  20. fix: column names were not correctly copied when using SELECT * FROM subqueries
  21. fix: when performing max/min function on string type data, the results are inaccurate and taosd will crash
  22. fix: stream computing does not support the use of the HAVING clause, but no error is reported during creation
  23. fix: the version information displayed by taos shell for the server is inaccurate, such as being unable to correctly distinguish between the community edition and the enterprise edition
  24. fix: in certain specific query scenarios, when JOIN and CAST are used together, taosd may crash

What's Changed

Read more

3.3.5.0

02 Jan 08:27
Compare
Choose a tag to compare

Behavior change and compatibility

Features

  1. feat: refactor MQTT to improve stability and performance
  2. feat: refactor taosX incremental backup-restore
  3. feat: add stmt2 apis in JDBC via websocket connection
  4. feat: add stmt2 api in Rust connector
  5. feat: adding error codes in error prompts in taos-CLI
  6. feat: superSet can connect TDengine with python connector
  7. feat: configurable grafana dashboards in explorer management
  8. feat: add taosX-agent in-memory cache queu capacity option

Enhancements

  1. enh: adjust the reporting mechanism of telemetry.
  2. enh: support for SQL-based statistics of disk space for a specified DB.
  3. enh: add memory management for SQL queries on the server side
  4. enh: INTERVAL clause allows the use of the AUTO keyword to specify the window offset.
  5. enh: reduce the impact on data write performance during data migration across multi-level storage
  6. enh: migrate from angular to react for grafana 11.3+
  7. enh: refactor taosAdapter websocket api for a slightly better perf
  8. enh: add health state in taosX task status
  9. enh: taosX add configurations to handle exceptions
  10. enh: support setting options for client connections, including time zone, character set, user IP, and user name.
  11. enh: taosdump support retry after connection timeout or broken
  12. enh: allow creating index for tags that already subscribed
  13. enh: taosX now support literal special chars in password
  14. enh: improve data write performance when Last Cache is activated.
  15. enh: COMPACT command supports automatic execution, concurrency setting, and progress observation.
  16. enh: support update global configuration parameters through SQL statements and persisting them.
  17. enh: update the default compression method for all data types to improve the compression ratio in most scenarios.
  18. enh: taosBenchmark --nodrop fix for mac/window
  19. enh: prohibit the simultaneous execution of DB compaction and replica change operations (Enterpris).
  20. enh: taosdump support primary key tables
  21. enh: display user IP and name in the results of the SHOW QUERIES and SHOW CONNECTIONS statements.
  22. enh: (JDBC)support batch insertion into multiple tables
  23. enh: support for dynamically modifying the dataDir parameter for multi-level storage.
  24. enh: prefer db file under data_dir
  25. enh: enforce users to set strong passwords, which must be 8 to 16 characters in length and include at least three types of characters from the following: uppercase letters, lowercase letters, numbers, and special characters.
  26. enh: improve the speed at which clients acquire the new Leader.
  27. enh: support negative regex pattern in opc point selector

Fixes

  1. fix: the potential for deadlocks when updating checkpoints in stream computing under high-load scenarios.
  2. fix: write tmq data into target error when terrno already set
  3. fix: taosd cannot start when there is data corruption in a block within the WAL
  4. fix: taosBenchmark fails when taosd disconnected in replica 2/3
  5. fix: log files being lost when they are switched frequently.
  6. fix: the stream computing stops due to the data update within the window.
  7. fix: libtaosws.so sets an incorrect error code when the connection is terminated while fetch data.
  8. fix: taosX opc error in case of @-prefixed name
  9. fix: fix permission denied with show vgroups sql in cloud
  10. fix: fix sql syntax error when migrating from large stables with compress options
  11. fix: incorrect memory estimation for vnode usage
  12. fix: failed to perform UNION ALL query on constant strings of the varchar type.
  13. fix: leader transfer during the execution of transaction may cause deadlock.
  14. fix: rust connector invliad pointer addr in ws_stmt_get_tag_fields
  15. fix: UNION statement fails when executing with subqueries containing multiple NULLs.
  16. fix: the pause operation of stream computing might fail.
  17. fix: when writing data into a sub-table with a table name length of 192 characters using an SQL statement, errors may occur if the table name is enclosed in backticks (`).
  18. fix: when performing a join query on super tables across different databases, if each database contains only one vnode, the query will return an error.
  19. fix: no enough disk space cause taosX panic
  20. fix: when write data to a super table, using both bound and unbound simultaneously will trigger an exception.
  21. fix: metrics non-exist cause panic when connect with agent
  22. fix: when creating indexes for tag with a large character length, taosd may crash.
  23. fix: when the input parameters for the functions first, last, last_row, and char exceed 127, the taosd may crash. #29241
  24. fix: when the number of rows in the result set of the LIMIT statement exceeds the size of a single data block, the returned count does not match the expectation.
  25. fix: when synchronizing data between clusters, if the target task is deleted, the source cluster may run out of memory
  26. fix: metadata read-write lock misconfiguration leads to a very small chance of blocking writes.
  27. fix: when importing CSV files using the INSERT INTO statement on the Windows platform, the absence of a newline character at the end of the file may lead to an issue of infinite loop reading.
  28. fix: after the tags of the table are updated, the stream computing fails to recognize and apply the ne values.
  29. fix: fix kafka timeout issue and improve performance and stability
  30. fix: in SQL queries, when both 'is null' and invalid 'in' filter conditions are included simultaneously, the query results are incorrect. #29067
  31. fix: SQL queries containing both 'IN' and 'BETWEEN' filter conditions result in incorrect query results. #28989
  32. fix: when performing multiplication or division operations between timestamp and numeric types, the results are incorrect. #28339
  33. fix: data type conversion error in the IN statement leads to incorrect query results. #29047 #28902
  34. fix: the error in filtering results when constant conditions are combined with OR operators. #28904
  35. fix: when performing subtraction operation on timestamp type, the negative value is not considered. #28906
  36. fix: tag values may display incorrectly when using GROUP BY tag synatix
  37. fix: gcc < 10 bug cause taosX compile error

What's Changed

Read more

3.3.4.8

03 Dec 03:24
Compare
Choose a tag to compare

Behavior change and compatibility

New Features

  1. feat: Interp function supports the fill(near) mode, supports returning the timestamp where the original data is located, and supports finding interpolations within a specified range.

Optimizations

  1. enh: improve the query performance of TSBS.
  2. enh: support alter multiple tag values of a single child table at the same time.
  3. enh: optimize the error code of the status window.
  4. enh: reduce resource consumption in the force window close mode of stream computing.
  5. enh: remove the restriction that window query must include aggregate functions.

Fixed issues

  1. fix: use websocket in node.js example of explorer
  2. fix: the problem that WAL is not distributed to multiple level-0 mount points.
  3. fix: abnormal exit of stream computing may lead to a deadlock.
  4. fix(taosX): fix drop table unexpected error when point set enable=0 in opc csv
  5. fix: failed to read WAL file when alter WAL_level from 0 to 2.
  6. fix: deadlock when create snode.
  7. fix: The race condition during replica snapshot synchronization.
  8. fix: the performance degradation of the percentile function after upgrading to 3.3.4.3.
  9. fix: the info of dataDir in ins_dnode_variables is incomplete.
  10. fix: WHERE condition not work in statements with INTERP function
  11. fix: taosd restart failed while use force window close mode in stream computing.
  12. Fix: SQL statements containing “GROUP BY constants” will report “Executor internal error”.
  13. fix: fix OPC-DA connection incorrect NOCONFIG error
  14. fix: in force_window_close mode, the stream computing fails to generate the sub-table names according to the specified rules.
  15. fix: 'schema is old' occurring in schemaless write mode under specific scenarios. #28846
  16. fix: taosX sync with subscription may lost messages in websocket
  17. fix: incorrect sub-table count when filtering by tags (which may cause taosdump crash).
  18. fix: restart a single dnode when RPC compression is enabled may lead to an abnormal cluster state.
  19. fix: unexpected Grafana alerting with CASE WHEN
  20. fix: taosd may crash when performing UNION queries frequently.
  21. fix: subscribe with enable.auto.commit=false not work as expected

What's Changed

Read more

3.3.4.3

22 Nov 05:44
Compare
Choose a tag to compare

Behavior change and compatibility

New Features

  • feat: the twa function in stream computing support time-driven result push mode.
  • feat: the interp function in stream computing support time-driver result push mode.
  • feat: optimized the error msg when compact + split vgroup operation is performed in sequence
  • feat: support Azure Blob

Optimizations

  • enh: improve the efficiency of pulling data between dnodes when performing large concurrent query.
  • enh: support use AVX2 and AVX512 to perform decoding optimization for double, timestamp and bigint types.
  • enh: adjust the result type of the case when statement.
  • enh: improve the data scanning speed of the query "select... from... where ts in (...)".
  • enh: add a compatiability guarantee mechanism for stream, to avoid new compatiblity issued caused by subsequent functions, but the previously created stream must be deleted and recreated.
  • enh: improve the data synchronization performance of taosX in interlace scenarios.
  • enh: support turn off encoding for integer and float data types.
  • enh: in a multi-replica database, snode must be used in stream computing.
  • enh: generate unique ID to identify each query task to avoid memory corruption.
  • enh: speed up the creation time of the database.
  • enh: modify the default value of s3MigrateEnabled to 0.
  • enh: support recording delete operations in the audit database.
  • enh: support create database in the specified dnode list [enterprise].
  • fix: adjust the error message when deleting data columns of the super table.

Fixed issues

  • fix: query performance of last_row has significantly decreased in version 3.3.3.0.
  • fix: taosd cannot start when the WAL entry is incomplete.
  • fix: incorrect query results when partitioning by a constant.
  • fix: when the scalar function include _wstart and the fill method is prev, the calculation result is wrong.
  • fix: the time zone setting problem on Windows.
  • fix: the translation can't finish if compacting on empty database [enterprise]
  • fix: logic error with transaction conflicts
  • fix: some errors of the mnode can cause transactions to be unable to stop.
  • fix: some errors of the mnode can cause transactions to be unable to stop.
  • fix: the problem of taosc driver retrying errors after clearing the dnode data.
  • fix: after Data Compact is abnormally terminated, intermediate files are not cleaned up.
  • fix: after adding a new column, the earliest mode of the Kafka connector cannot consume the data of the new column.
  • fix: the behavior of the interp function is incorrect when use fill(prev).
  • fix: the problem that TSMA abnormally stops during high-frequency metadata operations.
  • fix: the execution result of the "show create stable" statement is incorrect.
  • fix: the percentile function will crash when querying a large amount of data.
  • fix: syntax error when using partition by and having together.
  • fix: tbname is empty when interp function is used with partition by tbname, c1.
  • fix: taosd may crash while writing illegal boolean values through stmt.
  • fix: update table name description in opc-ua data-in
  • fix: library symbol 'version' confict with other lib which use the same symbol. #25920
  • fix: the number of JAVA process handles in JDBC driver keeps increasing on Windows environment.
  • fix: the occasional startup failure when upgrading from version 3.3.3.1 to 3.3.4.0.
  • fix: memory leak caused by repeated addition and deletion of tables on the Windows platform.
  • fix(stream): check the right return code for concurrent checkpoint trans.
  • fix: the "too many session" problem while perform large concurrent queries.
  • fix: the problem of taos shell crashing in slow query scenarios on the Windows platform.
  • fix: the encrypted database cannot be recovered when opening the dnode log.
  • fix: the problem that taosd cannot be started due to mnode synchronization timeout.
  • fix: the slow sorting of file group data during snapshot synchronization leads to the inability of Vnode to recover.
  • fix: when writing data with escape characters to a varchar field throug line protocol, taosd will crash.
  • fix: metadata file damage caused by incorrect logic processing of error code
  • fix: when a query statement contains multiple nested "not" conditional statements, not setting the scalar mode will lead to query errors.
  • fix: the problem of dnode going offline due to timeout of vnode stat report.
  • fix: taosd failed to start on servers that not support AVX instructions.
  • fix(taosX): handle 0x09xx error codes in migration

What's Changed

Read more

3.3.3.0

08 Oct 07:31
Compare
Choose a tag to compare

New Features/Improvements:

  1. New functions: pi、truncate/tunc、exp、ln、mod、rand、sign、degress、radians、char、ascii、position、trim、replace、repeat、substring/substr、substring_index、week、weekday、weekofyear、dayofweek、stddev_pop、var_pop
  2. Microsoft Azure Blob can be used with multi-level storage [Enterprise]
  3. Data transfer from MongoDB to TDengine [Enterprise]
  4. TDengine macOS client [Enterprise]
  5. By default, the logs of taosX are not recorded in syslog [Enterprise]
  6. TDengine server records all slow query information to the database storing monitoring data
  7. Display server version in the query result of show cluster machines
  8. Turned keywords LEVEL/ENCODE/COMPRESS into non-keywords, they can be used as column names/table names/database names
  9. Disable the method for dynamic modifying temporary directories

Optimizations:

  1. Performance enhancement of taosX replication [Enterprise]
  2. Unified storage policies for slow query and common logs
  3. Optimize the subscription feature where the offset file is too large and the loading is too slow
  4. Upgrade JDBC driver to 3.2.5
  5. Change commit to sync mode in Kafka connector
  6. Add new parameter: query from table whether an exception is reported when the table does not exist
  7. Expand the maximum window of the tsma interval to one year
  8. Create tables from CSV files

Fixed issues:

  1. MQTT data-in task does not restart automatically after server restart [Enterprise]
  2. Task termination issue caused by agent and PI connector connection errors on Windows [Enterprise]
  3. MQTT tasks fail to synchronize data after restarting taosadapter [Enterprise]
  4. MQTT tasks status are not correct [Enterprise]
  5. Tasks are not scheduled after restarting taosx [Enterprise]
  6. Taosx: Log optimization for MongoDB DataIn task [Enterprise]
  7. Backup failure issue when the local.toml file is empty [Enterprise]
  8. The issue of taosx replica when the network is interrupted [Enterprise]
  9. Fix the problem that meta data is not synchronized between version 3.1 and version 3.3 [Enterprise]
  10. Fix the issue where the MQTT task cannot automatically recover after the taoadapter restarts abnormally [Enterprise]
  11. Kafka Datain tasks stop consuming data [Enterprise]
  12. Crash issue when using last and interval in query
  13. Crash issue caused by updating stt_trigger value during database insertation
  14. Taoskeeper restart repeatedly after modifying the password of root user
  15. The stream computing can not continue working after the taosd instance in cloud service restart
  16. taosd deadlock caused by loading tsdb cache
  17. Unexpected error message when query with fill(0)
  18. Incorrect result of query with last_row
  19. taosd crash issue when the user specifies the information_schema database to log in the TDengine server
  20. The group by statement supports positional parameters and alias syntax
  21. Crash caused by an error of metadata clone function object
  22. taosd crash when filled data during cache updates
  23. Fix the random incorrect result of query with query with stddev
  24. Offline node can not be added into cluster for multi-level storage with database encryption scenario
  25. taos CLI can not enter password longer than 20 characters
  26. The ‘int data overflow’ error when inserting SQL string concatenation
  27. metadata consistency in a large number of concurrent queries
  28. MQTT task can not be stopped normally
  29. Can't export values contain comma or quote as CSV file
  30. Crash issue when multiple threads query to describe the same child table concurrently
  31. Results returned by data explorer do not follow the timezone configuration
  32. Memory leak issue of taosadapter when creating websocket connection
  33. Community version can not start properly on the redhat operating system
  34. Crash caused by invalid assert when two stt files are located in the data block timeline distribution void scenario
  35. S3 fails to pull data for a long time
  36. Use result set function to judge the order of timeline
  37. Performance issue of supertable projection query
  38. In multi-node environment, transaction accumulation is caused by inconsistent transaction return code and state
  39. Error appears after delete data when stt_trigger = 1
  40. taosd service OOM during during node recovery
  41. Modify the judgment error when limit is too small
  42. Issues in historian data source connectivity and retrieving sample data function
  43. taosd service cannot be stopped normally
  44. crash caused by last function query for the whole empty values of some column
  45. coredump caused by assert when the query cid is not in the schema of the current version
  46. OOM issue when writing large message, and add the syncLogBufferCacheAllowed parameter control
  47. Query error when timezone is set to UTC and data contains '1970'
  48. disable timeout when mnode sending sync message
  49. After the cluster node recovers abnormally, the authorization status of the cluster becomes invalid
  50. Query null pointer problem
  51. set vgroup as single replica temporarily when restoring vnode
  52. SQL Reserved Word could NOT be used as column name and tag name in TDengine database
  53. Continuous memory growth during highly concurrent queries
  54. Crash caused by the assertion failure during checkpoint processing occurred in stream computation
  55. Query issue in information_schema database
  56. taosd service OOM during during node recovery
  57. taosd crashes when importing data through taosx when schema changes.
  58. taosd Memory Leak
  59. taos client memory leak
  60. Open source users can not modify other database options after the stt_trigger value is modified
  61. Query result is incorrect with operator of NOT IN (NULL)
  62. taos shell and taosBenchmark can not connect to TDengine Cloud Instance

What's Changed

Read more

3.3.2.0

01 Jul 04:33
Compare
Choose a tag to compare

New Features/Improvements

  1. alter table add column can support encode and compress parameters
  2. Configuration parameter supportVnodes can be changed dynamically using alter command
  3. Minimize the impact on read/write by compact operation
  4. Adjust the default value of supportVnodes to 2*Cores+5
  5. lossyColumnn parameter is obsoleted
  6. Support specifying ENCODE and COMPRESS when adding columns to existing table
  7. Update SupportVnodes on the fly
  8. Support CentOS Stream

New Features/Improvements (Enterprise only)

  1. balance vgroup leader can be performed on a database (Enterprise only)
  2. Each mount point in multi-level storage can be configured as allowing new file or not (Enterprise only)
  3. Speed control can be set for cross-level data transfer
  4. IP white list can be adjusted dynamically
  5. New user doesn't have privilege to create database by default
  6. Optimized process of configuring key for database encryption
  7. Data compression for data transfer between TDengine 2.x and 3.x
  8. Data transfer from Oracle to TDengine
  9. Data transfer from SQL Server to TDengine
  10. OPC UA data points can be found and added in data in tasks dynamically
  11. Pi backfill task can be paused and resumed
  12. Pi backfill can work with data transformation
  13. Performance and stability improvement for Pi data in tasks
  14. VARBINARY and GEOMETRY data types can be used when creating tables in taos-explorer
  15. User can transfer user/password and privilege data between TDengine clusters using taos-explorer
  16. Pi data transfer supports newly added assets of an element
  17. taos-explorer can use native connection for the sink TDengine
  18. GSSAPI support for Kafka connector
  19. MQTT tasks can obtain sample data from the data source
  20. Object array support in MQTT data
  21. Data parsing with custom scripts
  22. Dynamic data filtering with plugins

Fixed Bugs

  1. metadata broken by TSMA
  2. count(*) result is wrong when filtering by supertable tags or where conditions
  3. The output precision is wrong of function to_iso8601()
  4. taosd exit abnormally because of querying first() and last() together with interval() and fill()
  5. Deleting a consumer group of one topic caused consumption failure of another consumer group of same name for another topic
  6. Column index of STMT binding over boundary caused taosd exited abnormally
  7. Only one parameter is changed successfully when altering multiple parameters for a table
  8. Union caused taosd hang when the leader is switched frequently
  9. Cast() caused taosd exited abnormally
  10. count window and sliding caused taosd exited abnormally
  11. Performance downgrade of group by tbname
  12. Other fixing for known bugs

What's Changed

Read more

3.3.1.0

28 Jun 07:33
Compare
Choose a tag to compare

Features/Improvements

  1. Improve the performance of transferring metadata

Fixed Bugs

  1. create/drop stable is not logged in operation logs
  2. steam-task-status is abnormal after performing redistribute and restart dnode
  3. Some other bug fixes for known issues

3.3.0.0

10 May 08:26
Compare
Choose a tag to compare

New Features and Improvements

  1. Full functional Join: including LEFT JOIN, RIGHT JOIN, FULL JOIN, SEMI JOIN, ANTI-SEMI JOIN in traditional databases, as well as ASOF JOIN and WINDOW JOIN in time series databases
  2. Composite Primary Key: time-series data is organized and sorted according to both timestamp and an additioanl column, which is called primary key
  3. Double replicas (Enterprise only): high availability and high reliability can be achieved with 2 replicas, i.e. lower hardware cost compared to 3 replicas
  4. S3 storage (Enterprise only): cold data can be stored in S3 to achieve lower storage cost, without compromising query or writing behavior
  5. TSMA: time-range SMA to accelerate aggregate query
  6. Configurable compression: encoding method, compression algorithm and compression level can be configured per column when creating super table
  7. Count Window: A new type of window based on counting rows can be used in both stream and batch processing
  8. Active-Active (Enterprise only): two standalone TDengine deployments can form a single business system to provide high availability with transparency to the client programs. It can also be used in disaster recovery
  9. Database Encryption (Enterprise only): database storage files are encrypted with transparency for reading and writing
  10. Multi-level storage (Enterprise only): Up to 64 mount points can be configured for each storage level
  11. Data In (Enterprise only): time-series data stored in postgreSql and MySQL can be replicated to TDengine in real time
  12. Data In (Enterprise only): optimized configuration method for OPC data points
  13. Data Explorer: a simplified version of data explorer is public for the community

What's Changed

Read more