You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by mm...@apache.org on 2021/02/06 22:58:55 UTC

[ignite] branch master updated: IGNITE-14069 Added release notes for 2.10 version (#8748)

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

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


The following commit(s) were added to refs/heads/master by this push:
     new 8489c4f  IGNITE-14069 Added release notes for 2.10 version (#8748)
8489c4f is described below

commit 8489c4fc9483b0b7ef19edb43a7270ac77e4e868
Author: Maxim Muzafarov <mm...@apache.org>
AuthorDate: Sun Feb 7 01:58:42 2021 +0300

    IGNITE-14069 Added release notes for 2.10 version (#8748)
---
 RELEASE_NOTES.txt | 234 +++++++++++++++++++++++++++++++++++++++++++++++++++++-
 1 file changed, 231 insertions(+), 3 deletions(-)

diff --git a/RELEASE_NOTES.txt b/RELEASE_NOTES.txt
index 576ec9c..b0c37e4 100644
--- a/RELEASE_NOTES.txt
+++ b/RELEASE_NOTES.txt
@@ -2,6 +2,234 @@ Apache Ignite Release Notes
 ===========================
 
 
+Apache Ignite In-Memory Distributed Database 2.10.0
+-----------------------------------------------------------
+
+
+(!) WARNINGS:
+* The community accepted MVCC API discontinuation in future releases
+* Enabling/disabling WAL doesn't work properly on unstable topology and will be fixed soon
+* Spring Data moved to ignite-extension and will be released separately
+* Node.js, Python, PHP thin clients moved to a dedicated repository
+
+
+Ignite:
+* Added API for checking network connectivity between all nodes in a cluster
+* Added API to get segment sizes
+* Added InitialSize and MaxSize to DataRegion metrics
+* Added RebalancingPartitionsTotal metrics
+* Added TDE CLI management tool
+* Added TDE cache key rotation
+* Added a metric for processed keys when rebuilding indexes
+* Added an ability to check driver metrics in Cassandra store
+* Added a cluster performance profiling
+* Added cluster snapshot security permissions
+* Added a command to control.sh to get an arbitrary Metric
+* Added a command to control.sh to get an arbitrary SystemView
+* Added control.sh API - schedule & cancel
+* Added control.sh API - status
+* Added core defragmentation functions
+* Added deadlock detection for cache entry reentrant locks
+* Added defragmentation JMX API for schedule/cancel/status
+* Added defragmentation parallelism implementation
+* Added events for snapshot operation state
+* Added explicit command.sh option to enable experimental commands
+* Added an extension for tracing the communication socket write with a number of sent bytes
+* Added fallback to full partition rebalancing in case historical supplier failed to read all necessary data updates from WAL
+* Added generic to maintenance mode feature
+* Added implementation readiness probe REST endpoint
+* Added new advanced heuristics for historical rebalance
+* Added new checkpoint metrics
+* Added new event firing before query execution
+* Added new event for node join validation failure
+* Added new index manipulation commands to control.sh
+* Added new metrics framework in ZookeeperDiscovery
+* Added new type of WAL records to track atomic updates on backup nodes
+* Added non markers checkpoint implementation
+* Added output IgniteSystemProperties via control.sh
+* Added special mode for maintenance of Ignite node. Employing Maintenance Mode for clearing corrupted PDS files
+* Added stopping warm-up to control.sh
+* Added support to graceful shutdown for ZookeeperDiscoverySpi
+* Added system view for binary metadata
+* Added system view for metastorage items
+* Added thin client support for Spring Transactions
+* Added thread dumps on failure processor invocations enabled by default
+* Added warming up strategy
+* Fixed AuthenticationContext did not contain subject address when subject is IgniteClient
+* Fixed BPlus tree lock retried limit reached with sqlOnHeapCacheEnabled
+* Fixed BinaryMarshaller needed to use context class loader for deserialization
+* Fixed CLI command to execute maintenance action in corrupted PDS scenario
+* Fixed ComputeScheduleExample
+* Fixed Continuous Query buffers to reduce heap usage
+* Fixed DurableBackgroundTask that could abandon incomplete task
+* Fixed FileWriteAheadLogManager creates 0-length WAL segments and could not start later
+* Fixed GridCacheOffheapManager which ignored candidate pages count for index partition
+* Fixed IgniteCache#isClosed() returned false on server node even if the cache had been closed before
+* Fixed IgniteScheduler that had to run inside the Ignite Sandbox with appropriate security context
+* Fixed NullPointerException at dumping long running operations
+* Fixed NullPointerException due to race on cache stop and transaction commit
+* Fixed NullPointerException during Cassandra Store initialization with PRIMITIVE strategy
+* Fixed NullPointerException in IgniteServiceProcessor when destroying a cache
+* Fixed NullPointerException in logSupplierDone(UUID nodeId)
+* Fixed NullPointerException on client start
+* Fixed NullPointerException on tx recovery
+* Fixed NullPointerException with empty persistence data region
+* Fixed OOM on creating rebalance iterator while rebalancing cache with large values
+* Fixed OpenCensus module had no runtime dependencies
+* Fixed Query cancellation froze on local lazy queries
+* Fixed UnsupportedOperationException on stopping grid
+* Fixed WAL archive cleanup from checkpoint to rollover
+* Fixed WAL compression did not work for binary recovery
+* Fixed WAL iterators required WRITE permissions
+* Fixed WAL segments did not released on releaseHistoryForPreloading()
+* Fixed assertion error of expired cache entries, which relate to a non-persistent data region in the persistent cluster
+* Fixed assertion error which happened on stale latch's acknowledge
+* Fixed blocking section in GridNioWorker and GridNioClientWorker which lead to false positive blocking thread detection
+* Fixed cache Interceptors deserialization on client nodes
+* Fixed checkpoint read lock failed if it was taking under write lock during the stopping node
+* Fixed checkpoint write lock missed during snapshot operation
+* Fixed client node with a static encrypted cache generation on node join
+* Fixed connection recovery timeout
+* Fixed control.sh baseline printed node IP addresses
+* Fixed control.sh did not print results to stdout
+* Fixed control.sh did not start if JMX port was set
+* Fixed control.sh showed passwords in the output
+* Fixed control.sh validate_indexes threw CorruptedTreeException and fails server node during check
+* Fixed critical system error happened on unregistering a JMX bean
+* Fixed deadlock between grid-timeout-worker and a thread opening a communication connection
+* Fixed deadlock between in GridEncryptionManager
+* Fixed deadlock in IgniteServiceProcessor
+* Fixed deadlock on Cache.putAll(Map<KV>)
+* Fixed deadlock when deleting multiple caches
+* Fixed deadlock when receiving ComputeTask result by IgniteClient
+* Fixed deb package dependence on a non-existent package which could not be installed on Debian 10
+* Fixed deserialization failed at IBinaryObject containing an IBinaryObject field
+* Fixed disabling the archive procedure with walCompactionEnabled might broke reading from wal on server restart
+* Fixed disco-notifier-worker handles IgniteInterruptedCheckedException incorrectly
+* Fixed duplication in select query during partition eviction for caches with 0 backups
+* Fixed error during purges by expiration: Unknown page type
+* Fixed exception was discarded in GridCacheProcessor
+* Fixed exchange worker waiting for new task from queue was considered as blocked
+* Fixed a few issues of command line warm-up in control.sh
+* Fixed handling of a rebalancing with disabled WAL
+* Fixed help information output for control.sh --property help
+* Fixed high contention on GridCachePartitionExchangeManager.ExchangeFutureSet#values
+* Fixed historical iterator on atomic group transferring additional rows
+* Fixed incorrect calculation of WAL segments that should be deleted from WAL archive
+* Fixed incorrect topology snapshot output on coordinator change
+* Fixed incorrect usage of Class.isAssignableFrom in SystemViewLocal and SystemViewMBean classes
+* Fixed incorrect work of predicates (< and >) in where clause with compound primary key
+* Fixed local metastorage system view failure if unmarshalled values were present
+* Fixed metastore which might leave uncompleted write futures during a node stop
+* Fixed model classes which required manual deserialization if used inside loaded job by p2p
+* Fixed operations started on client nodes were not traced
+* Fixed partial index rebuild failed in case indexed cache contained different data types
+* Fixed partition loss detection was not working if a dynamic cache was not started on a client
+* Fixed performance drop when there were many thin clients per server
+* Fixed pingNode() failure pinging nodes with unresolved addresses
+* Fixed printing warning if unordered map was used for bulk update operation on atomic cache
+* Fixed hanging rebalance not in the final state although all partitions were owned
+* Fixed releasing a segment if it was not present in FileWriteAheadLogManager#reserve
+* Fixed removing expired cache entries
+* Fixed restorePartitionStates triggered FailureHandler on node startup
+* Fixed rows buffers usage by reducing index for simple one-way reducer
+* Fixed scan query failure with an assertion error: Unexpected row key
+* Fixed security issue of JMX configuration
+* Fixed speed base throttling unexpectedly degraded to zero
+* Fixed spring data integration which did not introspect the fields of the key object
+* Fixed starvation in mgmt pool caused by MetadataTask execution
+* Fixed synchronization issues when different classloaders were used for deployment of same class
+* Fixed transaction commit completed successfully if a partition was lost on commit phase
+* Fixed validate index did not stop after process of control.sh was interrupted
+* Fixed validateKeyAndValue which attempted to deserialize key and value when QueryEntity.fields was not set
+* Fixed waiting for completion of operations on indexes before cache stop
+* Moved ClusterMetrics to the new metrics framework
+* Moved TcpDiscoveryStatistics to new metrics framework
+* Moved spring-data modules to ignite-extensions
+* Removed 'default' cache usage from REST API
+* Removed the WALPointer interface and using the FileWALPointer instead
+* Removed ability to delete segments from the middle of WAL archive
+* Removed unnecessary dependency to curator-client from ZookeeperDiscoverySpi
+* Removed unnecessary ZkPinger from ZookeeperDiscovery
+
+SQL:
+* Added lazy flag to synthetic SELECT used by first step of DML query
+* Added tracing of SQL queries
+* Added unification of fallback properties for SSL settings as per Java standard
+* Fixed REPLICATED cache could not be left-joined to PARTITIONED
+* Fixed decimal columns in SQL result set had invalid precision and scale
+* Fixed exception occurred on SQL caches during the client reconnection
+* Fixed tracing of SELECT queries caused incorrect span inheritance
+* Fixed transformation of sub-queries to JOINs when possible
+
+JDBC/ODBC:
+* Added ODBC SQLNumResultCols for prepared statement
+* Added ODBC driver assigned SQL_BINARY type to DATE fields
+* Added ODBC driver showed real nullability info
+* Added ODBC implementation of SQLRowCount for select queries
+* Added ODBC support of SQL_ATTR_ROW_ARRAY_SIZE with value more than one
+* Fixed thin driver reported incorrect property names
+
+Java thin-client:
+* Added non-blocking socket IO usage
+* Added support for IPv6 addresses
+* Added thin Client Continuous Query
+* Added thin client Java API - async API
+* Added thin client Kubernetes discovery
+* Fixed unnecessary CHM get/remove on each request to server
+* Fixed connect/disconnect during topology update might lead to partition divergence in ignite-sys-cache
+* Fixed exception type was lost on rethrow
+* Fixed message not fully read by client after SECURITY_VIOLATION error
+* Fixed thin client silently closed channel after inactivity
+* Fixed thin clients could not access the Ignite Service deployed through UriDeploymentSpi
+* Fixed unsupported protocol version exception on getting cache configuration
+
+Thin-client:
+* Moved Node.js thin client to a separate git repo
+* Moved PHP thin client to a separate git repo
+* Moved Python thin client to a separate git repo
+
+Ignite .NET:
+* Added CacheConfiguration.NodeFilter
+* Added Partitions and UpdateBatchSize to SqlFieldsQuery
+* Added RendezvousAffinityFunction.BackupFilter
+* Added includeExpired to ContinuousQuery
+* Added thin client service invocation
+* Added thin client transactions
+* Fixed CachePartialUpdateException: failed to update keys (using Cache.PutAsync)
+* Fixed DateTime usage as a cache key or value
+* Fixed GetAffinity failure with NullPointerException on client node
+* Fixed LINQ provider emitted incorrect table alias for queries with JOIN and GROUP BY combined
+* Fixed Service could not assign correct type to passed array parameters (.Net -> .Net call)
+* Fixed Service lost returned array type information
+* Fixed binary configuration for Compute API invocation
+* Fixed binary configuration of Ignite Java service params and result when calling it from Ignite.NET
+* Fixed child processes became zombies when persistence was used with direct-io on Linux
+* Fixed client should have peerClassLoading property in the IgniteConfiguration class
+* Fixed dispose hangs when continuous query was active on .NET Core 3.x
+* Fixed incorrect GetTotalPhysicalMemory result in Docker
+* Fixed interoperable DateTime
+* Fixed misleading LINQ exception when expression could not be translated
+* Fixed service that could not assign correct type to passed array parameters
+* Fixed slow enum serialization
+* Fixed wrong affinity key registration with AffinityKeyMapped attribute
+
+Ignite C++:
+* Added Windows support to CMake build system
+* Added implementation of Cluster API
+* Added implementation of SQL API
+* Added thin client transactions
+* Fixed compilation using msvc 14.1
+* Fixed odbc-example losing some values if run with 1 additional node
+
+ML:
+* Added catboost inference integration
+* Added initial JSON export/import support for all models
+* Added more distances between two Vectors
+* Added target encoding preprocessor
+* Fixed Incorrect Vector::kNorm evaluation for odd powers
+
+
 Apache Ignite In-Memory Computing Platform 2.9.1
 -----------------------------------------------------------
 
@@ -12,7 +240,7 @@ Ignite Core:
 * Added RebalancingPartitionsTotal metrics
 * Improved checkpoint concurrent behaviour
 * Fixed critical system error when unregister a JMX bean
-* Fixed IgniteCache#isClosed() returns false on server node even if the cache had been closed before
+* Fixed IgniteCache#isClosed() returned false on server node even if the cache had been closed before
 * Fixed inability to eagerly remove expired cache entries
 * Fixed partial index rebuild issue in case indexed cache contains different datatypes
 * Fixed local metastorage system view error if unmarshallable values present
@@ -22,13 +250,13 @@ Ignite Core:
 * Fixed issue when scan query fails with an assertion error: Unexpected row key
 * Fixed issue with archiving and enabled wal compaction setting on server restart
 * Fixed NPE during Cassandra Store initialization with PRIMITIVE strategy
-* Fixed synchronization problems when different classloaders are used for deployment of same class
+* Fixed synchronization problems when different classloaders were used for deployment of same class
 * Fixed exception on SQL caches when client reconnect
 * Fixed deadlock on multiple cache delete
 * Fixed NPE in IgniteServiceProcessor when destroying a cache
 * Fixed issue when DurableBackgroundTask can abandon incomplete task
 * Fixed issue related to cache interceptor deserialization on client nodes
-* Fixed issue when control.sh doesn't start if JMX port was set
+* Fixed issue when control.sh did not start if JMX port was set
 * Fixed issue when ZookeeperDiscoverySpiMBeanImpl#getCoordinator can return invalid node as coordinator
 * Fixed issue when valid blocking section in GridNioWorker and GridNioClientWorker leads to false positive blocking thread detection
 * Fixed several logging issues