You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by ag...@apache.org on 2017/03/14 14:43:13 UTC

[6/7] ignite git commit: Merge master into ignite-3477

Merge master into ignite-3477


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/91210eb2
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/91210eb2
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/91210eb2

Branch: refs/heads/ignite-3477-master
Commit: 91210eb21d25f90f8b3bcb68403c2bf5362f65bc
Parents: 02a0e34 0b996e6
Author: Alexey Goncharuk <al...@gmail.com>
Authored: Tue Mar 14 17:41:41 2017 +0300
Committer: Alexey Goncharuk <al...@gmail.com>
Committed: Tue Mar 14 17:41:41 2017 +0300

----------------------------------------------------------------------
 DEVNOTES.txt                                    |    5 +-
 NOTICE                                          |    2 +-
 RELEASE_NOTES.txt                               |   20 +
 assembly/LICENSE_FABRIC                         |   35 +-
 assembly/LICENSE_HADOOP                         |   17 +-
 assembly/NOTICE_FABRIC                          |    2 +-
 assembly/NOTICE_HADOOP                          |    2 +-
 assembly/dependencies-fabric-lgpl.xml           |    1 +
 assembly/dependencies-fabric.xml                |    1 +
 assembly/dependencies-hadoop.xml                |    3 +
 assembly/release-base.xml                       |    5 -
 assembly/release-fabric-base.xml                |    5 +
 assembly/release-sources.xml                    |    3 +-
 config/example-kube.xml                         |   53 +
 doap_Ignite.rdf                                 |    1 -
 examples/config/spark/example-shared-rdd.xml    |   83 +
 examples/pom-standalone-lgpl.xml                |   12 +
 examples/pom-standalone.xml                     |   12 +
 examples/pom.xml                                |   41 +-
 examples/schema-import/bin/h2-server.bat        |    2 +-
 examples/schema-import/bin/h2-server.sh         |    4 +-
 .../schema-import/bin/schema-import.properties  |    2 +-
 .../examples/spark/ScalarSharedRDDExample.scala |   89 +
 .../ignite/examples/spark/SharedRDDExample.java |  127 ++
 .../ignite/examples/spark/package-info.java     |   22 +
 .../IgniteExamplesJ8SelfTestSuite.java          |    1 +
 .../tests/examples/ScalarExamplesSelfTest.scala |    6 +
 .../examples/SharedRDDExampleSelfTest.java      |   36 +
 .../IgniteExamplesSparkSelfTestSuite.java       |   46 +
 .../src/main/resources/META-INF/licenses.txt.vm |    7 +-
 .../tcp/ipfinder/s3/TcpDiscoveryS3IpFinder.java |   37 +-
 .../TcpDiscoveryS3IpFinderAbstractSelfTest.java |   84 +
 ...3IpFinderAwsCredentialsProviderSelfTest.java |   46 +
 ...scoveryS3IpFinderAwsCredentialsSelfTest.java |   45 +
 .../s3/TcpDiscoveryS3IpFinderSelfTest.java      |   79 -
 .../ignite/testsuites/IgniteS3TestSuite.java    |   26 +-
 .../stream/camel/IgniteCamelStreamerTest.java   |    4 +-
 .../cassandra/persistence/PojoKeyField.java     |    2 +-
 modules/clients/src/test/config/jdbc-config.xml |    2 +-
 .../ClientAbstractMultiNodeSelfTest.java        |    8 +-
 .../jdbc2/JdbcAbstractDmlStatementSelfTest.java |   49 +-
 ...BinaryMarshallerInsertStatementSelfTest.java |    2 -
 ...cBinaryMarshallerMergeStatementSelfTest.java |    2 -
 .../jdbc2/JdbcInsertStatementSelfTest.java      |   51 +
 .../jdbc2/JdbcMergeStatementSelfTest.java       |   51 +
 .../internal/jdbc2/JdbcMetadataSelfTest.java    |    2 +-
 .../internal/jdbc2/JdbcStreamingSelfTest.java   |  187 ++
 .../jdbc2/JdbcUpdateStatementSelfTest.java      |   50 +
 .../tcp/redis/RedisProtocolSelfTest.java        |   13 +-
 .../ignite/jdbc/JdbcMetadataSelfTest.java       |    4 +-
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java   |    4 +-
 .../ignite/codegen/MessageCodeGenerator.java    |    2 +-
 modules/core/src/main/java/META-INF/NOTICE      |    2 +-
 .../src/main/java/org/apache/ignite/Ignite.java |    1 +
 .../java/org/apache/ignite/IgniteCompute.java   |   44 +-
 .../org/apache/ignite/IgniteJdbcDriver.java     |   30 +
 .../java/org/apache/ignite/IgniteMessaging.java |   11 +-
 .../apache/ignite/IgniteSystemProperties.java   |   52 +
 .../org/apache/ignite/cache/QueryEntity.java    |   22 +-
 .../cache/eviction/AbstractEvictionPolicy.java  |  203 +++
 .../ignite/cache/eviction/EvictionPolicy.java   |    2 -
 .../cache/eviction/fifo/FifoEvictionPolicy.java |  158 +-
 .../cache/eviction/lru/LruEvictionPolicy.java   |  159 +-
 .../eviction/random/RandomEvictionPolicy.java   |  124 --
 .../random/RandomEvictionPolicyMBean.java       |   42 -
 .../eviction/sorted/SortedEvictionPolicy.java   |  159 +-
 .../org/apache/ignite/cache/query/SqlQuery.java |   25 +
 .../store/jdbc/CacheAbstractJdbcStore.java      |   11 +-
 .../store/jdbc/CacheJdbcBlobStoreFactory.java   |    2 +-
 .../store/jdbc/JdbcTypesDefaultTransformer.java |   19 +
 .../cache/store/jdbc/JdbcTypesTransformer.java  |   17 +
 .../configuration/CacheConfiguration.java       |   45 +-
 .../internal/GridEventConsumeHandler.java       |    5 +
 .../ignite/internal/GridKernalContext.java      |    1 +
 .../ignite/internal/GridKernalContextImpl.java  |    1 +
 .../ignite/internal/GridKernalGatewayImpl.java  |   25 +-
 .../internal/GridMessageListenHandler.java      |    5 +
 .../internal/GridPerformanceSuggestions.java    |   92 -
 .../org/apache/ignite/internal/GridTopic.java   |    2 +-
 .../apache/ignite/internal/IgniteKernal.java    |   60 +-
 .../ignite/internal/IgniteMessagingImpl.java    |    6 +-
 .../ignite/internal/IgniteVersionUtils.java     |    2 +-
 .../ignite/internal/MarshallerContextImpl.java  |    4 +-
 .../internal/StripedExecutorMXBeanAdapter.java  |   90 +
 .../ignite/internal/binary/BinaryContext.java   |    3 +
 .../internal/binary/BinaryEnumObjectImpl.java   |    4 +-
 .../internal/binary/BinaryMarshaller.java       |    1 -
 .../ignite/internal/binary/BinaryTreeMap.java   |    6 +-
 .../impl/GridRouterCommandLineStartup.java      |    4 +-
 .../client/util/GridClientConsistentHash.java   |   14 +-
 .../cluster/ClusterNodeLocalMapImpl.java        |    1 -
 .../ignite/internal/jdbc2/JdbcConnection.java   |   72 +-
 .../internal/jdbc2/JdbcPreparedStatement.java   |   34 +-
 .../internal/jdbc2/JdbcSqlFieldsQuery.java      |    1 -
 .../ignite/internal/jdbc2/JdbcStatement.java    |   22 +-
 .../jdbc2/JdbcStreamedPreparedStatement.java    |   59 +
 .../internal/managers/GridManagerAdapter.java   |    2 +-
 .../managers/communication/GridIoManager.java   |  159 +-
 .../internal/managers/discovery/DiscoCache.java |  310 ++++
 .../discovery/GridDiscoveryManager.java         |  734 +++-----
 .../eventstorage/DiscoveryEventListener.java    |   33 +
 .../eventstorage/GridEventStorageManager.java   |  196 +-
 .../internal/mxbean/IgniteStandardMXBean.java   |   12 +-
 .../affinity/GridAffinityAssignmentCache.java   |   13 +-
 .../cache/CacheAffinitySharedManager.java       |   37 +-
 .../cache/CacheEvictableEntryImpl.java          |    4 +-
 .../processors/cache/CacheMetricsImpl.java      |    6 +-
 .../processors/cache/EntryGetResult.java        |   95 +
 .../processors/cache/EntryGetWithTtlResult.java |   58 +
 .../processors/cache/GridCacheAdapter.java      |  216 ++-
 .../cache/GridCacheAffinityManager.java         |   84 +-
 .../processors/cache/GridCacheAtomicFuture.java |    3 +-
 .../processors/cache/GridCacheContext.java      |  143 +-
 .../cache/GridCacheDeploymentManager.java       |    4 +-
 .../processors/cache/GridCacheEntryEx.java      |   42 +-
 .../cache/GridCacheEvictionManager.java         |   66 +-
 .../processors/cache/GridCacheGateway.java      |   48 +-
 .../processors/cache/GridCacheIoManager.java    |   19 +-
 .../cache/GridCacheManagerAdapter.java          |    2 +-
 .../processors/cache/GridCacheMapEntry.java     |  152 +-
 .../GridCachePartitionExchangeManager.java      |   78 +-
 .../processors/cache/GridCacheProcessor.java    |   98 +-
 .../processors/cache/GridCacheTtlManager.java   |    2 +-
 .../processors/cache/GridCacheUtils.java        |   31 +-
 .../processors/cache/IgniteCacheProxy.java      |    9 +-
 .../processors/cache/QueryCursorImpl.java       |    6 +-
 .../processors/cache/ReaderArguments.java       |   74 +
 .../cache/affinity/GridCacheAffinityImpl.java   |   18 +-
 .../binary/CacheObjectBinaryProcessorImpl.java  |    2 +-
 .../CacheDataStructuresManager.java             |    2 +-
 .../GridDistributedCacheAdapter.java            |    8 +-
 .../distributed/GridDistributedCacheEntry.java  |    3 -
 .../GridDistributedLockResponse.java            |    1 -
 .../dht/GridClientPartitionTopology.java        |   34 +-
 .../dht/GridDhtAssignmentFetchFuture.java       |   13 +-
 .../distributed/dht/GridDhtCacheAdapter.java    |   60 +-
 .../distributed/dht/GridDhtCacheEntry.java      |    2 +-
 .../cache/distributed/dht/GridDhtGetFuture.java |  111 +-
 .../distributed/dht/GridDhtGetSingleFuture.java |  101 +-
 .../distributed/dht/GridDhtLocalPartition.java  |  122 +-
 .../distributed/dht/GridDhtLockFuture.java      |   35 +-
 .../dht/GridDhtPartitionTopology.java           |    1 -
 .../dht/GridDhtPartitionTopologyImpl.java       |   62 +-
 .../dht/GridDhtTransactionalCacheAdapter.java   |   21 +-
 .../distributed/dht/GridDhtTxFinishFuture.java  |    8 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |    1 -
 .../distributed/dht/GridDhtTxLocalAdapter.java  |    8 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java |   48 +-
 .../cache/distributed/dht/GridDhtTxRemote.java  |    2 +-
 .../distributed/dht/GridDhtUnlockRequest.java   |    3 +-
 .../dht/GridPartitionedGetFuture.java           |   26 +-
 .../dht/GridPartitionedSingleGetFuture.java     |   21 +-
 .../GridDhtAtomicAbstractUpdateFuture.java      |    9 +-
 .../GridDhtAtomicAbstractUpdateRequest.java     |    2 +-
 .../dht/atomic/GridDhtAtomicCache.java          |   56 +-
 .../atomic/GridDhtAtomicSingleUpdateFuture.java |    6 +-
 .../GridDhtAtomicSingleUpdateRequest.java       |    5 +-
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |    6 +-
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |   10 +-
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |   31 +-
 .../atomic/GridNearAtomicFullUpdateRequest.java |    1 -
 .../GridNearAtomicSingleUpdateFuture.java       |    9 +-
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |   11 +-
 .../atomic/GridNearAtomicUpdateResponse.java    |   35 +-
 .../dht/colocated/GridDhtColocatedCache.java    |   35 +-
 .../colocated/GridDhtColocatedLockFuture.java   |   16 +-
 .../dht/preloader/GridDhtForceKeysFuture.java   |    8 +-
 .../dht/preloader/GridDhtPartitionDemander.java |   16 +-
 .../dht/preloader/GridDhtPartitionMap2.java     |    3 +-
 .../dht/preloader/GridDhtPartitionSupplier.java |    2 +-
 .../GridDhtPartitionsExchangeFuture.java        |   84 +-
 .../dht/preloader/GridDhtPreloader.java         |   43 +-
 .../distributed/near/GridNearAtomicCache.java   |    3 +-
 .../distributed/near/GridNearCacheEntry.java    |    6 +-
 .../distributed/near/GridNearGetFuture.java     |   40 +-
 .../distributed/near/GridNearGetRequest.java    |   39 +-
 .../distributed/near/GridNearLockFuture.java    |    9 +-
 .../distributed/near/GridNearLockRequest.java   |   81 +-
 ...arOptimisticSerializableTxPrepareFuture.java |    4 +-
 .../near/GridNearOptimisticTxPrepareFuture.java |   13 +-
 .../GridNearPessimisticTxPrepareFuture.java     |    2 +-
 .../near/GridNearSingleGetRequest.java          |   62 +-
 .../near/GridNearTransactionalCache.java        |    8 +-
 .../near/GridNearTxFinishFuture.java            |   15 +-
 .../cache/distributed/near/GridNearTxLocal.java |   29 +-
 .../processors/cache/local/GridLocalCache.java  |    1 +
 .../local/atomic/GridLocalAtomicCache.java      |   21 +-
 .../processors/cache/query/CacheQuery.java      |    1 -
 .../cache/query/GridCacheQueryAdapter.java      |    8 +
 .../cache/query/GridCacheQueryManager.java      |  122 +-
 .../cache/query/GridCacheSqlQuery.java          |  128 +-
 .../continuous/CacheContinuousQueryHandler.java |  102 +-
 .../continuous/CacheContinuousQueryManager.java |    2 +-
 .../cache/transactions/IgniteTxAdapter.java     |    4 +-
 .../cache/transactions/IgniteTxEntry.java       |    2 +-
 .../cache/transactions/IgniteTxHandler.java     |   20 +-
 .../transactions/IgniteTxLocalAdapter.java      |  149 +-
 .../cache/transactions/IgniteTxLocalEx.java     |    3 +
 .../cache/transactions/IgniteTxManager.java     |    3 +-
 .../cache/transactions/TxDeadlockDetection.java |    2 +-
 .../cache/transactions/TxEntryValueHolder.java  |    6 +-
 .../cache/version/GridCacheVersion.java         |    2 +-
 .../cache/version/GridCacheVersionManager.java  |    2 +-
 .../IgniteCacheObjectProcessorImpl.java         |    2 +-
 .../processors/clock/GridClockServer.java       |    4 +-
 .../clock/GridClockSyncProcessor.java           |    2 +-
 .../closure/GridClosureProcessor.java           |    2 +-
 .../processors/cluster/GridUpdateNotifier.java  |    2 +-
 .../continuous/GridContinuousHandler.java       |    5 +
 .../continuous/GridContinuousProcessor.java     |    3 +
 .../datastreamer/DataStreamProcessor.java       |    2 +-
 .../datastreamer/DataStreamerImpl.java          |    6 +-
 .../datastructures/DataStructuresProcessor.java |    3 +-
 .../datastructures/GridCacheLockImpl.java       |   17 +-
 .../datastructures/GridCacheSetImpl.java        |    2 +-
 .../datastructures/GridSetQueryPredicate.java   |    2 +-
 .../processors/hadoop/HadoopClasspathUtils.java |    4 +-
 .../processors/hadoop/HadoopTaskContext.java    |   10 +
 .../internal/processors/igfs/IgfsProcessor.java |    2 +-
 .../igfs/client/IgfsClientSizeCallable.java     |    1 -
 .../processors/job/GridJobProcessor.java        |    2 +-
 .../internal/processors/job/GridJobWorker.java  |    4 +
 .../internal/processors/odbc/IgniteTypes.java   |   69 +
 .../internal/processors/odbc/OdbcTypes.java     |  131 ++
 .../internal/processors/odbc/OdbcUtils.java     |   85 +
 .../processors/odbc/escape/OdbcEscapeUtils.java |   52 +-
 .../platform/PlatformAbstractBootstrap.java     |    3 +-
 .../platform/PlatformConfigurationEx.java       |    3 +-
 .../platform/cache/PlatformCache.java           |   23 +-
 .../transactions/PlatformTransactions.java      |    9 +
 .../platform/utils/PlatformUtils.java           |    2 +-
 .../processors/query/GridQueryIndexing.java     |   71 +-
 .../processors/query/GridQueryProcessor.java    |  334 ++--
 .../query/GridQueryTypeDescriptor.java          |    7 +
 .../processors/query/GridRunningQueryInfo.java  |  132 ++
 .../messages/GridQueryNextPageRequest.java      |   29 +-
 .../messages/GridQueryNextPageResponse.java     |   29 +-
 .../handlers/cache/GridCacheCommandHandler.java |   29 +-
 .../redis/GridRedisRestCommandHandler.java      |   36 +
 .../string/GridRedisSetCommandHandler.java      |   45 +-
 .../service/GridServiceProcessor.java           |   24 +-
 .../processors/task/GridTaskWorker.java         |    2 +-
 .../suggestions/GridPerformanceSuggestions.java |  105 ++
 .../JvmConfigurationSuggestions.java            |  104 ++
 .../suggestions/OsConfigurationSuggestions.java |  127 ++
 .../internal/suggestions/package-info.java      |   21 +
 .../ignite/internal/util/GridBusyLock.java      |    2 +-
 .../internal/util/GridStripedSpinBusyLock.java  |    2 +-
 .../ignite/internal/util/HostAndPortRange.java  |    2 +-
 .../ignite/internal/util/IgniteUtils.java       |   24 +-
 .../util/StripedCompositeReadWriteLock.java     |   50 +-
 .../ignite/internal/util/StripedExecutor.java   |   67 +-
 .../nio/GridAbstractCommunicationClient.java    |   37 +-
 .../util/nio/GridCommunicationClient.java       |    5 -
 .../visor/cache/VisorCacheClearTask.java        |   47 +-
 .../visor/cache/VisorCacheTypeMetadata.java     |    6 +
 .../visor/compute/VisorGatewayTask.java         |   30 +-
 .../visor/query/VisorCancelQueriesTask.java     |   72 +
 .../query/VisorCollectRunningQueriesTask.java   |   96 +
 .../internal/visor/query/VisorQueryJob.java     |    3 +-
 .../internal/visor/query/VisorRunningQuery.java |  132 ++
 .../internal/visor/util/VisorTaskUtils.java     |    8 +-
 .../ignite/lang/IgniteProductVersion.java       |    2 +-
 .../ignite/marshaller/jdk/JdkMarshaller.java    |    1 -
 .../optimized/OptimizedClassDescriptor.java     |    2 +-
 .../optimized/OptimizedMarshallerUtils.java     |    4 +-
 .../ignite/mxbean/StripedExecutorMXBean.java    |   90 +
 .../communication/tcp/TcpCommunicationSpi.java  |   52 +-
 .../tcp/TcpCommunicationSpiMBean.java           |    1 -
 .../ignite/spi/discovery/tcp/ClientImpl.java    |   94 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |   69 +-
 .../tcp/internal/TcpDiscoveryStatistics.java    |    8 +-
 .../messages/TcpDiscoveryAbstractMessage.java   |   21 +
 .../org/apache/ignite/thread/IgniteThread.java  |   26 +-
 .../resources/META-INF/classnames.properties    |    9 +-
 modules/core/src/test/config/log4j-test.xml     |    6 +
 .../CacheJdbcPojoStoreAbstractSelfTest.java     |   21 +-
 ...eJdbcStoreAbstractMultithreadedSelfTest.java |   17 +-
 .../ignite/cache/store/jdbc/model/Gender.java   |   41 +
 .../ignite/cache/store/jdbc/model/Person.java   |   31 +-
 .../internal/ClusterGroupHostsSelfTest.java     |    6 +-
 .../ComputeJobCancelWithServiceSelfTest.java    |    2 +-
 .../internal/GridCacheRecreateLockTest.java     |   78 +
 .../internal/GridContinuousTaskSelfTest.java    |   83 +-
 .../GridEventStorageCheckAllEventsSelfTest.java |    2 +-
 .../IgniteClientReconnectApiExceptionTest.java  |    6 +-
 ...niteClientReconnectFailoverAbstractTest.java |    4 +-
 .../communication/GridIoManagerSelfTest.java    |    4 +-
 .../GridDiscoveryManagerAliveCacheSelfTest.java |   58 +-
 .../GridDiscoveryManagerAttributesSelfTest.java |    4 +-
 .../discovery/GridDiscoveryManagerSelfTest.java |  214 ---
 .../cache/CacheAffinityCallSelfTest.java        |    8 +-
 .../cache/CacheConcurrentReadThroughTest.java   |  184 ++
 .../cache/CacheDeferredDeleteQueueTest.java     |  134 ++
 .../cache/CacheGetEntryAbstractTest.java        |   16 +-
 .../CacheSerializableTransactionsTest.java      |  179 +-
 .../CacheStartupInDeploymentModesTest.java      |    7 +-
 .../cache/CacheStopAndDestroySelfTest.java      |    6 +-
 .../processors/cache/CacheTxFastFinishTest.java |    2 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |   26 +-
 ...idCacheConfigurationConsistencySelfTest.java |    6 +-
 .../cache/GridCacheLifecycleAwareSelfTest.java  |   33 +
 .../cache/GridCacheMvccPartitionedSelfTest.java |   48 +-
 .../processors/cache/GridCacheMvccSelfTest.java |  208 +--
 .../processors/cache/GridCacheOffHeapTest.java  |  270 ---
 .../processors/cache/GridCacheStopSelfTest.java |    4 +-
 .../processors/cache/GridCacheTestEntryEx.java  |   33 +-
 .../cache/GridCacheUtilsSelfTest.java           |    2 +-
 ...ProjectionForCachesOnDaemonNodeSelfTest.java |    8 +-
 .../IgniteCacheConfigVariationsFullApiTest.java |    8 +-
 .../cache/IgniteCachePeekModesAbstractTest.java |    4 +-
 .../cache/IgniteCacheStoreCollectionTest.java   |    1 -
 ...gniteTopologyValidatorAbstractCacheTest.java |    6 +-
 ...niteTopologyValidatorGridSplitCacheTest.java |  334 ++++
 .../processors/cache/IgniteTxAbstractTest.java  |    3 +-
 .../cache/IgniteTxConfigCacheSelfTest.java      |    2 +-
 .../IgniteTxExceptionAbstractSelfTest.java      |    3 +-
 .../IgniteTxMultiThreadedAbstractTest.java      |    4 +-
 ...sExchangeOnDiscoveryHistoryOverflowTest.java |  190 ++
 .../CacheKeepBinaryWithInterceptorTest.java     |    1 -
 ...yAtomicEntryProcessorDeploymentSelfTest.java |    4 +-
 ...IgniteCacheAbstractExecutionContextTest.java |    2 -
 ...eAbstractDataStructuresFailoverSelfTest.java |   16 +-
 ...actQueueFailoverDataConsistencySelfTest.java |    2 +-
 ...CacheAtomicReferenceApiSelfAbstractTest.java |   60 +-
 ...idCacheAtomicStampedApiSelfAbstractTest.java |   59 +
 .../GridCacheQueueApiSelfAbstractTest.java      |   58 +
 .../GridCacheSetAbstractSelfTest.java           |   53 +
 .../IgniteAtomicLongApiAbstractSelfTest.java    |   27 +
 .../IgniteCountDownLatchAbstractSelfTest.java   |   43 +
 .../IgniteLockAbstractSelfTest.java             |   78 +-
 .../IgniteSemaphoreAbstractSelfTest.java        |   52 +-
 .../CacheGetFutureHangsSelfTest.java            |    6 +-
 .../CacheLateAffinityAssignmentTest.java        |    2 +-
 .../CacheLockReleaseNodeLeaveTest.java          |   64 +-
 ...ridCachePartitionNotLoadedEventSelfTest.java |    4 +-
 ...niteCacheClientNodeChangingTopologyTest.java |   20 +-
 ...teSynchronizationModesMultithreadedTest.java |    8 +-
 .../IgniteCacheCrossCacheTxFailoverTest.java    |    6 +-
 ...ePrimaryNodeFailureRecoveryAbstractTest.java |    4 +-
 ...gniteCachePutRetryTransactionalSelfTest.java |    4 +-
 ...eAtomicInvalidPartitionHandlingSelfTest.java |    4 +-
 ...idCacheNearOnlyMultiNodeFullApiSelfTest.java |    4 +-
 .../near/GridNearCacheStoreUpdateTest.java      |  466 +++++
 .../GridNearOffheapCacheStoreUpdateTest.java    |   35 +
 .../GridCacheRebalancingSyncSelfTest.java       |   71 +-
 .../GridCacheReplicatedNodeRestartSelfTest.java |    3 +-
 .../GridCacheReplicatedPreloadSelfTest.java     |    1 -
 .../cache/eviction/EvictionAbstractTest.java    |    4 +-
 .../IgniteCacheExpiryPolicyAbstractTest.java    |   45 +-
 ...eCacheExpiryPolicyWithStoreAbstractTest.java |  100 +-
 .../IgniteCacheTxExpiryPolicyWithStoreTest.java |   21 +
 .../IgniteCacheQueryCacheDestroySelfTest.java   |  142 ++
 .../cache/query/IndexingSpiQuerySelfTest.java   |   69 +-
 .../IndexingSpiQueryWithH2IndexingSelfTest.java |   36 +
 ...ContinuousQueryFailoverAbstractSelfTest.java |    6 +-
 .../ClientReconnectContinuousQueryTest.java     |  201 +++
 ...dCacheContinuousQueryNodesFilteringTest.java |    2 +-
 ...IgniteCacheContinuousQueryReconnectTest.java |   12 +-
 .../TxDeadlockDetectionNoHangsTest.java         |    2 +-
 .../transactions/TxDeadlockDetectionTest.java   |    2 +-
 .../TxOptimisticDeadlockDetectionTest.java      |    2 +-
 .../TxPessimisticDeadlockDetectionTest.java     |    2 +-
 ...ComputeJobExecutionErrorToLogManualTest.java |    4 +-
 .../datastreamer/DataStreamerImplSelfTest.java  |    8 +-
 .../datastreamer/DataStreamerTimeoutTest.java   |    6 +-
 .../processors/igfs/IgfsAbstractSelfTest.java   |   32 +-
 .../processors/igfs/IgfsFileInfoSelfTest.java   |    4 +-
 .../igfs/IgfsMetaManagerSelfTest.java           |    3 +-
 .../igfs/IgfsModeResolverSelfTest.java          |   10 +-
 .../processors/igfs/IgfsTaskSelfTest.java       |   87 +-
 .../igfs/benchmark/IgfsBenchmark.java           |    4 +-
 ...niteMessagingConfigVariationFullApiTest.java |  195 +-
 .../odbc/OdbcEscapeSequenceSelfTest.java        |  131 ++
 .../cache/GridCacheCommandHandlerSelfTest.java  |    1 -
 ...rviceDeploymentExceptionPropagationTest.java |    2 +-
 .../GridServiceProcessorStopSelfTest.java       |    2 +-
 .../service/IgniteServiceReassignmentTest.java  |    2 +-
 .../internal/util/IgniteUtilsSelfTest.java      |    5 +-
 .../internal/util/StripedExecutorTest.java      |  168 ++
 .../unsafe/GridOffheapSnapTreeSelfTest.java     |    7 +-
 .../lang/GridMetadataAwareAdapterSelfTest.java  |    4 +-
 .../GridMarshallerPerformanceTest.java          |    4 +
 .../ignite/messaging/GridMessagingSelfTest.java |  114 +-
 .../messaging/IgniteMessagingSendAsyncTest.java |  544 ++++++
 .../p2p/GridP2PSameClassLoaderSelfTest.java     |   14 +-
 .../ignite/platform/PlatformExceptionTask.java  |   78 +
 .../tcp/TcpCommunicationSpiDropNodesTest.java   |  323 ++++
 .../TcpCommunicationSpiFaultyClientTest.java    |  266 +++
 .../local/GridLocalDeploymentSpiSelfTest.java   |    6 +-
 ...lientDiscoverySpiFailureTimeoutSelfTest.java |    4 +-
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java |    8 +-
 .../TcpDiscoverySpiFailureTimeoutSelfTest.java  |   14 +-
 .../startup/GridRandomCommandLineLoader.java    |    2 +-
 .../testframework/GridSpiTestContext.java       |    5 +-
 .../ignite/testframework/GridTestNode.java      |    1 +
 .../ignite/testframework/IgniteTestSuite.java   |    2 +-
 .../testframework/junits/GridAbstractTest.java  |    2 +
 .../junits/common/GridCommonAbstractTest.java   |   77 +
 .../junits/multijvm/IgniteProcessProxy.java     |    5 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java |    2 +
 .../IgniteCacheDataStructuresSelfTestSuite.java |    2 -
 .../ignite/testsuites/IgniteCacheTestSuite.java |    2 +
 .../testsuites/IgniteCacheTestSuite2.java       |    9 +
 .../testsuites/IgniteCacheTestSuite5.java       |    3 +
 .../testsuites/IgniteComputeGridTestSuite.java  |    4 +
 .../testsuites/IgniteKernalSelfTestSuite.java   |    5 +-
 ...essagingConfigVariationFullApiTestSuite.java |    4 +-
 .../IgniteSpiCommunicationSelfTestSuite.java    |    5 +
 .../IgniteSpiDiscoverySelfTestSuite.java        |    2 +-
 .../IgniteTopologyValidatorTestSuit.java        |    1 +
 .../ignite/util/mbeans/GridMBeanSelfTest.java   |   10 +-
 modules/docker/1.9.0/Dockerfile                 |   46 +
 modules/docker/1.9.0/run.sh                     |   51 +
 modules/docker/Dockerfile                       |    4 +-
 .../CacheNoValueClassOnServerTestClient.java    |    3 +-
 .../CacheConfigurationP2PTestClient.java        |    3 +-
 modules/flink/pom.xml                           |    2 +-
 .../gce/TcpDiscoveryGoogleStorageIpFinder.java  |    4 +-
 .../query/h2/opt/GridH2SpatialIndex.java        |   56 +-
 .../query/h2/GridH2IndexingGeoSelfTest.java     |  409 +++--
 .../h2/GridH2IndexingSegmentedGeoSelfTest.java  |   37 +
 .../testsuites/GeoSpatialIndexingTestSuite.java |    2 +
 .../io/BytesWritablePartiallyRawComparator.java |   51 +
 .../hadoop/io/TextPartiallyRawComparator.java   |   68 +-
 .../hadoop/igfs/HadoopIgfsEndpoint.java         |    4 +-
 .../processors/hadoop/impl/HadoopUtils.java     |   66 +
 .../HadoopBasicFileSystemFactoryDelegate.java   |    2 +-
 .../hadoop/impl/igfs/HadoopIgfsInProc.java      |   40 +-
 .../hadoop/impl/v1/HadoopV1MapTask.java         |   89 +-
 .../hadoop/impl/v1/HadoopV1ReduceTask.java      |   69 +-
 .../hadoop/impl/v2/HadoopV2Context.java         |   13 +-
 .../hadoop/impl/v2/HadoopV2MapTask.java         |   18 +-
 .../hadoop/impl/v2/HadoopV2ReduceTask.java      |   14 +
 .../hadoop/impl/v2/HadoopV2TaskContext.java     |   12 +-
 .../hadoop/shuffle/HadoopShuffle.java           |    2 +-
 .../hadoop/shuffle/HadoopShuffleJob.java        |    8 -
 .../shuffle/direct/HadoopDirectDataInput.java   |    2 +-
 .../taskexecutor/HadoopExecutorService.java     |    6 +-
 .../hadoop/taskexecutor/HadoopRunnableTask.java |   12 +-
 .../child/HadoopChildProcessRunner.java         |   10 +-
 .../impl/HadoopAbstractMapReduceTest.java       |    2 +
 .../hadoop/impl/HadoopErrorSimulator.java       |   12 +-
 .../impl/HadoopMapReduceEmbeddedSelfTest.java   |    6 +-
 .../HadoopIgfs20FileSystemAbstractSelfTest.java |    3 +-
 .../IgniteHadoopFileSystemClientSelfTest.java   |    6 +-
 .../cache/query/GridCacheTwoStepQuery.java      |   35 +-
 .../query/h2/DmlStatementsProcessor.java        |  267 ++-
 .../query/h2/GridH2ResultSetIterator.java       |    3 +-
 .../processors/query/h2/IgniteH2Indexing.java   |  517 ++++--
 .../query/h2/dml/UpdatePlanBuilder.java         |    2 +-
 .../query/h2/opt/DistributedJoinMode.java       |   51 +
 .../query/h2/opt/GridH2CollocationModel.java    |   82 +-
 .../query/h2/opt/GridH2IndexBase.java           |  354 +++-
 .../query/h2/opt/GridH2QueryContext.java        |   84 +-
 .../query/h2/opt/GridH2RowDescriptor.java       |    5 -
 .../query/h2/opt/GridH2ScanIndex.java           |  273 +++
 .../processors/query/h2/opt/GridH2Table.java    |  254 +--
 .../query/h2/opt/GridH2TreeIndex.java           |  161 +-
 .../processors/query/h2/sql/DmlAstUtils.java    |   56 +-
 .../processors/query/h2/sql/GridSqlAlias.java   |   13 +-
 .../processors/query/h2/sql/GridSqlArray.java   |    8 +-
 .../processors/query/h2/sql/GridSqlAst.java     |   61 +
 .../processors/query/h2/sql/GridSqlColumn.java  |   85 +-
 .../processors/query/h2/sql/GridSqlConst.java   |    6 +-
 .../processors/query/h2/sql/GridSqlElement.java |   43 +-
 .../query/h2/sql/GridSqlFunction.java           |   18 +-
 .../processors/query/h2/sql/GridSqlJoin.java    |   35 +-
 .../processors/query/h2/sql/GridSqlKeyword.java |    3 +-
 .../query/h2/sql/GridSqlOperation.java          |    6 +-
 .../query/h2/sql/GridSqlOperationType.java      |    4 +-
 .../query/h2/sql/GridSqlParameter.java          |    4 +-
 .../query/h2/sql/GridSqlPlaceholder.java        |    2 +-
 .../processors/query/h2/sql/GridSqlQuery.java   |   91 +-
 .../query/h2/sql/GridSqlQueryParser.java        |  248 ++-
 .../query/h2/sql/GridSqlQuerySplitter.java      | 1686 +++++++++++++++---
 .../processors/query/h2/sql/GridSqlSelect.java  |  121 +-
 .../query/h2/sql/GridSqlSortColumn.java         |   41 +
 .../query/h2/sql/GridSqlStatement.java          |   11 +-
 .../query/h2/sql/GridSqlSubquery.java           |   31 +-
 .../processors/query/h2/sql/GridSqlTable.java   |   19 +-
 .../processors/query/h2/sql/GridSqlType.java    |    6 +-
 .../processors/query/h2/sql/GridSqlUnion.java   |   66 +-
 .../processors/query/h2/sql/GridSqlValue.java   |   25 -
 .../query/h2/twostep/GridMapQueryExecutor.java  |  313 +++-
 .../query/h2/twostep/GridMergeIndex.java        |  647 +++++--
 .../query/h2/twostep/GridMergeIndexSorted.java  |  380 ++++
 .../h2/twostep/GridMergeIndexUnsorted.java      |  101 +-
 .../query/h2/twostep/GridMergeTable.java        |   70 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |  273 ++-
 .../query/h2/twostep/GridResultPage.java        |   34 +-
 .../query/h2/twostep/msg/GridH2Geometry.java    |    2 +-
 .../h2/twostep/msg/GridH2IndexRangeRequest.java |   60 +-
 .../twostep/msg/GridH2IndexRangeResponse.java   |   62 +-
 .../h2/twostep/msg/GridH2QueryRequest.java      |   19 +-
 .../cache/BinarySerializationQuerySelfTest.java |    2 -
 .../CacheRandomOperationsMultithreadedTest.java |    4 +-
 ...CacheScanPartitionQueryFallbackSelfTest.java |    2 +-
 .../cache/CacheSqlQueryValueCopySelfTest.java   |  208 ++-
 .../ClientReconnectAfterClusterRestartTest.java |    4 +-
 .../cache/GridCacheCrossCacheQuerySelfTest.java |    2 +-
 .../GridCacheQueryIndexDisabledSelfTest.java    |   20 +-
 .../IgniteCacheAbstractFieldsQuerySelfTest.java |    2 +-
 ...niteCacheAbstractInsertSqlQuerySelfTest.java |    6 +-
 .../cache/IgniteCacheAbstractQuerySelfTest.java |  307 +++-
 .../IgniteCacheInsertSqlQuerySelfTest.java      |   14 +
 ...eLockPartitionOnAffinityRunAbstractTest.java |    1 -
 ...PartitionOnAffinityRunAtomicCacheOpTest.java |   11 +-
 ...niteCacheLockPartitionOnAffinityRunTest.java |   50 +-
 ...titionOnAffinityRunWithCollisionSpiTest.java |   10 +-
 .../cache/IgniteCacheMergeSqlQuerySelfTest.java |    1 -
 .../cache/IgniteCacheOffheapEvictQueryTest.java |    4 +-
 ...niteCacheP2pUnmarshallingQueryErrorTest.java |    4 +-
 .../IgniteCacheUpdateSqlQuerySelfTest.java      |   11 +-
 .../cache/IncorrectCacheTypeMetadataTest.java   |   72 +
 .../cache/IncorrectQueryEntityTest.java         |   75 +
 .../cache/QueryEntityCaseMismatchTest.java      |  107 ++
 ...niteCacheDistributedQueryCancelSelfTest.java |    4 +-
 .../IgniteCachePartitionedQuerySelfTest.java    |   85 +
 .../IgniteCacheQueryNodeRestartSelfTest2.java   |    4 +-
 .../IgniteSqlEntryCacheModeAgnosticTest.java    |  140 ++
 .../query/IgniteSqlSchemaIndexingTest.java      |   15 +-
 .../query/IgniteSqlSegmentedIndexSelfTest.java  |  263 +++
 .../query/IgniteSqlSplitterSelfTest.java        |  335 +++-
 .../h2/GridIndexingSpiAbstractSelfTest.java     |   50 +-
 .../h2/sql/AbstractH2CompareQueryTest.java      |   21 +-
 .../query/h2/sql/GridQueryParsingTest.java      |   75 +-
 .../query/h2/sql/H2CompareBigQueryTest.java     |   42 +-
 .../FetchingQueryCursorStressTest.java          |  277 +++
 .../IgniteCacheQuerySelfTestSuite.java          |   14 +
 .../IgniteCacheQuerySelfTestSuite3.java         |    2 +
 .../processors/query/h2/sql/bigQuery.sql        |   34 +-
 .../apache/ignite/stream/jms11/JmsStreamer.java |    4 +-
 .../ignite/stream/kafka/KafkaStreamer.java      |    6 +-
 .../ignite/stream/kafka/TestKafkaBroker.java    |    2 +-
 .../connect/IgniteSourceConnectorTest.java      |    2 +-
 modules/kubernetes/DEVNOTES.txt                 |   63 +
 modules/kubernetes/README.txt                   |   33 +
 modules/kubernetes/config/Dockerfile            |   62 +
 modules/kubernetes/config/example-kube.xml      |   44 +
 .../kubernetes/config/ignite-deployment.yaml    |   41 +
 modules/kubernetes/config/ignite-service.yaml   |   29 +
 modules/kubernetes/config/run.sh                |   50 +
 modules/kubernetes/licenses/apache-2.0.txt      |  202 +++
 modules/kubernetes/pom.xml                      |   93 +
 .../TcpDiscoveryKubernetesIpFinder.java         |  317 ++++
 .../tcp/ipfinder/kubernetes/package-info.java   |   22 +
 .../TcpDiscoveryKubernetesIpFinderSelfTest.java |   93 +
 .../tcp/ipfinder/kubernetes/package-info.java   |   22 +
 .../testsuites/IgniteKubernetesTestSuite.java   |   41 +
 .../stream/mqtt/IgniteMqttStreamerTest.java     |    4 +-
 .../BundleDelegatingClassLoader.java            |    4 +-
 .../classloaders/ContainerSweepClassLoader.java |    4 +-
 modules/platforms/cpp/binary/Makefile.am        |    3 +
 .../platforms/cpp/binary/include/Makefile.am    |    6 +
 .../cpp/binary/include/ignite/binary/binary.h   |   15 +-
 .../binary/binary_array_identity_resolver.h     |   64 +
 .../ignite/binary/binary_identity_resolver.h    |   61 +
 .../include/ignite/binary/binary_object.h       |   78 +
 .../binary/include/ignite/binary/binary_type.h  |   16 -
 .../ignite/impl/binary/binary_object_header.h   |  250 +++
 .../ignite/impl/binary/binary_object_impl.h     |  109 ++
 .../include/ignite/impl/binary/binary_schema.h  |    2 +-
 .../ignite/impl/binary/binary_type_impl.h       |  149 ++
 .../ignite/impl/binary/binary_type_snapshot.h   |   18 +-
 .../include/ignite/impl/binary/binary_utils.h   |  236 +--
 .../ignite/impl/binary/binary_writer_impl.h     |   11 +-
 .../ignite/impl/interop/interop_output_stream.h |   10 +-
 .../cpp/binary/project/vs/binary.vcxproj        |    9 +
 .../binary/project/vs/binary.vcxproj.filters    |   27 +
 .../binary/binary_array_identity_resolver.cpp   |   42 +
 .../cpp/binary/src/binary/binary_type.cpp       |    4 +-
 .../src/impl/binary/binary_object_header.cpp    |   51 +
 .../src/impl/binary/binary_object_impl.cpp      |   56 +
 .../src/impl/binary/binary_type_manager.cpp     |   12 +-
 .../cpp/binary/src/impl/binary/binary_utils.cpp |  169 +-
 .../src/impl/binary/binary_writer_impl.cpp      |    4 +-
 .../src/impl/interop/interop_output_stream.cpp  |    5 +
 modules/platforms/cpp/common/Makefile.am        |    5 +-
 .../platforms/cpp/common/include/Makefile.am    |    1 +
 .../include/ignite/common/platform_utils.h      |   79 +
 .../cpp/common/include/ignite/common/utils.h    |  249 ++-
 .../os/linux/src/common/platform_utils.cpp      |   81 +
 .../cpp/common/os/linux/src/common/utils.cpp    |  136 --
 .../common/os/win/src/common/platform_utils.cpp |   88 +
 .../cpp/common/os/win/src/common/utils.cpp      |  142 --
 .../cpp/common/project/vs/common.vcxproj        |    5 +-
 .../common/project/vs/common.vcxproj.filters    |   18 +-
 .../platforms/cpp/common/project/vs/targetver.h |   25 -
 .../platforms/cpp/common/src/common/utils.cpp   |  153 ++
 modules/platforms/cpp/core-test/Makefile.am     |    6 +-
 .../cpp/core-test/config/cache-identity.xml     |  121 ++
 .../cpp/core-test/config/cache-query.xml        |   10 -
 .../cpp/core-test/config/cache-store.xml        |   71 +
 .../core-test/include/ignite/binary_test_defs.h |   25 +
 .../cpp/core-test/include/ignite/complex_type.h |  135 ++
 .../cpp/core-test/include/ignite/test_type.h    |  186 ++
 .../cpp/core-test/include/ignite/test_utils.h   |   63 +
 .../cpp/core-test/project/vs/core-test.vcxproj  |   12 +
 .../project/vs/core-test.vcxproj.filters        |   38 +-
 .../src/binary_identity_resolver_test.cpp       |  522 ++++++
 .../cpp/core-test/src/binary_object_test.cpp    |  282 +++
 .../src/binary_reader_writer_raw_test.cpp       |    2 +-
 .../core-test/src/binary_reader_writer_test.cpp |    2 +-
 .../cpp/core-test/src/binary_session_test.cpp   |    6 +-
 .../cpp/core-test/src/cache_query_test.cpp      |  151 +-
 .../cpp/core-test/src/cache_store_test.cpp      |  151 ++
 .../platforms/cpp/core-test/src/cache_test.cpp  |   43 +-
 .../cpp/core-test/src/continuous_query_test.cpp |   33 +-
 .../cpp/core-test/src/handle_registry_test.cpp  |    2 +-
 .../cpp/core-test/src/ignite_error_test.cpp     |    2 +-
 .../cpp/core-test/src/ignition_test.cpp         |   21 +-
 .../cpp/core-test/src/interop_memory_test.cpp   |    2 +-
 .../cpp/core-test/src/interop_test.cpp          |   42 +-
 .../cpp/core-test/src/reference_test.cpp        |    2 +-
 .../platforms/cpp/core-test/src/test_utils.cpp  |   86 +
 .../cpp/core-test/src/transactions_test.cpp     |   25 +-
 .../cpp/core/include/ignite/cache/cache.h       |   54 +-
 .../cache/query/continuous/continuous_query.h   |    2 +-
 .../core/include/ignite/impl/cache/cache_impl.h |   19 +
 .../ignite/impl/interop/interop_target.h        |   25 +
 .../cpp/core/src/impl/cache/cache_impl.cpp      |   48 +
 .../platforms/cpp/core/src/impl/ignite_impl.cpp |    4 +-
 .../core/src/impl/interop/interop_target.cpp    |   36 +-
 .../platforms/cpp/jni/project/vs/jni.vcxproj    |    1 -
 .../cpp/jni/project/vs/jni.vcxproj.filters      |    3 -
 .../platforms/cpp/jni/project/vs/targetver.h    |   25 -
 modules/platforms/cpp/odbc-test/Makefile.am     |    1 +
 .../odbc-test/include/sql_test_suite_fixture.h  |   13 +
 .../cpp/odbc-test/include/test_utils.h          |   51 +-
 .../cpp/odbc-test/project/vs/odbc-test.vcxproj  |    1 +
 .../project/vs/odbc-test.vcxproj.filters        |    3 +
 .../cpp/odbc-test/src/api_robustness_test.cpp   |   37 +-
 .../src/application_data_buffer_test.cpp        |   24 +-
 .../cpp/odbc-test/src/queries_test.cpp          |   71 +-
 .../src/sql_aggregate_functions_test.cpp        |    5 +-
 .../src/sql_date_time_functions_test.cpp        |   26 +-
 .../src/sql_esc_convert_function_test.cpp       |  160 ++
 .../src/sql_numeric_functions_test.cpp          |    1 +
 .../cpp/odbc-test/src/sql_outer_join_test.cpp   |    1 +
 .../odbc-test/src/sql_string_functions_test.cpp |    1 +
 .../odbc-test/src/sql_test_suite_fixture.cpp    |   88 +-
 .../cpp/odbc-test/src/sql_types_test.cpp        |  131 +-
 .../platforms/cpp/odbc-test/src/test_utils.cpp  |   60 +-
 .../odbc/src/app/application_data_buffer.cpp    |   66 +-
 .../platforms/cpp/odbc/src/app/parameter.cpp    |    4 +-
 .../cpp/odbc/src/config/connection_info.cpp     |  260 ++-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite.AspNet.nuspec                 |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite.Core.Tests.csproj             |    2 +
 .../Binary/BinaryStructureTest.cs               |  122 ++
 .../Cache/CacheAbstractTest.cs                  |   21 +
 .../Cache/CacheAbstractTransactionalTest.cs     |  339 ++++
 .../Cache/Query/CacheLinqTest.cs                |   96 +
 .../Cache/Store/CacheParallelLoadStoreTest.cs   |    9 +-
 .../Cache/Store/CacheStoreSessionTest.cs        |   22 +-
 .../Cache/Store/CacheStoreTest.cs               |  367 ++--
 .../Cache/Store/CacheTestStore.cs               |   14 +
 .../Cache/Store/NamedNodeCacheStoreTest.cs      |   34 +
 .../Apache.Ignite.Core.Tests/ExceptionsTest.cs  |   38 +
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite.Core.Schema.nuspec            |    2 +-
 .../Apache.Ignite.Core.csproj                   |    2 +
 .../Apache.Ignite.Core.nuspec                   |    2 +-
 .../dotnet/Apache.Ignite.Core/Cache/ICache.cs   |    4 +-
 .../Impl/Binary/BinaryReader.cs                 |  137 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |  104 +-
 .../Apache.Ignite.Core/Impl/ExceptionUtils.cs   |    6 +-
 .../Transactions/CacheTransactionManager.cs     |  161 ++
 .../Impl/Transactions/Transaction.cs            |    8 +
 .../Impl/Transactions/TransactionImpl.cs        |   13 +
 .../Impl/Transactions/TransactionsImpl.cs       |   10 +
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite.EntityFramework.nuspec        |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite.Linq.nuspec                   |    2 +-
 .../Impl/CacheQueryExpressionVisitor.cs         |  127 +-
 .../Impl/CacheQueryModelVisitor.cs              |    3 +
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite.Log4Net.nuspec                |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite.NLog.nuspec                   |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite/Properties/AssemblyInfo.cs    |    2 +-
 .../Apache.Ignite.Examples.csproj               |    2 +
 .../Datagrid/QueryDmlExample.cs                 |  162 ++
 .../Datagrid/TransactionExample.cs              |   75 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 modules/scalar-2.10/pom.xml                     |    2 +-
 modules/scalar/pom.xml                          |    2 +-
 modules/spark-2.10/pom.xml                      |   54 +
 modules/spark/pom.xml                           |  183 +-
 .../org/apache/ignite/spark/IgniteContext.scala |   22 +-
 .../apache/ignite/spark/JavaIgniteContext.scala |    6 +
 .../spark/JavaEmbeddedIgniteRDDSelfTest.java    |   10 +-
 .../spark/JavaStandaloneIgniteRDDSelfTest.java  |   25 +-
 .../util/spring/IgniteSpringHelperImpl.java     |    8 +-
 .../src/test/config/jdbc-pojo-store-builtin.xml |    8 +
 .../src/test/config/jdbc-pojo-store-obj.xml     |    8 +
 .../ignite/internal/GridFactorySelfTest.java    |    2 +-
 .../internal/IgniteDynamicCacheConfigTest.java  |    4 +-
 .../GridSpringTransactionManagerSelfTest.java   |    2 +-
 .../ant/beautifier/GridJavadocAntTask.java      |    1 +
 .../ignite/tools/classgen/ClassesGenerator.java |    6 +-
 .../twitter/IgniteTwitterStreamerTest.java      |    4 +-
 .../GridUriDeploymentFileProcessorSelfTest.java |    3 +-
 .../scala/org/apache/ignite/visor/visor.scala   |  115 +-
 .../commands/mem/VisorMemoryCommandSpec.scala   |   33 +
 modules/web-console/backend/app/agent.js        |   92 +-
 modules/web-console/backend/app/browser.js      |   54 +
 modules/web-console/backend/app/mongo.js        |   49 +-
 modules/web-console/backend/app/routes.js       |    5 +-
 modules/web-console/backend/app/settings.js     |    8 +-
 modules/web-console/backend/index.js            |   10 -
 .../web-console/backend/routes/activities.js    |   45 +
 modules/web-console/backend/routes/admin.js     |    2 +-
 modules/web-console/backend/routes/agent.js     |   10 +-
 modules/web-console/backend/routes/profile.js   |    4 +-
 modules/web-console/backend/routes/public.js    |    1 -
 .../web-console/backend/services/activities.js  |  116 ++
 .../web-console/backend/services/sessions.js    |    6 +-
 modules/web-console/backend/services/users.js   |   20 +-
 .../backend/test/unit/ActivitiesService.test.js |  131 ++
 modules/web-console/frontend/.eslintrc          |    1 +
 modules/web-console/frontend/.gitignore         |    1 +
 modules/web-console/frontend/app/app.config.js  |   25 +-
 modules/web-console/frontend/app/app.js         |   36 +-
 .../activities-user-dialog.controller.js        |   27 +
 .../activities-user-dialog.tpl.pug              |   36 +
 .../components/activities-user-dialog/index.js  |   35 +
 .../form-field-datepicker.pug                   |   55 +
 .../form-field-datepicker.scss                  |   20 +
 .../list-of-registered-users/index.js           |   28 +
 .../list-of-registered-users.categories.js      |   30 +
 .../list-of-registered-users.column-defs.js     |   80 +
 .../list-of-registered-users.controller.js      |  238 +++
 .../list-of-registered-users.tpl.pug            |   58 +
 .../ui-grid-header/ui-grid-header.scss          |   85 +
 .../ui-grid-header/ui-grid-header.tpl.pug       |   27 +
 .../ui-grid-settings/ui-grid-settings.pug       |   33 +
 .../ui-grid-settings/ui-grid-settings.scss      |   99 +
 .../app/core/activities/Activities.data.js      |   34 +
 .../frontend/app/core/admin/Admin.data.js       |   77 +
 modules/web-console/frontend/app/core/index.js  |   25 +
 modules/web-console/frontend/app/data/i18n.js   |   39 +
 .../app/directives/centered/centered.css        |   37 -
 .../directives/centered/centered.directive.js   |    2 +-
 .../app/directives/centered/centered.scss       |   37 +
 .../information/information.directive.js        |    4 +-
 .../app/directives/information/information.jade |   20 -
 .../app/directives/information/information.pug  |   20 +
 .../ui-ace-docker/ui-ace-docker.directive.js    |    4 +-
 .../directives/ui-ace-docker/ui-ace-docker.jade |   31 -
 .../directives/ui-ace-docker/ui-ace-docker.pug  |   31 +
 .../ui-ace-java/ui-ace-java.directive.js        |    4 +-
 .../app/directives/ui-ace-java/ui-ace-java.jade |   22 -
 .../app/directives/ui-ace-java/ui-ace-java.pug  |   22 +
 .../ui-ace-pojos/ui-ace-pojos.directive.js      |    4 +-
 .../directives/ui-ace-pojos/ui-ace-pojos.jade   |   40 -
 .../directives/ui-ace-pojos/ui-ace-pojos.pug    |   40 +
 .../ui-ace-pom/ui-ace-pom.controller.js         |    4 +-
 .../ui-ace-pom/ui-ace-pom.directive.js          |    4 +-
 .../app/directives/ui-ace-pom/ui-ace-pom.jade   |   17 -
 .../app/directives/ui-ace-pom/ui-ace-pom.pug    |   17 +
 .../ui-ace-sharp/ui-ace-sharp.directive.js      |    4 +-
 .../directives/ui-ace-sharp/ui-ace-sharp.jade   |   22 -
 .../directives/ui-ace-sharp/ui-ace-sharp.pug    |   22 +
 .../ui-ace-spring/ui-ace-spring.directive.js    |    4 +-
 .../directives/ui-ace-spring/ui-ace-spring.jade |   17 -
 .../directives/ui-ace-spring/ui-ace-spring.pug  |   17 +
 .../ui-grid-settings/ui-grid-settings.jade      |   33 -
 .../ui-grid-settings/ui-grid-settings.scss      |   38 -
 .../app/filters/uiGridSubcategories.filter.js   |   24 +
 .../frontend/app/helpers/jade/form.jade         |   28 -
 .../frontend/app/helpers/jade/form.pug          |   28 +
 .../helpers/jade/form/form-field-checkbox.jade  |   38 -
 .../helpers/jade/form/form-field-checkbox.pug   |   38 +
 .../helpers/jade/form/form-field-datalist.jade  |   51 -
 .../helpers/jade/form/form-field-datalist.pug   |   51 +
 .../app/helpers/jade/form/form-field-down.jade  |   18 -
 .../app/helpers/jade/form/form-field-down.pug   |   18 +
 .../helpers/jade/form/form-field-dropdown.jade  |   51 -
 .../helpers/jade/form/form-field-dropdown.pug   |   51 +
 .../helpers/jade/form/form-field-feedback.jade  |   32 -
 .../helpers/jade/form/form-field-feedback.pug   |   32 +
 .../app/helpers/jade/form/form-field-label.jade |   23 -
 .../app/helpers/jade/form/form-field-label.pug  |   23 +
 .../helpers/jade/form/form-field-number.jade    |   53 -
 .../app/helpers/jade/form/form-field-number.pug |   53 +
 .../helpers/jade/form/form-field-password.jade  |   47 -
 .../helpers/jade/form/form-field-password.pug   |   47 +
 .../app/helpers/jade/form/form-field-text.jade  |   64 -
 .../app/helpers/jade/form/form-field-text.pug   |   64 +
 .../app/helpers/jade/form/form-field-up.jade    |   18 -
 .../app/helpers/jade/form/form-field-up.pug     |   18 +
 .../app/helpers/jade/form/form-group.jade       |   23 -
 .../app/helpers/jade/form/form-group.pug        |   23 +
 .../frontend/app/helpers/jade/mixins.jade       |  609 -------
 .../frontend/app/helpers/jade/mixins.pug        |  609 +++++++
 .../frontend/app/modules/Demo/Demo.module.js    |  166 --
 .../frontend/app/modules/agent/agent.module.js  |   19 +-
 .../app/modules/branding/branding.provider.js   |    2 +-
 .../modules/branding/header-logo.directive.js   |    4 +-
 .../app/modules/branding/header-logo.jade       |   18 -
 .../app/modules/branding/header-logo.pug        |   18 +
 .../branding/powered-by-apache.directive.js     |    4 +-
 .../app/modules/branding/powered-by-apache.jade |   18 -
 .../app/modules/branding/powered-by-apache.pug  |   18 +
 .../modules/configuration/Version.service.js    |   35 +-
 .../configuration/configuration.module.js       |    6 +-
 .../generator/ConfigurationGenerator.js         |    9 +-
 .../configuration/generator/Maven.service.js    |   10 +-
 .../frontend/app/modules/demo/Demo.module.js    |  173 ++
 .../app/modules/dialog/dialog.factory.js        |    2 +-
 .../frontend/app/modules/dialog/dialog.jade     |   26 -
 .../frontend/app/modules/dialog/dialog.tpl.pug  |   26 +
 .../getting-started/GettingStarted.provider.js  |    3 +-
 .../frontend/app/modules/loading/loading.css    |   73 -
 .../app/modules/loading/loading.directive.js    |    8 +-
 .../frontend/app/modules/loading/loading.jade   |   23 -
 .../frontend/app/modules/loading/loading.pug    |   23 +
 .../frontend/app/modules/loading/loading.scss   |   73 +
 .../frontend/app/modules/nodes/Nodes.service.js |    4 +-
 .../app/modules/nodes/nodes-dialog.jade         |   35 -
 .../app/modules/nodes/nodes-dialog.tpl.pug      |   35 +
 .../app/modules/sql/notebook.controller.js      |    4 +-
 .../frontend/app/modules/sql/sql.controller.js  |   28 +-
 .../frontend/app/modules/sql/sql.module.js      |   17 +-
 .../frontend/app/modules/states/admin.state.js  |    6 +-
 .../app/modules/states/configuration.state.js   |   23 +-
 .../states/configuration/caches/affinity.jade   |   82 -
 .../states/configuration/caches/affinity.pug    |   82 +
 .../configuration/caches/client-near-cache.jade |   50 -
 .../configuration/caches/client-near-cache.pug  |   50 +
 .../configuration/caches/concurrency.jade       |   65 -
 .../states/configuration/caches/concurrency.pug |   65 +
 .../states/configuration/caches/general.jade    |   69 -
 .../states/configuration/caches/general.pug     |   69 +
 .../states/configuration/caches/memory.jade     |  109 --
 .../states/configuration/caches/memory.pug      |  108 ++
 .../configuration/caches/near-cache-client.jade |   51 -
 .../configuration/caches/near-cache-client.pug  |   51 +
 .../configuration/caches/near-cache-server.jade |   52 -
 .../configuration/caches/near-cache-server.pug  |   52 +
 .../configuration/caches/node-filter.jade       |   59 -
 .../states/configuration/caches/node-filter.pug |   59 +
 .../states/configuration/caches/query.jade      |  114 --
 .../states/configuration/caches/query.pug       |  114 ++
 .../states/configuration/caches/rebalance.jade  |   66 -
 .../states/configuration/caches/rebalance.pug   |   66 +
 .../states/configuration/caches/statistics.jade |   39 -
 .../states/configuration/caches/statistics.pug  |   39 +
 .../states/configuration/caches/store.jade      |  250 ---
 .../states/configuration/caches/store.pug       |  250 +++
 .../states/configuration/clusters/atomic.jade   |   54 -
 .../states/configuration/clusters/atomic.pug    |   54 +
 .../configuration/clusters/attributes.jade      |   57 -
 .../configuration/clusters/attributes.pug       |   57 +
 .../states/configuration/clusters/binary.jade   |   77 -
 .../states/configuration/clusters/binary.pug    |   77 +
 .../configuration/clusters/cache-key-cfg.jade   |   50 -
 .../configuration/clusters/cache-key-cfg.pug    |   50 +
 .../configuration/clusters/checkpoint.jade      |   86 -
 .../configuration/clusters/checkpoint.pug       |   86 +
 .../configuration/clusters/checkpoint/fs.jade   |   66 -
 .../configuration/clusters/checkpoint/fs.pug    |   66 +
 .../configuration/clusters/checkpoint/jdbc.jade |   48 -
 .../configuration/clusters/checkpoint/jdbc.pug  |   48 +
 .../configuration/clusters/checkpoint/s3.jade   |  178 --
 .../configuration/clusters/checkpoint/s3.pug    |  178 ++
 .../configuration/clusters/collision.jade       |   63 -
 .../states/configuration/clusters/collision.pug |   63 +
 .../clusters/collision/custom.jade              |   24 -
 .../configuration/clusters/collision/custom.pug |   24 +
 .../clusters/collision/fifo-queue.jade          |   27 -
 .../clusters/collision/fifo-queue.pug           |   27 +
 .../clusters/collision/job-stealing.jade        |   63 -
 .../clusters/collision/job-stealing.pug         |   63 +
 .../clusters/collision/priority-queue.jade      |   42 -
 .../clusters/collision/priority-queue.pug       |   42 +
 .../configuration/clusters/communication.jade   |  100 --
 .../configuration/clusters/communication.pug    |  100 ++
 .../configuration/clusters/connector.jade       |  104 --
 .../states/configuration/clusters/connector.pug |  104 ++
 .../configuration/clusters/deployment.jade      |  237 ---
 .../configuration/clusters/deployment.pug       |  237 +++
 .../configuration/clusters/discovery.jade       |   88 -
 .../states/configuration/clusters/discovery.pug |   88 +
 .../states/configuration/clusters/events.jade   |   68 -
 .../states/configuration/clusters/events.pug    |   68 +
 .../states/configuration/clusters/failover.jade |   73 -
 .../states/configuration/clusters/failover.pug  |   73 +
 .../states/configuration/clusters/general.jade  |   76 -
 .../states/configuration/clusters/general.pug   |   76 +
 .../clusters/general/discovery/cloud.jade       |  134 --
 .../clusters/general/discovery/cloud.pug        |  134 ++
 .../clusters/general/discovery/google.jade      |   38 -
 .../clusters/general/discovery/google.pug       |   38 +
 .../clusters/general/discovery/jdbc.jade        |   31 -
 .../clusters/general/discovery/jdbc.pug         |   31 +
 .../clusters/general/discovery/multicast.jade   |   99 -
 .../clusters/general/discovery/multicast.pug    |   99 +
 .../clusters/general/discovery/s3.jade          |   27 -
 .../clusters/general/discovery/s3.pug           |   27 +
 .../clusters/general/discovery/shared.jade      |   23 -
 .../clusters/general/discovery/shared.pug       |   23 +
 .../clusters/general/discovery/vm.jade          |   79 -
 .../clusters/general/discovery/vm.pug           |   79 +
 .../clusters/general/discovery/zookeeper.jade   |   85 -
 .../clusters/general/discovery/zookeeper.pug    |   85 +
 .../bounded-exponential-backoff.jade            |   27 -
 .../retrypolicy/bounded-exponential-backoff.pug |   27 +
 .../discovery/zookeeper/retrypolicy/custom.jade |   24 -
 .../discovery/zookeeper/retrypolicy/custom.pug  |   24 +
 .../retrypolicy/exponential-backoff.jade        |   27 -
 .../retrypolicy/exponential-backoff.pug         |   27 +
 .../zookeeper/retrypolicy/forever.jade          |   22 -
 .../discovery/zookeeper/retrypolicy/forever.pug |   22 +
 .../zookeeper/retrypolicy/n-times.jade          |   25 -
 .../discovery/zookeeper/retrypolicy/n-times.pug |   25 +
 .../zookeeper/retrypolicy/one-time.jade         |   23 -
 .../zookeeper/retrypolicy/one-time.pug          |   23 +
 .../zookeeper/retrypolicy/until-elapsed.jade    |   25 -
 .../zookeeper/retrypolicy/until-elapsed.pug     |   25 +
 .../states/configuration/clusters/igfs.jade     |   38 -
 .../states/configuration/clusters/igfs.pug      |   38 +
 .../configuration/clusters/load-balancing.jade  |  107 --
 .../configuration/clusters/load-balancing.pug   |  107 ++
 .../states/configuration/clusters/logger.jade   |   66 -
 .../states/configuration/clusters/logger.pug    |   66 +
 .../configuration/clusters/logger/custom.jade   |   25 -
 .../configuration/clusters/logger/custom.pug    |   25 +
 .../configuration/clusters/logger/log4j.jade    |   50 -
 .../configuration/clusters/logger/log4j.pug     |   50 +
 .../configuration/clusters/logger/log4j2.jade   |   39 -
 .../configuration/clusters/logger/log4j2.pug    |   39 +
 .../configuration/clusters/marshaller.jade      |   76 -
 .../configuration/clusters/marshaller.pug       |   76 +
 .../states/configuration/clusters/metrics.jade  |   51 -
 .../states/configuration/clusters/metrics.pug   |   51 +
 .../states/configuration/clusters/odbc.jade     |   48 -
 .../states/configuration/clusters/odbc.pug      |   48 +
 .../states/configuration/clusters/ssl.jade      |  110 --
 .../states/configuration/clusters/ssl.pug       |  110 ++
 .../states/configuration/clusters/swap.jade     |   72 -
 .../states/configuration/clusters/swap.pug      |   72 +
 .../states/configuration/clusters/thread.jade   |   48 -
 .../states/configuration/clusters/thread.pug    |   48 +
 .../states/configuration/clusters/time.jade     |   47 -
 .../states/configuration/clusters/time.pug      |   47 +
 .../configuration/clusters/transactions.jade    |   69 -
 .../configuration/clusters/transactions.pug     |   69 +
 .../states/configuration/domains/general.jade   |   52 -
 .../states/configuration/domains/general.pug    |   52 +
 .../states/configuration/domains/query.jade     |  172 --
 .../states/configuration/domains/query.pug      |  172 ++
 .../states/configuration/domains/store.jade     |  127 --
 .../states/configuration/domains/store.pug      |  127 ++
 .../modules/states/configuration/igfs/dual.jade |   42 -
 .../modules/states/configuration/igfs/dual.pug  |   42 +
 .../states/configuration/igfs/fragmentizer.jade |   43 -
 .../states/configuration/igfs/fragmentizer.pug  |   43 +
 .../states/configuration/igfs/general.jade      |   57 -
 .../states/configuration/igfs/general.pug       |   57 +
 .../modules/states/configuration/igfs/ipc.jade  |   60 -
 .../modules/states/configuration/igfs/ipc.pug   |   60 +
 .../modules/states/configuration/igfs/misc.jade |  108 --
 .../modules/states/configuration/igfs/misc.pug  |  108 ++
 .../states/configuration/igfs/secondary.jade    |   45 -
 .../states/configuration/igfs/secondary.pug     |   45 +
 .../configuration/summary/summary.controller.js |   11 +-
 .../configuration/summary/summary.worker.js     |   34 +-
 .../frontend/app/modules/states/errors.state.js |    4 +-
 .../app/modules/states/password.state.js        |    6 +-
 .../app/modules/states/profile.state.js         |    4 +-
 .../frontend/app/modules/states/signin.state.js |    2 +-
 .../app/modules/user/AclRoute.provider.js       |   31 +-
 .../frontend/app/modules/user/Auth.service.js   |    2 +-
 .../frontend/app/modules/user/permissions.js    |    2 +-
 .../frontend/app/modules/user/user.module.js    |    6 +-
 .../frontend/app/services/Clone.service.js      |    4 +-
 .../frontend/app/services/Confirm.service.js    |    4 +-
 .../app/services/ConfirmBatch.service.js        |    4 +-
 modules/web-console/frontend/app/vendor.js      |    1 +
 .../frontend/controllers/admin-controller.js    |  234 ---
 .../frontend/controllers/caches-controller.js   |    4 +-
 .../frontend/controllers/domains-controller.js  |   16 +-
 .../frontend/gulpfile.babel.js/paths.js         |   28 +-
 .../frontend/gulpfile.babel.js/tasks/build.js   |    2 +-
 .../frontend/gulpfile.babel.js/tasks/bundle.js  |    8 +-
 .../frontend/gulpfile.babel.js/tasks/jade.js    |   49 -
 .../frontend/gulpfile.babel.js/tasks/watch.js   |    5 +-
 .../gulpfile.babel.js/webpack/common.js         |  292 +--
 .../webpack/environments/development.js         |   90 +-
 .../webpack/environments/production.js          |   41 +-
 .../webpack/environments/test.js                |   52 +-
 .../frontend/gulpfile.babel.js/webpack/index.js |    4 +-
 modules/web-console/frontend/package.json       |  183 +-
 .../stylesheets/_font-awesome-custom.scss       |   28 +
 .../frontend/public/stylesheets/style.scss      |   31 +-
 .../frontend/test/e2e/exampe.test.js            |    4 +-
 .../frontend/test/karma.conf.babel.js           |    7 +-
 .../frontend/test/protractor.conf.js            |   16 +-
 .../frontend/test/unit/JavaTransformer.test.js  |    2 +-
 .../frontend/test/unit/JavaTypes.test.js        |  137 +-
 .../frontend/test/unit/SharpTransformer.test.js |    2 +-
 .../test/unit/SpringTransformer.test.js         |    2 +-
 .../frontend/test/unit/SqlTypes.test.js         |    7 +-
 .../frontend/test/unit/UserAuth.test.js         |    4 +-
 .../frontend/test/unit/Version.test.js          |   27 +-
 .../test/unit/defaultName.filter.test.js        |   27 +-
 modules/web-console/frontend/views/403.jade     |   22 -
 modules/web-console/frontend/views/403.pug      |   22 +
 modules/web-console/frontend/views/404.jade     |   22 -
 modules/web-console/frontend/views/404.pug      |   22 +
 modules/web-console/frontend/views/base.jade    |   22 -
 modules/web-console/frontend/views/base.pug     |   22 +
 .../frontend/views/configuration/caches.jade    |   55 -
 .../frontend/views/configuration/caches.tpl.pug |   55 +
 .../frontend/views/configuration/clusters.jade  |   68 -
 .../views/configuration/clusters.tpl.pug        |   68 +
 .../views/configuration/domains-import.jade     |  170 --
 .../views/configuration/domains-import.tpl.pug  |  170 ++
 .../frontend/views/configuration/domains.jade   |   66 -
 .../views/configuration/domains.tpl.pug         |   66 +
 .../frontend/views/configuration/igfs.jade      |   51 -
 .../frontend/views/configuration/igfs.tpl.pug   |   51 +
 .../frontend/views/configuration/sidebar.jade   |   29 -
 .../views/configuration/sidebar.tpl.pug         |   29 +
 .../summary-project-structure.jade              |   27 -
 .../summary-project-structure.tpl.pug           |   28 +
 .../views/configuration/summary-tabs.jade       |   25 -
 .../views/configuration/summary-tabs.pug        |   25 +
 .../frontend/views/configuration/summary.jade   |   90 -
 .../views/configuration/summary.tpl.pug         |   90 +
 .../frontend/views/includes/footer.jade         |   23 -
 .../frontend/views/includes/footer.pug          |   23 +
 .../frontend/views/includes/header.jade         |   52 -
 .../frontend/views/includes/header.pug          |   52 +
 modules/web-console/frontend/views/index.jade   |   47 -
 modules/web-console/frontend/views/index.pug    |   47 +
 modules/web-console/frontend/views/reset.jade   |   48 -
 .../web-console/frontend/views/reset.tpl.pug    |   48 +
 .../frontend/views/settings/admin.jade          |   51 -
 .../frontend/views/settings/admin.tpl.pug       |   25 +
 .../frontend/views/settings/profile.jade        |   76 -
 .../frontend/views/settings/profile.tpl.pug     |   76 +
 modules/web-console/frontend/views/signin.jade  |  163 --
 .../web-console/frontend/views/signin.tpl.pug   |  163 ++
 .../frontend/views/sql/cache-metadata.jade      |   40 -
 .../frontend/views/sql/cache-metadata.tpl.pug   |   40 +
 .../frontend/views/sql/chart-settings.jade      |   40 -
 .../frontend/views/sql/chart-settings.tpl.pug   |   40 +
 .../frontend/views/sql/notebook-new.jade        |   33 -
 .../frontend/views/sql/notebook-new.tpl.pug     |   33 +
 .../frontend/views/sql/paragraph-rate.jade      |   31 -
 .../frontend/views/sql/paragraph-rate.tpl.pug   |   31 +
 modules/web-console/frontend/views/sql/sql.jade |  278 ---
 .../web-console/frontend/views/sql/sql.tpl.pug  |  278 +++
 .../views/templates/agent-download.jade         |   50 -
 .../views/templates/agent-download.tpl.pug      |   50 +
 .../frontend/views/templates/alert.jade         |   21 -
 .../frontend/views/templates/alert.tpl.pug      |   21 +
 .../frontend/views/templates/batch-confirm.jade |   34 -
 .../views/templates/batch-confirm.tpl.pug       |   34 +
 .../frontend/views/templates/clone.jade         |   39 -
 .../frontend/views/templates/clone.tpl.pug      |   39 +
 .../frontend/views/templates/confirm.jade       |   33 -
 .../frontend/views/templates/confirm.tpl.pug    |   33 +
 .../frontend/views/templates/demo-info.jade     |   47 -
 .../frontend/views/templates/demo-info.tpl.pug  |   47 +
 .../frontend/views/templates/dropdown.jade      |   24 -
 .../frontend/views/templates/dropdown.tpl.pug   |   24 +
 .../views/templates/getting-started.jade        |   34 -
 .../views/templates/getting-started.tpl.pug     |   34 +
 .../frontend/views/templates/message.jade       |   28 -
 .../frontend/views/templates/message.tpl.pug    |   28 +
 .../frontend/views/templates/pagination.jade    |   32 -
 .../frontend/views/templates/select.jade        |   26 -
 .../frontend/views/templates/select.tpl.pug     |   26 +
 .../views/templates/validation-error.jade       |   25 -
 .../views/templates/validation-error.tpl.pug    |   25 +
 modules/web-console/web-agent/README.txt        |    2 +-
 .../web-agent/bin/ignite-web-agent.bat          |    4 +-
 .../web-agent/bin/ignite-web-agent.sh           |    2 +
 .../ignite/console/agent/AgentLauncher.java     |  259 ++-
 .../apache/ignite/console/agent/AgentUtils.java |   80 +
 .../console/agent/handlers/AbstractHandler.java |  110 --
 .../agent/handlers/AbstractListener.java        |  104 ++
 .../console/agent/handlers/DatabaseHandler.java |  298 ----
 .../agent/handlers/DatabaseListener.java        |  316 ++++
 .../console/agent/handlers/RestHandler.java     |  276 ---
 .../console/agent/handlers/RestListener.java    |  287 +++
 .../ignite/console/demo/AgentClusterDemo.java   |  472 +----
 .../ignite/console/demo/AgentDemoUtils.java     |   79 +
 .../demo/service/DemoCachesLoadService.java     |  482 +++++
 .../service/DemoRandomCacheLoadService.java     |  120 ++
 .../service/DemoServiceClusterSingleton.java    |   41 +
 .../demo/service/DemoServiceKeyAffinity.java    |   41 +
 .../service/DemoServiceMultipleInstances.java   |   41 +
 .../demo/service/DemoServiceNodeSingleton.java  |   41 +
 .../ignite/cache/websession/WebSessionV2.java   |    2 +-
 .../internal/websession/WebSessionSelfTest.java |    6 +-
 modules/yardstick/DEVNOTES-standalone.txt       |   16 +
 modules/yardstick/DEVNOTES.txt                  |   20 +
 modules/yardstick/README.txt                    |  140 +-
 .../config/benchmark-atomic-win.properties      |    2 +-
 .../config/benchmark-atomic.properties          |   35 +-
 .../config/benchmark-bin-identity.properties    |   16 +-
 .../config/benchmark-cache-load-win.properties  |    2 +-
 .../config/benchmark-cache-load.properties      |    4 +-
 .../config/benchmark-client-mode.properties     |   68 +-
 .../config/benchmark-compute-win.properties     |    2 +-
 .../config/benchmark-compute.properties         |   30 +-
 .../config/benchmark-failover.properties        |    2 +-
 .../yardstick/config/benchmark-full.properties  |   62 +-
 .../config/benchmark-multicast.properties       |  107 +-
 .../config/benchmark-put-indexed-val.properties |   23 +-
 .../benchmark-query-put-separated.properties    |    3 +-
 .../config/benchmark-query-win.properties       |    2 +-
 .../yardstick/config/benchmark-query.properties |   33 +-
 .../config/benchmark-remote-sample.properties   |   80 +
 .../config/benchmark-remote.properties          |  119 ++
 .../config/benchmark-sample.properties          |   80 +
 .../config/benchmark-sql-dml.properties         |   36 +-
 .../yardstick/config/benchmark-store.properties |    3 +-
 .../config/benchmark-tx-win.properties          |    2 +-
 .../yardstick/config/benchmark-tx.properties    |   33 +-
 .../yardstick/config/benchmark-win.properties   |    2 +-
 modules/yardstick/config/benchmark.properties   |   76 +-
 modules/yardstick/config/ignite-base-config.xml |   25 +
 .../yardstick/config/ignite-remote-config.xml   |   47 +
 .../test-max-int-values-offheap.properties      |    3 +-
 .../test-max-int-values-onheap.properties       |    3 +-
 .../config/test-max-int-values-swap.properties  |    3 +-
 modules/yardstick/pom-standalone.xml            |  209 +++
 modules/yardstick/pom.xml                       |   14 +-
 .../yardstick/IgniteBenchmarkArguments.java     |   28 +-
 .../org/apache/ignite/yardstick/IgniteNode.java |    2 +-
 .../cache/IgniteGetAllOffHeapBenchmark.java     |   30 +
 .../yardstick/cache/IgniteGetBenchmark.java     |   30 +
 .../cache/IgnitePutAllOffHeapBenchmark.java     |   30 +
 .../cache/IgnitePutAllTxOffHeapBenchmark.java   |   30 +
 .../IgnitePutOffHeapIndexedValue8Benchmark.java |   30 +
 .../cache/IgnitePutRemoveBenchmark.java         |   42 +
 .../cache/IgnitePutRemoveTxBenchmark.java       |   30 +
 .../cache/IgnitePutValue8Benchmark.java         |   42 +
 .../IgniteCacheRandomOperationBenchmark.java    |   49 +
 .../apache/ignite/yarn/ApplicationMaster.java   |    4 +-
 .../org/apache/ignite/yarn/IgniteProvider.java  |    4 +-
 modules/zeromq/README.txt                       |   37 +
 modules/zeromq/licenses/apache-2.0.txt          |  202 +++
 modules/zeromq/pom.xml                          |   75 +
 .../stream/zeromq/IgniteZeroMqStreamer.java     |  146 ++
 .../ignite/stream/zeromq/ZeroMqTypeSocket.java  |   56 +
 .../ignite/stream/zeromq/package-info.java      |   21 +
 .../stream/zeromq/IgniteZeroMqStreamerTest.java |  235 +++
 .../zeromq/IgniteZeroMqStreamerTestSuite.java   |   37 +
 .../ZeroMqStringSingleTupleExtractor.java       |   46 +
 .../ignite/stream/zeromq/package-info.java      |   21 +
 .../tcp/ipfinder/zk/ZookeeperIpFinderTest.java  |    2 +-
 parent/pom.xml                                  |   10 +-
 pom.xml                                         |  101 +-
 1168 files changed, 42843 insertions(+), 18852 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcMetadataSelfTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/clients/src/test/java/org/apache/ignite/jdbc/JdbcMetadataSelfTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/codegen/src/main/java/org/apache/ignite/codegen/MessageCodeGenerator.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/Ignite.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java
----------------------------------------------------------------------
diff --cc modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java
index 504b589,47a66fe..9318790
--- a/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java
@@@ -279,13 -283,9 +283,16 @@@ public final class IgniteSystemProperti
      /** Maximum size for atomic cache queue delete history (default is 200 000 entries per partition). */
      public static final String IGNITE_ATOMIC_CACHE_DELETE_HISTORY_SIZE = "IGNITE_ATOMIC_CACHE_DELETE_HISTORY_SIZE";
  
 +    /** Maximum amount of concurrent updates per system thread in atomic caches in case of PRIMARY_SYNC or FULL_ASYNC
 +     * write synchronization mode. If this limit is exceeded then update will be performed with FULL_SYNC
 +     * synchronization mode. If value is {@code 0} then limit is unbounded.
 +     */
 +    public static final String IGNITE_ATOMIC_CACHE_MAX_CONCURRENT_DHT_UPDATES =
 +        "IGNITE_ATOMIC_CACHE_MAX_CONCURRENT_DHT_UPDATES";
 +
+     /** Ttl of removed cache entries (ms). */
+     public static final String IGNITE_CACHE_REMOVED_ENTRIES_TTL = "IGNITE_CACHE_REMOVED_ENTRIES_TTL";
+ 
      /**
       * Comma separated list of addresses in format "10.100.22.100:45000,10.100.22.101:45000".
       * Makes sense only for {@link org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder}.
@@@ -539,13 -544,15 +560,22 @@@
       */
      public static final String IGNITE_UNWRAP_BINARY_FOR_INDEXING_SPI = "IGNITE_UNWRAP_BINARY_FOR_INDEXING_SPI";
  
 +    /**
 +     * System property to specify maximum payload size in bytes for {@code H2TreeIndex}.
 +     * <p>
 +     * Defaults to {@code 0}, meaning that inline index store is disabled.
 +     */
 +    public static final String IGNITE_MAX_INDEX_PAYLOAD_SIZE = "IGNITE_MAX_INDEX_PAYLOAD_SIZE";
 +
+     /** Returns true for system properties only avoiding sending sensitive information. */
+     private static final IgnitePredicate<Map.Entry<String, String>> PROPS_FILTER = new IgnitePredicate<Map.Entry<String, String>>() {
+         @Override public boolean apply(final Map.Entry<String, String> entry) {
+             final String key = entry.getKey();
+ 
+             return key.startsWith("java.") || key.startsWith("os.") || key.startsWith("user.");
+         }
+     };
+ 
      /**
       * Enforces singleton.
       */

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/cache/store/jdbc/CacheAbstractJdbcStore.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
----------------------------------------------------------------------
diff --cc modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
index c41be0c2,e160ba9..20ec5e6
--- a/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
@@@ -221,9 -223,9 +221,12 @@@ public class CacheConfiguration<K, V> e
      /** Default threshold for concurrent loading of keys from {@link CacheStore}. */
      public static final int DFLT_CONCURRENT_LOAD_ALL_THRESHOLD = 5;
  
 +    /** Default partition loss policy. */
 +    public static final PartitionLossPolicy DFLT_PARTITION_LOSS_POLICY = PartitionLossPolicy.IGNORE;
 +
+     /** Default query parallelism. */
+     public static final int DFLT_QUERY_PARALLELISM = 1;
+ 
      /** Cache name. */
      private String name;
  
@@@ -405,9 -413,9 +408,12 @@@
      /** Query entities. */
      private Collection<QueryEntity> qryEntities;
  
 +    /** Partition loss policy. */
 +    private PartitionLossPolicy partitionLossPolicy = DFLT_PARTITION_LOSS_POLICY;
 +
+     /** */
+     private int qryParallelism = DFLT_QUERY_PARALLELISM;
+ 
      /** Empty constructor (all values are initialized to their defaults). */
      public CacheConfiguration() {
          /* No-op. */

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/internal/GridEventConsumeHandler.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContext.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContextImpl.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/internal/GridMessageListenHandler.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/internal/GridTopic.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
----------------------------------------------------------------------
diff --cc modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
index a6d9011,cdbe2e3..05002a7
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
@@@ -941,15 -938,17 +949,21 @@@ public class IgniteKernal implements Ig
              // Suggest configuration optimizations.
              suggestOptimizations(cfg);
  
+             // Suggest JVM optimizations.
+             ctx.performance().addAll(JvmConfigurationSuggestions.getSuggestions());
+ 
+             // Suggest Operation System optimizations.
+             ctx.performance().addAll(OsConfigurationSuggestions.getSuggestions());
+ 
              // Notify discovery manager the first to make sure that topology is discovered.
 -            ctx.discovery().onKernalStart();
 +            ctx.discovery().onKernalStart(activeOnStart);
  
              // Notify IO manager the second so further components can send and receive messages.
 -            ctx.io().onKernalStart();
 +            ctx.io().onKernalStart(activeOnStart);
 +
 +            // Start plugins.
 +            for (PluginProvider provider : ctx.plugins().allProviders())
 +                provider.onIgniteStart();
  
              // Callbacks.
              for (GridComponent comp : ctx) {

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/internal/MarshallerContextImpl.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/internal/binary/BinaryContext.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/internal/binary/BinaryEnumObjectImpl.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/internal/managers/GridManagerAdapter.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/internal/managers/communication/GridIoManager.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java
----------------------------------------------------------------------
diff --cc modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java
index 7129896,db9638d..239e0a7
--- a/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java
@@@ -98,9 -94,7 +94,8 @@@ import org.apache.ignite.internal.util.
  import org.apache.ignite.internal.util.typedef.internal.U;
  import org.apache.ignite.internal.util.worker.GridWorker;
  import org.apache.ignite.lang.IgniteFuture;
 +import org.apache.ignite.lang.IgniteInClosure;
  import org.apache.ignite.lang.IgnitePredicate;
- import org.apache.ignite.lang.IgniteProductVersion;
  import org.apache.ignite.lang.IgniteUuid;
  import org.apache.ignite.plugin.security.SecurityCredentials;
  import org.apache.ignite.plugin.segmentation.SegmentationPolicy;

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/internal/managers/eventstorage/GridEventStorageManager.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheAffinitySharedManager.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheEvictableEntryImpl.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/91210eb2/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheMetricsImpl.java
----------------------------------------------------------------------
diff --cc modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheMetricsImpl.java
index 60d42ea,753cca1..1613af7
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheMetricsImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheMetricsImpl.java
@@@ -215,9 -222,9 +215,9 @@@ public class CacheMetricsImpl implement
      /** {@inheritDoc} */
      @Override public long getOffHeapPrimaryEntriesCount() {
          try {
 -            return cctx.swap().offheapEntriesCount(true, false, cctx.affinity().affinityTopologyVersion());
 +            return cctx.offheap().entriesCount(true, false, cctx.affinity().affinityTopologyVersion());
          }
-         catch (IgniteCheckedException e) {
+         catch (IgniteCheckedException ignored) {
              return 0;
          }
      }
@@@ -225,9 -232,9 +225,9 @@@
      /** {@inheritDoc} */
      @Override public long getOffHeapBackupEntriesCount() {
          try {
 -            return cctx.swap().offheapEntriesCount(false, true, cctx.affinity().affinityTopologyVersion());
 +            return cctx.offheap().entriesCount(false, true, cctx.affinity().affinityTopologyVersion());
          }
-         catch (IgniteCheckedException e) {
+         catch (IgniteCheckedException ignored) {
              return 0;
          }
      }