Releases: apache/iotdb
Releases · apache/iotdb
Apache IoTDB 1.3.2
Features & Improvements
- Storage Module: Performance improvement in the insertRecords interface for writing
- Query Module: New Explain Analyze statement added (monitoring the time spent on each stage of a single SQL execution)
- Query Module: New UDAF (User-Defined Aggregate Function) framework added
- Query Module: New MaxBy/MinBy functions added, supporting the retrieval of maximum/minimum values along with the corresponding timestamps
- Query Module: Performance improvement in value filtering queries
- Data Synchronization: Path matching supports path pattern
- Data Synchronization: Supports metadata synchronization (including time series and related attributes, permissions, etc.)
- Stream Processing: Added Alter Pipe statement, supporting hot updates of plugins for Pipe tasks
- System Module: System data point count statistics now include statistics for data imported by loading TsFile
- Scripts and Tools: New local upgrade backup tool added (backing up original data through hard links)
- Scripts and Tools: New export-data/import-data scripts added, supporting data export in CSV, TsFile formats or SQL statements
- Scripts and Tools: Windows environment now supports distinguishing ConfigNode, DataNode, and Cli by window name
...
Bugs
- Optimize the error message when a NullPointerException (NPE) occurs due to a timeout when dropping a database.
- Add logs for notifyLeaderReady, notifyLeaderChanged, and procedure worker.
- Add compatibility handling for existing erroneous data during file merging.
- Fix the deadlock issue caused by flushing empty files during querying.
- Fix the issue where Ratis becomes unresponsive during read, write, and delete operations.
- Fix the concurrent bug in load and merge operations.
- Fix the issue where the system's compression ratio is recorded as a negative number in the file for certain scenarios.
- Fix the ConcurrentModificationException issue during memory estimation for merge tasks.
- Fix potential deadlocks that may occur when writing, automatically creating, and deleting databases concurrently.
...
What's Changed
- Delete write mem control parameters by @l2280212 in #12007
- Pipe: Ensure at-least-once semantic by forcibly starting PipeHistoricalDataRegionTsFileExtractor after pipe restart by @Caideyipi in #12010
- Separate the synchronized block of AbstractCompactionEstimator file info cache by @shuwenwei in #12019
- Pipe: using clusterId to judge whether the target cluster is source cluster by @xuanronaldo in #11994
- Storage Engine: fix wal delete thread exception because multi thread safety question by @caozj1011 in #12020
- PBTree: Fix Dead Lock and Refactor write/update inteface by @bigreybear in #11985
- Remove sql
merge
by @shuwenwei in #12021 - Load: Trigger last flush time map & tsfile resource degrading after successful load by @SteveYurongSu in #12024
- feat(jdbc):getDouble add type check by @CritasWang in #12023
- Remove infinite retry logic for replica inconsistency to avoid potential problems by @OneSizeFitsQuorum in #12028
- Pipe: Support "sink.host" and "connector.host" key in receiver IP specification by @Caideyipi in #12017
- Fixed Ratis query not retrying when DataNode restarts by @OneSizeFitsQuorum in #12029
- Pipe: support replace and modify mode for alter pipe sql by @VGalaxies in #12018
- Storage Engine: put DeviceCache into the total memory of the storage engine by @caozj1011 in #12016
- Bump jackson.version from 2.15.2 to 2.15.3 by @dependabot in #12014
- IT framework supports restarting cluster by @l2280212 in #12022
- Fix typo for parameter dn_multi_dir_strategy by @OneSizeFitsQuorum in #12033
- Upgrade github action version to fix the warning by @HTHou in #12032
- Introduce UDAF(User-Defined Aggregation Functions) by @Sh-Zh-7 in #12005
- Pipe: Move parsing event logic into PipeProcessorSubtask to separate CPU intensive and IO intensive tasks by @DanielWang2035 in #11965
- DataNodeDevicePathCache should use free memory of memtable by @HTHou in #12034
- Pipe: Revert "Pipe: stop pipe using restarting strategy to unpin the wal's reference count to avoid WAL stacking (#11971)" to avoid unnecessary pipe drop during subtask exception handling by @Caideyipi in #12031
- Pipe: Removed mayLinkedTsFileCountReachDangerousThreshold judgement from stuck restart logic by @Caideyipi in #12041
- Pipe: fixed the bug that processor dies when encountered memory shortage for tablets in a period of time by @Caideyipi in #12042
- Pipe: Reduced pipe logs and controlled how often the log is printed below a certain frequency by @Caideyipi in #11973
- [IOTDB-6296] Fix memory leak in MQTTService by @JackieTien97 in #12046
- Pipe: Pattern parsing pruning: When pattern is at the level below database, the parsing logic can be skipped if tsfiles / tablets completely match with the pattern by @Caideyipi in #12049
- Bump org.apache.commons:commons-compress from 1.21 to 1.26.0 by @dependabot in #12058
- Bump ip from 2.0.0 to 2.0.1 in /iotdb-connector/grafana-plugin by @dependabot in #12057
- Pipe: fixed potential lose point bug caused by cancelled flush of historical extractor by @Caideyipi in #12056
- Fix it which use 'merge' command by @shuwenwei in #12060
- Pipe: Fixed the bug that CN cannot sense drop pipe failure in meta sync and may lead to constantly skip of drop pipe by @Caideyipi in #12059
- [IOTDB-6297] Optimize the distribute plan in the situation of
aggregation with align by device
by @Beyyes in #12043 - [IOTDB-6298] Fix number overflow in group by time interval by @JackieTien97 in #12065
- [IOTDB-6299] Fix bug in merging overlapped data process caused by filter & offset push down by @liuminghui233 in #12068
- Introduce Aggregation Function MinBy by @lancelly in #12071
- Add recover IT for Procedure, and delete ProcedureStore by @liyuheng55555 in #12045
- PBTree: Implement dual-buffer container for MNode management by @linxt20 in #12048
- Optimize flushing memtable check by @HTHou in #12081
- [IOTDB-6302] Enhance the support of ISO_LOCAL_DATE_TIME timestamp format by @HTHou in #12086
- IT: revert some changes in restart IT to make the error log clear when failed to restart by @l2280212 in #12066
- change ci to github ci by @CritasWang in #12073
- feat(bat): add title and set format by @CritasWang in #12069
- Fix dead lock in PBTree.SchemaFile by @bigreybear in #12079
- fix.root privileges lost and grant role. by @ColinLeeo in #12091
- [IOTDB-6300] Support place time column at any column index in insert statement by @JackieTien97 in #12074
- Make Drop database timeout return message more detailed by @Cpaulyz in #12082
- Fix VolatileSubtreeIterator missing update buffer if all nodes in new buffer are not qualified by @Cpaulyz in #12093
- Pbtree: MNode iterating with merge sort upon disk and buffer by @linxt20 in #12077
- Add FileUtils.moveFileSafe function by @liyuheng55555 in #12094
- Add logs for data partition allocation by @CRZbulabula in #12090
- fix: IoTDBPreparedStatement implement addBatch function by @CritasWang in #12095
- [IOTDB-6303] Correct the default path of user, role and procedure folder by @CRZbulabula in #12089
- Cache clusterId in IoTDBConfig by @liyuheng55555 in #12053
- Implement new plan optimizer: PredicatePushDown by @liuminghui233 in #11859
- Optimize ConfigNode ConsensusManager init logic by @OneSizeFitsQuorum in #12098
- Do not wait to retry when configLeader exists by @Pengzna in #12075
- Faster repair data by @shuwenwei in #12039
- Bump org.scala-lang:scala-library from 2.12.18 to 2.12.19 by @dependabot in #12104
- Bump flink.version from 1.17.0 to 1.17.2 by @dependabot in #12103
- [IOTDB-6305] Add show current_timestamp statement by @yx-zhang in #12106
- [IOTDB-6306] Fix t...
Apache IoTDB 1.3.1
Features & Improvements
- Add cluster script for one-click start-stop (start-all/stop-all.sh & start-all/stop-all.bat)
- Add script for one-click instance information collection (collect-info.sh & collect-info.bat)
- Add new statistical aggregators include stddev and variance
- Add repair tsfile data command
- Support setting timeout threshold for Fill clause. When time beyond the threshold, do not fill value.
- Simplify the time range specification for data synchronization, directly set start and end times
- Improved system observability (adding dispersion monitoring of cluster nodes, observability of distributed task scheduling framework)
- Optimized default log output strategy
- Enhance memory control for Load TsFile, covering the entire process
- Rest API (Version 2) adds column type return.
- Improve the process of query execution
- Session automatically fetch all available DataNodes
...
Bugs
- Fix issue with abnormal behavior when time precision is not in milliseconds during grouping by month.
- Fix issue with abnormal behavior when duration contains multiple units during grouping by month.
- Fix bug where limit and offset cannot be pushed down when there is an order by clause.
- Fix abnormal behavior in combination scenario of grouping by month + align by device + limit.
- Fix deserialization errors during IoT protocol synchronization.
- Fix concurrent exceptions in deleting timeseries.
- Fix issue where group by level in view sequences does not execute correctly.
- Fix potential issue of metadata creation failure when increasing election timeout
New Contributors
Full Changelog: v1.3.0...v1.3.1
Apache IoTDB 1.3.0
Features & Improvements
- Optimize the permission module and support timeseries permission control
- Optimize heap and off-heap memory configuration in startup script
- Computed-type view timeseries support LAST queries
- Add pipe-related monitoring metrics
- Pipe rename 'Extractor' to 'Source' and 'Connector' to 'Sink'
- [IOTDB-6138] Support Negative timestamp
- [IOTDB-6193] Reject Node startup when loading configuration file failed
- [IOTDB-6194] Rename target_config_node_list to seed_config_node
- [IOTDB-6200] Change schema template to device template
- [IOTDB-6207] Add Write Point Metrics for load function
- [IOTDB-6208] Node error detection through broken thrift pipe
- [IOTDB-6217] When the number of time series reaches the upper limit, the prompt message should be changed to prioritize using device templates
- [IOTDB-6218] Rename storage_query_schema_consensus_free_memory_proportion to datanode_memory_proportion
- [IOTDB-6219] Fix the display problem of explain that the print result is not aligned
- [IOTDB-6220] Pipe: Add check logic to avoid self-transmission
- [IOTDB-6222] Optimize the performance of Python client
- [IOTDB-6230] Add HEAPDUMP configuration in datanode-env.sh
- [IOTDB-6231]SchemaCache supports precise eviction
- [IOTDB-6232] Adding SSL function to dn_rpc_port
Bugs
- [IOTDB-6160] while using ` in target path, select into will throw error
- [IOTDB-6167] DataNode can't register to cluster when fetch system configuration throws NPE
- [IOTDB-6168] ConfigNode register retry logic does not worked
- [IOTDB-6171] NPE will be thrown while printing FI with debug on
- [IOTDB-6184] Merge Sort finishes one iterator too long
- [IOTDB-6191] Fix group by year not considering leap years
- [IOTDB-6226] Fix the problem of inaccurate GC monitor detection at the beginning and adjusting the alert threshold
- [IOTDB-6239] Show regions display error create time
New Contributors
- @clayburn made their first contribution in #11243
- @chunshao90 made their first contribution in #11385
Full Changelog: v1.2.2...v1.3.0
Apache IoTDB 1.2.2
Features & Improvements
- [IOTDB-6029] Implementing flink-sql-iotdb-connector
- [IOTDB-6084] Pipe: support node-urls in connector-v1
- [IOTDB-6103] Adding count_time aggregation feature
- [IOTDB-6112] Limit & Offset push down doesn't take effect while there exist time filter
- [IOTDB-6115] Limit & Offset push down doesn't take effect while there exist null value
- [IOTDB-6120] push down limit/offset in query with group by time
- [IOTDB-6129] ConfigNode restarts without relying on Seed-ConfigNode
- [IOTDB-6131] Iotdb rest service supports insertRecords function
- [IOTDB-6151] Move DataNode's system.properties to upper dir
- [IOTDB-6173] Change default encoder of INT32 and INT64 from RLE to TS_2DIFF
- Adjust the default thrift timeout parameter to 60s
- Accelerate the deletion execution
Bugs
- [IOTDB-6064] Pipe: Fix deadlock in rolling back procedures concurrently
- [IOTDB-6081] Pipe: use HybridExtractor instead of LogExtractor when realtime mode is set to log to avoid OOM under heavy insertion load
- [IOTDB-6145] Pipe: can not release TsFile or WAL resource after pipe is dropped
- [IOTDB-6146] Pipe: can not transfer data after 1000+ pipes' creating and dropping
- [IOTDB-6082] Improve disk space metrics
- [IOTDB-6104] tmp directory won't be cleaned after udf query end
- [IOTDB-6119] Add ConfigNode leader service check
- [IOTDB-6125] Fix DataPartition allocation bug when insert big batch data
- [IOTDB-6127] Pipe: buffered events in processor stage can not be consumed by connector
- [IOTDB-6132] CrossSpaceCompaction: The estimated memory size is too large for cross space compaction task
- [IOTDB-6133] NullPointerException occurs in unsequence InnerSpaceCompactionTask
- [IOTDB-6148] Pipe: Fixed the bug that some uncommited progresses may be reported
- [IOTDB-6156] Fixed TConfiguration invalidly in Thrift AsyncServer For IoTConsensus
- [IOTDB-6164] Can create illegal path through rest api
- Fix datanode status is ReadOnly because the disk is full
- Fix DataPartition allocation bug when insert big batch
- Fix flush point statistics
- Fix SchemaFileSketchTool is not found
- Refactoring DeleteOutdatedFileTask in WalNode
- Add compression and encoding type check for FastCompactionPerformer
- Add lazy page reader for aligned page reader to avoid huge memory cost when reading rows of aligned timeseries
- Pipe: use PipeTaskCoordinatorLock instead of ReentrantLock for multi thread sync
- Pipe: fix pipe procedure stuck because of data node async request forever waiting for response
- Pipe: fix NPE when HybridProgressIndex.updateToMinimumIsAfterProgressIndex after system reboot (DR: SimpleConsensus)
- Pipe: fix pipe coordinator deadlock causing CN election timeout
- Pipe: Improve performance for 10000+ pipes
- RATIS-1873. Remove RetryCache assertion that doesn't hold
Full Changelog: v1.2.1...v1.2.2
Apache IoTDB 1.2.1
Features & Improvements
- [IOTDB-5557] The metadata query results are inconsistent
- [IOTDB-5997] Improve efficiency of ConfigNode PartitionInfo loadSnapshot
- [IOTDB-6019] Fix concurrent update of last query
- [IOTDB-6036] The mods file is too large, causing Query very slow even OOM problem
- [IOTDB-6055] Enable auto restart of the pipes stopped by ConfigNode because of critical exception
- [IOTDB-6066] Add ConfigNode timeslot metric
- [IOTDB-6073] Add ClientManager metrics
- [IOTDB-6077] Add force stop
- [IOTDB-6079] Cluster computing resource balance
- [IOTDB-6082] Improve disk space metrics
- [IOTDB-6087] Implement stream interface of Mods read
- [IOTDB-6090] Add memory estimator on inner space compaction
- [IOTDB-6092] Factor mods files into memory estimates for cross-space compaction tasks
- [IOTDB-6093] Add multiple validation methods after compaction
- [IOTDB-6106] Fixed the timeout parameter not working in thrift asyncClient
- [IOTDB-6108] AlignedTVList memory calculation is imprecise
Bugs
- [IOTDB-5855] DataRegion leader Distribution is same as DataRegion Distribution
- [IOTDB-5860] Total Number of file is wrong
- [IOTDB-5996] Incorrect time display of show queries
- [IOTDB-6057] Resolve the compatibility from 1.1.x to 1.2.0
- [IOTDB-6065] Considering LastCacheContainer in the memory estimation of SchemaCacheEntry
- [IOTDB-6074] Ignore error message when TagManager createSnapshot
- [IOTDB-6075] Pipe: File resource races when different tsfile load operations concurrently modify the same tsfile at receiver
- [IOTDB-6076] Add duplicate checking when upsert alias
- [IOTDB-6078] fix timeChunk default compressType
- [IOTDB-6089] Improve the lock behaviour of the pipe heartbeat
- [IOTDB-6091] Add compression and encoding type check for FastCompactionPerformer
- [IOTDB-6094] Load:Fix construct tsFileResource bug
- [IOTDB-6095] Tsfiles in sequence space may be overlap with each other due to LastFlushTime bug
- [IOTDB-6096] M4 will output zero while meeting null
- [IOTDB-6097] ipe subscription running with the pattern option may cause OOM
- [IOTDB-6098] Flush error when writing aligned timeseries
- [IOTDB-6100] Pipe: Fix running in hybrid mode will cause wal cannot be deleted & some pipe data lost due to wrong ProducerType of Disruptor
- [IOTDB-6105] Load: NPE when analyzing tsfile
New Contributors
- @ZhangChaoming made their first contribution in #10152
- @qiuyluo made their first contribution in #10422
Full Changelog: v1.2.0...v1.2.1
Apache IoTDB 1.2.0
New Feature
- [IOTDB-5567] add SQL for querying seriesslotid and timeslotid
- [IOTDB-5631] Add a built-in aggregation functions named time_duration
- [IOTDB-5636] Add round as built-in scalar function
- [IOTDB-5637] Add substr as built-in scalar function
- [IOTDB-5638] Support case when syntax in IoTDB
- [IOTDB-5643] Add REPLACE as a built-in scalar function
- [IOTDB-5683] Support aggregation function Mode for query
- [IOTDB-5711] Python API should support connecting multiple nodes
- [IOTDB-5752] Python Client supports write redirection
- [IOTDB-5765] Support Order By Expression
- [IOTDB-5771] add SPRINTZ and RLBE encodor and LZMA2 compressor
- [IOTDB-5924] Add SessionPool deletion API
- [IOTDB-5950] Support Dynamic Schema Template
- [IOTDB-5951] Support show timeseries/device with specific string contained in path
- [IOTDB-5955] Support create timeseries using schema template in Session API
Improvements
- [IOTDB-5630] Make function cast a built-in function
- [IOTDB-5689] Close Isink when ISourceHandle is closed
- [IOTDB-5715] Improve the performance of query order by time desc
- [IOTDB-5763] Optimize the memory estimate for INTO operations
- [IOTDB-5887] Optimize the construction performance of PathPatternTree without wildcards
- [IOTDB-5888] TTL logs didn' t consider timestamp precision
- [IOTDB-5896] Failed to execute delete statement
- [IOTDB-5908] Add more query metrics
- [IOTDB-5911] print-iotdb-data-dir tool cannot work
- [IOTDB-5914] Remove redundant debug log in Session
- [IOTDB-5919] show variables add a variable timestamp_precision
- [IOTDB-5926] Optimize metric implementation
- [IOTDB-5929] Enable DataPartition inherit policy
- [IOTDB-5943] Avoid rpc invoking for SimpleQueryTerminator when endpoint is local address
- [IOTDB-5944] Follower doesn' t need to update last cache when using IoT_consensus
- [IOTDB-5945] Add a cache to avoid initialize duplicated device id object in write process
- [IOTDB-5946] Optimize the implement of tablet in Go client
- [IOTDB-5949] Support show timeseries with datatype filter
- [IOTDB-5952] Support FIFO strategy in DataNodeSchemaCache
- [IOTDB-6022] The WAL piles up when multi-replica iotconsensus is written at high concurrency
Bug Fixes
- [IOTDB-5604] NPE when execute Agg + align by device query without assigned DataRegion
- [IOTDB-5619] group by tags query NPE
- [IOTDB-5644] Unexpected result when there are no select expressions after analyzed in query
- [IOTDB-5657] Limit does not take effect in last query
- [IOTDB-5700] UDF query did not clean temp file after the query is finished
- [IOTDB-5716] Wrong dependency when pipeline consumeOneByOneOperator
- [IOTDB-5717] Incorrect result when querying with limit push-downing & order by time desc
- [IOTDB-5722] Wrong default execution branch in PlanVisitor
- [IOTDB-5735] The result of adding the distinct function to the align by device is incorrect
- [IOTDB-5755] Fix the problem that 123w can not be used in Identifier
- [IOTDB-5756] NPE when where predicate is NotEqualExpression and one of subExpression is not exist
- [IOTDB-5757] Not Supported Exception when use like ' s3 || false' in where even Type of s3 is Boolean
- [IOTDB-5760] Query is blocked because of no memory
- [IOTDB-5764] Cannot specify alias successfully when the FROM clause contains multiple path suffixes
- [IOTDB-5769] Offset doesn' t take effect in some special case
- [IOTDB-5774] The syntax that path nodes start or end with a wildcard to fuzzy match is not supported
- [IOTDB-5784] Incorrect result when querying with offset push-down and time filter
- [IOTDB-5815] NPE when using UDF to query
- [IOTDB-5837] Exceptions for select into using placeholders
- [IOTDB-5851] Using limit clause in show devices query will throw NPE
- [IOTDB-5858] Metric doesn' t display the schemaCache hit ratio
- [IOTDB-5861] Last quey is incomplete
- [IOTDB-5889] TTL Cannot delete expired tsfiles
- [IOTDB-5897] NullPointerException In compaction
- [IOTDB-5905] Some aligned timeseries data point lost after flush
- [IOTDB-5934] Optimize cluster partition policy
- [IOTDB-5953] LastCache memory control param does not take effect
- [IOTDB-5963] Sometimes we may get out-of-order query result
- [IOTDB-6016] Release file num cost after cross compaction task
New Contributors
- @EliasMei made their first contribution in #9291
- @nikam14 made their first contribution in #9368
- @riverbuilding made their first contribution in #9379
- @lichenyu20 made their first contribution in #9458
Full Changelog: v1.1.2...v1.2.0
Apache IoTDB 1.1.2
New Feature
- [IOTDB-5919]show variables add a variable timestamp_precision
- Add Python SessionPool
Improvement/Bugfix
- [IOTDB-5901] Load: load tsfile without data will throw NPE
- [IOTDB-5903] Fix cannot select any inner space compaction task when there is only unsequence data
- [IOTDB-5878] Allow ratis-client retry when gRPC IO Unavailable
- [IOTDB-5939] Correct Flusing Task Timeout Detect Thread
- [IOTDB-5905] Fix aligned timeseries data point lost after flushed in some scenario
- [IOTDB-5963] Make sure that TsBlock blocked on memory is added in queue before the next TsBlock returned by root operator
- [IOTDB-5819] Fix npe when booting net metrics
- [IOTDB-6023] Pipe: Fix load tsfile error while handling empty value chunk
- [IOTDB-5971] Fix potential QUOTE problem in iotdb reporter
- [IOTDB-5993] ConfigNode leader changing causes lacking some DataPartition allocation result in the response of getOrCreateDataPartition method
- [IOTDB-5910] Fix compaction scheduler thread pool is not shutdown when aborting compaction
- [IOTDB-6056] Pipe: Failed to load tsfile with empty pages (NPE occurs when loading)
- [IOTDB-5916]Fix exception when file is deleted during compaction selection
- [IOTDB-5896] Fix the NPE issue when taking snapshot in WAL combined with Aligned Binary
- [IOTDB-5929] Enable DataPartition inherit policy
- [IOTDB-5934] Optimize cluster partition policy
- [IOTDB-5926] Remove Useless Rater in Timer
- [IOTDB-6030] Improve efficiency of ConfigNode PartitionInfo takeSnapshot
- [IOTDB-5997] Improve efficiency of ConfigNode PartitionInfo loadSnapshot
- Fix potential deadlock when freeing memory in MemoryPool
- Release resource of FI after all drivers have been closed
- Set default degree of parallelism back to the num of CPU
- Make SequenceStrategy and MaxDiskUsableSpaceFirstStrategy are allowed in cluster mode
- Fix npe exception when invalid in metric module
- Fix CQ does not take effect in ns time_precision
- Fix storage engine memory config initialization
- Fix template related schema query
- add default charset setting in start-datanode.bat and print default charset when starting
- Fix TsfileResource error after delete device in sequence working memtable
- load TsFile bugs: Not checking whether the tsfile data loaded locally is in the same time partition during the loading process & LoadTsFilePieceNode error when loading tsfile with empty value chunks
- Fix alias query failure after restarting DataNode
Apache IoTDB 1.1.1
New Feature
- [IOTDB-2569] ZSTD compression
Improvement/Bugfix
- [IOTDB-5781] Change the default strategy to SequenceStrategy
- [IOTDB-5780] Let users know a node was successfully removed and data is recovered
- [IOTDB-5735] The result of adding the distinct function to the align by device is incorrect
- [IOTDB-5777] When writing data using non-root users, the permission authentication module takes too long
- [IOTDB-5835] Fix wal accumulation caused by datanode restart
- [IOTDB-5828] Optimize the implementation of some metric items in the metric module to prevent Prometheus pull timeouts
- [IOTDB-5813] ConfigNode restart error due to installSnapshot failed
- [IOTDB-5657] Limit does not take effect in last query
- [IOTDB-5717] Incorrect result when querying with limit push-downing & order by time desc
- [IOTDB-5722] Wrong default execution branch in PlanVisitor
- [IOTDB-5784] Incorrect result when querying with offset push-down and time filter
- [IOTDB-5815] NPE when using UDF to query
- [IOTDB-5829] Query with limit clause will cause other concurrent query break down
- [IOTDB-5824] show devices with * cannot display satisfied devices
- [IOTDB-5831] Drop database won't delete totally files in disk
- [IOTDB-5818] Cross_space compaction of Aligned timeseries is stucked
- [IOTDB-5859] Compaction error when using Version as first sort dimension
- [IOTDB-5869] Fix load overlap sequence TsFile
Apache IoTDB 1.1.0
New Features
- [IOTDB-4572] support order by time in align by device
- [IOTDB-4816] Support Show Queries command
- [IOTDB-4817] Support kill query command
- [IOTDB-5077] Support new command formats in SHOW REGIONS
- [IOTDB-5108] Support region migration
- [IOTDB-5202] Support show regions with specific database
- [IOTDB-5282] Add SQL show variables, which can display the current cluster variables
- [IOTDB-5341] Support GROUP BY VARIATION in aggregation query
- [IOTDB-5372] Support data type cast in SELECT INTO
- [IOTDB-5382] Support DIFF as built-in scalar function in IoTDB
- [IOTDB-5393] Show Region creation time when execute show regions
- [IOTDB-5456] Implement COUNT_IF built-in aggregation function
- [IOTDB-5515] Support GROUP BY CONDITION in aggregation query
- [IOTDB-5555] Enable modify dn_rpc_port and dn_rpc_address in datanode-engine.properties
- Support docker deployment
- Rename SeriesSlotId to SeriesSlotNum in show regions
Improvements
- [IOTDB-4497] Improve NodeStatus definition
- [IOTDB-5066] Upgraded the GetSlots SQLs
- [IOTDB-5161] Add output type check for WHERE & HAVING clause and refuse expressions whose return type are not boolean exist in WHERE & HAVING clause
- [IOTDB-5185] Fixed that old snapshot is not deleted in IoTConsensus
- [IOTDB-5287] Added status “Discouraged” to RegionGroup
- [IOTDB-5449] Wait for query resource while the query queue is full instead of throwing exception directly
- change STARTUP_RETRY_INTERVAL_IN_MS from 30s to 3s
Bug Fixes
- [IOTDB-4684] Fix devices with the same name but different alignment properties are compacted into the wrong alignment property
- [IOTDB-5061] Add initialize state check when create snapshot
- [IOTDB-5090] Fix the NPE when executing stop-datanode.sh
- [IOTDB-5112] Fixed IoTConsensus synchronization stuck under low load or during restart
- [IOTDB-5126] Fix that show-regions show IP rather than hostname even though the hostname is used when registering
- [IOTDB-5165] Fix fail to pass compaction validation when resources degrade to FileTimeIndex
- [IOTDB-5170] Fix the problem that datanode is closed when executing stop-confignode.bat on Windows platform
- [IOTDB-5199] Fix NPE in StorageExector inLoading process
- [IOTDB-5216] Fix order by timeseries doesn't take effect in aligned last query
- [IOTDB-5228] NPE if the file does not exist while creating TsFileSequenceReader instance
- [IOTDB-5240] Fix schema template timeseries read/write error after restart
- [IOTDB-5245] Fix data is incomplete in last query
- [IOTDB-5277] Fix DataNode restart failure when SchemaRegion loading snapshot
- [IOTDB-5278] Fix JDBC Driver cannot connect to the dbeaver
- [IOTDB-5285] Fix TimePartition error when restarting with different time partition configuration
- [IOTDB-5269] Fix wrong data of devices ought to be deleted after executing
delete from
sql - [IOTDB-5324] Fix wal cann't be deleted in destDataNode after region migration when data_replication_factor is 1 in IoTConsensus
- [IOTDB-5389] Cause DataNode startup to fail when wal_mode is disabled in IoTConsensus
- [IOTDB-5414] Fix timeseries with alias deleted success but can still be queried by alias
- [IOTDB-5426] Cannot trigger flush for sequence file when timed flush enabled
- [IOTDB-5441] Fix NPE while fetch schema that is not in template used by related device
- [IOTDB-5469] Fix get schema info failure after creating template with backquote characters successfully
- [IOTDB-5474] Fix count nodes using level bug
- [IOTDB-5480] IoTConsensus sync lag may be negative under single copy
- [IOTDB-5488] Support set system to readonly on local
- [IOTDB-5492] Skip broken tsfile when recovering system
- [IOTDB-5512] Fixed IoTConsensus may repeatedly send some log when restarting
- [IOTDB-5516] Fix creating timeseries failure after dropping all databases
- [IOTDB-5526] Fix deleting timeseries failure when it belongs to a device activating template
- [IOTDB-5548] Fix dropping template failure when using pure number as template name
- [IOTDB-5592] Fix unexpected error while using full path(starting with root) in having/where clause
- [IOTDB-5620] Fix flush stuck when there is a lot of time partitions in each DataRegion
- [IOTDB-5639] Fix file not found exception in cross space compaction selector
- [IOTDB-5657] Fix LIMIT&OFFSET does not take effect in last query
- [IOTDB-5684] Fix log folder generation when using ConfigNode's Simple consensus protocol
- [IOTDB-5685] Fix error msg of failing to create a timeseries on an existing path when ReadOnly state
- [IOTDB-5686] Fix devices with the same name but different alignment properties meets error in inner seq compaction
- [IOTDB-5700] Clean temporary files created by UDF query after it finishes
- Add SHOW_CQ privilege
Apache IoTDB 1.0.1
New Features
- [IOTDB-5102] Support explain the sqls using align by device clause
- [IOTDB-5282] Add SQL show variables, which can display the current cluster variables
Improvements
- [IOTDB-4595] Add real-time monitoring data for tsfile merge
- [IOTDB-5125] Stop the process when port is already in use when launching ConfigNode or DataNode
- [IOTDB-5185] Fixed that old snapshot is not deleted in IoTConsensus
- [IOTDB-5202] Support showing regions regarding database
- [IOTDB-5205] Construct Cluster Node startup protocol, reject start or restart request of ConfigNode or DataNode when using wrong data
- [IOTDB-5208] Fix increase of file handles when TsFileResource is degraded and compacted with fast performer
- [IOTDB-5223] Cause DataNode startup to fail when multiple disks are configured in the data directory and the dataRegion consensus protocol uses Ratis
- [IOTDB-5232] Add Schema Memory Usage metric monitor
- [IOTDB-5249] Add interface to set datatype when users customize the payload formatter of mqtt
- [IOTDB-5258] Add timeout parameter for ExportCSV/ExportTsFile Tool
- [IOTDB-5306] Change the default port of ConfigNode and DataNode
- [IOTDB-5326] Add cluster_name parameter to distinguish different cluster
- [IOTDB-5389] Cause DataNode starup to fail when wal_mode is disabled in IoTConsensus
Bug Fixes
- [IOTDB-4978] Fix possible deadLock while using select into
- [IOTDB-5090] Fix the NPE when executing stop-datanode.sh
- [IOTDB-5116] Fix wrong empty result set in aggregation query while there is no data in queried timeseries
- [IOTDB-5118] Fix that datanode opens too many file handles (TYPE DIR)
- [IOTDB-5174] Fixed restart failure when IoTConsensus hostname containing '-'
- [IOTDB-5126] Fix that show-regions show IP rather than hostname even though the hostname is used when registering
- [IOTDB-5135] Fix the Sync snapshot failure (also blocks ConfigNode snapshot) when sync file is empty
- [IOTDB-5141] Fix fast compaction scheduler bug
- [IOTDB-5144] Fix classCastException in IoTDBDatabaseMetadata of jdbc
- [IOTDB-5158] Fix failure of getting devices from tsfile
- [IOTDB-5170] Fix the problem that datanode is closed when executing stop-confignode.bat on Windows platform
- [IOTDB-5210] Fix concurrent bug caused by init and close of driver
- [IOTDB-5212] Upgrade an illegal CQ verification prompt from v0.14.0 to v1.0
- [IOTDB-5215] Fix the wrong usage of chunkPointNumLowerBound in IoTDBDescriptor
- [IOTDB-5216] Fix order by timeseries doesn't take effect in aligned last query
- [IOTDB-5222] Fix the load of some metric related configuration
- [IOTDB-5231] Fix that Datanode could not start when binding 9091 error
- [IOTDB-5233] Correct the message of unsupported thrift interface of schema template
- [IOTDB-5236] Fix DeleteData Python API cannot work
- [IOTDB-5240] Fix schema template timeseries read/write error after restart
- [IOTDB-5261] Fix the number of clients in client pool of AsyncIoTConsensusServiceClient can not be changed through dn_max_connection_for_internal_service
- [IOTDB-5266] Refine the code of cross selector and fix the bug when using FileTImeIndex
- [IOTDB-5269] Fix wrong data of devices ought to be deleted after executing
delete from
sql - [IOTDB-5277] Fix DataNode restart failure when SchemaRegion loading snapshot
- [IOTDB-5278] Fix JDBC Driver cannot connect to the dbeaver
- [IOTDB-5285] Fix TimePartition error when restarting with different time partition configuration
- [IOTDB-5286] Fix target files are selected to participate in other compaction task
- [IOTDB-5313] Fix Python client doesn't handle REDIRECTION_RECOMMEND correctly
- [IOTDB-5452] Add leastDataRegionGroupNumSetByUser examination to ensure that leastDataRegionGroupNum will not be changed by system
- [IOTDB-5498] Fix SessionPool OOM problem when the number of devices and sessions is large
- [IOTDB-5501] Fix memory leak in MemoryPool
- [IOTDB-5525] Fix the partition error of device after partition fetcher