You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@ignite.apache.org by GitBox <gi...@apache.org> on 2020/02/05 19:11:23 UTC

[GitHub] [ignite] Mmuzaf commented on a change in pull request #7367: IGNITE-12626: update RELEASE_NOTES for 2.8

Mmuzaf commented on a change in pull request #7367: IGNITE-12626: update RELEASE_NOTES for 2.8
URL: https://github.com/apache/ignite/pull/7367#discussion_r375452140
 
 

 ##########
 File path: RELEASE_NOTES.txt
 ##########
 @@ -1,6 +1,372 @@
 Apache Ignite Release Notes
 ===========================
 
+
+Apache Ignite In-Memory Database and Caching Platform 2.8
+---------------------------------------------------------
+
+
+Ignite:
+* Added @IgniteExperimental API annotation to notify users about unstable API
+* Added IGNITE_CONSISTENT_ID system property
+* Added IGNITE_DISCOVERY_DISABLE_CACHE_METRICS_UPDATE system property
+* Added IGNITE_YARN_QUEUE property to override YARN queue name
+* Added JMX ability to exclude node from topology
+* Added JMX metrics for partition map exchange timings
+* Added SSL support for ZookeeperSpi
+* Added Spark SQL Table Schema Specification
+* Added WAL page snapshot records compression
+* Added ability to override all caches 'rebalanceThrottle' option via JVM node option
+* Added ability to set default parallelism of rebuild indexes in configuration
+* Added ability to track system/user time held in the transaction
+* Added binary mode (withKeepBinary) to Data Structures Queue
+* Added cache mode which allows reads with consistency check and fix
+* Added cache validation logic on primary node instead of near node
+* Added cluster activation/deactivation events
+* Added configuration for explicit plugins providing (via spring configuration)
+* Added disk page compression support
+* Added extra logging for client-server connections in TcpDiscoverySpi implementations
+* Added information about possible long GC pause to checkpoint started message
+* Added initial support of Spark 2.4 (new internal changes since Spark 2.3)
+* Added parallel write&evict same key in CacheWriteBehindStore
+* Added possibility to have different rebalance thread pool size for nodes in the cluster
+* Added support TcpCommunicationSpi of TLSv1.3
+* Added support TcpDiscoveryS3IpFinder client-side encryption
+* Added support UriDeploymentSpi for JAR files
+* Added support array as key for the cache
+* Added support discovery messages for service deployment
+* Added support for baseline auto-adjustment
+* Added support for Kubernetes discovery for non-ready pods
+* Added support for spring data update/delete operations
+* Added support logical recovery phase outside of PME
+* Added support of best effort affinity for thin clients (partition awareness)
+* Added support of node discovery through AWS ELB
+* Added transaction label to transaction cache events (e.g. EVT_TX_STARTED, EVT_TX_COMMITTED)
+* Added transactions support to thin clients
+* Added 'limit' as a parameter for TextQuery constructor and builder
+* Added ignite-spring-data_2.2 module to be used with Spring Framework 5.2.x and Spring Data 2.2.x
+* Added integration with hibernate 5.3
+* Added support for non-blocking PME on node left
+* Ass support for IgniteSpark skipStore option for internal dataStreamer (IgniteRdd and Ignite DataFrame)
+* Avoid synchronous initialization of storage managers during PME
+* Fixed B+Tree corruption caused by byte array values
+* Fixed ComputeJob cancel method executes with the wrong SecurityContext
+* Fixed IGNITE_ENABLE_FORCIBLE_NODE_KILL system property behaviour
+* Fixed IO race during read\write cache configurations
+* Fixed Ignite Queue hanging after several read/write operations
+* Fixed IgniteCache replace method does not work in a binary mode without classes
+* Fixed P2P for remote filter and filter factory
+* Fixed RobinHoodBackwardShiftHashMap on big-endian architectures
+* Fixed ScanQuery doesn't take lost partitions into account
+* Fixed Spark DataFrame will get the wrong schema if a user executes add/drop column DDL
+* Fixed TTL manager may not clear entries from the underlying CacheDataStore
+* Fixed TcpDiscovery lock on SSLSocket close
+* Fixed WebSessionFilter does not work with jetty 9.4 anymore
+* Fixed a new exchange coordinator skips client fast reply for a previous exchange
+* Fixed activate\deactivate hanging
+* Fixed affinity calculation and fetching on client nodes
+* Fixed binary metadata is not registered during the start of the cache
+* Fixed blinking baseline node sometimes unable to connect to a cluster
+* Fixed cache start while the cache is restarting with the same name
+* Fixed checkpoint temp files don't removed on a node start
+* Fixed client does not survive after several cluster restarts for ZookeeperDiscoverySpi
+* Fixed cluster hanging on cache invoke with binary objects creation
+* Fixed compatibility issue with JDBC drivers of older versions
+* Fixed continuous query handlers are not called on backups when a one-phase commit is used
+* Fixed data corruption when an exception occurred during tx commit without node stopping
+* Fixed data loss during starting of the nodes with empty persistence data storage
+* Fixed deadlock between restore partition states and checkpoint begin phase
+* Fixed deadlock on client node in case of network problems or long GC pauses
+* Fixed detection of corrupted index storage on a file system
+* Fixed dynamic columns and indexes can be lost after the cluster restart
+* Fixed exchange hanging while new node restoring state from disk and starting caches
+* Fixed exchange on node left hanging when a cluster is in the transition state
+* Fixed index usage is not applicable for mixed IN and EQUALS queries
+* Fixed node hanging on join to topology
+* Fixed node hanging with TcpDiscoveryS3IpFinder while stopping
+* Fixed p2p incorrectly loaded classes of remote query filter
+* Fixed partition hanging in MOVING state after node joined and rebalanced
+* Fixed partition may restore wrong MOVING state during crash recovery
+* Fixed possible exceptions during simultaneous cache group stop and partition eviction
+* Fixed race between rollback exception and timeout exception on changing transaction state
+* Fixed segmenting node can cause ring topology broke
+* Fixed stopping caches concurrently with node join may lead to a crash of the node
+* Fixed transaction commit exception about missing binary schema on large clusters
+* Fixed transaction prepare-commit ordering in one-phase commit scenario
+* Fixed transactions that potentially may cause hanging in COMMITING state and partitions desync
+* Fixed validation of joining nodes for Zookeeper
+* Fixed when collocated IgniteSet close is not working on non-affinity node
+* Forbidding joining persistence node to an in-memory cluster
+* IGNITE_DISABLE_WAL_DURING_REBALANCING turned on by default
+* Improved CRC32 calculation algorithms for internal usages
+* Improved LRT diagnostic messages
+* Improved PME speed during full partition map generation (parallel execution)
+* Improved PME speed during full partition map updating (parallel execution)
+* Improved PME speed for starting multiple caches on joining node
+* Improved large clusters discovery meta exchange (by add compression on Discovery data bag)
+* Improved logging for the index rebuild procedure
+* Improved read of hot variables in WAL
+* Improved speed of WAL segment archiving
+* Improved speed of checkpoint finalization on binary memory recovery
+* Optimize GC pressure on rebalance procedure
+* Optimize HistoryAffinityAssignment heap usage
+* Performance improvements for affinity initialization for started cache groups
+* Removed IGNITE_SERVICES_COMPATIBILITY_MODE system property
+* Removed Java 7 and AI 1.x leftovers from IgniteSystemProperties & IgniteProductVersion
+* Replaced IGNITE_BINARY_META_UPDATE_TIMEOUT with IGNITE_WAIT_SCHEMA_UPDATE
+* Service Grid now uses discovery messages for service deployment
+* Massive performance and stability improvements
+
+
+SQL:
+* Added Decimal precision and scale constraint
+* Added KILL QUERY command
+* Added a table row count statistics for the local queries
+* Added a view with the list of existing SCHEMAS
+* Added a view with the list of existing tables
+* Added ability to specify query parallelism in CREATE TABLE's WITH "" clause
+* Added automatic pages history dump on CorruptedTreeException
+* Added cluster-wide unique identifier for running queries
+* Added counter left partition for index rebuild to cache group metrics
+* Added default query timeout
+* Added drop _VER field support
+* Added extract partition info from BETWEEN and range conditions for integer types
+* Added extract partition info from JOINs
+* Added lazy execution for the local queries
+* Added query history statistics API
+* Added support for data page scan on ScanQuery, SqlQuery and SqlFieldsQuery
+* Added support of allocating memory for a data region when the first cache assigned to this region is created
+* Added support of autoclose iterator for query cursor when all data has been read
+* Added support of trivial IN-operation for partition extraction
+* Added tracking all running queries on initial query node
+* Added validation for PK index does not use wrapped object
+* Added warning about long query execution printed by timeout (instead of on query finished)
+* Disabled implicit distributed joins when queryParallelizm > 1
+* Do not store default precision and scale in the QueryEntity for CHAR/VARCHAR and DECIMAL types
+* Fixed DDL operations don't work on not started caches on non-affinity nodes
+* Fixed IF NOT EXISTS in CREATE TABLE doesn't work
+* Fixed SQL event is not fired when a query is reduced to local form
+* Fixed SQL query when the value has SQL field which name equals to affinity key name
+* Fixed cache destroy operation which has created via SQL
+* Fixed creating table with DateTime for PK on a server node
+* Fixed error parsing INLINE_SIZE if CREATE INDEX is one of the multiple statements
+* Fixed exception after change column type (drop, add)
+* Fixed partition pruning is integrated with DML
+* Fixed security checks are skipped on some SELECT paths
+* Fixed subjectId is lost for SqlFieldsQuery event on the local node
+* Fixed when same SQL requests with multiple statements produce a different result
+* Fixed when unable to find row by an index created on partial baseline topology
+* Forbid mixing _key and key columns in the DML queries
+* Move rebalance configuration properties to the IgniteConfiguration level
+* Optimize query execution if it targets only one or none partitions
+* Reduce excessive int boxing when accessing cache by ID
+* Remove scan index for merge table
+* Renamed IGNITE schema to SYS
+
+
+MVCC:
+* Added continuous query failover for mvcc-caches
+* Added deadlock detector
+* Added late affinity assignment support
+* Added mvcc-compatible cache peek operation for key-value API
+* Fixed JVM crash when node stopped with errors
+* Fixed SQL API methods should throw proper TransactionExceptions in case of tx failure
+* Fixed client operation hangs if all data nodes left the cluster
+* Fixed client reconnect became unstable after mvcc coordinator reassign
+* Fixed concurrent cache stop can cause vacuum failure
+* Fixed failure to perform non-MVCC SQL from transactions
+* Fixed implicit mvcc transaction could use completed one instead of starting new
+* Fixed incorrect data region metrics
+* Fixed incorrect exception is thrown if no data nodes found for a partition
+* Fixed missing EntryProcessor resource injection
+* Fixed mvcc history can be missed during remove operation
+* Fixed mvcc-cache rebalance procedure leads to data loss
+* Fixed query trackers are not released
+* Fixed query with specified explicit partitions
+* Fixed race on invokeAll operations
+* Fixed read transactions remap when coordinator fails
+* Fixed removeAll on unstable topology
+* Fixed transaction asynchronous rollback
+* Fixed update operation hanging on backup on unstable topology
+* Fixed vacuums do not clean up all outdated versions
+
+
+JDBC:
+* Added cache expiry policies
+* Added support JDBC thin driver: connection timeout
+* Added support data page scan for JDBC
+* Added support of handling multiple async requests in parallel
+* Added support query cancel
+* Added support query timeout
+* Fixed JDBC getPrimaryKeys returns wrong value for COLUMN_NAME
+* Fixed JDBC thin driver metadata misses caches with queryEntities and names containing underscores
+* Fixed STREAMING mode fails on streamer reopen on not ordered mode
+* Fixed memory leak caused by executing a JDBC prepared statement
+* Fixed sqline command !tables works incorrectly for a client node
+* Fixed suspended optimistic transaction automatically resumes to last thread after a timeout
+* Now driver starts with a random server to connect
+* Updated handshake protocol so that the node returns its UUID
+
+
+ODBC:
+* Fixed SQLColumns does not work for tables with escape sequences in name
+* Fixed backward compatibility between 2.5 and 2.7
+
+
+Web Agent:
+* Added support for the cluster-ID
+* Added support of two way SSL authentication in Web Console agent
+* Fixed flag --disable-demo doesn't work
+* Fixed hostname verifier must be disabled if "-Dtrust.all=true".
+* Improve information message in case REST command failed on cluster
+* Improve logging when cluster topology changed
+
+
+Web Console:
+* Added TypeScript support
+* Added ability to cancel queries
+* Added ability to configure disk page compression properties
+* Added check for supported MongoDb version before WC start
+* Added email confirmation
+* Added management events (EVT_MANAGEMENT_TASK_STARTED)
+* Added missed configurations for some of the properties from IgniteConfiguration
+* Added option to disable self-registration on Web Console
+* Added possibility to configure distributed MVCC
+* Added support for "date", "time" and "date-and-time" on InputDialog
+* Added support for "type=number" on InputDialog
+* Added support for new countries Taiwan, Hong Kong, Singapore
+* Fixed can't select cluster memory eviction mode
+* Fixed long-running SQL queries could be randomly cancelled from WC
+* Fixed memory leak in chart component
+* Fixed priority for field validations
+* Fixed validation in Firefox
+* Update styles of top menu items
+* Update to RxJS 6
+
+
+Node.js:
+* Fixed Node.js thin client UUID marshalling
+
+
+Ignite .NET:
 
 Review comment:
   Thank you, Pavel.
   I've fixed notes according your suggestions.

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services