You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by sb...@apache.org on 2016/02/19 17:18:57 UTC

[48/50] [abbrv] ignite git commit: ignite-961 Master branch merged into ignite-961 branch.

ignite-961 Master branch merged into ignite-961 branch.


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

Branch: refs/heads/ignite-961
Commit: 1367eb92aea957fa4e1342ea300040c21bf52941
Parents: 5ee7d14 cfffa2c
Author: agura <ag...@gridgain.com>
Authored: Mon Feb 15 17:11:31 2016 +0300
Committer: agura <ag...@gridgain.com>
Committed: Mon Feb 15 17:11:31 2016 +0300

----------------------------------------------------------------------
 .gitignore                                      |    4 +
 DEVNOTES.txt                                    |    4 +-
 examples/pom.xml                                |    2 +-
 examples/schema-import/pom.xml                  |    2 +-
 .../examples/datagrid/CacheAffinityExample.java |    8 +-
 .../java8/datagrid/CacheAffinityExample.java    |    6 +-
 modules/aop/pom.xml                             |    2 +-
 modules/apache-license-gen/pom.xml              |    2 +-
 modules/aws/pom.xml                             |    2 +-
 modules/benchmarks/pom.xml                      |  140 ++
 .../benchmarks/jmh/JmhAbstractBenchmark.java    |  150 ++
 .../jmh/cache/JmhCacheAbstractBenchmark.java    |  184 +++
 .../benchmarks/jmh/cache/JmhCacheBenchmark.java |  145 ++
 .../jmh/runner/JmhIdeBenchmarkRunner.java       |  236 +++
 .../internal/benchmarks/model/IntValue.java     |   91 ++
 modules/camel/pom.xml                           |    2 +-
 modules/clients/pom.xml                         |    2 +-
 .../internal/client/ClientGetAffinityTask.java  |    4 +-
 modules/cloud/pom.xml                           |    2 +-
 modules/codegen/pom.xml                         |    2 +-
 modules/core/pom.xml                            |    2 +-
 .../java/org/apache/ignite/IgniteCache.java     |   45 +-
 .../java/org/apache/ignite/IgniteCluster.java   |    7 +-
 .../apache/ignite/IgniteSystemProperties.java   |   12 +-
 .../org/apache/ignite/IgniteTransactions.java   |    4 +-
 .../ignite/binary/BinaryBasicIdMapper.java      |  167 ++
 .../ignite/binary/BinaryBasicNameMapper.java    |  141 ++
 .../apache/ignite/binary/BinaryIdMapper.java    |   19 +-
 .../apache/ignite/binary/BinaryNameMapper.java  |   47 +
 .../ignite/binary/BinaryObjectBuilder.java      |    8 +-
 .../ignite/binary/BinaryTypeConfiguration.java  |   23 +-
 .../org/apache/ignite/cache/CacheEntry.java     |    9 +-
 .../apache/ignite/cache/CacheInterceptor.java   |    5 +
 .../apache/ignite/cache/CacheMemoryMode.java    |    2 +
 .../apache/ignite/cache/affinity/Affinity.java  |   24 +-
 .../configuration/BinaryConfiguration.java      |   28 +
 .../configuration/CacheConfiguration.java       |    2 +-
 .../configuration/IgniteConfiguration.java      |    8 +-
 .../apache/ignite/internal/GridComponent.java   |    5 +-
 .../internal/GridEventConsumeHandler.java       |    3 +-
 .../internal/GridMessageListenHandler.java      |   22 +-
 .../ignite/internal/GridUpdateNotifier.java     |  454 ------
 .../apache/ignite/internal/IgniteKernal.java    |  235 ++-
 .../ignite/internal/IgniteNodeAttributes.java   |    3 +
 .../ignite/internal/IgniteVersionUtils.java     |    4 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |    7 +-
 .../ignite/internal/MarshallerContextImpl.java  |   86 +-
 .../internal/binary/BinaryClassDescriptor.java  |   86 +-
 .../ignite/internal/binary/BinaryContext.java   |  347 ++--
 .../internal/binary/BinaryEnumObjectImpl.java   |   16 +-
 .../internal/binary/BinaryFieldAccessor.java    |   45 +-
 .../internal/binary/BinaryInternalIdMapper.java |  161 --
 .../internal/binary/BinaryInternalMapper.java   |  131 ++
 .../internal/binary/BinaryMarshaller.java       |    5 +-
 .../binary/BinaryMetadataCollector.java         |   22 +-
 .../binary/BinaryObjectOffheapImpl.java         |   34 +-
 .../internal/binary/BinaryPrimitives.java       |  117 +-
 .../internal/binary/BinaryReaderExImpl.java     |   22 +-
 .../ignite/internal/binary/BinaryUtils.java     |  130 +-
 .../ignite/internal/binary/BinaryWriteMode.java |    3 +
 .../internal/binary/BinaryWriterExImpl.java     |   64 +-
 .../internal/binary/GridBinaryMarshaller.java   |   31 +-
 .../binary/builder/BinaryBuilderSerializer.java |   32 +-
 .../binary/builder/BinaryObjectBuilderImpl.java |   14 +-
 .../binary/builder/BinaryValueWithType.java     |    3 +-
 .../streams/BinaryAbstractInputStream.java      |   53 +-
 .../streams/BinaryAbstractOutputStream.java     |   90 +-
 .../binary/streams/BinaryAbstractStream.java    |   34 -
 .../binary/streams/BinaryHeapInputStream.java   |   43 +-
 .../binary/streams/BinaryHeapOutputStream.java  |   86 +-
 .../streams/BinaryMemoryAllocatorChunk.java     |    9 +-
 .../streams/BinaryOffheapInputStream.java       |   42 +-
 .../streams/BinaryOffheapOutputStream.java      |   94 +-
 .../internal/direct/DirectMessageReader.java    |   11 +
 .../internal/direct/DirectMessageWriter.java    |   18 +
 .../direct/state/DirectMessageState.java        |   10 +
 .../stream/v1/DirectByteBufferStreamImplV1.java |  116 +-
 .../stream/v2/DirectByteBufferStreamImplV2.java |  361 ++++-
 .../ignite/internal/jdbc/JdbcConnection.java    |   14 +-
 .../managers/discovery/CustomEventListener.java |    4 +-
 .../discovery/DiscoveryCustomMessage.java       |    9 -
 .../discovery/GridDiscoveryManager.java         |   61 +-
 .../affinity/GridAffinityAssignment.java        |   36 +-
 .../affinity/GridAffinityAssignmentCache.java   |    2 +-
 .../affinity/GridAffinityProcessor.java         |   60 +-
 .../processors/cache/CacheEntryImplEx.java      |   14 +-
 .../cache/CacheEntrySerializablePredicate.java  |    3 +-
 .../cache/CacheEvictableEntryImpl.java          |    4 +-
 .../cache/CacheInvokeDirectResult.java          |    4 +-
 .../processors/cache/CacheLazyEntry.java        |    3 +
 .../processors/cache/CacheMetricsSnapshot.java  |    4 +-
 .../processors/cache/CacheObjectContext.java    |   91 +-
 .../processors/cache/CacheOperationContext.java |   43 +-
 .../cache/DynamicCacheChangeBatch.java          |    5 -
 .../processors/cache/GridCacheAdapter.java      |  553 +++++--
 .../cache/GridCacheAffinityManager.java         |   77 +-
 .../cache/GridCacheClearAllRunnable.java        |    2 +-
 .../processors/cache/GridCacheContext.java      |   70 +-
 .../processors/cache/GridCacheEntryEx.java      |   11 +-
 .../cache/GridCacheEvictionManager.java         |    7 +-
 .../processors/cache/GridCacheIoManager.java    |   23 +
 .../processors/cache/GridCacheMapEntry.java     |  232 +--
 .../processors/cache/GridCacheMvccManager.java  |   41 +-
 .../cache/GridCacheOffheapSwapEntry.java        |   24 +-
 .../processors/cache/GridCachePreloader.java    |    6 +
 .../cache/GridCachePreloaderAdapter.java        |    5 +
 .../processors/cache/GridCacheProcessor.java    |  169 +-
 .../processors/cache/GridCacheProxyImpl.java    |   62 +-
 .../processors/cache/GridCacheReturn.java       |    2 +
 .../cache/GridCacheSwapEntryImpl.java           |   61 +-
 .../processors/cache/GridCacheSwapManager.java  |   46 +-
 .../cache/GridCacheUpdateAtomicResult.java      |    4 +-
 .../processors/cache/GridCacheUtils.java        |   57 +-
 .../processors/cache/IgniteCacheProxy.java      |   96 +-
 .../processors/cache/IgniteInternalCache.java   |   85 +
 .../cache/affinity/GridCacheAffinityImpl.java   |   48 +-
 .../binary/CacheObjectBinaryProcessorImpl.java  |  165 +-
 .../distributed/GridCacheTxRecoveryFuture.java  |    2 +-
 .../GridDistributedLockResponse.java            |    2 +-
 .../GridDistributedTxFinishRequest.java         |   11 +-
 .../GridDistributedTxPrepareRequest.java        |    2 +-
 .../GridDistributedTxPrepareResponse.java       |    4 +-
 .../dht/CacheDistributedGetFutureAdapter.java   |   45 +-
 .../dht/GridClientPartitionTopology.java        |    7 +
 .../dht/GridDhtAffinityAssignmentResponse.java  |    4 +-
 .../distributed/dht/GridDhtCacheAdapter.java    |   79 +-
 .../distributed/dht/GridDhtEmbeddedFuture.java  |   13 +-
 .../cache/distributed/dht/GridDhtGetFuture.java |  182 ++-
 .../distributed/dht/GridDhtGetSingleFuture.java |  476 ++++++
 .../distributed/dht/GridDhtLocalPartition.java  |   76 +-
 .../distributed/dht/GridDhtLockFuture.java      |   46 +-
 .../distributed/dht/GridDhtLockRequest.java     |    2 +-
 .../distributed/dht/GridDhtPartitionState.java  |    2 +-
 .../dht/GridDhtPartitionTopology.java           |    5 +
 .../dht/GridDhtPartitionTopologyImpl.java       |   52 +-
 .../distributed/dht/GridDhtTxFinishFuture.java  |    2 +-
 .../distributed/dht/GridDhtTxFinishRequest.java |   90 +-
 .../dht/GridDhtTxFinishResponse.java            |    4 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |    1 +
 .../distributed/dht/GridDhtTxPrepareFuture.java |   44 +-
 .../dht/GridDhtTxPrepareRequest.java            |    2 +-
 .../dht/GridPartitionedGetFuture.java           |  257 +--
 .../dht/GridPartitionedSingleGetFuture.java     |  244 +--
 .../dht/atomic/GridDhtAtomicCache.java          |  317 +++-
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |   87 +-
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |   59 +-
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |    6 +-
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |   10 +-
 .../dht/atomic/GridNearAtomicUpdateRequest.java |   44 +-
 .../atomic/GridNearAtomicUpdateResponse.java    |    4 +-
 .../dht/colocated/GridDhtColocatedCache.java    |   82 +-
 .../colocated/GridDhtColocatedLockFuture.java   |    6 +-
 .../dht/preloader/GridDhtForceKeysResponse.java |    6 +-
 .../GridDhtPartitionDemandMessage.java          |    6 +-
 .../dht/preloader/GridDhtPartitionDemander.java |   15 +-
 .../GridDhtPartitionSupplyMessageV2.java        |    6 +-
 .../GridDhtPartitionsExchangeFuture.java        |   14 +-
 .../preloader/GridDhtPartitionsFullMessage.java |    2 +-
 .../GridDhtPartitionsSingleMessage.java         |    4 +-
 .../dht/preloader/GridDhtPreloader.java         |   16 +
 .../distributed/near/GridNearAtomicCache.java   |    6 +-
 .../distributed/near/GridNearCacheAdapter.java  |    6 +-
 .../distributed/near/GridNearCacheEntry.java    |    3 +-
 .../distributed/near/GridNearGetFuture.java     |  284 ++--
 .../distributed/near/GridNearGetResponse.java   |    4 +-
 .../distributed/near/GridNearLockFuture.java    |    2 +-
 ...arOptimisticSerializableTxPrepareFuture.java |   53 +-
 .../near/GridNearOptimisticTxPrepareFuture.java |    6 +-
 ...ridNearOptimisticTxPrepareFutureAdapter.java |    6 +-
 .../GridNearPessimisticTxPrepareFuture.java     |   10 +-
 .../near/GridNearSingleGetResponse.java         |    2 +-
 .../near/GridNearTransactionalCache.java        |    9 +-
 .../near/GridNearTxFinishFuture.java            |  503 ++++--
 .../near/GridNearTxFinishRequest.java           |    5 +
 .../near/GridNearTxFinishResponse.java          |    4 +-
 .../cache/distributed/near/GridNearTxLocal.java |   69 +-
 .../near/GridNearTxPrepareResponse.java         |    4 +-
 .../processors/cache/dr/GridCacheDrInfo.java    |   49 +-
 .../local/atomic/GridLocalAtomicCache.java      |  106 +-
 .../cache/query/GridCacheQueryManager.java      |   30 +-
 .../cache/query/GridCacheQueryRequest.java      |   16 +-
 .../cache/query/GridCacheQueryResponse.java     |   18 +-
 .../continuous/CacheContinuousQueryHandler.java |   30 +-
 .../CacheContinuousQueryListener.java           |    2 +-
 .../continuous/CacheContinuousQueryManager.java |  120 +-
 .../cache/transactions/IgniteInternalTx.java    |    6 +
 .../cache/transactions/IgniteTxAdapter.java     |   23 +-
 .../cache/transactions/IgniteTxEntry.java       |   43 +-
 .../cache/transactions/IgniteTxHandler.java     |   26 +-
 .../transactions/IgniteTxLocalAdapter.java      |  283 +++-
 .../cache/transactions/IgniteTxLocalEx.java     |    3 +-
 .../cache/transactions/IgniteTxManager.java     |   42 +-
 .../cache/version/GridCacheVersionManager.java  |   23 +-
 .../IgniteCacheObjectProcessorImpl.java         |    9 +-
 .../processors/cluster/ClusterProcessor.java    |  193 ++-
 .../processors/cluster/GridUpdateNotifier.java  |  457 ++++++
 .../continuous/AbstractContinuousMessage.java   |   10 +-
 .../continuous/GridContinuousHandler.java       |    4 +-
 .../continuous/GridContinuousProcessor.java     |   86 +-
 .../datastreamer/DataStreamerRequest.java       |    1 +
 .../datastructures/DataStructuresProcessor.java |   11 +-
 .../GridCacheAtomicReferenceImpl.java           |   68 +-
 .../processors/igfs/IgfsAckMessage.java         |    4 +-
 .../internal/processors/igfs/IgfsProcessor.java |   17 +-
 .../platform/PlatformAbstractTarget.java        |   28 +-
 .../processors/platform/PlatformIgnition.java   |    6 +-
 .../platform/PlatformNoopProcessor.java         |   30 +
 .../processors/platform/PlatformProcessor.java  |   53 +
 .../platform/PlatformProcessorImpl.java         |   57 +-
 .../platform/cache/PlatformCache.java           |   22 +-
 .../callback/PlatformCallbackUtils.java         |    1 -
 .../platform/compute/PlatformCompute.java       |  132 +-
 .../cpp/PlatformCppConfigurationClosure.java    |   32 +
 .../datastructures/PlatformAtomicReference.java |  141 ++
 .../datastructures/PlatformAtomicSequence.java  |  122 ++
 .../dotnet/PlatformDotNetCacheStore.java        |   72 +-
 .../PlatformDotNetConfigurationClosure.java     |   80 +-
 .../platform/events/PlatformEvents.java         |   16 +-
 .../platform/memory/PlatformAbstractMemory.java |    6 +-
 .../PlatformBigEndianOutputStreamImpl.java      |   14 +-
 .../memory/PlatformInputStreamImpl.java         |   53 +-
 .../platform/memory/PlatformMemoryUtils.java    |  108 +-
 .../memory/PlatformOutputStreamImpl.java        |   58 +-
 .../platform/messaging/PlatformMessaging.java   |    7 +-
 .../platform/services/PlatformServices.java     |   14 +-
 .../utils/PlatformConfigurationUtils.java       |  621 ++++++++
 .../platform/utils/PlatformUtils.java           |   52 +-
 .../processors/query/GridQueryProcessor.java    |    7 +-
 .../processors/rest/GridRestProcessor.java      |   10 +
 .../handlers/cache/GridCacheCommandHandler.java |    6 +-
 .../handlers/log/GridLogCommandHandler.java     |  171 ++
 .../rest/request/GridRestLogRequest.java        |   10 +-
 .../service/GridServiceProcessor.java           |   17 +-
 .../processors/service/ServiceContextImpl.java  |    4 +-
 .../processors/task/GridTaskProcessor.java      |    2 +-
 .../ignite/internal/util/GridHandleTable.java   |   17 +-
 .../internal/util/GridSpinReadWriteLock.java    |   10 +-
 .../ignite/internal/util/GridStringBuilder.java |   19 +
 .../apache/ignite/internal/util/GridUnsafe.java | 1483 +++++++++++++++++-
 .../ignite/internal/util/IgniteUtils.java       |  119 +-
 .../util/future/GridCompoundFuture.java         |  316 +---
 .../util/future/GridCompoundIdentityFuture.java |    6 +-
 .../internal/util/future/GridFutureAdapter.java |    2 +
 .../internal/util/io/GridUnsafeDataInput.java   |  145 +-
 .../internal/util/io/GridUnsafeDataOutput.java  |  165 +-
 .../internal/util/nio/GridDirectParser.java     |   52 +-
 .../ignite/internal/util/nio/GridNioServer.java |  183 ++-
 .../util/nio/GridSelectorNioSessionImpl.java    |    2 +-
 .../util/nio/SelectedSelectionKeySet.java       |  132 ++
 .../util/offheap/unsafe/GridUnsafeMap.java      |   75 +-
 .../util/offheap/unsafe/GridUnsafeMemory.java   |  106 +-
 .../ignite/internal/visor/cache/VisorCache.java |   75 +-
 .../visor/cache/VisorCacheConfiguration.java    |   31 +-
 .../cache/VisorCacheQueryConfiguration.java     |   31 +-
 .../cache/VisorCacheQueryConfigurationV2.java   |   47 +
 .../cache/VisorCacheStoreConfiguration.java     |   39 +-
 .../cache/VisorCacheStoreConfigurationV2.java   |   48 +
 .../internal/visor/cache/VisorCacheV2.java      |   73 +
 .../visor/node/VisorIgfsConfiguration.java      |   32 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |   21 +-
 .../visor/node/VisorNodeDataCollectorTask.java  |    2 +-
 .../org/apache/ignite/lang/IgniteBiTuple.java   |    6 +-
 .../ignite/lang/IgniteProductVersion.java       |   18 +
 .../optimized/OptimizedClassDescriptor.java     |   59 +-
 .../optimized/OptimizedMarshaller.java          |    5 +-
 .../optimized/OptimizedMarshallerUtils.java     |   47 +-
 .../optimized/OptimizedObjectInputStream.java   |   25 +-
 .../optimized/OptimizedObjectOutputStream.java  |    4 +-
 .../OptimizedObjectStreamRegistry.java          |    4 +-
 .../PlatformDotNetCacheStoreFactoryNative.java  |   58 +
 .../extensions/communication/MessageWriter.java |    9 +-
 .../plugin/security/SecurityCredentials.java    |    4 +-
 .../communication/tcp/TcpCommunicationSpi.java  |    9 +-
 .../ignite/spi/discovery/DiscoverySpi.java      |    2 +
 .../ignite/spi/discovery/tcp/ClientImpl.java    |    6 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |   21 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |    1 -
 .../tcp/ipfinder/TcpDiscoveryIpFinder.java      |   14 +-
 .../ipfinder/jdbc/TcpDiscoveryJdbcIpFinder.java |   48 +-
 .../TcpDiscoveryMulticastIpFinder.java          |   12 +-
 .../TcpDiscoveryCustomEventMessage.java         |    6 +-
 .../apache/ignite/spi/indexing/IndexingSpi.java |    4 +-
 .../ignite/stream/socket/SocketStreamer.java    |    3 +-
 .../resources/META-INF/classnames.properties    |   15 +-
 .../core/src/main/resources/ignite.properties   |    2 +-
 .../java/org/apache/ignite/GridTestIoUtils.java |  117 +-
 .../ignite/internal/GridAffinityMappedTest.java |    8 +-
 .../internal/GridAffinityNoCacheSelfTest.java   |  294 ++++
 .../internal/GridAffinityP2PSelfTest.java       |    8 +-
 .../ignite/internal/GridAffinitySelfTest.java   |   10 +-
 .../internal/GridNodeMetricsLogSelfTest.java    |   98 ++
 .../internal/GridUpdateNotifierSelfTest.java    |  137 --
 ...eClientReconnectContinuousProcessorTest.java |   32 +-
 ...UpdateNotifierPerClusterSettingSelfTest.java |  130 ++
 .../internal/TestRecordingCommunicationSpi.java |  157 ++
 .../binary/BinaryBasicIdMapperSelfTest.java     |   51 +
 .../binary/BinaryBasicNameMapperSelfTest.java   |   50 +
 .../BinaryConfigurationConsistencySelfTest.java |  231 +++
 .../internal/binary/BinaryEnumsSelfTest.java    |   12 +-
 .../binary/BinaryFieldsOffheapSelfTest.java     |   13 +-
 .../BinaryFooterOffsetsOffheapSelfTest.java     |   13 +-
 .../binary/BinaryMarshallerSelfTest.java        |  569 ++++++-
 .../BinaryObjectBuilderAdditionalSelfTest.java  |   95 +-
 ...naryObjectBuilderDefaultMappersSelfTest.java | 1165 ++++++++++++++
 .../binary/BinaryObjectBuilderSelfTest.java     | 1108 -------------
 ...ilderSimpleNameLowerCaseMappersSelfTest.java |   41 +
 .../BinarySimpleNameTestPropertySelfTest.java   |   94 ++
 .../binary/GridBinaryMetaDataSelfTest.java      |  371 -----
 .../binary/GridBinaryWildcardsSelfTest.java     |  338 +++-
 ...aultBinaryMappersBinaryMetaDataSelfTest.java |  389 +++++
 ...CaseBinaryMappersBinaryMetaDataSelfTest.java |   41 +
 .../internal/binary/TestMappedObject.java       |   25 +
 .../mutabletest/GridBinaryTestClasses.java      |    3 +-
 ...BuilderNonCompactDefaultMappersSelfTest.java |   30 +
 .../BinaryObjectBuilderNonCompactSelfTest.java  |   30 -
 ...mpactSimpleNameLowerCaseMappersSelfTest.java |   31 +
 .../AbstractBinaryStreamByteOrderSelfTest.java  |  464 ++++++
 .../BinaryHeapStreamByteOrderSelfTest.java      |   29 +
 .../BinaryOffheapStreamByteOrderSelfTest.java   |   31 +
 ...ByteBufferStreamImplV2ByteOrderSelfTest.java |  244 +++
 .../cache/CacheConfigurationLeakTest.java       |   62 +
 .../cache/CacheGetEntryAbstractTest.java        |  803 ++++++++++
 ...GetEntryOptimisticReadCommittedSeltTest.java |   36 +
 ...etEntryOptimisticRepeatableReadSeltTest.java |   36 +
 ...eGetEntryOptimisticSerializableSeltTest.java |   36 +
 ...etEntryPessimisticReadCommittedSeltTest.java |   36 +
 ...tEntryPessimisticRepeatableReadSeltTest.java |   36 +
 ...GetEntryPessimisticSerializableSeltTest.java |   36 +
 .../cache/CacheReadThroughRestartSelfTest.java  |   43 +-
 .../CacheSerializableTransactionsTest.java      |  142 +-
 ...cheAbstractFullApiMultithreadedSelfTest.java |   13 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |  147 +-
 .../cache/GridCacheAffinityRoutingSelfTest.java |   10 +-
 .../cache/GridCacheConcurrentMapSelfTest.java   |   13 +-
 .../GridCacheConcurrentTxMultiNodeTest.java     |    4 +-
 .../GridCacheConditionalDeploymentSelfTest.java |    4 +-
 ...idCacheConfigurationConsistencySelfTest.java |   58 +-
 .../GridCacheDaemonNodeAbstractSelfTest.java    |   17 +-
 .../GridCacheDeploymentOffHeapSelfTest.java     |    4 +-
 ...ridCacheDeploymentOffHeapValuesSelfTest.java |   41 +
 .../cache/GridCacheDeploymentSelfTest.java      |   11 +-
 .../cache/GridCacheEntryMemorySizeSelfTest.java |    6 +-
 .../GridCacheInterceptorAbstractSelfTest.java   |  172 +-
 .../GridCacheOffHeapValuesEvictionSelfTest.java |  210 +++
 ...hePartitionedProjectionAffinitySelfTest.java |    8 +-
 .../cache/GridCachePutAllFailoverSelfTest.java  |    4 +-
 .../processors/cache/GridCacheStopSelfTest.java |    2 +-
 .../processors/cache/GridCacheTestEntryEx.java  |    5 +-
 .../cache/GridCacheUtilsSelfTest.java           |  136 +-
 .../IgniteCacheEntryListenerAbstractTest.java   |  454 ++++--
 ...cheEntryListenerAtomicOffheapTieredTest.java |   32 +
 ...cheEntryListenerAtomicOffheapValuesTest.java |   32 +
 ...niteCacheEntryListenerExpiredEventsTest.java |  202 +++
 ...teCacheEntryListenerTxOffheapTieredTest.java |   32 +
 ...teCacheEntryListenerTxOffheapValuesTest.java |   32 +
 .../cache/IgniteCacheEntryListenerTxTest.java   |    1 +
 ...IgniteCacheGetCustomCollectionsSelfTest.java |  128 ++
 ...gniteCacheLoadRebalanceEvictionSelfTest.java |  188 +++
 .../cache/IgniteCacheNearLockValueSelfTest.java |   62 +-
 .../cache/IgniteCacheStoreCollectionTest.java   |   12 +
 ...eDynamicCacheStartNoExchangeTimeoutTest.java |    7 +
 .../cache/IgniteDynamicCacheStartSelfTest.java  |   30 +-
 ...niteDynamicCacheStartStopConcurrentTest.java |  119 ++
 ...eMarshallerCacheConcurrentReadWriteTest.java |  189 +++
 .../GridCacheBinaryObjectsAbstractSelfTest.java |   17 +-
 .../GridCacheBinaryStoreAbstractSelfTest.java   |   10 +
 ...naryStoreBinariesDefaultMappersSelfTest.java |   81 +
 .../GridCacheBinaryStoreBinariesSelfTest.java   |   66 -
 ...yStoreBinariesSimpleNameMappersSelfTest.java |   40 +
 .../IgniteClientDataStructuresAbstractTest.java |    3 +
 ...ridCachePartitionNotLoadedEventSelfTest.java |    7 +-
 .../IgniteCacheAtomicNodeRestartTest.java       |    2 +
 ...niteCacheClientNodeChangingTopologyTest.java |    4 +-
 .../distributed/IgniteCacheGetRestartTest.java  |  280 ++++
 .../distributed/IgniteCachePrimarySyncTest.java |  129 ++
 .../IgniteCacheReadFromBackupTest.java          |  427 +++++
 .../IgniteCacheSingleGetMessageTest.java        |   88 +-
 .../IgniteCrossCacheTxStoreSelfTest.java        |    1 +
 .../IgniteTxPreloadAbstractTest.java            |    2 +-
 ...GridCacheDhtEvictionNearReadersSelfTest.java |    2 +-
 .../dht/GridCacheDhtMultiBackupTest.java        |    4 +-
 .../GridCacheDhtPreloadMessageCountTest.java    |   62 +-
 .../dht/GridCacheTxNodeFailureSelfTest.java     |   13 +-
 .../IgniteCacheCommitDelayTxRecoveryTest.java   |  376 +++++
 .../IgniteCachePutRetryAbstractSelfTest.java    |   36 +-
 ...gniteCachePutRetryTransactionalSelfTest.java |   21 +
 .../near/GridCacheGetStoreErrorSelfTest.java    |    9 +-
 .../near/GridCacheNearOnlyTopologySelfTest.java |    4 +-
 .../near/GridCacheNearReadersSelfTest.java      |   19 +-
 .../near/GridCacheNearTxMultiNodeSelfTest.java  |    4 +-
 ...titionedExplicitLockNodeFailureSelfTest.java |    6 +-
 .../GridCachePartitionedNodeRestartTest.java    |    4 +-
 ...ePartitionedOptimisticTxNodeRestartTest.java |    4 +-
 .../GridCacheRebalancingSyncSelfTest.java       |    8 +
 .../GridCacheReplicatedPreloadSelfTest.java     |  221 ++-
 .../RandomEvictionPolicyCacheSizeSelfTest.java  |   79 -
 .../random/RandomEvictionPolicySelfTest.java    |  363 -----
 ...ContinuousQueryFailoverAbstractSelfTest.java |   96 ++
 ...tomicPrimaryWriteOrderOffheapTieredTest.java |   33 +
 ...tinuousQueryFailoverTxOffheapTieredTest.java |   32 +
 .../CacheContinuousQueryLostPartitionTest.java  |  256 +++
 ...acheContinuousQueryRandomOperationsTest.java |  684 ++++++++
 ...ridCacheContinuousQueryAbstractSelfTest.java |   27 +-
 ...eContinuousQueryAtomicOffheapTieredTest.java |   32 +
 ...eContinuousQueryAtomicOffheapValuesTest.java |   32 +
 ...ntinuousQueryPartitionAtomicOneNodeTest.java |   37 +
 ...heContinuousQueryPartitionTxOneNodeTest.java |   37 +
 ...tinuousQueryReplicatedAtomicOneNodeTest.java |   31 +
 ...ontinuousQueryReplicatedOneNodeSelfTest.java |  120 --
 ...eContinuousQueryReplicatedTxOneNodeTest.java |  193 +++
 ...CacheContinuousQueryTxOffheapTieredTest.java |   32 +
 ...CacheContinuousQueryTxOffheapValuesTest.java |   32 +
 ...IgniteCacheContinuousQueryReconnectTest.java |  192 +++
 .../IgniteCacheWriteBehindNoUpdateSelfTest.java |  178 +++
 .../cluster/GridUpdateNotifierSelfTest.java     |  140 ++
 .../continuous/GridEventConsumeSelfTest.java    |    3 +
 .../igfs/IgfsProcessorValidationSelfTest.java   |   27 +
 .../processors/igfs/IgfsStreamsSelfTest.java    |    4 +-
 .../handlers/log/GridLogCommandHandlerTest.java |  190 +++
 .../GridServicePackagePrivateSelfTest.java      |   51 +
 .../IgniteServiceDynamicCachesSelfTest.java     |  183 +++
 .../processors/service/inner/MyService.java     |   30 +
 .../service/inner/MyServiceFactory.java         |   30 +
 .../processors/service/inner/MyServiceImpl.java |   45 +
 ...dUnsafeDataInputOutputByteOrderSelfTest.java |  249 +++
 .../internal/util/nio/GridNioSelfTest.java      |   11 +-
 .../ignite/lang/GridBasicPerformanceTest.java   |   11 +-
 .../apache/ignite/lang/GridTupleSelfTest.java   |   42 +-
 .../ignite/loadtests/dsi/GridDsiClient.java     |    4 +-
 ...namicProxySerializationMultiJvmSelfTest.java |  131 ++
 .../platform/PlatformComputeBroadcastTask.java  |    7 +
 .../platform/PlatformComputeEchoTask.java       |    6 +-
 .../GridSessionCheckpointAbstractSelfTest.java  |    6 +-
 .../tcp/GridCacheDhtLockBackupSelfTest.java     |    4 +-
 ...dTcpCommunicationSpiRecoveryAckSelfTest.java |    1 -
 ...CommunicationRecoveryAckClosureSelfTest.java |   21 +-
 .../tcp/TcpClientDiscoverySpiSelfTest.java      |    2 +-
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java |    9 +-
 .../startup/GridRandomCommandLineLoader.java    |    4 +-
 .../ignite/testframework/GridTestUtils.java     |   34 +-
 .../config/GridTestProperties.java              |    5 +-
 .../testframework/junits/GridAbstractTest.java  |   30 +-
 .../junits/common/GridCommonAbstractTest.java   |   36 +-
 .../multijvm/IgniteCacheProcessProxy.java       |   59 +-
 .../junits/multijvm/IgniteNodeRunner.java       |   16 +-
 .../junits/multijvm/IgniteProcessProxy.java     |   19 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java |    9 +-
 .../testsuites/IgniteBinaryBasicTestSuite.java  |   97 ++
 ...ctsSimpleNameMapperComputeGridTestSuite.java |   38 +
 .../IgniteBinaryObjectsTestSuite.java           |   40 +-
 ...iteBinarySimpleNameMapperBasicTestSuite.java |   38 +
 ...rySimpleNameMapperCacheFullApiTestSuite.java |   39 +
 .../IgniteCacheEvictionSelfTestSuite.java       |    4 -
 .../IgniteCacheRestartTestSuite2.java           |    3 +
 .../ignite/testsuites/IgniteCacheTestSuite.java |   10 +
 .../testsuites/IgniteCacheTestSuite2.java       |    2 +
 .../testsuites/IgniteCacheTestSuite3.java       |    2 +
 .../testsuites/IgniteCacheTestSuite4.java       |   21 +
 .../testsuites/IgniteCacheTestSuite5.java       |    4 +
 .../IgniteCacheTxRecoverySelfTestSuite.java     |    3 +
 .../testsuites/IgniteComputeGridTestSuite.java  |    4 +-
 .../testsuites/IgniteKernalSelfTestSuite.java   |    8 +-
 .../IgniteMarshallerSelfTestSuite.java          |    4 +
 .../testsuites/IgniteRestHandlerTestSuite.java  |    4 +-
 modules/docker/1.5.0.final/Dockerfile           |   40 +
 modules/docker/1.5.0.final/run.sh               |   50 +
 modules/docker/Dockerfile                       |    6 +-
 modules/extdata/p2p/pom.xml                     |    2 +-
 .../p2p/CacheDeploymentAffinityKeyMapper.java   |   35 +
 .../CacheDeploymentAlwaysTruePredicate2.java    |   30 +
 ...oymentCacheEntryEventSerializableFilter.java |   32 +
 .../p2p/CacheDeploymentCacheEntryListener.java  |   31 +
 ...CacheDeploymentCachePluginConfiguration.java |   74 +
 ...heDeploymentStoreSessionListenerFactory.java |   83 +
 .../tests/p2p/CacheDeploymentTestEnumValue.java |   47 +
 .../p2p/CacheDeploymentTestStoreFactory.java    |  113 ++
 .../extdata/uri/modules/uri-dependency/pom.xml  |    2 +-
 modules/extdata/uri/pom.xml                     |    2 +-
 modules/flume/pom.xml                           |    2 +-
 modules/gce/pom.xml                             |    2 +-
 modules/geospatial/pom.xml                      |    2 +-
 modules/hadoop/pom.xml                          |    2 +-
 .../hadoop/fs/BasicHadoopFileSystemFactory.java |   37 +-
 .../fs/CachingHadoopFileSystemFactory.java      |    2 +-
 .../fs/IgniteHadoopIgfsSecondaryFileSystem.java |    6 +-
 .../fs/KerberosHadoopFileSystemFactory.java     |  217 +++
 .../hadoop/fs/v1/IgniteHadoopFileSystem.java    |    7 +-
 .../hadoop/fs/v2/IgniteHadoopFileSystem.java    |    7 +
 .../hadoop/shuffle/HadoopShuffleJob.java        |    5 +-
 .../hadoop/shuffle/HadoopShuffleMessage.java    |   10 +-
 .../shuffle/streams/HadoopDataOutStream.java    |    6 +-
 .../processors/hadoop/v2/HadoopV2Context.java   |    2 +
 .../processors/hadoop/v2/HadoopV2MapTask.java   |   23 +-
 ...KerberosHadoopFileSystemFactorySelfTest.java |  121 ++
 .../HadoopConcurrentHashMultimapSelftest.java   |    6 +-
 .../collections/HadoopSkipListSelfTest.java     |    5 +-
 .../testsuites/IgniteHadoopTestSuite.java       |    3 +
 modules/hibernate/pom.xml                       |    2 +-
 modules/indexing/pom.xml                        |    2 +-
 .../query/h2/opt/GridH2IndexBase.java           |    5 +-
 .../query/h2/opt/GridH2TreeIndex.java           |    2 +-
 .../query/h2/twostep/GridMergeIndex.java        |   32 +-
 .../h2/twostep/GridMergeIndexUnsorted.java      |   19 +-
 .../query/h2/twostep/GridMergeTable.java        |   16 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |    2 +-
 .../cache/CacheQueryBuildValueTest.java         |  144 ++
 .../CacheQueryOffheapEvictDataLostTest.java     |  138 ++
 .../CacheRandomOperationsMultithreadedTest.java |  507 ++++++
 .../cache/IgniteCacheAbstractQuerySelfTest.java |   10 +-
 ...niteCacheP2pUnmarshallingQueryErrorTest.java |   18 +-
 .../near/IgniteCacheQueryNodeFailTest.java      |  148 ++
 .../IgniteBinaryCacheQueryTestSuite.java        |  188 +--
 ...narySimpleNameMapperCacheQueryTestSuite.java |   38 +
 .../IgniteCacheQuerySelfTestSuite.java          |   31 +-
 .../IgniteCacheWithIndexingTestSuite.java       |    2 +
 modules/jcl/pom.xml                             |    2 +-
 modules/jms11/pom.xml                           |    2 +-
 modules/json/pom.xml                            |    2 +-
 .../java/org/apache/ignite/json/IgniteJson.java |    2 +-
 modules/jta/pom.xml                             |    2 +-
 modules/kafka/README.txt                        |  111 +-
 modules/kafka/pom.xml                           |   71 +-
 .../ignite/stream/kafka/KafkaStreamer.java      |    2 +-
 .../kafka/connect/IgniteSinkConnector.java      |   91 ++
 .../kafka/connect/IgniteSinkConstants.java      |   38 +
 .../stream/kafka/connect/IgniteSinkTask.java    |  165 ++
 .../kafka/IgniteKafkaStreamerSelfTestSuite.java |    9 +-
 .../stream/kafka/KafkaEmbeddedBroker.java       |  387 -----
 .../kafka/KafkaIgniteStreamerSelfTest.java      |   13 +-
 .../ignite/stream/kafka/SimplePartitioner.java  |   53 -
 .../ignite/stream/kafka/TestKafkaBroker.java    |  237 +++
 .../kafka/connect/IgniteSinkConnectorTest.java  |  250 +++
 .../kafka/src/test/resources/example-ignite.xml |   71 +
 modules/log4j/pom.xml                           |    2 +-
 modules/log4j2/pom.xml                          |    2 +-
 modules/mesos/pom.xml                           |    2 +-
 modules/mqtt/pom.xml                            |    2 +-
 modules/nodejs/pom.xml                          |    2 +-
 modules/osgi-karaf/pom.xml                      |    2 +-
 .../osgi-karaf/src/main/resources/features.xml  |   12 +-
 modules/osgi-paxlogging/pom.xml                 |    2 +-
 modules/osgi/pom.xml                            |    2 +-
 modules/platforms/cpp/common/configure.ac       |    2 +-
 .../cpp/common/include/ignite/common/exports.h  |   19 +
 .../cpp/common/include/ignite/common/java.h     |   44 +
 .../cpp/common/project/vs/common.vcxproj        |    2 +-
 .../platforms/cpp/common/project/vs/module.def  |   19 +-
 modules/platforms/cpp/common/src/exports.cpp    |   68 +
 modules/platforms/cpp/common/src/java.cpp       |  245 +++
 modules/platforms/cpp/core-test/Makefile.am     |    1 +
 modules/platforms/cpp/core-test/configure.ac    |    2 +-
 .../cpp/core-test/project/vs/core-test.vcxproj  |    1 +
 .../project/vs/core-test.vcxproj.filters        |    3 +
 .../platforms/cpp/core-test/src/cache_test.cpp  |   12 +
 .../cpp/core-test/src/interop_memory_test.cpp   |   95 ++
 modules/platforms/cpp/core/configure.ac         |    2 +-
 .../include/ignite/impl/ignite_environment.h    |   19 +-
 .../cpp/core/src/impl/cache/cache_impl.cpp      |    2 +-
 .../cpp/core/src/impl/ignite_environment.cpp    |   30 +-
 modules/platforms/cpp/examples/configure.ac     |    2 +-
 modules/platforms/cpp/ignite/configure.ac       |    2 +-
 .../Apache.Ignite.Benchmarks.csproj             |    4 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Apache.Ignite.Core.Tests.TestDll.csproj     |    4 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Apache.Ignite.Core.Tests.csproj             |   12 +-
 .../Binary/BinaryBuilderSelfTest.cs             |    8 +-
 .../Binary/BinarySelfTest.cs                    |   41 +
 .../Binary/BinaryStructureTest.cs               |   38 +-
 .../Cache/CacheAbstractTest.cs                  |   93 +-
 .../Cache/CacheAffinityTest.cs                  |    2 +-
 .../Cache/CacheConfigurationTest.cs             |  538 +++++++
 .../Cache/CacheDynamicStartTest.cs              |    4 +-
 .../Cache/CacheTestAsyncWrapper.cs              |    7 +
 .../Query/CacheQueriesCodeConfigurationTest.cs  |  295 ++++
 .../Cache/Query/CacheQueriesTest.cs             |    2 +-
 .../Continuous/ContinuousQueryAbstractTest.cs   |    2 +-
 .../Cache/Store/CacheStoreSessionTest.cs        |    2 +-
 .../Cache/Store/CacheStoreTest.cs               |   23 +-
 .../Compute/CancellationTest.cs                 |  174 ++
 .../Compute/ComputeApiTest.cs                   |    2 +-
 .../Config/Compute/compute-grid2.xml            |   21 +
 .../Config/Compute/compute-grid3.xml            |   31 +-
 .../DataStructures/AtomicReferenceTest.cs       |  239 +++
 .../DataStructures/AtomicSequenceTest.cs        |  131 ++
 .../Dataload/DataStreamerTest.cs                |    4 +-
 .../Apache.Ignite.Core.Tests/ExceptionsTest.cs  |    2 +-
 .../Apache.Ignite.Core.Tests/FutureTest.cs      |    1 +
 .../IgniteConfigurationSectionTest.cs           |   69 +
 .../IgniteConfigurationSerializerTest.cs        |  554 +++++++
 .../IgniteConfigurationTest.cs                  |  367 +++++
 .../Apache.Ignite.Core.Tests/MarshallerTest.cs  |    4 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../SerializationTest.cs                        |    2 +-
 .../Apache.Ignite.Core.Tests/TestRunner.cs      |    5 +-
 .../dotnet/Apache.Ignite.Core.Tests/app.config  |   54 +
 .../Apache.Ignite.Core.csproj                   |   52 +-
 .../Apache.Ignite.Core.ruleset                  |   26 +
 .../Binary/BinaryConfiguration.cs               |   30 +-
 .../Binary/BinaryTypeConfiguration.cs           |    5 +
 .../Binary/BinaryTypeNames.cs                   |   64 +-
 .../Apache.Ignite.Core/Binary/IBinaryObject.cs  |    8 +
 .../Binary/IBinarySerializer.cs                 |    6 +-
 .../Cache/CachePartialUpdateException.cs        |    2 +
 .../Apache.Ignite.Core/Cache/CacheResult.cs     |   41 +-
 .../Configuration/CacheAtomicWriteOrderMode.cs  |   43 +
 .../Cache/Configuration/CacheAtomicityMode.cs   |   54 +
 .../Cache/Configuration/CacheConfiguration.cs   |  601 +++++++
 .../Cache/Configuration/CacheMemoryMode.cs      |   60 +
 .../Cache/Configuration/CacheMode.cs            |   52 +
 .../Cache/Configuration/CacheRebalanceMode.cs   |   51 +
 .../CacheWriteSynchronizationMode.cs            |   45 +
 .../Cache/Configuration/QueryAlias.cs           |   59 +
 .../Cache/Configuration/QueryEntity.cs          |  401 +++++
 .../Cache/Configuration/QueryField.cs           |  109 ++
 .../Cache/Configuration/QueryIndex.cs           |  137 ++
 .../Cache/Configuration/QueryIndexField.cs      |   66 +
 .../Cache/Configuration/QueryIndexType.cs       |   40 +
 .../Configuration/QuerySqlFieldAttribute.cs     |   60 +
 .../Configuration/QueryTextFieldAttribute.cs    |   36 +
 .../Cache/Event/ICacheEntryEventFilter.cs       |    1 +
 .../Cache/Event/ICacheEntryEventListener.cs     |    1 +
 .../dotnet/Apache.Ignite.Core/Cache/ICache.cs   |    6 +
 .../Cache/Query/Continuous/ContinuousQuery.cs   |    2 +-
 .../Apache.Ignite.Core/Cache/Query/QueryBase.cs |    2 +-
 .../Cache/Query/SqlFieldsQuery.cs               |    2 +-
 .../Apache.Ignite.Core/Cache/Query/SqlQuery.cs  |    6 +-
 .../Apache.Ignite.Core/Cache/Query/TextQuery.cs |    7 +-
 .../Cache/Store/CacheStoreAdapter.cs            |    3 +
 .../Apache.Ignite.Core/Common/IFactory.cs       |   34 +
 .../Common/IgniteFutureCancelledException.cs    |    1 +
 .../Compute/ComputeJobAdapter.cs                |    2 +-
 .../Compute/ComputeJobResultPolicy.cs           |    2 -
 .../Compute/ComputeTaskAdapter.cs               |    2 +
 .../Compute/ComputeTaskSplitAdapter.cs          |   17 +-
 .../DataStructures/IAtomicReference.cs          |   64 +
 .../DataStructures/IAtomicSequence.cs           |   69 +
 .../Datastream/StreamTransformer.cs             |    2 +
 .../Datastream/StreamVisitor.cs                 |    2 +
 .../Discovery/IDiscoverySpi.cs                  |   32 +
 .../Discovery/Tcp/ITcpDiscoveryIpFinder.cs      |   34 +
 .../Multicast/TcpDiscoveryMulticastIpFinder.cs  |  135 ++
 .../Tcp/Static/TcpDiscoveryStaticIpFinder.cs    |   86 +
 .../Discovery/Tcp/TcpDiscoveryIpFinderBase.cs   |   78 +
 .../Discovery/Tcp/TcpDiscoverySpi.cs            |  144 ++
 .../Apache.Ignite.Core/Events/CacheEvent.cs     |    8 +-
 .../Events/CacheQueryExecutedEvent.cs           |    4 +-
 .../Events/CacheQueryReadEvent.cs               |    6 +-
 .../Events/CacheRebalancingEvent.cs             |    4 +-
 .../Events/CheckpointEvent.cs                   |    4 +-
 .../Apache.Ignite.Core/Events/DiscoveryEvent.cs |    4 +-
 .../Apache.Ignite.Core/Events/EventBase.cs      |   69 +-
 .../dotnet/Apache.Ignite.Core/IIgnite.cs        |   60 +
 .../Apache.Ignite.Core/IgniteConfiguration.cs   |  347 +++-
 .../IgniteConfigurationSection.cs               |   80 +
 .../IgniteConfigurationSection.xsd              |  281 ++++
 .../dotnet/Apache.Ignite.Core/Ignition.cs       |   69 +-
 .../Apache.Ignite.Core/Impl/Binary/Binary.cs    |   47 +-
 .../Impl/Binary/BinaryEnum.cs                   |    6 +
 .../Impl/Binary/BinaryFullTypeDescriptor.cs     |    2 +-
 .../Impl/Binary/BinaryObject.cs                 |   50 +-
 .../Impl/Binary/BinaryObjectBuilder.cs          |   75 +-
 .../Impl/Binary/BinaryReader.cs                 |    3 +-
 .../Impl/Binary/BinaryReaderExtensions.cs       |   19 +
 .../Impl/Binary/BinaryReflectiveSerializer.cs   |    2 +-
 .../Impl/Binary/BinarySystemHandlers.cs         |    9 +-
 .../Impl/Binary/BinaryUtils.cs                  |  173 +-
 .../Impl/Binary/BinaryWriter.cs                 |    3 +
 .../Impl/Binary/Io/BinaryHeapStream.cs          |    9 +
 .../Apache.Ignite.Core/Impl/Binary/JavaTypes.cs |   92 ++
 .../Impl/Binary/Marshaller.cs                   |   27 +-
 .../Impl/Binary/Metadata/BinaryType.cs          |    2 +
 .../Impl/Binary/SerializableObjectHolder.cs     |   13 +-
 .../Impl/Binary/Structure/BinaryStructure.cs    |    3 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |   51 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheOp.cs    |    3 +-
 .../Impl/Cache/Query/AbstractQueryCursor.cs     |    4 +-
 .../Continuous/ContinuousQueryFilterHolder.cs   |    2 +-
 .../Continuous/ContinuousQueryHandleImpl.cs     |    4 +-
 .../Impl/Cache/Query/FieldsQueryCursor.cs       |    2 +
 .../Impl/Cache/Query/QueryCursor.cs             |    2 +
 .../Impl/Cache/Store/CacheStore.cs              |   29 +-
 .../Impl/Common/BooleanLowerCaseConverter.cs    |   60 +
 .../Impl/Common/CancelledTask.cs                |    3 +
 .../Common/CopyOnWriteConcurrentDictionary.cs   |    1 +
 .../Impl/Common/DelegateConverter.cs            |   11 +-
 .../Apache.Ignite.Core/Impl/Common/Future.cs    |   16 +-
 .../Impl/Common/FutureType.cs                   |   18 +-
 .../Common/IgniteConfigurationXmlSerializer.cs  |  407 +++++
 .../Impl/Common/LoadedAssembliesResolver.cs     |    1 +
 .../Impl/Common/TypeStringConverter.cs          |  115 ++
 .../Closure/ComputeAbstractClosureTask.cs       |    2 +
 .../Compute/Closure/ComputeMultiClosureTask.cs  |    2 +
 .../Closure/ComputeReducingClosureTask.cs       |    2 +
 .../Compute/Closure/ComputeSingleClosureTask.cs |    2 +
 .../Impl/DataStructures/AtomicReference.cs      |   92 ++
 .../Impl/DataStructures/AtomicSequence.cs       |   90 ++
 .../Impl/Datastream/DataStreamerBatch.cs        |    1 +
 .../Impl/Datastream/DataStreamerImpl.cs         |    5 +-
 .../Impl/Events/EventTypeConverter.cs           |  133 ++
 .../Apache.Ignite.Core/Impl/ExceptionUtils.cs   |   56 +-
 .../Apache.Ignite.Core/Impl/Handle/Handle.cs    |    8 +-
 .../Impl/Handle/HandleRegistry.cs               |    1 +
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs    |  104 ++
 .../Impl/IgniteConfigurationEx.cs               |   57 -
 .../Apache.Ignite.Core/Impl/IgniteManager.cs    |    5 +-
 .../Apache.Ignite.Core/Impl/IgniteProxy.cs      |   34 +
 .../Apache.Ignite.Core/Impl/IgniteUtils.cs      |   13 +-
 .../Impl/InteropExceptionHolder.cs              |   11 +-
 .../Memory/PlatformBigEndianMemoryStream.cs     |    8 +
 .../Impl/Memory/PlatformMemory.cs               |    2 +
 .../Impl/Memory/PlatformMemoryManager.cs        |    2 +
 .../Impl/Memory/PlatformMemoryStream.cs         |  322 +++-
 .../Impl/Memory/PlatformRawMemory.cs            |    4 +-
 .../Apache.Ignite.Core/Impl/PlatformTarget.cs   |    3 +-
 .../Impl/Resource/ResourceProcessor.cs          |    2 +-
 .../Impl/Resource/ResourceTypeDescriptor.cs     |    2 +-
 .../Impl/Services/ServiceProxy.cs               |    2 +
 .../Impl/Services/ServiceProxyInvoker.cs        |    1 +
 .../Impl/Transactions/TransactionsImpl.cs       |    4 +-
 .../Impl/Unmanaged/IgniteJniNativeMethods.cs    |   51 +-
 .../Impl/Unmanaged/UnmanagedCallbacks.cs        |    5 +-
 .../Impl/Unmanaged/UnmanagedUtils.cs            |  121 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Services/ServiceInvocationException.cs      |    2 +
 modules/platforms/dotnet/Apache.Ignite.FxCop    |  354 +----
 modules/platforms/dotnet/Apache.Ignite.sln      |    4 +-
 .../Apache.Ignite.sln.TeamCity.DotSettings      |   30 +
 .../dotnet/Apache.Ignite/Apache.Ignite.csproj   |    5 +-
 .../Apache.Ignite/Properties/AssemblyInfo.cs    |    6 +-
 .../Apache.Ignite.Examples.csproj               |    4 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Services/ServicesExample.cs                 |    2 +-
 .../Apache.Ignite.ExamplesDll.csproj            |    4 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 modules/rest-http/pom.xml                       |    2 +-
 modules/scalar-2.10/pom.xml                     |    2 +-
 modules/scalar/pom.xml                          |    2 +-
 modules/schedule/pom.xml                        |    2 +-
 modules/schema-import/pom.xml                   |    2 +-
 modules/slf4j/pom.xml                           |    2 +-
 modules/spark-2.10/pom.xml                      |    2 +-
 modules/spark/pom.xml                           |    2 +-
 .../org/apache/ignite/spark/IgniteContext.scala |   11 +-
 modules/spring/pom.xml                          |    2 +-
 .../ignite/internal/GridFactorySelfTest.java    |    2 +-
 modules/ssh/pom.xml                             |    2 +-
 modules/storm/README.txt                        |   37 +
 modules/storm/licenses/apache-2.0.txt           |  202 +++
 modules/storm/pom.xml                           |  102 ++
 .../ignite/stream/storm/StormStreamer.java      |  304 ++++
 .../ignite/stream/storm/package-info.java       |   22 +
 .../storm/IgniteStormStreamerSelfTestSuite.java |   38 +
 .../storm/StormIgniteStreamerSelfTest.java      |  184 +++
 .../ignite/stream/storm/TestStormSpout.java     |  141 ++
 .../storm/src/test/resources/example-ignite.xml |   71 +
 modules/tools/pom.xml                           |    2 +-
 modules/twitter/pom.xml                         |    2 +-
 modules/urideploy/pom.xml                       |    2 +-
 modules/visor-console-2.10/pom.xml              |    2 +-
 modules/visor-console/pom.xml                   |    2 +-
 .../commands/cache/VisorCacheCommand.scala      |   10 +-
 .../visor/commands/node/VisorNodeCommand.scala  |    1 +
 .../commands/tasks/VisorTasksCommand.scala      |    4 +-
 .../commands/top/VisorTopologyCommand.scala     |    5 +-
 .../scala/org/apache/ignite/visor/visor.scala   |    7 +-
 modules/visor-plugins/pom.xml                   |    2 +-
 modules/web/pom.xml                             |    2 +-
 modules/yardstick/.gitignore                    |    2 +
 .../config/benchmark-multicast.properties       |    7 +
 modules/yardstick/pom.xml                       |    2 +-
 .../org/apache/ignite/yardstick/IgniteNode.java |    3 +
 .../IgniteGetEntriesPutAllTxBenchmark.java      |   73 +
 .../yardstick/cache/IgniteGetTxBenchmark.java   |   30 +
 .../yardstick/cache/IgniteInvokeBenchmark.java  |   65 +
 .../cache/IgniteInvokeTxBenchmark.java          |   30 +
 .../cache/IgnitePutGetEntryBenchmark.java       |   47 +
 .../cache/IgnitePutGetEntryTxBenchmark.java     |   73 +
 modules/yarn/pom.xml                            |    2 +-
 .../apache/ignite/yarn/ApplicationMaster.java   |   12 +-
 .../apache/ignite/yarn/ClusterProperties.java   |  144 +-
 .../yarn/IgniteApplicationMasterSelfTest.java   |   52 +
 modules/zookeeper/pom.xml                       |    2 +-
 .../tcp/ipfinder/zk/ZookeeperIpFinderTest.java  |   80 +-
 parent/pom.xml                                  |  217 ++-
 pom.xml                                         |   20 +-
 786 files changed, 39734 insertions(+), 9675 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/1367eb92/examples/pom.xml
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/1367eb92/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/1367eb92/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheObjectContext.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/1367eb92/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/binary/CacheObjectBinaryProcessorImpl.java
----------------------------------------------------------------------
diff --cc modules/core/src/main/java/org/apache/ignite/internal/processors/cache/binary/CacheObjectBinaryProcessorImpl.java
index a96f705,f091fc7..c85acf6
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/binary/CacheObjectBinaryProcessorImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/binary/CacheObjectBinaryProcessorImpl.java
@@@ -68,7 -73,7 +73,6 @@@ import org.apache.ignite.internal.proce
  import org.apache.ignite.internal.processors.cache.CacheEntryPredicateAdapter;
  import org.apache.ignite.internal.processors.cache.CacheObject;
  import org.apache.ignite.internal.processors.cache.CacheObjectContext;
--import org.apache.ignite.internal.processors.cache.CacheObjectImpl;
  import org.apache.ignite.internal.processors.cache.GridCacheContext;
  import org.apache.ignite.internal.processors.cache.GridCacheEntryEx;
  import org.apache.ignite.internal.processors.cache.GridCacheUtils;
@@@ -402,31 -472,30 +471,30 @@@ public class CacheObjectBinaryProcessor
              return new IgniteBiTuple<>(marshalToBinary(tup.get1()), marshalToBinary(tup.get2()));
          }
  
-         if (obj instanceof Collection) {
-             Collection<Object> col = (Collection<Object>)obj;
+         {
+             Collection<Object> pCol = BinaryUtils.newKnownCollection(obj);
  
-             Collection<Object> pCol;
+             if (pCol != null) {
+                 Collection<?> col = (Collection<?>)obj;
  
-             if (col instanceof Set)
-                 pCol = (Collection<Object>)BinaryUtils.newSet((Set<?>)col);
-             else
-                 pCol = new ArrayList<>(col.size());
+                 for (Object item : col)
+                     pCol.add(marshalToBinary(item));
  
-             for (Object item : col)
-                 pCol.add(marshalToBinary(item));
- 
-             return pCol;
+                 return pCol;
+             }
          }
  
 -        {
 +        if (obj instanceof Map && !ctx.json().jsonObject(obj)) {
-             Map<?, ?> map = (Map<?, ?>)obj;
+             Map<Object, Object> pMap = BinaryUtils.newKnownMap(obj);
  
-             Map<Object, Object> pMap = BinaryUtils.newMap((Map<Object, Object>)obj);
+             if (pMap != null) {
+                 Map<?, ?> map = (Map<?, ?>)obj;
  
-             for (Map.Entry<?, ?> e : map.entrySet())
-                 pMap.put(marshalToBinary(e.getKey()), marshalToBinary(e.getValue()));
+                 for (Map.Entry<?, ?> e : map.entrySet())
+                     pMap.put(marshalToBinary(e.getKey()), marshalToBinary(e.getValue()));
  
-             return pMap;
+                 return pMap;
+             }
          }
  
          if (obj instanceof Map.Entry) {

http://git-wip-us.apache.org/repos/asf/ignite/blob/1367eb92/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridNearAtomicUpdateFuture.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/1367eb92/modules/core/src/main/java/org/apache/ignite/internal/processors/cacheobject/IgniteCacheObjectProcessorImpl.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/1367eb92/modules/core/src/main/java/org/apache/ignite/internal/processors/query/GridQueryProcessor.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/1367eb92/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestProcessor.java
----------------------------------------------------------------------
diff --cc modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestProcessor.java
index cd2b6b4,6d20547..0e5d078
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestProcessor.java
@@@ -44,11 -44,11 +44,12 @@@ import org.apache.ignite.internal.proce
  import org.apache.ignite.internal.processors.rest.handlers.GridRestCommandHandler;
  import org.apache.ignite.internal.processors.rest.handlers.cache.GridCacheCommandHandler;
  import org.apache.ignite.internal.processors.rest.handlers.datastructures.DataStructuresCommandHandler;
+ import org.apache.ignite.internal.processors.rest.handlers.log.GridLogCommandHandler;
  import org.apache.ignite.internal.processors.rest.handlers.query.QueryCommandHandler;
 +import org.apache.ignite.internal.processors.rest.handlers.scripting.IgniteScriptingCommandHandler;
  import org.apache.ignite.internal.processors.rest.handlers.task.GridTaskCommandHandler;
  import org.apache.ignite.internal.processors.rest.handlers.top.GridTopologyCommandHandler;
 -import org.apache.ignite.internal.processors.rest.handlers.version.GridVersionCommandHandler;
 +import org.apache.ignite.internal.processors.rest.handlers.version.GridVersionNameCommandHandler;
  import org.apache.ignite.internal.processors.rest.protocols.tcp.GridTcpRestProtocol;
  import org.apache.ignite.internal.processors.rest.request.GridRestCacheRequest;
  import org.apache.ignite.internal.processors.rest.request.GridRestRequest;
@@@ -436,6 -436,16 +437,15 @@@ public class GridRestProcessor extends 
      /** {@inheritDoc} */
      @Override public void start() throws IgniteCheckedException {
          if (isRestEnabled()) {
+             // Register handlers.
+             addHandler(new GridCacheCommandHandler(ctx));
+             addHandler(new GridTaskCommandHandler(ctx));
+             addHandler(new GridTopologyCommandHandler(ctx));
 -            addHandler(new GridVersionCommandHandler(ctx));
++            addHandler(new GridVersionNameCommandHandler(ctx));
+             addHandler(new DataStructuresCommandHandler(ctx));
+             addHandler(new QueryCommandHandler(ctx));
+             addHandler(new GridLogCommandHandler(ctx));
+ 
 -
              // Start protocols.
              startTcpProtocol();
              startHttpProtocol();

http://git-wip-us.apache.org/repos/asf/ignite/blob/1367eb92/modules/json/pom.xml
----------------------------------------------------------------------
diff --cc modules/json/pom.xml
index 77f890c,0000000..192c47f
mode 100644,000000..100644
--- a/modules/json/pom.xml
+++ b/modules/json/pom.xml
@@@ -1,76 -1,0 +1,76 @@@
 +<?xml version="1.0" encoding="UTF-8"?>
 +
 +<!--
 +  Licensed to the Apache Software Foundation (ASF) under one or more
 +  contributor license agreements.  See the NOTICE file distributed with
 +  this work for additional information regarding copyright ownership.
 +  The ASF licenses this file to You under the Apache License, Version 2.0
 +  (the "License"); you may not use this file except in compliance with
 +  the License.  You may obtain a copy of the License at
 +
 +       http://www.apache.org/licenses/LICENSE-2.0
 +
 +  Unless required by applicable law or agreed to in writing, software
 +  distributed under the License is distributed on an "AS IS" BASIS,
 +  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 +  See the License for the specific language governing permissions and
 +  limitations under the License.
 +-->
 +
 +<!--
 +    POM file.
 +-->
 +<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
 +    <modelVersion>4.0.0</modelVersion>
 +
 +    <parent>
 +        <groupId>org.apache.ignite</groupId>
 +        <artifactId>ignite-parent</artifactId>
 +        <version>1</version>
 +        <relativePath>../../parent</relativePath>
 +    </parent>
 +
 +    <artifactId>ignite-json</artifactId>
-     <version>1.5.1.final-SNAPSHOT</version>
++    <version>1.6.0-SNAPSHOT</version>
 +    <url>http://ignite.apache.org</url>
 +
 +    <dependencies>
 +        <dependency>
 +            <groupId>javax.json</groupId>
 +            <artifactId>javax.json-api</artifactId>
 +            <version>1.0</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.ignite</groupId>
 +            <artifactId>ignite-core</artifactId>
 +            <version>${project.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.ignite</groupId>
 +            <artifactId>ignite-spring</artifactId>
 +            <version>${project.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.ignite</groupId>
 +            <artifactId>ignite-log4j</artifactId>
 +            <version>${project.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.ignite</groupId>
 +            <artifactId>ignite-indexing</artifactId>
 +            <version>${project.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.ignite</groupId>
 +            <artifactId>ignite-core</artifactId>
 +            <version>${project.version}</version>
 +            <type>test-jar</type>
 +            <scope>test</scope>
 +        </dependency>
 +    </dependencies>
 +</project>

http://git-wip-us.apache.org/repos/asf/ignite/blob/1367eb92/modules/json/src/main/java/org/apache/ignite/json/IgniteJson.java
----------------------------------------------------------------------
diff --cc modules/json/src/main/java/org/apache/ignite/json/IgniteJson.java
index 010d49f,0000000..983dc44
mode 100644,000000..100644
--- a/modules/json/src/main/java/org/apache/ignite/json/IgniteJson.java
+++ b/modules/json/src/main/java/org/apache/ignite/json/IgniteJson.java
@@@ -1,35 -1,0 +1,35 @@@
 +/*
 + * Licensed to the Apache Software Foundation (ASF) under one or more
 + * contributor license agreements.  See the NOTICE file distributed with
 + * this work for additional information regarding copyright ownership.
 + * The ASF licenses this file to You under the Apache License, Version 2.0
 + * (the "License"); you may not use this file except in compliance with
 + * the License.  You may obtain a copy of the License at
 + *
 + *      http://www.apache.org/licenses/LICENSE-2.0
 + *
 + * Unless required by applicable law or agreed to in writing, software
 + * distributed under the License is distributed on an "AS IS" BASIS,
 + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 + * See the License for the specific language governing permissions and
 + * limitations under the License.
 + */
 +
 +package org.apache.ignite.json;
 +
 +import javax.json.spi.JsonProvider;
 +import org.apache.ignite.Ignite;
 +import org.apache.ignite.internal.processors.json.IgniteJsonProvider;
 +
 +/**
-  *
++ * Provides JSON API implementation.
 + */
 +public class IgniteJson {
 +    /**
 +     * @param ignite Ignite.
 +     * @return Ignite JSON API provider.
 +     */
 +    public static JsonProvider jsonProvider(Ignite ignite) {
 +        return new IgniteJsonProvider();
 +    }
 +}

http://git-wip-us.apache.org/repos/asf/ignite/blob/1367eb92/modules/nodejs/pom.xml
----------------------------------------------------------------------
diff --cc modules/nodejs/pom.xml
index 02ef15b,0000000..f50b61d
mode 100644,000000..100644
--- a/modules/nodejs/pom.xml
+++ b/modules/nodejs/pom.xml
@@@ -1,82 -1,0 +1,82 @@@
 +<?xml version="1.0" encoding="UTF-8"?>
 +
 +<!--
 +  Licensed to the Apache Software Foundation (ASF) under one or more
 +  contributor license agreements.  See the NOTICE file distributed with
 +  this work for additional information regarding copyright ownership.
 +  The ASF licenses this file to You under the Apache License, Version 2.0
 +  (the "License"); you may not use this file except in compliance with
 +  the License.  You may obtain a copy of the License at
 +
 +       http://www.apache.org/licenses/LICENSE-2.0
 +
 +  Unless required by applicable law or agreed to in writing, software
 +  distributed under the License is distributed on an "AS IS" BASIS,
 +  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 +  See the License for the specific language governing permissions and
 +  limitations under the License.
 +-->
 +
 +<!--
 +    POM file.
 +-->
 +<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
 +    <modelVersion>4.0.0</modelVersion>
 +
 +    <parent>
 +        <groupId>org.apache.ignite</groupId>
 +        <artifactId>ignite-parent</artifactId>
 +        <version>1</version>
 +        <relativePath>../../parent</relativePath>
 +    </parent>
 +
 +    <artifactId>ignite-nodejs</artifactId>
-     <version>1.5.1.final-SNAPSHOT</version>
++    <version>1.6.0-SNAPSHOT</version>
 +
 +    <dependencies>
 +        <dependency>
 +            <groupId>org.apache.ignite</groupId>
 +            <artifactId>ignite-core</artifactId>
 +            <version>${project.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.ignite</groupId>
 +            <artifactId>ignite-spring</artifactId>
 +            <version>${project.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.ignite</groupId>
 +            <artifactId>ignite-log4j</artifactId>
 +            <version>${project.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.ignite</groupId>
 +            <artifactId>ignite-indexing</artifactId>
 +            <version>${project.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.ignite</groupId>
 +            <artifactId>ignite-rest-http</artifactId>
 +            <version>${project.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>junit</groupId>
 +            <artifactId>junit</artifactId>
 +            <version>4.11</version>
 +            <scope>test</scope>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.ignite</groupId>
 +            <artifactId>ignite-core</artifactId>
 +            <version>${project.version}</version>
 +            <type>test-jar</type>
 +            <scope>test</scope>
 +        </dependency>
 +    </dependencies>
 +</project>

http://git-wip-us.apache.org/repos/asf/ignite/blob/1367eb92/modules/rest-http/pom.xml
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/1367eb92/parent/pom.xml
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/1367eb92/pom.xml
----------------------------------------------------------------------
diff --cc pom.xml
index 8f88daa,bead3ae..1f17e70
--- a/pom.xml
+++ b/pom.xml
@@@ -84,7 -84,7 +85,8 @@@
          <module>modules/osgi-paxlogging</module>
          <module>modules/osgi-karaf</module>
          <module>modules/osgi</module>
 +        <module>modules/json</module>
+ 		<module>modules/benchmarks</module>
      </modules>
  
      <profiles>