You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@iotdb.apache.org by qi...@apache.org on 2022/01/20 11:40:53 UTC

[iotdb] branch master updated: Add 0.13.0 release note (#4934)

This is an automated email from the ASF dual-hosted git repository.

qiaojialin pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/iotdb.git


The following commit(s) were added to refs/heads/master by this push:
     new 8af4682  Add 0.13.0 release note (#4934)
8af4682 is described below

commit 8af4682c0fd77fcc768e2ec9075bdcac002c8266
Author: Haonan <hh...@outlook.com>
AuthorDate: Thu Jan 20 19:40:17 2022 +0800

    Add 0.13.0 release note (#4934)
---
 RELEASE_NOTES.md | 433 +++++++++++++++++++++++++++++++++++++++++++++++++++++++
 1 file changed, 433 insertions(+)

diff --git a/RELEASE_NOTES.md b/RELEASE_NOTES.md
index 8a5db33..08bc128 100644
--- a/RELEASE_NOTES.md
+++ b/RELEASE_NOTES.md
@@ -19,6 +19,415 @@
 
 -->
 
+# Apache IoTDB 0.13.0
+
+## New Features
+
+* [IOTDB-924] Support insert multi rows in SQL
+* [IOTDB-959] Add Create Storage Group Grammar 
+* [IOTDB-1037] set rpc\_compression as a parameter in JDBC URL
+* [IOTDB-1059] Support sql statement insert without timestamp
+* [IOTDB-1143] Support Continuous query
+* [IOTDB-1199] Support aligned timeseries and schema template 
+* [IOTDB-1319] Support Trigger
+* [IOTDB-1391] Add a new Aggregation function extreme (max absolute value)
+* [IOTDB-1399] Add a session interface to connect multiple nodes
+* [IOTDB-1400] Support arithmetic operations in SELECT clauses
+* [IOTDB-1403] Dictionary encoding for TEXT
+* [IOTDB-1490] Add built-in UDTFs: sinh, conh, tanh
+* [IOTDB-1514] Support null in insertTablet
+* [IOTDB-1524] Support SELECT ... INTO ... clause 
+* [IOTDB-1647] Nested Expressions in SELECT clauses
+* [IOTDB-1673] CLI upgrade to JLine3
+* [IOTDB-1739] Constant timeseries generating functions (const, pi and e) 
+* [IOTDB-1760] Support avg, count, extreme, first\_value, last\_value, max\_time, max\_value, min\_time, min\_value, sum aggregations in group by fill
+* [IOTDB-1761] Add metric framework for IoTDB
+* [IOTDB-1775] Add CAST function to convert data type
+* [IOTDB-1823] Support group by multi level
+* [IOTDB-1844] Query support timeseries prefix and suffix matching: root.\*sg\*
+* [IOTDB-1859] Support REST API
+* [IOTDB-1860] New Grafana plugin
+* [IOTDB-1886] Support Constant Expressions in Select Clauses
+* [IOTDB-1973] Supports aggregate queries, constants, and arithmetic nested expressions in SELECT clauses
+* [IOTDB-1986] Support select UDF as alisa clauses 
+* [IOTDB-1989] Spark-IoTDB-connector support inserting data
+* [IOTDB-2131] Support previous, linear, constant value fill funtion New fill
+* [ISSUE-3811] Provide a data type column for the last query dataset 
+* add rabbitmq example
+
+## Improvements
+
+* [IOTDB-1280] Rewrite the Antlr grammar file
+* [IOTDB-1372] Enhance management of TsFileResource 
+* [IOTDB-1428] Ask query threads to quit if query is timeout 
+* [IOTDB-1450] Deletion should only delete related time partitions
+* [IOTDB-1463] Implement builder pattern for Session and SessionPool 
+* [IOTDB-1477] Optimize code logic of generateAlignByDevicePlan() 
+* [IOTDB-1559] Refactor the IT framework
+* [IOTDB-1564] Make hearbeat and election timeout parameters be configurable
+* [IOTDB-1581] Consider deletions when recovering tsFileResource of incomplete tsfile 
+* [IOTDB-1607] Optimize Tracing
+* [IOTDB-1613] Recover mods file if  write modification failed
+* [IOTDB-1639] Refactoring the cluster class structure to make it consistent with the server module 
+* [IOTDB-1730] client-cpp, enhance session::insertTablet() etc.'s performance 
+* [IOTDB-1852] Accelerate queryies by using statistics
+* [IOTDB-1857] Remove useless handle logic for CountPlan in executeNonQuery in cluster module
+* [IOTDB-1884] Distinguish between zero and null values in sum aggregation
+* [IOTDB-1924] Remove the operation of clearing the cache after the compaction is over
+* [IOTDB-1950] Add Bloom Filter cache for query 
+* [IOTDB-2001] Remove redundant StorageGroupNotReadyException
+* [IOTDB-2011] Update last cache while doing show latest timeseries query
+* [IOTDB-2022] SessionDataSet implements AutoCloseable
+* [IOTDB-2075] Accelerate the process of insertTablets by using thread pool
+* [IOTDB-2119] IoTDB CSV export tools add timestamp accuracy setting function 
+* [IOTDB-2162] Simplify the recovery merge process
+* [IOTDB-2176] Limit target chunk size when performing inner space compaction
+* [IOTDB-2193] Reduce unnecessary lock operations of RaftLogManager to improve writing performance 
+* [IOTDB-2195] Control the concurrent query execution thread
+* [ISSUE-3445] New compaction strategy and compaction scheduling strategy
+* [ISSUE-3856] refine exception handling logic in commitTo in RaftLogManager
+* [Cluster] No need to shake hands with itself when one node restart 
+
+
+## Incompatible changes
+
+* [IOTDB-1026] Support wildcard \*\* in Path And Replace PrefixPath usage with PathPattern in IOTDB-SQL
+* [IOTDB-1620] Support backtick (\`) character and double quotes (") to quote identifiers 
+* [IOTDB-1650] Rename the sql command `move` to `unload` 
+
+## Miscellaneous changes
+
+* [IOTDB-1342] modify error message about LIMIT and OFFSET used in conjunction with the FILL clause
+* [IOTDB-1372] delete devices field in FileTimeIndex 
+* [IOTDB-1531] Check tsfile creation time when recovering
+* [IOTDB-1541] Change sequence of wal and memtable in insertion
+* [IOTDB-1923] Separate the request unpacking and execution processing logic of TSServiceImpl
+* [IOTDB-1969] Remove statistic resources of old metric framework from iotdb-server
+* [IOTDB-2014] MicrometerPrometheusReporter#getReporterType return null 
+* [IOTDB-2043] refactor: remove haveSorted param from Session
+* [IOTDB-2154] add TsFileUtils.isTsFileComplete
+* [IOTDB-2206] Rename StorageGroupProcessor to VirtualStorageGroupProcessor
+* [IOTDB-2208] Reconstruct the process of generating resultset header of query
+* [ISSUE-4047] Generic type in Statistics extend Serializable 
+* Add compaction version in cache key
+* Add a constructor of IoTDBDescriptorHolder to prohibit instantiation
+
+## Bug Fixes
+
+* [IOTDB-1266] Fix SHOW TIMESERIES will only display 2000 timeseries
+* [IOTDB-1478] The whole IoTDB can not read/write if any one sg is not ready
+* [IOTDB-1562] Fix incorrect exception processing in insertXXX() API
+* [IOTDB-1583] Raft log failed to be committed in cluster version 
+* [IOTDB-1592] BugFix: SLimit Not effective in align by device 
+* [IOTDB-1736] Fix error code is not printed in TSServiceImpl's log 
+* [IOTDB-1749] sync-tool's lockInstance() dose not take effect
+* [IOTDB-1758] sync-tool, empty uuid file cause tool can not auto-recovery
+* [IOTDB-1848] Failed to initialize pool: Does not support setReadOnly in grafana-connector
+* [IOTDB-1853] Fix bug about more than one TimeseriesMetadata in TsFile
+* [IOTDB-2010] fix incomplete show timeseries result
+* [IOTDB-2021] Fix Bloom Filter Cache doesn't take effect bug 
+* [IOTDB-2060] Fix NPE when using fill without a filter
+* [IOTDB-2074] Fix NullPointerException when recovering compaction in MacOS
+* [IOTDB-2077] Unexpected exception when executing raw data query without VF with limit clause
+* [IOTDB-2088] Fix IndexOutOfBound exception in AggregationPlan.groupAggResultByLevel
+* [IOTDB-2116] Fix all client connections are stuck bug caused by logback bug 
+* [IOTDB-2129] Wrong result returned when querying by nested expressions with aliases
+* [IOTDB-2143] fix wrong precision in cluster mode
+* [IOTDB-2153] [IOTDB-2157] fix incorrect path search space 
+* [IOTDB-2159] Fix wrong status code when inserting data to a read-only cluster
+* [IOTDB-2163] Fix unexpected amount of columns in a cluster slimit query
+* [IOTDB-2174] Fix Regexp filter serializing and deserializing error 
+* [IOTDB-2180] Fix show latest timeseries in cluster
+* [IOTDB-2183] Fix the config problems in cluster mode
+* [IOTDB-2185] Fix get an exception when parsing the header of CSV
+* [IOTDB-2209] Fix logback CVE-2021-42550 issue
+* [IOTDB-2251] [IOTDB-2252] Fix Query deadlock 
+* [IOTDB-2267] UDF: Error code 500 caused by user logic
+* [IOTDB-2282] fix tag recovery bug after tag upsert
+* [IOTDB-2290] Fix Incorrect query result in C++ client 
+* Fix CPP client could not be successfully built on windows
+* Fix dead lock in setDataTTL method
+
+
+# Apache IoTDB 0.12.4
+
+## New Features
+
+* [IOTDB-1823] group by multi level
+
+## Improvements
+
+* [IOTDB-2027] Rollback invalid entry after WAL writing failure
+* [IOTDB-2061] Add max concurrent sub query parameter, read data in batches to limit max IO and add max cached buffer size configuration
+* [IOTDB-2065] release TsFileSequenceReader soon when it is no longer used
+* [IOTDB-2072] Remove TVListAllocator to reduce the TVList mem cost
+* [IOTDB-2101] Reduce the memory footprint of QueryDataSource
+* [IOTDB-2102] Push limit operator down to each reader
+* [IOTDB-2123] Accelerate recovery process
+* update user guide for cpp-cpi and disable compiling nodejs in cpp-cli
+* Ignore too many WAL BufferOverflow log
+
+
+## Bug Fixes
+* [IOTDB-1408] Statement with 'as' executes incorrectly in mutil-path scenes
+* [IOTDB-2023] Fix serializing and deserializing bugs of Filters
+* [IOTDB-2025] Fix count nodes and devices incorrectly in cluster
+* [IOTDB-2031] Fix incorrect result of descending query with value filter in cluster
+* [IOTDB-2032] Fix incorrect result of descending query with multiple time partitions
+* [IOTDB-2039] Fix data redundant after too many open files exception occurs during compaction
+* [IOTDB-2047] Fix NPE when memControl is disabled and insert TEXT value to a non-TEXT series
+* [IOTDB-2058] Fix Query is blocked without sub-query-threads exist bug
+* [IOTDB-2063] Fix MinTimeDescAggregationResult implementation bug
+* [IOTDB-2064] Fix the NPE caused by map serde
+* [IOTDB-2068] Fix GZIP compressor meets ArrayIndexOutOfBoundsException
+* [IOTDB-2124] the filtering condition does not take efffect for last query in cluster
+* [IOTDB-2138] Fix data loss after IoTDB recover
+* [IOTDB-2140] Fix merge throw NullPointerException
+* [IOTDB-2152] PyClient: Override `__eq__()` of TSDataType, TSEncoding and Compressor to avoid unexpected comparation behaviour
+* [IOTDB-2160] Fix cluster groupby query cross-node reference leaks
+* [ISSUE-3335] Fix the bug of start-cli.sh -e mode can't work with wild card \*
+* fix memory leak: replace RandomDeleteCache with Caffine CacheLoader
+* Fix connection refused using session when users forget to set client ip
+
+
+# Apache IoTDB 0.12.3
+
+## Improvements
+
+* [IOTDB-842] Better Export/Import-CSV Tool
+* [IOTDB-1738] Cache paths list in batched insert plan
+* [IOTDB-1792] remove tomcat-embed dependency and make all transitive dependencies versions consistent
+* [ISSUE-4072] Parallel insert records in Session
+* Print the file path while meeting error in case of reading chunk
+
+## Bug Fixes
+
+* [IOTDB-1275] Fix backgroup exec for cli -e function causes an infinite loop
+* [IOTDB-1287] Fix C++ class Session has 2 useless sort()
+* [IOTDB-1289] fix CPP mem-leak in SessionExample.cpp insertRecords()
+* [IOTDB-1484] fix auto create schema in cluster
+* [IOTDB-1578] Set unsequnce when loading TsFile with the same establish time
+* [IOTDB-1619] Fix an error msg when restart iotdb-cluster
+* [IOTDB-1629] fix the NPE when using value fill in cluster mode
+* [IOTDB-1632] Fix Value fill function fills even when the data exists
+* [IOTDB-1651] add reconnect to solve out of sequence in sync module
+* [IOTDB-1659] Fix Windows CLI cannot set maxPRC less than or equal to 0
+* [IOTDB-1670] Fix cli -e mode didn't fetch timestamp_precision from server
+* [IOTDB-1674] Fix command interpret error causing somaxconn warning failed
+* [IOTDB-1677] Fix not generate file apache-iotdb-0.x.x-client-cpp-linux-x86_64-bin.zip.sha512
+* [IOTDB-1678] Fix client-cpp session bug: can cause connection leak.
+* [IOTDB-1679] client-cpp: Session descontruction need release server resource
+* [IOTDB-1690] Fix align by device type cast error
+* [IOTDB-1693] fix IoTDB restart does not truncate broken ChunkGroup bug
+* [IOTDB-1703] Fix MManager slow recover with tag
+* [IOTDB-1714] fix Could not find or load main class when start with jmx on win 
+* [IOTDB-1723] Fix concurrency issue in compaction selection
+* [IOTDB-1726] Wrong hashCode() and equals() method in ChunkMetadata
+* [IOTDB-1727] Fix Slow creation of timeseries with tag
+* [IOTDB-1731] Fix sync error between different os
+* [IOTDB-1733] Fix dropping built-in function
+* [IOTDB-1741] Avoid double close in level compaction execution
+* [IOTDB-1785] Fix Illegal String ending with . being parsed to PartialPath
+* [IOTDB-1836] Fix Query Exception Bug after deleting all sgs
+* [IOTDB-1837] Fix tagIndex rebuild failure after upgrade mlog from mlog.txt to mlog.bin
+* [IOTDB-1838] The compacting status in SGP is always false
+* [IOTDB-1846] Fix the error when count the total number of devices in cluster mode
+* [IoTDB-1847] Not throw excpetion when pulling non--existent time series
+* [IOTDB-1850] Fix deserialize page merge rate limiter
+* [IoTDB-1865] Compaction is blocking when removing old files in Cluster
+* [IOTDB-1868] Use RwLock to reduce the lock time for nodeRing
+* [IOTDB-1872] Fix data increases abnormally after IoTDB restarts
+* [IOTDB-1877] Fix Sync recovery and reconnection bugs in both sender and receiver
+* [IOTDB-1879] Fix some Unsequence files never be merged to higher level or Sequence folder
+* [IOTDB-1887] Fix importing csv data containing null throws exception
+* [IOTDB-1893] Fix Can not release file lock in sync verify singleton 
+* [IOTDB-1895] Cache leader optimization for batch write interfaces on multiple devices
+* [IOTDB-1903] Fix IndexOutOfRangeException when starting IoTDB
+* [IoTDB-1913] Fix When exporting a amount of data from csv, it will report network error or OOM
+* [IOTDB-1925] Fix the modification of max_select_unseq_file_num_in_each_compaction parameter does not take effect
+* [IOTDB-1958] Add storage group not ready exception
+* [IOTDB-1961] Cluster query memory leak
+* [IOTDB-1975] OOM caused by that MaxQueryDeduplicatedPathNum doesn't take effect
+* [IOTDB-1983] Fix DescReadWriteBatchData serializing bug
+* [IOTDB-1990] Fix unchecked null result by calling IReaderByTimestamp.getValuesInTimestamps()
+* [ISSUE-3945] Fix Fuzzy query not support multiDevices and alignByDevice Dataset
+* [ISSUE-4288] Fix CI issue caused by the invalid pentaho download url
+* [ISSUE-4293] SessionPool: InterruptedException is not properly handled in synchronized wait()
+* [ISSUE-4308] READ_TIMESERIES privilege granted to users and roles can not take effect when quering by UDFs
+* fix merge ClassCastException: MeasurementMNode
+* change sync version check to major version
+* init dummyIndex after restart cluster
+
+# Apache IoTDB 0.12.2
+
+## New Features
+
+* [IOTDB-959] Add create storage group Grammar
+* [IOTDB-1399] Add a session interface to connect multiple nodes
+* [IOTDB-1466] Support device template
+* [IOTDB-1491] UDTF query supported in cluster
+* [IOTDB-1496] Timed flush memtable
+* [IOTDB-1536] Support fuzzy query REGEXP
+* [IOTDB-1561] Support fill by specific value
+* [IOTDB-1565] Add sql: set system to readonly/writable
+* [IOTDB-1569] Timed close TsFileProcessor
+* [IOTDB-1586] Support mysql-style Like clause
+* [ISSUE-3811] Provide a data type column for the last query dataset
+* TTL can be set to the prefix path of storage group
+* add JMX monitor to all ThreadPools in the server module
+
+## Improvements
+
+* [IOTDB-1566] Do not restrict concurrent write partitions
+* [IOTDB-1585] ModificationFile‘s write interface blocking
+* [IOTDB-1587] SessionPool optimization: a more aggressive Session creation strategy
+* Use StringCachedPool in TsFileResource to reduce the memory size
+* write performance optimization when replicaNum == 1
+* Optimize Primitive Array Manager
+* Function Improvement: add overlapped page rate in Tracing
+
+## Bug Fixes
+
+* [IOTDB-1282] fix C++ class SessionDataSet mem-leak
+* [IOTDB-1407] fix Filtering time series based on tags query fails Occasionally
+* [IOTDB-1437] Fix the TsFileSketchTool NPE
+* [IOTDB-1442] Time filter & TTL do not take effect in cluster
+* [IOTDB-1452] remove compaction log/ change logger to daily
+* [IOTDB-1447] ClientPool is blocking other nodes when one node fails
+* [IOTDB-1456] Fix Error occurred while executing delete timeseries statement
+* [IOTDB-1461] Fix compaction conflicts with ttl
+* [IOTDB-1462] Fix cross space compaction recover null pointer bug
+* [IOTDB-1464] fix take byte array null pointer
+* [IOTDB-1469] fix cross space compaction lost data bug
+* [IOTDB-1471] Fix path not right in "sg may not ready" log
+* [IOTDB-1475] MeasurementId check while create timeseries or template/ disable time or timestamp in timeseries path
+* [IOTDB-1488] Fix metaMember's forwarding clientPool timeout in cluster module
+* [IOTDB-1494] fix compaction block flush bug
+* [IoTDB-1499] Remove series registration using IoTDBSink
+* [IoTDB-1501] Fix compaction recover delete tsfile bug
+* [IOTDB-1529] Fix mlog recover idx bug and synchronize setStorageGroup
+* [IOTDB-1537] fix insertTablet permission
+* [IOTDB-1539] Fix delete operation with value filter is abnormal
+* [IOTDB-1540] Bug Fix: 500 when using IN operator
+* [IOTDB-1541] Fix query result not right due to non-precise time index of resource
+* [IOTDB-1542] Cpp client segment fault: char[] buffer overflow caused by long exception message
+* [IOTDB-1545] Query dataset memory leak on server caused by cpp client
+* [IOTDB-1546] Optimize the Upgrade Tool rewrite logic to reduce the temp memory cost
+* [IOTDB-1552] Only allow equivalent filter for TEXT data type
+* [IOTDB-1556] Abort auto create device when meet exception in setStorageGroup
+* [IOTDB-1574] Deleted file handler leak
+* [IOTDB-1580] Error result of order by time desc when enable time partition
+* [IOTDB-1584] Doesn't support order by time desc in cluster mode
+* [IOTDB-1588] Bug fix: MAX_TIME is incorrect in cluster mode
+* [IOTDB-1594] Fix show timeseries returns incorrect tag value
+* [IOTDB-1600] Fix InsertRowsOfOneDevicePlan being not supported in cluster mode
+* [IOTDB-1610] Fix TsFileRewriteTool writing incorrect data file
+* [ISSUE-3116] Bug when using natural month unit in time interval in group by query
+* [ISSUE-3316] Query result with the same time range is inconsistent in group by query
+* [ISSUE-3436] Fix query result not right after deleting multiple time interval of one timeseries
+* [ISSUE-3458] fix load configuration does not take effect
+* [ISSUE-3545] Fix Time interval value is disorder in group by month
+* [ISSUE-3653] fix Max_time and last return inconsistent result
+* [ISSUE-3690] Memory leaks on the server when cpp client invokes checkTimeseriesExists
+* [ISSUE-3805] OOM caused by Chunk cache
+* [ISSUE-3865] Meaningless connection reset issues caused by low default value for SOMAXCONN
+* Fix DataMigrationExample OOM if migrate too many timeseries
+* Handle false positive cases which may cause NPE of tsfile bloom filter
+* Fix Windows shell error on JDK11 & fix iotdb-env.bat not working
+* Fix cluster auto create schema bug when retry locally
+* Fix thrift out of sequence in cluster module
+* Skip non exist measurement in where clause in align by device
+* fix blocking query when selecting TsFile in compaction
+* Fix redundant data in compaction recover
+* Fix load tsfile with time partition enable
+
+## Incompatible changes
+
+* [IOTDB-1485] Replace tsfile_size_threshold by unseq_tsfile_size/seq_tsfile_size
+
+## Miscellaneous changes
+
+* [IOTDB-1499] Remove unused exception throwing notation in IoTDBSink
+* [IOTDB-1500] Remove current dynamic query memory control
+* [ISSUE-3674] Disable thrift code generation for Javascript
+* enable cacheLeader by default
+* add audit log when execute delete and set sg for tracing
+* modify nodeTool user to root
+
+# Apache IoTDB 0.12.1
+
+## Bug Fixes
+
+* [GITHUB-3373] Remove the broken cached leader connection & optimize the insertRecords method in session
+* [IOTDB-1433] Fix bug in getMetadataAndEndOffset when querying non-exist device
+* [IOTDB-1432] fix level compaction loss data
+* [IOTDB-1427] Fix compaction lock with query
+* [IOTDB-1420] Fix compaction ttl bug
+* [IOTDB-1419] Remove redundant clearCompactionStatus, fix continuous compaction doesn't take effect when
+  enablePartition
+* [IOTDB-1415] Fix OOM caused by ChunkCache
+* [IOTDB-1414] NPE occurred when call getStorageGroupNodeByPath() method using not exist path
+* [IOTDB-1412] Unclear exception message thrown when executing empty InsertTabletPlan
+* [IOTDB-1411] Fix thriftMaxFrameSize and thriftDefaultBufferSize does not in effect
+* [IOTDB-1398] Do not select unseq files when there are uncompacted old unseq files
+* [IOTDB-1390] Fix unseq compaction loss data bug
+* [IOTDB-1384] Fix group by bug
+* [ISSUE-3378] Fix NPE when clear upgrade folder; Fix some upgraded pageHeader missing statistics
+* [GITHUB-3339] Try to fix sg dead lock
+* [GITHUB-3329] Fix upgrade NPE and DeadLock
+* [GITHUB-3319] Fix upgrade tool cannot close file reader
+* [IOTDB-1212] Fix The given error message is not right when executing select sin(non_existence) from root.sg1.d1
+* [IOTDB-1219] Fix a potential NPE issue in UDF module
+* [IOTDB-1286] Fix 4 C++ mem-leak points
+* [IOTDB-1294] Fix delete operation become invalid after compaction
+* [IOTDB-1313] Fix lossing time precision when import csv with unsupported timestamp format
+* [IOTDB-1316] The importCsv tool should continue inserting if a part of insertion failed
+* [IOTDB-1317] Fix log CatchUp always failed due to not check the follower's match index
+* [IOTDB-1323] Fix return a success message when encounter RuntimeException during the insertion process
+* [IOTDB-1325] Fix StackOverflow Exception in group by natural month query
+* [IOTDB-1330] Fix the load tsfile bug when the cross multi partition's tsfile only have one page
+* [IOTDB-1348] Fix Last plan not work in cluster mode
+* [IOTDB-1376] Fix BatchProcessException was not correctly handled in BaseApplier
+* [ISSUE-3277] Fix TotalSeriesNumber in MManager counted twice when recovering
+* [ISSUE-3116] Fix bug when using natural month unit in time interval in group by query
+* [ISSUE-3309] Fix InsertRecordsOfOneDevice runs too slow
+* Fix the plan index is always zero when using insertRecords interface to run the cluster
+* Add authority check for users create timeseries using executeBatch interface without the privilege
+* Fix versionInfo NPE when query upgrading 0.11 tsfile
+* Fix upgrade tool cannot load old tsfile if time partition enabled in 0.11
+* Fix import csv throw ArrayOutOfIndexError when the last value in a line is null
+* Fix upgrade tool cannot close file reader
+
+## Improvements
+
+* [GITHUB-3399] Change the default primitive array size to 32
+* [IOTDB-1387] Support Without Null ALL in align by device clause, Filter RowRecord automatically if any column in it is
+  null or all columns are null
+* [IOTDB-1385] Extract the super user to the configuration
+* [IOTDB-1315] ExportCsvTool should support timestamp `yyyy-MM-dd'T'HH:mm:ss.SSSZ`
+* [IOTDB-1339] optimize TimeoutChangeableTSnappyFramedTransport
+* [IOTDB-1356] Separate unseq_file_num_in_each_level from selecting candidate file in unseq compaction
+* [IOTDB-1357] Compaction use append chunk merge strategy when chunk is already large enough
+* [IOTDB-1380] Automatically close the dataset while there is no more data
+* Optimize sync leader for meta
+
+## New Features
+
+* [GITHUB-3389] TTL can be set to any path
+* [GITHUB-3387] Add parameter compaction_interval=10000ms
+* [IOTDB-1190] Fully support HTTP URL char set in timeseries path
+* [IOTDB-1321][IOTDB-1322] Filter RowRecord automatically if any column in it is null or all columns are null
+* [IOTDB-1357] Compaction use append chunk merge strategy when chunk is already large
+* [ISSUE-3089] Make it possible for storage groups to have name with hyphen
+
+## Miscellaneous changes
+
+* [GITHUB-3346] upgrade netty and claim exclusion for enforcer check
+* [IOTDB-1259] upgrade libthrift from 0.12.0/0.13.0 to 0.14.1
+* Uncomment the less used configurations
+* Enable the configration `concurrent_writing_time_partition`
+
+
 # Apache IoTDB 0.12.0
 
 ## New Features
@@ -79,6 +488,30 @@
 * [PR-2582] Fix sync bug for tsfiles's directory changed by vitural storage group
 * [ISSUE-2911] Fix The write stream is not closed when executing the command 'tracing off'
 
+# Apache IoTDB 0.11.4
+
+## Bug Fixes
+
+* IOTDB-1303 Disable group by without aggregation function in select clause
+* IOTDB-1306 Fix insertion blocked caused the deadlock in memory control module
+* IOTDB-1308 Fix users with READ_TIMESERIES permission cannot execute group by fill queries
+* IOTDB-1344 Fix cannot create timeseries caused by the timeseries count doesn't reset when deleting storage group
+* IOTDB-1384 Some value will disappear while using group by query
+* IOTDB-1398 Do not select unseq files when there are uncompacted old unseq files
+* ISSUE-3316 Fix query result with the same time range is inconsistent in group by query
+* Fix TotalSeriesNumber in MManager counted twice when recovering
+* Fix unseq compaction throws a wrong exception if some paths are not in the file
+* Fix overlapped data should be consumed first exception when query
+
+## Improvements
+
+* IOTDB-1356 Separate unseq_file_num_in_each_level from selecting candidate file in unseq compaction
+* IOTDB-1412 Unclear exception message thrown when executing empty InsertTabletPlan
+* continuous compaction in level compaction strategy when no tsfile is to be closed
+
+## New Features
+
+* support brackets with number in timeseries path
 
 # Apache IoTDB 0.11.3