You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by dp...@apache.org on 2019/03/15 12:24:42 UTC

[ignite] branch ignite-11464-modules-indexing updated (7bee9a2 -> 341f9e3)

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

dpavlov pushed a change to branch ignite-11464-modules-indexing
in repository https://gitbox.apache.org/repos/asf/ignite.git.


    from 7bee9a2  IGNITE-11464: Automatic modules support for Ignite Indexing module: License failure fixed
     add 7100b05  How To Document reference was added
     add 0f10617  IGNITE-11322 [USABILITY] Extend Node FAILED message by add consistentId if it exist - Fixes #6180.
     add 436d601  IGNITE-11199 Add extra logging for client-server connections in TCP discovery - Fixes #6048.
     add 094bddf  IGNITE-11437 Start grid in remote JVM fails in test framework if TDE is enabled (#6202)
     add 70a4d69  Merge remote-tracking branch 'apache/master'
     add 30a4ac63 IGNITE-11462: Fix mvcc test GridCachePartitionedNearDisabledMvccTxMultiThreadedSelfTest.
     add 6008a0a  IGNITE-9470: MVCC TX: Mvcc transactions should throw proper exception. This closes #6131.
     add 646e5f8  IGNITE-8178 ZookeeperDiscoverySpiTest#testReconnectServersRestart* tests fail on TC (#5755)
     add a8a3073  IGNITE-11430: SQL: Changed timestamp with TZ to simple timestamp for running queries SQL system view. This closes #6206.
     add 285be9a  IGNITE-11446: SQL: Renamed CACHE_GROUPS_IO to LOCAL_CACHE_GROUPS_IO. This closes #6221.
     add 23afdde2 IGNITE-8420. Web console Restored muted tests. Deleted unused tests.
     add b77fd79  IGNITE-8420 Web console: Fixed test.
     add 5268718  IGNITE-11469: Automatic modules Support for Apache Ignite rest-http (#6228)
     add 51740f8  IGNITE-11364 failedNodes collection is cleaned up if received from failed node - Fixes #6215.
     add ff9431f  IGNITE-9927: Fix flaky failures in CacheContinuousQueryOperationFromCallbackTest. This closes #5914.
     add b774826  IGNITE-10250 Fixed IgniteQueue hang caused by an incorrect CQ notification - Fixes #5456.
     add cfa12b1  IGNITE-10674 Remove MARSH_CLASS_NAME=BinaryMarshaller from tests. (#6205)
     add 3068fdc  IGNITE-11500 Web Console: Create template for email. (#6244)
     add 9ce4a82  IGNITE-10561: MVCC: Fix MVCC cache rebalance. This closes #5799.
     add 2d7590d  IGNITE-11152: IgniteTxManager.idMap possible memory leak. This closes #6220.
     add 051cc06  IGNITE-11497 Web console: Tuned "index.html" caching options.
     add 06c70c5  IGNITE-11506 Web console: Tweak CSS to show long user name.
     add 9dd4f75  WC-964 Web Console: Minor tweak of error message.
     add 455b56d  IGNITE-11227: SQL: Decoupled query execution entry point from DML. This closes #6246.
     add 3e80ca4  IGNITE-10414: SQL: Fixed schema resolution for JDBC drivers. This closes #6088.
     add aaa37fc  IGNITE-11227: SQL: Added missing security checks which were incorrectly removed in IGNITE-11227.
     add c2da3d5  IGNITE-11035 Updates in queries page - Fixes #6021.
     add 88d621a  IGNITE-11496 Web Console: Long running SQL queries could be randomly canceled.
     add bb74ce0  IGNITE-10261: MVCC: cache operation may hang during late affinity assignment. This closes #5995.
     add 890d056  IGNITE-11519 Pack configuration tests in test-jar. (#6253)
     add df15ae1  IGNITE-11509 Remove DistributedBaselineConfiguration and replace to methods on IgniteCluster - Fixes #6250.
     add 84c4582  IGNITE-11469: Automatic modules Support for Apache Ignite rest-http: fix of NCDFE (#6256)
     add 3b2dada  IGNITE-5250: SQL: disallow updates of composite key and value columns. This closes #6193.
     add e623f4f  IGNITE-11532 Fix partition loss policy is not handled properly for implicit single key transactions - Fixes #6259.
     add 5ad4b94  IGNITE-11340: SQL: Fixed OOME suite tests. This closes #6231.
     add ec728ac  IGNITE-11377 Display time to baseline auto-adjust event in console.sh - Fixes #6178.
     add 25818be  IGNITE-10768: MVCC: CacheMvccBasicContinuousQueryTest.testUpdateCountersGapClosedSimplePartitioned may hang. This closes #5859.
     add 2aa5341  IGNITE-11079: MVCC: IgniteCacheContinuousQueryBackupQueueTest is flacky. This closes #6249.
     add 9cef98a  IGNITE-11391 Fix test on free list is freezes sometimes - Fixes #6171.
     add 0ad916b  IGNITE-8574 Change Baseline auto-adjust parameters via JMX - Fixes #6181.
     add 1f1807b  IGNITE-11384 Added ability for services hot redeployment via DeploymentSpi - Fixes #6060.
     add 42633b5  IGNITE-10991: JDBC Thin Driver: fixed streaming mode handling for ordered mode. This closes #6146.
     add 54a7983  IGNITE-7139: SQL: Lazy execution support for local queries. This closes #6262.
     add 08f8b4e  IGNITE-11435: SQL: Implemented LOCAL_SQL_QUERY_HISTORY view. This closes #6255.
     add 48712c3  IGNITE-11323 Reduce boilerplate "System.setProperty" code in tests - Fixes #6109.
     add ee172d2  IGNITE-11461 Automatic modules tests with java11 and standalone project (#6214)
     new 341f9e3  Merge branch 'master' into ignite-11464-modules-indexing

The 1 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 .../internal/jdbc2/JdbcAbstractSchemaCaseTest.java |  228 ++++
 .../internal/jdbc2/JdbcMetadataSelfTest.java       |    2 +-
 .../JdbcSchemaCaseSelfTest.java}                   |   28 +-
 .../tcp/redis/RedisProtocolGetAllAsArrayTest.java  |   17 +-
 .../ignite/jdbc/AbstractJdbcPojoQuerySelfTest.java |   12 -
 .../ignite/jdbc/JdbcErrorsAbstractSelfTest.java    |    2 +-
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java      |    8 +-
 .../thin/JdbcThinBulkLoadAbstractSelfTest.java     |    2 +-
 .../thin/JdbcThinDataPageScanPropertySelfTest.java |   33 +-
 .../jdbc/thin/JdbcThinSchemaCaseSelfTest.java}     |   23 +-
 .../ignite/jdbc/thin/JdbcThinSchemaCaseTest.java   |  114 --
 .../thin/JdbcThinStreamingAbstractSelfTest.java    |   22 +-
 .../thin/JdbcThinStreamingResetStreamTest.java     |  142 +++
 .../main/java/org/apache/ignite/IgniteCluster.java |   29 +-
 .../org/apache/ignite/IgniteSystemProperties.java  |    5 +
 .../org/apache/ignite/internal/IgniteKernal.java   |    8 +-
 .../internal/cluster/IgniteClusterAsyncImpl.java   |   37 +-
 .../ignite/internal/cluster/IgniteClusterImpl.java |   75 +-
 .../ignite/internal/commandline/Arguments.java     |   25 +-
 .../internal/commandline/CommandHandler.java       |  407 +++----
 .../baseline/AutoAdjustCommandArg.java}            |   35 +-
 .../commandline/baseline/BaselineArguments.java    |  165 +++
 .../commandline/baseline/BaselineCommand.java      |  103 ++
 .../internal/jdbc/thin/JdbcThinConnection.java     |   31 +-
 .../ignite/internal/jdbc2/JdbcConnection.java      |    2 +-
 .../apache/ignite/internal/jdbc2/JdbcUtils.java    |   22 +
 .../processors/cache/GridCacheAdapter.java         |   10 +
 .../processors/cache/GridCacheContext.java         |   12 +-
 .../processors/cache/GridCacheEntryEx.java         |   11 +
 .../processors/cache/GridCacheMapEntry.java        |  195 +++-
 .../processors/cache/GridCacheMvccEntryInfo.java   |    9 +
 .../processors/cache/GridCacheProcessor.java       |   11 +
 .../cache/IgniteCacheOffheapManager.java           |   55 +-
 .../cache/IgniteCacheOffheapManagerImpl.java       |  262 ++---
 .../processors/cache/IgniteRebalanceIterator.java  |    6 +
 .../cache/distributed/dht/GridDhtGetFuture.java    |   14 +
 .../distributed/dht/GridDhtGetSingleFuture.java    |   14 +
 .../dht/GridDhtTxAbstractEnlistFuture.java         |   29 +-
 .../dht/GridDhtTxQueryFirstEnlistRequest.java      |    1 +
 .../dht/GridPartitionedSingleGetFuture.java        |   12 +-
 .../dht/preloader/GridDhtForceKeysFuture.java      |    2 +
 .../dht/preloader/GridDhtPartitionDemander.java    |  262 ++++-
 .../dht/preloader/GridDhtPartitionSupplier.java    |   85 +-
 .../preloader/GridDhtPartitionsExchangeFuture.java |    7 +-
 .../dht/preloader/GridDhtPreloader.java            |    4 +
 .../dht/preloader/IgniteRebalanceIteratorImpl.java |   31 +
 .../near/GridNearTxAbstractEnlistFuture.java       |   13 +
 .../processors/cache/mvcc/MvccProcessorImpl.java   |   12 +-
 .../internal/processors/cache/mvcc/MvccUtils.java  |   11 +-
 .../processors/cache/mvcc/txlog/TxLog.java         |    7 +-
 .../cache/persistence/CacheDataRowAdapter.java     |   18 +-
 .../cache/persistence/GridCacheOffheapManager.java |   19 +-
 .../cache/persistence/file/FilePageStore.java      |    2 +-
 .../cache/persistence/tree/io/DataPageIO.java      |   42 +-
 .../persistence/wal/FileWriteAheadLogManager.java  |   11 +-
 .../continuous/CacheContinuousQueryHandler.java    |   16 +-
 .../IgniteTxImplicitSingleStateImpl.java           |   10 +-
 .../processors/cache/tree/CacheDataRowStore.java   |    4 +-
 .../processors/cache/tree/CacheDataTree.java       |    2 +-
 .../cache/tree/mvcc/data/MvccDataRow.java          |   18 +-
 .../tree/mvcc/search/MvccSnapshotSearchRow.java    |    2 +-
 .../cluster/BaselineConfigurationMXBeanImpl.java   |   69 ++
 .../processors/cluster/ClusterProcessor.java       |   16 +-
 .../autoadjust/BaselineAutoAdjustData.java         |   45 +-
 .../autoadjust/BaselineAutoAdjustExecutor.java     |    2 +
 .../autoadjust/BaselineAutoAdjustScheduler.java    |   17 +-
 .../autoadjust/BaselineAutoAdjustStatistic.java    |   90 ++
 .../baseline/autoadjust/ChangeTopologyWatcher.java |   25 +-
 .../odbc/jdbc/JdbcBatchExecuteRequest.java         |    2 +-
 .../odbc/jdbc/JdbcBatchExecuteResult.java          |    2 +-
 .../odbc/jdbc/JdbcOrderedBatchExecuteRequest.java  |    2 +-
 .../odbc/jdbc/JdbcOrderedBatchExecuteResult.java   |    2 +-
 .../odbc/jdbc/JdbcQueryExecuteRequest.java         |    2 +-
 .../odbc/jdbc/JdbcQueryExecuteResult.java          |    2 +-
 .../internal/processors/odbc/jdbc/JdbcRequest.java |    6 +
 .../processors/odbc/jdbc/JdbcRequestHandler.java   |   29 +-
 .../internal/processors/odbc/jdbc/JdbcResult.java  |    6 +
 .../processors/odbc/odbc/OdbcRequestHandler.java   |   19 +-
 .../processors/query/GridQueryIndexing.java        |   15 +-
 .../processors/query/GridQueryProcessor.java       |   13 +-
 .../processors/query/QueryHistoryMetrics.java      |   15 +-
 .../processors/query/QueryHistoryMetricsValue.java |   10 +-
 .../processors/query/SqlClientContext.java         |   25 +-
 .../processors/service/IgniteServiceProcessor.java |    8 +-
 .../internal/util/future/GridFutureAdapter.java    |    4 +-
 .../baseline/VisorBaselineAutoAdjustSettings.java  |   30 +-
 .../internal/visor/baseline/VisorBaselineTask.java |   32 +-
 .../visor/baseline/VisorBaselineTaskResult.java    |   39 +-
 .../visor/baseline/VisorBaselineViewTask.java      |   11 +-
 .../internal/visor/query/VisorQueryPingTask.java   |   88 ++
 .../VisorQueryPingTaskResult.java}                 |   50 +-
 .../ignite/mxbean/BaselineConfigurationMXBean.java |   45 +
 .../ignite/spi/discovery/tcp/ServerImpl.java       |   25 +-
 .../encryption/keystore/KeystoreEncryptionSpi.java |    4 +-
 .../ignite/cache/ResetLostPartitionTest.java       |    2 -
 .../affinity/AffinityDistributionLoggingTest.java  |   37 +-
 .../cache/affinity/AffinityHistoryCleanupTest.java |  138 ++-
 .../failure/FailureHandlingConfigurationTest.java  |   54 +-
 .../ConsistentIdImplicitlyExplicitlyTest.java      |   18 +-
 ...dCachePartitionExchangeManagerHistSizeTest.java |   23 +-
 .../ignite/internal/GridVersionSelfTest.java       |   11 +-
 .../ignite/internal/IgniteClientRejoinTest.java    |   14 +-
 .../IgniteDiscoveryMassiveNodeFailTest.java        |   19 +-
 ...iteUpdateNotifierPerClusterSettingSelfTest.java |   20 +-
 .../BinaryConfigurationConsistencySelfTest.java    |   28 +-
 .../BinarySimpleNameTestPropertySelfTest.java      |   19 +-
 .../commandline/CommandHandlerParsingTest.java     |    4 +-
 .../GridCacheMixedPartitionExchangeSelfTest.java   |   10 +-
 .../GridCacheMvccMultiThreadedUpdateSelfTest.java  |   49 +-
 ...OffHeapMultiThreadedUpdateAbstractSelfTest.java |   23 +-
 .../processors/cache/GridCacheTestEntryEx.java     |   16 +
 .../IgniteClientCacheInitializationFailTest.java   |   12 +-
 .../cache/IgniteClientCacheStartFailoverTest.java  |    5 +-
 .../IgniteMvccTxMultiThreadedAbstractTest.java     |    7 -
 .../IgniteMvccTxSingleThreadedAbstractTest.java    |    3 -
 .../cache/IgnitePdsDataRegionMetricsTxTest.java    |    4 -
 .../processors/cache/IgniteTxAbstractTest.java     |    8 +-
 .../cache/IgniteTxExceptionAbstractSelfTest.java   |   32 +-
 .../CacheLateAffinityAssignmentTest.java           |    4 -
 .../GridCachePreloadRestartAbstractSelfTest.java   |    2 +-
 .../IgniteCachePartitionLossPolicySelfTest.java    |   46 +
 ...WriteSynchronizationModesMultithreadedTest.java |   29 +-
 .../IgniteTxConcurrentRemoveObjectsTest.java       |   24 +-
 ...CacheColocatedMvccTxSingleThreadedSelfTest.java |    3 -
 .../dht/GridCacheColocatedTxExceptionSelfTest.java |   58 -
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java     |   14 +-
 ...achePartitionedMvccTxMultiThreadedSelfTest.java |   12 +-
 ...chePartitionedMvccTxSingleThreadedSelfTest.java |    3 -
 .../GridCacheRebalancingSyncSelfTest.java          |   30 +-
 ...acheRebalancingUnmarshallingFailedSelfTest.java |   43 +-
 ...CacheReplicatedMvccTxMultiThreadedSelfTest.java |    4 +-
 .../GridCacheReplicatedTxExceptionSelfTest.java    |   58 -
 .../mvcc/CacheMvccConfigurationValidationTest.java |    6 +
 .../cache/mvcc/CacheMvccTransactionsTest.java      |  178 +--
 ...itePdsCacheStartStopWithFreqCheckpointTest.java |   13 +-
 .../IgnitePdsContinuousRestartTest.java            |    9 -
 .../persistence/IgnitePdsDynamicCacheTest.java     |   13 +-
 .../IgnitePdsPartitionsStateRecoveryTest.java      |    7 +-
 .../IgnitePdsRecoveryAfterFileCorruptionTest.java  |    6 +-
 ...ocalWalModeChangeDuringRebalancingSelfTest.java |   11 +-
 .../ClientAffinityAssignmentWithBaselineTest.java  |   25 +-
 .../db/checkpoint/CheckpointFreeListTest.java      |    7 +-
 ...CheckpointSimulationWithRealCpDisabledTest.java |    2 +-
 ...heContinuousQueryOperationFromCallbackTest.java |  292 ++++-
 .../CacheContinuousQueryOrderingEventTest.java     |   39 +-
 .../continuous/CacheKeepBinaryIterationTest.java   |    6 -
 .../IgniteCacheContinuousQueryBackupQueueTest.java |    7 +-
 .../cache/transactions/TxRollbackAsyncTest.java    |    4 +-
 .../cluster/BaselineConfigurationMXBeanTest.java   |   84 ++
 .../cluster/ChangeTopologyWatcherTest.java         |   20 +-
 .../database/IgniteDbDynamicCacheSelfTest.java     |   13 +-
 ...ServiceHotRedeploymentViaDeploymentSpiTest.java |  161 +++
 .../tcp/TcpDiscoveryNetworkIssuesTest.java         |  215 ++++
 .../apache/ignite/testframework/GridTestUtils.java |   75 +-
 .../ignite/testframework/MvccFeatureChecker.java   |    1 -
 .../testframework/config/GridTestProperties.java   |    3 -
 .../testframework/junits/GridAbstractTest.java     |   74 +-
 .../testframework/junits/IgniteTestResources.java  |    4 +-
 .../junits/SystemPropertiesList.java}              |   25 +-
 .../testframework/junits/WithSystemProperty.java}  |   30 +-
 .../junits/multijvm/IgniteClusterProcessProxy.java |   25 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java    |    2 +
 ...bjectsSimpleNameMapperComputeGridTestSuite.java |    1 -
 ...IgniteBinarySimpleNameMapperBasicTestSuite.java |    1 -
 ...inarySimpleNameMapperCacheFullApiTestSuite.java |    1 -
 .../testsuites/IgniteServiceGridTestSuite.java     |    2 +
 .../IgniteSpiDiscoverySelfTestSuite.java           |    3 +
 .../apache/ignite/util/GridCommandHandlerTest.java |   72 +-
 .../testsuites/IgniteBinaryHibernateTestSuite.java |   37 -
 .../IgniteBinaryHibernate5TestSuite.java           |   37 -
 .../IgniteBinaryHibernate53TestSuite.java          |   37 -
 .../processors/query/h2/CommandProcessor.java      |   26 +-
 .../processors/query/h2/IgniteH2Indexing.java      | 1172 +++++++++++---------
 ...eryParserCacheKey.java => QueryDescriptor.java} |  110 +-
 .../processors/query/h2/QueryParameters.java       |  215 ++++
 .../internal/processors/query/h2/QueryParser.java  |  131 ++-
 .../processors/query/h2/QueryParserResult.java     |   29 +-
 .../processors/query/h2/SchemaManager.java         |    2 +
 .../internal/processors/query/h2/dml/DmlUtils.java |    5 +-
 .../processors/query/h2/dml/UpdatePlan.java        |   10 +-
 .../processors/query/h2/dml/UpdatePlanBuilder.java |   89 +-
 .../h2/sys/view/SqlAbstractLocalSystemView.java    |   22 -
 .../view/SqlSystemViewCacheGroupsIOStatistics.java |    2 +-
 .../sys/view/SqlSystemViewQueryHistoryMetrics.java |   92 ++
 .../h2/sys/view/SqlSystemViewRunningQueries.java   |    4 +-
 .../cache/IgniteCacheInsertSqlQuerySelfTest.java   |   91 +-
 .../cache/IgniteCacheSqlDmlErrorSelfTest.java      |   21 +-
 .../IgniteCacheSqlInsertValidationSelfTest.java    |   19 +-
 .../cache/IgniteCacheUpdateSqlQuerySelfTest.java   |  284 +++--
 .../cache/StartCachesInParallelTest.java           |   43 +-
 ...tributedPartitionQueryNodeRestartsSelfTest.java |   22 +-
 ...cheQueryNodeRestartDistributedJoinSelfTest.java |   27 +-
 .../index/DynamicIndexAbstractBasicSelfTest.java   |   67 +-
 .../cache/index/H2DynamicTableSelfTest.java        |   36 +-
 ...ransactionsCommandsWithMvccEnabledSelfTest.java |    2 +-
 .../mvcc/CacheMvccBasicContinuousQueryTest.java    |   36 +-
 .../mvcc/CacheMvccPartitionedSqlQueriesTest.java   |    2 +-
 .../mvcc/CacheMvccReplicatedSqlQueriesTest.java    |    2 +-
 .../mvcc/CacheMvccSqlQueriesAbstractTest.java      |   99 +-
 .../mvcc/CacheMvccSqlTxQueriesAbstractTest.java    |   68 +-
 .../cache/mvcc/MvccDeadlockDetectionTest.java      |    4 +-
 .../persistence/db/wal/IgniteWalRecoveryTest.java  |  140 ++-
 .../transaction/DmlInsideTransactionTest.java      |   26 +-
 ...tStoreQueryWithMultipleClassesPerCacheTest.java |    8 +-
 .../IgnitePersistentStoreSchemaLoadTest.java       |    6 +-
 .../query/IgniteSqlKeyValueFieldsTest.java         |   14 +-
 .../processors/query/LocalQueryLazyTest.java       |  108 ++
 .../processors/query/RunningQueriesTest.java       |  105 +-
 .../SqlIncompatibleDataTypeExceptionTest.java      |  199 ++++
 .../processors/query/SqlQueryHistorySelfTest.java  |    2 +-
 .../processors/query/SqlSystemViewsSelfTest.java   |  124 ++-
 .../processors/query/h2/QueryDataPageScanTest.java |    5 +-
 .../DisappearedCacheCauseRetryMessageSelfTest.java |    4 +-
 ...DisappearedCacheWasNotFoundMessageSelfTest.java |    4 +-
 .../twostep/NonCollocatedRetryMessageSelfTest.java |   17 +-
 .../h2/twostep/RetryCauseMessageSelfTest.java      |    4 +-
 .../processors/query/oom/AbstractQueryOOMTest.java |   69 +-
 .../IgniteBinaryCacheQueryTestSuite.java           |    3 +
 .../IgniteBinaryCacheQueryTestSuite2.java          |    3 +
 .../cpp/odbc/src/streaming/streaming_context.cpp   |    2 +
 .../ApiParity/ClusterParityTest.cs                 |    4 +-
 modules/rest-http/pom.xml                          |   12 +-
 modules/web-console/DEVNOTES.txt                   |    2 +-
 modules/web-console/backend/app/browsersHandler.js |    1 +
 modules/web-console/backend/app/schemas.js         |    5 +-
 modules/web-console/backend/index.js               |    0
 modules/web-console/backend/package.json           |    3 +-
 modules/web-console/backend/routes/admin.js        |    5 +-
 modules/web-console/backend/services/auth.js       |    6 +-
 modules/web-console/backend/services/mails.js      |  158 ++-
 modules/web-console/backend/services/users.js      |   22 +-
 modules/web-console/backend/templates/base.html    |   21 +
 .../frontend/app/components/breadcrumbs/style.scss |    5 +-
 .../app/components/cluster-selector/controller.js  |   10 +-
 .../app/components/cluster-selector/template.pug   |    4 +-
 .../component.spec.js                              |    8 +-
 .../components/queries-notebook/controller.ts      |  668 ++++++-----
 .../components/queries-notebook/template.tpl.pug   |    8 +-
 .../components/user-menu/style.scss                |   15 +
 .../components/user-menu/template.pug              |    4 +-
 .../page-configure-basic/controller.spec.js        |  206 ----
 .../page-configure-basic/reducer.spec.js           |   19 +-
 .../components/page-configure-basic/reducer.ts     |   22 +-
 .../generator/generator/JavaTransformer.spec.js    |   55 -
 .../generator/generator/SharpTransformer.spec.js   |   53 -
 .../generator/generator/SpringTransformer.spec.js  |   54 -
 .../services/ConfigurationDownload.spec.js         |   22 +-
 .../configuration/services/PageConfigure.spec.js   |  240 ----
 .../app/configuration/store/reducer.spec.js        |   31 +-
 .../app/modules/agent/AgentManager.service.js      |  125 +--
 .../frontend/app/services/Version.service.js       |  104 +-
 .../frontend/app/services/Version.spec.js          |   18 +-
 .../frontend/public/stylesheets/style.scss         |    2 +-
 modules/web-console/frontend/views/index.pug       |    2 +
 modules/web-console/pom.xml                        |   12 +-
 .../zk/internal/ZookeeperDiscoveryImpl.java        |    6 +-
 .../tcp/ipfinder/zk/ZookeeperIpFinderTest.java     |    5 +-
 .../zk/ZookeeperDiscoverySpiTestSuite1.java        |   14 +-
 .../ZookeeperDiscoveryClientReconnectTest.java     |   15 +-
 ...erDiscoveryConcurrentStartAndStartStopTest.java |   13 +-
 ...coverySegmentationAndConnectionRestoreTest.java |  108 +-
 .../ZookeeperDiscoverySpiSaslFailedAuthTest.java   |   13 +-
 ...ookeeperDiscoverySpiSaslSuccessfulAuthTest.java |    8 +-
 .../zk/internal/ZookeeperDiscoverySpiTestBase.java |    4 +-
 264 files changed, 7050 insertions(+), 4617 deletions(-)
 create mode 100644 modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcAbstractSchemaCaseTest.java
 copy modules/clients/src/test/java/org/apache/ignite/internal/{processors/rest/protocols/tcp/redis/RedisProtocolGetAllAsArrayTest.java => jdbc2/JdbcSchemaCaseSelfTest.java} (54%)
 copy modules/{web-console/frontend/app/components/web-console-header/components/user-menu/style.scss => clients/src/test/java/org/apache/ignite/jdbc/thin/JdbcThinSchemaCaseSelfTest.java} (60%)
 delete mode 100644 modules/clients/src/test/java/org/apache/ignite/jdbc/thin/JdbcThinSchemaCaseTest.java
 create mode 100644 modules/clients/src/test/java/org/apache/ignite/jdbc/thin/JdbcThinStreamingResetStreamTest.java
 copy modules/{clients/src/test/java/org/apache/ignite/internal/processors/rest/protocols/tcp/redis/RedisProtocolGetAllAsArrayTest.java => core/src/main/java/org/apache/ignite/internal/commandline/baseline/AutoAdjustCommandArg.java} (56%)
 create mode 100644 modules/core/src/main/java/org/apache/ignite/internal/commandline/baseline/BaselineArguments.java
 create mode 100644 modules/core/src/main/java/org/apache/ignite/internal/commandline/baseline/BaselineCommand.java
 create mode 100644 modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/BaselineConfigurationMXBeanImpl.java
 create mode 100644 modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/baseline/autoadjust/BaselineAutoAdjustStatistic.java
 create mode 100644 modules/core/src/main/java/org/apache/ignite/internal/visor/query/VisorQueryPingTask.java
 copy modules/core/src/main/java/org/apache/ignite/internal/visor/{baseline/VisorBaselineAutoAdjustSettings.java => query/VisorQueryPingTaskResult.java} (53%)
 create mode 100644 modules/core/src/main/java/org/apache/ignite/mxbean/BaselineConfigurationMXBean.java
 create mode 100644 modules/core/src/test/java/org/apache/ignite/internal/processors/cluster/BaselineConfigurationMXBeanTest.java
 create mode 100644 modules/core/src/test/java/org/apache/ignite/internal/processors/service/ServiceHotRedeploymentViaDeploymentSpiTest.java
 create mode 100644 modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryNetworkIssuesTest.java
 copy modules/{web-console/frontend/app/components/web-console-header/components/user-menu/style.scss => core/src/test/java/org/apache/ignite/testframework/junits/SystemPropertiesList.java} (67%)
 copy modules/{web-console/frontend/app/components/web-console-header/components/user-menu/style.scss => core/src/test/java/org/apache/ignite/testframework/junits/WithSystemProperty.java} (62%)
 delete mode 100644 modules/hibernate-4.2/src/test/java/org/apache/ignite/testsuites/IgniteBinaryHibernateTestSuite.java
 delete mode 100644 modules/hibernate-5.1/src/test/java/org/apache/ignite/testsuites/IgniteBinaryHibernate5TestSuite.java
 delete mode 100644 modules/hibernate-5.3/src/test/java/org/apache/ignite/testsuites/IgniteBinaryHibernate53TestSuite.java
 rename modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/{QueryParserCacheKey.java => QueryDescriptor.java} (52%)
 create mode 100644 modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/QueryParameters.java
 create mode 100644 modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/sys/view/SqlSystemViewQueryHistoryMetrics.java
 create mode 100644 modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/LocalQueryLazyTest.java
 create mode 100644 modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/SqlIncompatibleDataTypeExceptionTest.java
 mode change 100644 => 100755 modules/web-console/backend/index.js
 create mode 100644 modules/web-console/backend/templates/base.html
 delete mode 100644 modules/web-console/frontend/app/configuration/components/page-configure-basic/controller.spec.js
 delete mode 100644 modules/web-console/frontend/app/configuration/generator/generator/JavaTransformer.spec.js
 delete mode 100644 modules/web-console/frontend/app/configuration/generator/generator/SharpTransformer.spec.js
 delete mode 100644 modules/web-console/frontend/app/configuration/generator/generator/SpringTransformer.spec.js
 delete mode 100644 modules/web-console/frontend/app/configuration/services/PageConfigure.spec.js


[ignite] 01/01: Merge branch 'master' into ignite-11464-modules-indexing

Posted by dp...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

dpavlov pushed a commit to branch ignite-11464-modules-indexing
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 341f9e3bc54213644c08d9cf10b8f84ea2d4d6e4
Merge: 7bee9a2 ee172d2
Author: Dmitriy Pavlov <dp...@apache.org>
AuthorDate: Fri Mar 15 15:22:37 2019 +0300

    Merge branch 'master' into ignite-11464-modules-indexing
    
    # Conflicts:
    #	modules/dev-utils/ignite-modules-test/src/test/java/module-info.java
    #	modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/IgniteH2Indexing.java

 .../internal/jdbc2/JdbcAbstractSchemaCaseTest.java |  228 ++++
 .../internal/jdbc2/JdbcMetadataSelfTest.java       |    2 +-
 .../JdbcSchemaCaseSelfTest.java}                   |   28 +-
 .../tcp/redis/RedisProtocolGetAllAsArrayTest.java  |   17 +-
 .../ignite/jdbc/AbstractJdbcPojoQuerySelfTest.java |   12 -
 .../ignite/jdbc/JdbcErrorsAbstractSelfTest.java    |    2 +-
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java      |    8 +-
 .../thin/JdbcThinBulkLoadAbstractSelfTest.java     |    2 +-
 .../thin/JdbcThinDataPageScanPropertySelfTest.java |   33 +-
 .../jdbc/thin/JdbcThinSchemaCaseSelfTest.java}     |   23 +-
 .../ignite/jdbc/thin/JdbcThinSchemaCaseTest.java   |  114 --
 .../thin/JdbcThinStreamingAbstractSelfTest.java    |   22 +-
 .../thin/JdbcThinStreamingResetStreamTest.java     |  142 +++
 .../main/java/org/apache/ignite/IgniteCluster.java |   29 +-
 .../org/apache/ignite/IgniteSystemProperties.java  |    5 +
 .../org/apache/ignite/internal/IgniteKernal.java   |    8 +-
 .../internal/cluster/IgniteClusterAsyncImpl.java   |   37 +-
 .../ignite/internal/cluster/IgniteClusterImpl.java |   75 +-
 .../ignite/internal/commandline/Arguments.java     |   25 +-
 .../internal/commandline/CommandHandler.java       |  407 +++----
 .../baseline/AutoAdjustCommandArg.java}            |   35 +-
 .../commandline/baseline/BaselineArguments.java    |  165 +++
 .../commandline/baseline/BaselineCommand.java      |  103 ++
 .../internal/jdbc/thin/JdbcThinConnection.java     |   31 +-
 .../ignite/internal/jdbc2/JdbcConnection.java      |    2 +-
 .../apache/ignite/internal/jdbc2/JdbcUtils.java    |   22 +
 .../processors/cache/GridCacheAdapter.java         |   10 +
 .../processors/cache/GridCacheContext.java         |   12 +-
 .../processors/cache/GridCacheEntryEx.java         |   11 +
 .../processors/cache/GridCacheMapEntry.java        |  195 +++-
 .../processors/cache/GridCacheMvccEntryInfo.java   |    9 +
 .../processors/cache/GridCacheProcessor.java       |   11 +
 .../cache/IgniteCacheOffheapManager.java           |   55 +-
 .../cache/IgniteCacheOffheapManagerImpl.java       |  262 ++---
 .../processors/cache/IgniteRebalanceIterator.java  |    6 +
 .../cache/distributed/dht/GridDhtGetFuture.java    |   14 +
 .../distributed/dht/GridDhtGetSingleFuture.java    |   14 +
 .../dht/GridDhtTxAbstractEnlistFuture.java         |   29 +-
 .../dht/GridDhtTxQueryFirstEnlistRequest.java      |    1 +
 .../dht/GridPartitionedSingleGetFuture.java        |   12 +-
 .../dht/preloader/GridDhtForceKeysFuture.java      |    2 +
 .../dht/preloader/GridDhtPartitionDemander.java    |  262 ++++-
 .../dht/preloader/GridDhtPartitionSupplier.java    |   85 +-
 .../preloader/GridDhtPartitionsExchangeFuture.java |    7 +-
 .../dht/preloader/GridDhtPreloader.java            |    4 +
 .../dht/preloader/IgniteRebalanceIteratorImpl.java |   31 +
 .../near/GridNearTxAbstractEnlistFuture.java       |   13 +
 .../processors/cache/mvcc/MvccProcessorImpl.java   |   12 +-
 .../internal/processors/cache/mvcc/MvccUtils.java  |   11 +-
 .../processors/cache/mvcc/txlog/TxLog.java         |    7 +-
 .../cache/persistence/CacheDataRowAdapter.java     |   18 +-
 .../cache/persistence/GridCacheOffheapManager.java |   19 +-
 .../cache/persistence/file/FilePageStore.java      |    2 +-
 .../cache/persistence/tree/io/DataPageIO.java      |   42 +-
 .../persistence/wal/FileWriteAheadLogManager.java  |   11 +-
 .../continuous/CacheContinuousQueryHandler.java    |   16 +-
 .../IgniteTxImplicitSingleStateImpl.java           |   10 +-
 .../processors/cache/tree/CacheDataRowStore.java   |    4 +-
 .../processors/cache/tree/CacheDataTree.java       |    2 +-
 .../cache/tree/mvcc/data/MvccDataRow.java          |   18 +-
 .../tree/mvcc/search/MvccSnapshotSearchRow.java    |    2 +-
 .../cluster/BaselineConfigurationMXBeanImpl.java   |   69 ++
 .../processors/cluster/ClusterProcessor.java       |   16 +-
 .../autoadjust/BaselineAutoAdjustData.java         |   45 +-
 .../autoadjust/BaselineAutoAdjustExecutor.java     |    2 +
 .../autoadjust/BaselineAutoAdjustScheduler.java    |   17 +-
 .../autoadjust/BaselineAutoAdjustStatistic.java    |   90 ++
 .../baseline/autoadjust/ChangeTopologyWatcher.java |   25 +-
 .../odbc/jdbc/JdbcBatchExecuteRequest.java         |    2 +-
 .../odbc/jdbc/JdbcBatchExecuteResult.java          |    2 +-
 .../odbc/jdbc/JdbcOrderedBatchExecuteRequest.java  |    2 +-
 .../odbc/jdbc/JdbcOrderedBatchExecuteResult.java   |    2 +-
 .../odbc/jdbc/JdbcQueryExecuteRequest.java         |    2 +-
 .../odbc/jdbc/JdbcQueryExecuteResult.java          |    2 +-
 .../internal/processors/odbc/jdbc/JdbcRequest.java |    6 +
 .../processors/odbc/jdbc/JdbcRequestHandler.java   |   29 +-
 .../internal/processors/odbc/jdbc/JdbcResult.java  |    6 +
 .../processors/odbc/odbc/OdbcRequestHandler.java   |   19 +-
 .../processors/query/GridQueryIndexing.java        |   15 +-
 .../processors/query/GridQueryProcessor.java       |   13 +-
 .../processors/query/QueryHistoryMetrics.java      |   15 +-
 .../processors/query/QueryHistoryMetricsValue.java |   10 +-
 .../processors/query/SqlClientContext.java         |   25 +-
 .../processors/service/IgniteServiceProcessor.java |    8 +-
 .../internal/util/future/GridFutureAdapter.java    |    4 +-
 .../baseline/VisorBaselineAutoAdjustSettings.java  |   30 +-
 .../internal/visor/baseline/VisorBaselineTask.java |   32 +-
 .../visor/baseline/VisorBaselineTaskResult.java    |   39 +-
 .../visor/baseline/VisorBaselineViewTask.java      |   11 +-
 .../internal/visor/query/VisorQueryPingTask.java   |   88 ++
 .../VisorQueryPingTaskResult.java}                 |   50 +-
 .../ignite/mxbean/BaselineConfigurationMXBean.java |   45 +
 .../ignite/spi/discovery/tcp/ServerImpl.java       |   25 +-
 .../encryption/keystore/KeystoreEncryptionSpi.java |    4 +-
 .../ignite/cache/ResetLostPartitionTest.java       |    2 -
 .../affinity/AffinityDistributionLoggingTest.java  |   37 +-
 .../cache/affinity/AffinityHistoryCleanupTest.java |  138 ++-
 .../failure/FailureHandlingConfigurationTest.java  |   54 +-
 .../ConsistentIdImplicitlyExplicitlyTest.java      |   18 +-
 ...dCachePartitionExchangeManagerHistSizeTest.java |   23 +-
 .../ignite/internal/GridVersionSelfTest.java       |   11 +-
 .../ignite/internal/IgniteClientRejoinTest.java    |   14 +-
 .../IgniteDiscoveryMassiveNodeFailTest.java        |   19 +-
 ...iteUpdateNotifierPerClusterSettingSelfTest.java |   20 +-
 .../BinaryConfigurationConsistencySelfTest.java    |   28 +-
 .../BinarySimpleNameTestPropertySelfTest.java      |   19 +-
 .../commandline/CommandHandlerParsingTest.java     |    4 +-
 .../GridCacheMixedPartitionExchangeSelfTest.java   |   10 +-
 .../GridCacheMvccMultiThreadedUpdateSelfTest.java  |   49 +-
 ...OffHeapMultiThreadedUpdateAbstractSelfTest.java |   23 +-
 .../processors/cache/GridCacheTestEntryEx.java     |   16 +
 .../IgniteClientCacheInitializationFailTest.java   |   12 +-
 .../cache/IgniteClientCacheStartFailoverTest.java  |    5 +-
 .../IgniteMvccTxMultiThreadedAbstractTest.java     |    7 -
 .../IgniteMvccTxSingleThreadedAbstractTest.java    |    3 -
 .../cache/IgnitePdsDataRegionMetricsTxTest.java    |    4 -
 .../processors/cache/IgniteTxAbstractTest.java     |    8 +-
 .../cache/IgniteTxExceptionAbstractSelfTest.java   |   32 +-
 .../CacheLateAffinityAssignmentTest.java           |    4 -
 .../GridCachePreloadRestartAbstractSelfTest.java   |    2 +-
 .../IgniteCachePartitionLossPolicySelfTest.java    |   46 +
 ...WriteSynchronizationModesMultithreadedTest.java |   29 +-
 .../IgniteTxConcurrentRemoveObjectsTest.java       |   24 +-
 ...CacheColocatedMvccTxSingleThreadedSelfTest.java |    3 -
 .../dht/GridCacheColocatedTxExceptionSelfTest.java |   58 -
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java     |   14 +-
 ...achePartitionedMvccTxMultiThreadedSelfTest.java |   12 +-
 ...chePartitionedMvccTxSingleThreadedSelfTest.java |    3 -
 .../GridCacheRebalancingSyncSelfTest.java          |   30 +-
 ...acheRebalancingUnmarshallingFailedSelfTest.java |   43 +-
 ...CacheReplicatedMvccTxMultiThreadedSelfTest.java |    4 +-
 .../GridCacheReplicatedTxExceptionSelfTest.java    |   58 -
 .../mvcc/CacheMvccConfigurationValidationTest.java |    6 +
 .../cache/mvcc/CacheMvccTransactionsTest.java      |  178 +--
 ...itePdsCacheStartStopWithFreqCheckpointTest.java |   13 +-
 .../IgnitePdsContinuousRestartTest.java            |    9 -
 .../persistence/IgnitePdsDynamicCacheTest.java     |   13 +-
 .../IgnitePdsPartitionsStateRecoveryTest.java      |    7 +-
 .../IgnitePdsRecoveryAfterFileCorruptionTest.java  |    6 +-
 ...ocalWalModeChangeDuringRebalancingSelfTest.java |   11 +-
 .../ClientAffinityAssignmentWithBaselineTest.java  |   25 +-
 .../db/checkpoint/CheckpointFreeListTest.java      |    7 +-
 ...CheckpointSimulationWithRealCpDisabledTest.java |    2 +-
 ...heContinuousQueryOperationFromCallbackTest.java |  292 ++++-
 .../CacheContinuousQueryOrderingEventTest.java     |   39 +-
 .../continuous/CacheKeepBinaryIterationTest.java   |    6 -
 .../IgniteCacheContinuousQueryBackupQueueTest.java |    7 +-
 .../cache/transactions/TxRollbackAsyncTest.java    |    4 +-
 .../cluster/BaselineConfigurationMXBeanTest.java   |   84 ++
 .../cluster/ChangeTopologyWatcherTest.java         |   20 +-
 .../database/IgniteDbDynamicCacheSelfTest.java     |   13 +-
 ...ServiceHotRedeploymentViaDeploymentSpiTest.java |  161 +++
 .../tcp/TcpDiscoveryNetworkIssuesTest.java         |  215 ++++
 .../apache/ignite/testframework/GridTestUtils.java |   75 +-
 .../ignite/testframework/MvccFeatureChecker.java   |    1 -
 .../testframework/config/GridTestProperties.java   |    3 -
 .../testframework/junits/GridAbstractTest.java     |   74 +-
 .../testframework/junits/IgniteTestResources.java  |    4 +-
 .../junits/SystemPropertiesList.java}              |   25 +-
 .../testframework/junits/WithSystemProperty.java}  |   30 +-
 .../junits/multijvm/IgniteClusterProcessProxy.java |   25 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java    |    2 +
 ...bjectsSimpleNameMapperComputeGridTestSuite.java |    1 -
 ...IgniteBinarySimpleNameMapperBasicTestSuite.java |    1 -
 ...inarySimpleNameMapperCacheFullApiTestSuite.java |    1 -
 .../testsuites/IgniteServiceGridTestSuite.java     |    2 +
 .../IgniteSpiDiscoverySelfTestSuite.java           |    3 +
 .../apache/ignite/util/GridCommandHandlerTest.java |   72 +-
 .../testsuites/IgniteBinaryHibernateTestSuite.java |   37 -
 .../IgniteBinaryHibernate5TestSuite.java           |   37 -
 .../IgniteBinaryHibernate53TestSuite.java          |   37 -
 .../processors/query/h2/CommandProcessor.java      |   26 +-
 .../processors/query/h2/IgniteH2Indexing.java      | 1172 +++++++++++---------
 ...eryParserCacheKey.java => QueryDescriptor.java} |  110 +-
 .../processors/query/h2/QueryParameters.java       |  215 ++++
 .../internal/processors/query/h2/QueryParser.java  |  131 ++-
 .../processors/query/h2/QueryParserResult.java     |   29 +-
 .../processors/query/h2/SchemaManager.java         |    2 +
 .../internal/processors/query/h2/dml/DmlUtils.java |    5 +-
 .../processors/query/h2/dml/UpdatePlan.java        |   10 +-
 .../processors/query/h2/dml/UpdatePlanBuilder.java |   89 +-
 .../h2/sys/view/SqlAbstractLocalSystemView.java    |   22 -
 .../view/SqlSystemViewCacheGroupsIOStatistics.java |    2 +-
 .../sys/view/SqlSystemViewQueryHistoryMetrics.java |   92 ++
 .../h2/sys/view/SqlSystemViewRunningQueries.java   |    4 +-
 .../cache/IgniteCacheInsertSqlQuerySelfTest.java   |   91 +-
 .../cache/IgniteCacheSqlDmlErrorSelfTest.java      |   21 +-
 .../IgniteCacheSqlInsertValidationSelfTest.java    |   19 +-
 .../cache/IgniteCacheUpdateSqlQuerySelfTest.java   |  284 +++--
 .../cache/StartCachesInParallelTest.java           |   43 +-
 ...tributedPartitionQueryNodeRestartsSelfTest.java |   22 +-
 ...cheQueryNodeRestartDistributedJoinSelfTest.java |   27 +-
 .../index/DynamicIndexAbstractBasicSelfTest.java   |   67 +-
 .../cache/index/H2DynamicTableSelfTest.java        |   36 +-
 ...ransactionsCommandsWithMvccEnabledSelfTest.java |    2 +-
 .../mvcc/CacheMvccBasicContinuousQueryTest.java    |   36 +-
 .../mvcc/CacheMvccPartitionedSqlQueriesTest.java   |    2 +-
 .../mvcc/CacheMvccReplicatedSqlQueriesTest.java    |    2 +-
 .../mvcc/CacheMvccSqlQueriesAbstractTest.java      |   99 +-
 .../mvcc/CacheMvccSqlTxQueriesAbstractTest.java    |   68 +-
 .../cache/mvcc/MvccDeadlockDetectionTest.java      |    4 +-
 .../persistence/db/wal/IgniteWalRecoveryTest.java  |  140 ++-
 .../transaction/DmlInsideTransactionTest.java      |   26 +-
 ...tStoreQueryWithMultipleClassesPerCacheTest.java |    8 +-
 .../IgnitePersistentStoreSchemaLoadTest.java       |    6 +-
 .../query/IgniteSqlKeyValueFieldsTest.java         |   14 +-
 .../processors/query/LocalQueryLazyTest.java       |  108 ++
 .../processors/query/RunningQueriesTest.java       |  105 +-
 .../SqlIncompatibleDataTypeExceptionTest.java      |  199 ++++
 .../processors/query/SqlQueryHistorySelfTest.java  |    2 +-
 .../processors/query/SqlSystemViewsSelfTest.java   |  124 ++-
 .../processors/query/h2/QueryDataPageScanTest.java |    5 +-
 .../DisappearedCacheCauseRetryMessageSelfTest.java |    4 +-
 ...DisappearedCacheWasNotFoundMessageSelfTest.java |    4 +-
 .../twostep/NonCollocatedRetryMessageSelfTest.java |   17 +-
 .../h2/twostep/RetryCauseMessageSelfTest.java      |    4 +-
 .../processors/query/oom/AbstractQueryOOMTest.java |   69 +-
 .../IgniteBinaryCacheQueryTestSuite.java           |    3 +
 .../IgniteBinaryCacheQueryTestSuite2.java          |    3 +
 .../cpp/odbc/src/streaming/streaming_context.cpp   |    2 +
 .../ApiParity/ClusterParityTest.cs                 |    4 +-
 modules/rest-http/pom.xml                          |   12 +-
 modules/web-console/DEVNOTES.txt                   |    2 +-
 modules/web-console/backend/app/browsersHandler.js |    1 +
 modules/web-console/backend/app/schemas.js         |    5 +-
 modules/web-console/backend/index.js               |    0
 modules/web-console/backend/package.json           |    3 +-
 modules/web-console/backend/routes/admin.js        |    5 +-
 modules/web-console/backend/services/auth.js       |    6 +-
 modules/web-console/backend/services/mails.js      |  158 ++-
 modules/web-console/backend/services/users.js      |   22 +-
 modules/web-console/backend/templates/base.html    |   21 +
 .../frontend/app/components/breadcrumbs/style.scss |    5 +-
 .../app/components/cluster-selector/controller.js  |   10 +-
 .../app/components/cluster-selector/template.pug   |    4 +-
 .../component.spec.js                              |    8 +-
 .../components/queries-notebook/controller.ts      |  668 ++++++-----
 .../components/queries-notebook/template.tpl.pug   |    8 +-
 .../components/user-menu/style.scss                |   15 +
 .../components/user-menu/template.pug              |    4 +-
 .../page-configure-basic/controller.spec.js        |  206 ----
 .../page-configure-basic/reducer.spec.js           |   19 +-
 .../components/page-configure-basic/reducer.ts     |   22 +-
 .../generator/generator/JavaTransformer.spec.js    |   55 -
 .../generator/generator/SharpTransformer.spec.js   |   53 -
 .../generator/generator/SpringTransformer.spec.js  |   54 -
 .../services/ConfigurationDownload.spec.js         |   22 +-
 .../configuration/services/PageConfigure.spec.js   |  240 ----
 .../app/configuration/store/reducer.spec.js        |   31 +-
 .../app/modules/agent/AgentManager.service.js      |  125 +--
 .../frontend/app/services/Version.service.js       |  104 +-
 .../frontend/app/services/Version.spec.js          |   18 +-
 .../frontend/public/stylesheets/style.scss         |    2 +-
 modules/web-console/frontend/views/index.pug       |    2 +
 modules/web-console/pom.xml                        |   12 +-
 .../zk/internal/ZookeeperDiscoveryImpl.java        |    6 +-
 .../tcp/ipfinder/zk/ZookeeperIpFinderTest.java     |    5 +-
 .../zk/ZookeeperDiscoverySpiTestSuite1.java        |   14 +-
 .../ZookeeperDiscoveryClientReconnectTest.java     |   15 +-
 ...erDiscoveryConcurrentStartAndStartStopTest.java |   13 +-
 ...coverySegmentationAndConnectionRestoreTest.java |  108 +-
 .../ZookeeperDiscoverySpiSaslFailedAuthTest.java   |   13 +-
 ...ookeeperDiscoverySpiSaslSuccessfulAuthTest.java |    8 +-
 .../zk/internal/ZookeeperDiscoverySpiTestBase.java |    4 +-
 264 files changed, 7050 insertions(+), 4617 deletions(-)

diff --cc modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/IgniteH2Indexing.java
index 3e1d776,467dd15..8164787
--- a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/IgniteH2Indexing.java
+++ b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/IgniteH2Indexing.java
@@@ -68,10 -68,9 +68,9 @@@ import org.apache.ignite.internal.proce
  import org.apache.ignite.internal.processors.cache.persistence.tree.io.PageIO;
  import org.apache.ignite.internal.processors.cache.query.GridCacheQueryMarshallable;
  import org.apache.ignite.internal.processors.cache.query.GridCacheQueryType;
 -import org.apache.ignite.internal.processors.cache.query.GridCacheTwoStepQuery;
 +import org.apache.ignite.internal.processors.cache.query.indexing.GridCacheTwoStepQuery;
  import org.apache.ignite.internal.processors.cache.query.IgniteQueryErrorCode;
 -import org.apache.ignite.internal.processors.cache.query.RegisteredQueryCursor;
 +import org.apache.ignite.internal.processors.cache.query.indexing.RegisteredQueryCursor;
- import org.apache.ignite.internal.processors.cache.query.SqlFieldsQueryEx;
  import org.apache.ignite.internal.processors.cache.transactions.IgniteTxAdapter;
  import org.apache.ignite.internal.processors.cache.tree.CacheDataTree;
  import org.apache.ignite.internal.processors.odbc.SqlStateCode;
diff --cc modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/dml/UpdatePlanBuilder.java
index b95a49b,033a892..ffb3012
--- a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/dml/UpdatePlanBuilder.java
+++ b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/dml/UpdatePlanBuilder.java
@@@ -28,13 -28,12 +28,12 @@@ import java.util.HashSet
  import java.util.List;
  import java.util.Set;
  import org.apache.ignite.IgniteCheckedException;
+ import org.apache.ignite.IgniteSystemProperties;
  import org.apache.ignite.binary.BinaryObject;
  import org.apache.ignite.binary.BinaryObjectBuilder;
- import org.apache.ignite.cache.query.SqlFieldsQuery;
  import org.apache.ignite.internal.processors.cache.GridCacheContext;
 -import org.apache.ignite.internal.processors.cache.query.GridCacheTwoStepQuery;
 +import org.apache.ignite.internal.processors.cache.query.indexing.GridCacheTwoStepQuery;
  import org.apache.ignite.internal.processors.cache.query.IgniteQueryErrorCode;
- import org.apache.ignite.internal.processors.cache.query.SqlFieldsQueryEx;
  import org.apache.ignite.internal.processors.query.GridQueryProperty;
  import org.apache.ignite.internal.processors.query.GridQueryTypeDescriptor;
  import org.apache.ignite.internal.processors.query.IgniteSQLException;