You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by vk...@apache.org on 2016/02/05 01:09:54 UTC

[7/7] ignite git commit: IGNITE-2249 - Merged from master

IGNITE-2249 - Merged from master


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

Branch: refs/heads/ignite-2249
Commit: 68d6130287f55ab5c2a70611fe378b3228d3dd52
Parents: 02fd4b0 e2be94e
Author: Valentin Kulichenko <va...@gmail.com>
Authored: Thu Feb 4 16:07:31 2016 -0800
Committer: Valentin Kulichenko <va...@gmail.com>
Committed: Thu Feb 4 16:07:31 2016 -0800

----------------------------------------------------------------------
 .gitignore                                      |    1 +
 README.md                                       |  194 +++
 doap_Ignite.rdf                                 |   67 +
 examples/pom.xml                                |    2 +-
 examples/schema-import/pom.xml                  |    2 +-
 .../hibernate/HibernateL2CacheExample.java      |   26 +-
 .../hibernate/CacheHibernateStoreExample.java   |    5 +
 .../store/auto/CacheBinaryAutoStoreExample.java |    1 +
 .../examples/datagrid/CacheAffinityExample.java |   13 +-
 .../examples/datagrid/CacheApiExample.java      |    5 +
 .../examples/datagrid/CacheAsyncApiExample.java |    5 +
 .../datagrid/CacheContinuousQueryExample.java   |    5 +
 .../datagrid/CacheDataStreamerExample.java      |    5 +
 .../datagrid/CacheEntryProcessorExample.java    |    5 +
 .../examples/datagrid/CacheEventsExample.java   |    5 +
 .../examples/datagrid/CacheQueryExample.java    |    6 +
 .../datagrid/CacheTransactionExample.java       |    6 +-
 .../starschema/CacheStarSchemaExample.java      |   10 +-
 .../store/auto/CacheAutoStoreExample.java       |    5 +
 .../store/jdbc/CacheJdbcStoreExample.java       |    5 +
 .../store/spring/CacheSpringStoreExample.java   |    5 +
 .../streaming/StreamTransformerExample.java     |    4 +
 .../streaming/StreamVisitorExample.java         |   13 +-
 .../streaming/wordcount/QueryWords.java         |   51 +-
 .../socket/WordsSocketStreamerServer.java       |   86 +-
 .../java8/datagrid/CacheAffinityExample.java    |   11 +-
 .../java8/datagrid/CacheApiExample.java         |    5 +
 .../java8/datagrid/CacheAsyncApiExample.java    |    5 +
 .../datagrid/CacheEntryProcessorExample.java    |    5 +
 .../streaming/StreamTransformerExample.java     |    9 +-
 .../java8/streaming/StreamVisitorExample.java   |    5 +
 modules/aop/pom.xml                             |    4 +-
 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 +-
 .../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/affinity/Affinity.java  |   24 +-
 .../configuration/BinaryConfiguration.java      |   28 +
 .../configuration/CacheConfiguration.java       |    2 +-
 .../configuration/FileSystemConfiguration.java  |   54 +-
 .../configuration/IgniteConfiguration.java      |    8 +-
 .../org/apache/ignite/igfs/IgfsUserContext.java |   16 +-
 .../igfs/secondary/IgfsSecondaryFileSystem.java |   14 -
 .../apache/ignite/internal/GridComponent.java   |    5 +-
 .../internal/GridEventConsumeHandler.java       |    3 +-
 .../internal/GridMessageListenHandler.java      |    6 +-
 .../ignite/internal/GridUpdateNotifier.java     |  454 ------
 .../apache/ignite/internal/IgniteKernal.java    |  221 +--
 .../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  |   64 +-
 .../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     |   14 +-
 .../ignite/internal/binary/BinaryUtils.java     |   78 +
 .../internal/binary/BinaryWriterExImpl.java     |   30 +-
 .../internal/binary/GridBinaryMarshaller.java   |   28 +-
 .../binary/builder/BinaryBuilderSerializer.java |   16 +-
 .../binary/builder/BinaryObjectBuilderImpl.java |    2 +-
 .../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/GridAffinityProcessor.java         |   60 +-
 .../processors/cache/CacheEntryImplEx.java      |   14 +-
 .../cache/CacheEntrySerializablePredicate.java  |    3 +-
 .../cache/CacheInvokeDirectResult.java          |    4 +-
 .../processors/cache/CacheMetricsSnapshot.java  |    4 +-
 .../processors/cache/CacheObjectContext.java    |   91 +-
 .../processors/cache/CacheOperationContext.java |   43 +-
 .../cache/DynamicCacheChangeBatch.java          |    5 -
 .../processors/cache/GridCacheAdapter.java      |  505 ++++--
 .../cache/GridCacheAffinityManager.java         |   47 +-
 .../processors/cache/GridCacheContext.java      |   66 +-
 .../cache/GridCacheEvictionManager.java         |    7 +-
 .../processors/cache/GridCacheIoManager.java    |   23 +
 .../processors/cache/GridCacheMapEntry.java     |   12 +-
 .../processors/cache/GridCacheMvccManager.java  |   43 +-
 .../cache/GridCacheOffheapSwapEntry.java        |   24 +-
 .../processors/cache/GridCacheProcessor.java    |  155 +-
 .../processors/cache/GridCacheProxyImpl.java    |   62 +-
 .../processors/cache/GridCacheReturn.java       |    2 +
 .../cache/GridCacheSwapEntryImpl.java           |   61 +-
 .../cache/GridCacheUpdateAtomicResult.java      |    4 +-
 .../processors/cache/GridCacheUtils.java        |   36 +-
 .../processors/cache/IgniteCacheProxy.java      |   96 +-
 .../processors/cache/IgniteInternalCache.java   |   85 +
 .../cache/affinity/GridCacheAffinityImpl.java   |   48 +-
 .../binary/CacheObjectBinaryProcessorImpl.java  |  160 +-
 .../distributed/GridCacheTxRecoveryFuture.java  |    2 +-
 .../GridDistributedLockResponse.java            |    2 +-
 .../GridDistributedTxFinishRequest.java         |   11 +-
 .../GridDistributedTxPrepareRequest.java        |    2 +-
 .../GridDistributedTxPrepareResponse.java       |    4 +-
 .../GridDistributedTxRemoteAdapter.java         |   12 +-
 .../dht/CacheDistributedGetFutureAdapter.java   |   55 +-
 .../dht/GridClientPartitionTopology.java        |    2 +
 .../dht/GridDhtAffinityAssignmentResponse.java  |    4 +-
 .../distributed/dht/GridDhtCacheAdapter.java    |    7 +-
 .../cache/distributed/dht/GridDhtGetFuture.java |    8 +-
 .../distributed/dht/GridDhtLockFuture.java      |   46 +-
 .../distributed/dht/GridDhtLockRequest.java     |    2 +-
 .../dht/GridDhtPartitionTopologyImpl.java       |   27 +-
 .../distributed/dht/GridDhtTxFinishFuture.java  |   17 +-
 .../distributed/dht/GridDhtTxFinishRequest.java |   90 +-
 .../dht/GridDhtTxFinishResponse.java            |    4 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |   32 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java |   52 +-
 .../dht/GridDhtTxPrepareRequest.java            |    2 +-
 .../dht/GridPartitionedGetFuture.java           |  257 +--
 .../dht/GridPartitionedSingleGetFuture.java     |  244 +--
 .../dht/atomic/GridDhtAtomicCache.java          |  236 ++-
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |    2 +-
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |   21 +-
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |    6 +-
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |   10 +-
 .../dht/atomic/GridNearAtomicUpdateRequest.java |   44 +-
 .../atomic/GridNearAtomicUpdateResponse.java    |    4 +-
 .../dht/colocated/GridDhtColocatedCache.java    |   42 +-
 .../colocated/GridDhtColocatedLockFuture.java   |    6 +-
 .../dht/preloader/GridDhtForceKeysResponse.java |    6 +-
 .../GridDhtPartitionDemandMessage.java          |    6 +-
 .../dht/preloader/GridDhtPartitionDemander.java |   15 +-
 .../GridDhtPartitionSupplyMessageV2.java        |    6 +-
 .../GridDhtPartitionsExchangeFuture.java        |    8 +-
 .../preloader/GridDhtPartitionsFullMessage.java |    2 +-
 .../GridDhtPartitionsSingleMessage.java         |    4 +-
 .../distributed/near/GridNearAtomicCache.java   |    6 +-
 .../distributed/near/GridNearCacheAdapter.java  |    6 +-
 .../distributed/near/GridNearCacheEntry.java    |    3 +-
 .../distributed/near/GridNearGetFuture.java     |  286 ++--
 .../distributed/near/GridNearGetResponse.java   |    4 +-
 .../distributed/near/GridNearLockFuture.java    |    2 +-
 ...arOptimisticSerializableTxPrepareFuture.java |  143 +-
 .../near/GridNearOptimisticTxPrepareFuture.java |   67 +-
 ...ridNearOptimisticTxPrepareFutureAdapter.java |    6 +-
 .../GridNearPessimisticTxPrepareFuture.java     |   14 +-
 .../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 |   71 +-
 .../near/GridNearTxPrepareFutureAdapter.java    |    8 +-
 .../near/GridNearTxPrepareResponse.java         |    4 +-
 .../processors/cache/dr/GridCacheDrInfo.java    |   49 +-
 .../cache/local/GridLocalLockFuture.java        |   19 +-
 .../local/atomic/GridLocalAtomicCache.java      |  106 +-
 .../cache/query/GridCacheQueryRequest.java      |   16 +-
 .../cache/query/GridCacheQueryResponse.java     |   18 +-
 .../continuous/CacheContinuousQueryHandler.java |   27 +-
 .../cache/transactions/IgniteInternalTx.java    |    6 +
 .../cache/transactions/IgniteTxAdapter.java     |   47 +-
 .../cache/transactions/IgniteTxEntry.java       |   55 +-
 .../cache/transactions/IgniteTxHandler.java     |   26 +-
 .../transactions/IgniteTxLocalAdapter.java      |  321 ++--
 .../cache/transactions/IgniteTxLocalEx.java     |    3 +-
 .../cache/transactions/IgniteTxManager.java     |   42 +-
 .../version/GridCachePlainVersionedEntry.java   |    2 +-
 .../cache/version/GridCacheVersionManager.java  |   23 +-
 .../IgniteCacheObjectProcessorImpl.java         |    7 +-
 .../processors/cluster/ClusterProcessor.java    |  193 ++-
 .../processors/cluster/GridUpdateNotifier.java  |  457 ++++++
 .../continuous/AbstractContinuousMessage.java   |   10 +-
 .../continuous/GridContinuousHandler.java       |    4 +-
 .../continuous/GridContinuousProcessor.java     |   26 +-
 .../datastreamer/DataStreamerRequest.java       |    1 +
 .../datastructures/DataStructuresProcessor.java |   11 +-
 .../processors/hadoop/HadoopPayloadAware.java   |   28 +
 .../processors/igfs/IgfsAckMessage.java         |    4 +-
 .../ignite/internal/processors/igfs/IgfsEx.java |   13 -
 .../internal/processors/igfs/IgfsImpl.java      |   28 +-
 .../internal/processors/igfs/IgfsPaths.java     |   62 +-
 .../internal/processors/igfs/IgfsProcessor.java |    3 -
 .../igfs/IgfsSecondaryFileSystemImpl.java       |   11 -
 .../platform/PlatformAbstractTarget.java        |   31 +-
 .../processors/platform/PlatformIgnition.java   |    6 +-
 .../platform/PlatformNoopProcessor.java         |   20 +
 .../processors/platform/PlatformProcessor.java  |   33 +
 .../platform/PlatformProcessorImpl.java         |   39 +-
 .../processors/platform/PlatformTarget.java     |   22 +
 .../platform/cache/PlatformCache.java           |   22 +-
 .../platform/compute/PlatformCompute.java       |  164 +-
 .../cpp/PlatformCppConfigurationClosure.java    |   32 +
 .../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/PlatformFutureUtils.java     |  119 +-
 .../platform/utils/PlatformListenable.java      |   47 +
 .../platform/utils/PlatformUtils.java           |   52 +-
 .../processors/query/GridQueryProcessor.java    |    7 +-
 .../processors/rest/GridRestProcessor.java      |    3 +
 .../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 +-
 .../ignite/internal/util/GridJavaProcess.java   |    3 -
 .../internal/util/GridSpinReadWriteLock.java    |   10 +-
 .../ignite/internal/util/GridStringBuilder.java |   19 +
 .../apache/ignite/internal/util/GridUnsafe.java | 1483 +++++++++++++++++-
 .../ignite/internal/util/IgniteUtils.java       |  157 +-
 .../util/future/GridCompoundFuture.java         |  314 +---
 .../util/future/GridCompoundIdentityFuture.java |    6 +-
 .../internal/util/future/GridFutureAdapter.java |    2 +
 .../internal/util/io/GridUnsafeDataInput.java   |  145 +-
 .../internal/util/io/GridUnsafeDataOutput.java  |  165 +-
 .../ignite/internal/util/lang/GridFunc.java     |    3 +
 .../internal/util/nio/GridDirectParser.java     |   52 +-
 .../ignite/internal/util/nio/GridNioServer.java |   56 +-
 .../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      |   27 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |   21 +-
 .../visor/node/VisorNodeDataCollectorTask.java  |    2 +-
 .../ignite/lang/IgniteProductVersion.java       |   18 +
 .../optimized/OptimizedClassDescriptor.java     |   22 +-
 .../optimized/OptimizedMarshaller.java          |    5 +-
 .../optimized/OptimizedMarshallerUtils.java     |   44 +-
 .../optimized/OptimizedObjectInputStream.java   |   10 +-
 .../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    |   16 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |    1 -
 .../tcp/ipfinder/TcpDiscoveryIpFinder.java      |   14 +-
 .../ipfinder/jdbc/TcpDiscoveryJdbcIpFinder.java |   48 +-
 .../TcpDiscoveryMulticastIpFinder.java          |   12 +-
 .../TcpDiscoveryCustomEventMessage.java         |   10 +-
 .../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   |  290 ++++
 .../internal/GridAffinityP2PSelfTest.java       |    8 +-
 .../ignite/internal/GridAffinitySelfTest.java   |   10 +-
 .../internal/GridUpdateNotifierSelfTest.java    |  137 --
 ...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  |    4 +-
 ...naryObjectBuilderDefaultMappersSelfTest.java | 1149 ++++++++++++++
 .../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/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 +-
 ...hePartitionedProjectionAffinitySelfTest.java |    8 +-
 .../cache/GridCachePutAllFailoverSelfTest.java  |    4 +-
 .../processors/cache/GridCacheStopSelfTest.java |    2 +-
 .../cache/GridCacheUtilsSelfTest.java           |  136 +-
 ...IgniteCacheGetCustomCollectionsSelfTest.java |  128 ++
 ...gniteCacheLoadRebalanceEvictionSelfTest.java |  188 +++
 .../cache/IgniteCacheNearLockValueSelfTest.java |   62 +-
 .../cache/IgniteCacheStoreCollectionTest.java   |  175 +++
 ...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 +
 ...eAbstractDataStructuresFailoverSelfTest.java |  311 +---
 .../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 +
 ...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/GridCacheNearTxMultiNodeSelfTest.java  |    4 +-
 ...titionedExplicitLockNodeFailureSelfTest.java |    6 +-
 .../GridCachePartitionedNodeRestartTest.java    |    4 +-
 ...ePartitionedOptimisticTxNodeRestartTest.java |    4 +-
 .../GridCacheRebalancingSyncSelfTest.java       |    8 +
 .../GridCacheReplicatedPreloadSelfTest.java     |  108 ++
 .../RandomEvictionPolicyCacheSizeSelfTest.java  |   79 -
 .../random/RandomEvictionPolicySelfTest.java    |  363 -----
 ...ContinuousQueryFailoverAbstractSelfTest.java |   86 +
 .../CacheContinuousQueryLostPartitionTest.java  |  256 +++
 ...ridCacheContinuousQueryAbstractSelfTest.java |   10 +-
 ...ntinuousQueryPartitionAtomicOneNodeTest.java |   37 +
 ...heContinuousQueryPartitionTxOneNodeTest.java |   37 +
 ...tinuousQueryReplicatedAtomicOneNodeTest.java |   31 +
 ...ontinuousQueryReplicatedOneNodeSelfTest.java |  120 --
 ...eContinuousQueryReplicatedTxOneNodeTest.java |  193 +++
 .../IgniteCacheWriteBehindNoUpdateSelfTest.java |  178 +++
 .../cluster/GridUpdateNotifierSelfTest.java     |  140 ++
 .../continuous/GridEventConsumeSelfTest.java    |    3 +
 .../processors/igfs/IgfsAbstractSelfTest.java   |    8 +-
 .../igfs/IgfsExUniversalFileSystemAdapter.java  |   11 +-
 .../processors/igfs/IgfsStreamsSelfTest.java    |    4 +-
 .../igfs/UniversalFileSystemAdapter.java        |    5 +-
 .../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 +-
 .../ignite/loadtests/dsi/GridDsiClient.java     |    4 +-
 .../platform/PlatformComputeBroadcastTask.java  |    7 +
 .../platform/PlatformComputeEchoTask.java       |    6 +-
 .../tcp/GridCacheDhtLockBackupSelfTest.java     |    4 +-
 ...dTcpCommunicationSpiRecoveryAckSelfTest.java |    1 -
 ...CommunicationRecoveryAckClosureSelfTest.java |   21 +-
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java |    7 +-
 .../startup/GridRandomCommandLineLoader.java    |    4 +-
 .../ignite/testframework/GridTestUtils.java     |   34 +-
 .../config/GridTestProperties.java              |    5 +-
 .../testframework/junits/GridAbstractTest.java  |   30 +-
 .../junits/common/GridCommonAbstractTest.java   |   34 +-
 .../multijvm/IgniteCacheProcessProxy.java       |   59 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java |    4 +-
 .../testsuites/IgniteBinaryBasicTestSuite.java  |   95 ++
 ...ctsSimpleNameMapperComputeGridTestSuite.java |   38 +
 .../IgniteBinaryObjectsTestSuite.java           |   40 +-
 ...iteBinarySimpleNameMapperBasicTestSuite.java |   38 +
 ...rySimpleNameMapperCacheFullApiTestSuite.java |   39 +
 .../IgniteCacheEvictionSelfTestSuite.java       |    4 -
 .../IgniteCacheRestartTestSuite2.java           |    3 +
 .../testsuites/IgniteCacheTestSuite3.java       |    2 +
 .../testsuites/IgniteCacheTestSuite4.java       |   21 +
 .../testsuites/IgniteCacheTestSuite5.java       |    4 +
 .../IgniteCacheTxRecoverySelfTestSuite.java     |    3 +
 .../testsuites/IgniteComputeGridTestSuite.java  |    4 +-
 .../testsuites/IgniteKernalSelfTestSuite.java   |    6 +-
 .../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 +-
 .../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                      |   10 +-
 modules/hadoop/pom.xml                          |    2 +-
 .../hadoop/fs/BasicHadoopFileSystemFactory.java |  226 +++
 .../fs/CachingHadoopFileSystemFactory.java      |   86 +
 .../hadoop/fs/HadoopFileSystemFactory.java      |   52 +
 .../fs/IgniteHadoopIgfsSecondaryFileSystem.java |  260 +--
 .../hadoop/fs/v1/IgniteHadoopFileSystem.java    |  154 +-
 .../hadoop/fs/v2/IgniteHadoopFileSystem.java    |  122 +-
 .../processors/hadoop/HadoopClassLoader.java    |  689 ++++++--
 .../hadoop/SecondaryFileSystemProvider.java     |  139 --
 .../hadoop/fs/HadoopFileSystemCacheUtils.java   |    8 +-
 .../hadoop/fs/HadoopLazyConcurrentMap.java      |    5 +-
 .../hadoop/shuffle/HadoopShuffleJob.java        |    5 +-
 .../hadoop/shuffle/HadoopShuffleMessage.java    |   10 +-
 .../shuffle/streams/HadoopDataOutStream.java    |    6 +-
 .../hadoop/v2/HadoopNativeCodeLoader.java       |   74 -
 .../processors/hadoop/v2/HadoopV2Context.java   |    2 +
 .../processors/hadoop/v2/HadoopV2MapTask.java   |   23 +-
 .../ignite/igfs/Hadoop1DualAbstractTest.java    |   14 +-
 .../igfs/HadoopFIleSystemFactorySelfTest.java   |  326 ++++
 ...oopFileSystemUniversalFileSystemAdapter.java |   53 +-
 ...oopSecondaryFileSystemConfigurationTest.java |   27 +-
 .../IgniteHadoopFileSystemAbstractSelfTest.java |   71 +-
 ...condaryFileSystemInitializationSelfTest.java |  214 +++
 .../hadoop/HadoopAbstractWordCountTest.java     |   46 +-
 .../hadoop/HadoopClassLoaderTest.java           |  101 +-
 .../hadoop/HadoopMapReduceEmbeddedSelfTest.java |    2 +-
 .../processors/hadoop/HadoopMapReduceTest.java  |   15 +-
 .../hadoop/HadoopSnappyFullMapReduceTest.java   |   28 +
 .../processors/hadoop/HadoopSnappyTest.java     |  102 ++
 .../processors/hadoop/HadoopTasksV2Test.java    |    2 +-
 .../hadoop/deps/CircularWIthHadoop.java         |   32 +
 .../hadoop/deps/CircularWithoutHadoop.java      |   27 +
 .../processors/hadoop/deps/WithCast.java        |   41 +
 .../hadoop/deps/WithClassAnnotation.java        |   28 +
 .../hadoop/deps/WithConstructorInvocation.java  |   31 +
 .../processors/hadoop/deps/WithExtends.java     |   27 +
 .../processors/hadoop/deps/WithField.java       |   29 +
 .../processors/hadoop/deps/WithImplements.java  |   36 +
 .../hadoop/deps/WithIndirectField.java          |   27 +
 .../processors/hadoop/deps/WithInitializer.java |   33 +
 .../processors/hadoop/deps/WithInnerClass.java  |   31 +
 .../hadoop/deps/WithLocalVariable.java          |   38 +
 .../hadoop/deps/WithMethodAnnotation.java       |   32 +
 .../hadoop/deps/WithMethodArgument.java         |   31 +
 .../hadoop/deps/WithMethodCheckedException.java |   31 +
 .../hadoop/deps/WithMethodInvocation.java       |   31 +
 .../hadoop/deps/WithMethodReturnType.java       |   31 +
 .../hadoop/deps/WithMethodRuntimeException.java |   31 +
 .../processors/hadoop/deps/WithOuterClass.java  |   38 +
 .../hadoop/deps/WithParameterAnnotation.java    |   31 +
 .../processors/hadoop/deps/WithStaticField.java |   29 +
 .../hadoop/deps/WithStaticInitializer.java      |   34 +
 .../processors/hadoop/deps/Without.java         |   25 +
 .../hadoop/examples/HadoopWordCount1Reduce.java |    1 +
 .../hadoop/examples/HadoopWordCount2.java       |   18 +-
 .../examples/HadoopWordCount2Reducer.java       |    1 +
 .../HadoopConcurrentHashMultimapSelftest.java   |    6 +-
 .../collections/HadoopSkipListSelfTest.java     |    5 +-
 .../testsuites/IgniteHadoopTestSuite.java       |   26 +-
 modules/hibernate/pom.xml                       |    2 +-
 modules/indexing/pom.xml                        |   10 +-
 .../query/h2/opt/GridH2IndexBase.java           |    5 +-
 .../query/h2/opt/GridH2TreeIndex.java           |    2 +-
 ...niteCacheP2pUnmarshallingQueryErrorTest.java |   20 +-
 .../IgniteBinaryCacheQueryTestSuite.java        |  188 +--
 ...narySimpleNameMapperCacheQueryTestSuite.java |   38 +
 .../IgniteCacheQuerySelfTestSuite.java          |   10 +-
 modules/jcl/pom.xml                             |    4 +-
 modules/jms11/pom.xml                           |    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                          |    4 +-
 modules/mesos/pom.xml                           |    2 +-
 modules/mqtt/pom.xml                            |    2 +-
 modules/osgi-karaf/pom.xml                      |    6 +-
 modules/osgi-paxlogging/pom.xml                 |    2 +-
 modules/osgi/pom.xml                            |   10 +-
 modules/platforms/cpp/common/configure.ac       |    2 +-
 .../cpp/common/include/ignite/common/exports.h  |   11 +-
 .../cpp/common/include/ignite/common/java.h     |   25 +-
 .../cpp/common/project/vs/common.vcxproj        |    2 +-
 .../platforms/cpp/common/project/vs/module.def  |   10 +-
 modules/platforms/cpp/common/src/exports.cpp    |   36 +-
 modules/platforms/cpp/common/src/java.cpp       |  134 +-
 modules/platforms/cpp/core-test/configure.ac    |    2 +-
 modules/platforms/cpp/core/configure.ac         |    2 +-
 modules/platforms/cpp/examples/configure.ac     |    2 +-
 modules/platforms/cpp/ignite/configure.ac       |    2 +-
 .../Apache.Ignite.Benchmarks.csproj             |    4 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Apache.Ignite.Core.Tests.TestDll.csproj     |    4 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Apache.Ignite.Core.Tests.csproj             |    6 +-
 .../Binary/BinaryBuilderSelfTest.cs             |    8 +-
 .../Binary/BinarySelfTest.cs                    |    9 +
 .../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                   |   22 +-
 .../Config/Compute/compute-grid2.xml            |   21 +
 .../Config/Compute/compute-grid3.xml            |   31 +-
 .../Dataload/DataStreamerTest.cs                |    4 +-
 .../Apache.Ignite.Core.Tests/ExceptionsTest.cs  |    2 +-
 .../IgniteConfigurationTest.cs                  |  367 +++++
 .../Apache.Ignite.Core.Tests/MarshallerTest.cs  |    4 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../SerializationTest.cs                        |    2 +-
 .../Apache.Ignite.Core.Tests/TestRunner.cs      |    5 +-
 .../Apache.Ignite.Core.csproj                   |   39 +-
 .../Apache.Ignite.Core.ruleset                  |   26 +
 .../Binary/BinaryConfiguration.cs               |   30 +-
 .../Binary/BinaryTypeConfiguration.cs           |    5 +
 .../Binary/BinaryTypeNames.cs                   |   64 +-
 .../Apache.Ignite.Core/Binary/IBinaryObject.cs  |    8 +
 .../Cache/CachePartialUpdateException.cs        |    3 +
 .../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            |    4 +
 .../Apache.Ignite.Core/Common/IFactory.cs       |   34 +
 .../Common/IgniteFutureCancelledException.cs    |   66 +
 .../Compute/ComputeJobAdapter.cs                |    2 +-
 .../Compute/ComputeJobResultPolicy.cs           |    2 -
 .../Compute/ComputeTaskAdapter.cs               |    3 +
 .../Compute/ComputeTaskSplitAdapter.cs          |   18 +-
 .../Apache.Ignite.Core/Compute/ICompute.cs      |  233 +++
 .../Datastream/StreamTransformer.cs             |    2 +
 .../Datastream/StreamVisitor.cs                 |    2 +
 .../Discovery/IDiscoverySpi.cs                  |   32 +
 .../Discovery/Tcp/ITcpDiscoveryIpFinder.cs      |   34 +
 .../Multicast/TcpDiscoveryMulticastIpFinder.cs  |  133 ++
 .../Tcp/Static/TcpDiscoveryStaticIpFinder.cs    |   84 +
 .../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      |   70 +-
 .../dotnet/Apache.Ignite.Core/IIgnite.cs        |   32 +
 .../Apache.Ignite.Core/IgniteConfiguration.cs   |  347 +++-
 .../dotnet/Apache.Ignite.Core/Ignition.cs       |   30 +-
 .../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                 |    1 +
 .../Impl/Binary/BinaryReaderExtensions.cs       |   19 +
 .../Impl/Binary/BinaryReflectiveSerializer.cs   |    2 +-
 .../Impl/Binary/BinarySystemHandlers.cs         |    9 +-
 .../Impl/Binary/BinaryUtils.cs                  |    7 +-
 .../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/CancelledTask.cs                |   50 +
 .../Common/CopyOnWriteConcurrentDictionary.cs   |    1 +
 .../Impl/Common/DelegateConverter.cs            |   11 +-
 .../Apache.Ignite.Core/Impl/Common/Future.cs    |   76 +-
 .../Impl/Common/LoadedAssembliesResolver.cs     |    1 +
 .../Closure/ComputeAbstractClosureTask.cs       |    3 +
 .../Compute/Closure/ComputeMultiClosureTask.cs  |    2 +
 .../Closure/ComputeReducingClosureTask.cs       |    2 +
 .../Compute/Closure/ComputeSingleClosureTask.cs |    2 +
 .../Apache.Ignite.Core/Impl/Compute/Compute.cs  |  157 +-
 .../Impl/Compute/ComputeImpl.cs                 |   15 +-
 .../Impl/Datastream/DataStreamerBatch.cs        |    1 +
 .../Impl/Datastream/DataStreamerImpl.cs         |    5 +-
 .../Apache.Ignite.Core/Impl/ExceptionUtils.cs   |   56 +-
 .../Impl/Handle/HandleRegistry.cs               |    1 +
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs    |   54 +
 .../Impl/IgniteConfigurationEx.cs               |   57 -
 .../Apache.Ignite.Core/Impl/IgniteManager.cs    |    5 +-
 .../Apache.Ignite.Core/Impl/IgniteProxy.cs      |   22 +
 .../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         |    2 +
 .../Impl/Memory/PlatformRawMemory.cs            |    4 +-
 .../Apache.Ignite.Core/Impl/PlatformTarget.cs   |   53 +-
 .../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    |   30 +-
 .../Impl/Unmanaged/UnmanagedCallbacks.cs        |    5 +-
 .../Impl/Unmanaged/UnmanagedUtils.cs            |   73 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../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    |    8 +-
 .../Apache.Ignite.Examples.csproj               |    4 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Services/ServicesExample.cs                 |    2 +-
 .../Apache.Ignite.ExamplesDll.csproj            |    4 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 modules/rest-http/pom.xml                       |    2 +-
 modules/scalar-2.10/pom.xml                     |    2 +-
 modules/scalar/pom.xml                          |    2 +-
 modules/schedule/pom.xml                        |    4 +-
 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                          |    4 +-
 .../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/top/VisorTopologyCommand.scala     |    5 +-
 .../scala/org/apache/ignite/visor/visor.scala   |    3 +-
 modules/visor-plugins/pom.xml                   |    2 +-
 modules/web/pom.xml                             |    4 +-
 .../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 +
 .../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                                  |  124 +-
 pom.xml                                         |   20 +-
 764 files changed, 34394 insertions(+), 10130 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/68d61302/modules/core/src/main/java/org/apache/ignite/internal/MarshallerContextImpl.java
----------------------------------------------------------------------
diff --cc modules/core/src/main/java/org/apache/ignite/internal/MarshallerContextImpl.java
index 53fa720,e3f2bc9..05fe8ef
--- a/modules/core/src/main/java/org/apache/ignite/internal/MarshallerContextImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/MarshallerContextImpl.java
@@@ -72,11 -80,10 +80,11 @@@ public class MarshallerContextImpl exte
       */
      public void onMarshallerCacheStarted(GridKernalContext ctx) throws IgniteCheckedException {
          ctx.cache().marshallerCache().context().continuousQueries().executeInternalQuery(
-             new ContinuousQueryListener(log, workDir),
+             new ContinuousQueryListener(ctx.log(MarshallerContextImpl.class), workDir),
              null,
              ctx.cache().marshallerCache().context().affinityNode(),
 -            true
 +            true,
 +            false
          );
      }
  

http://git-wip-us.apache.org/repos/asf/ignite/blob/68d61302/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/binary/CacheObjectBinaryProcessorImpl.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/68d61302/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryHandler.java
----------------------------------------------------------------------
diff --cc modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryHandler.java
index d3b4e71,7e66ad3..adb82bd
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryHandler.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryHandler.java
@@@ -149,8 -149,8 +149,11 @@@ public class CacheContinuousQueryHandle
      private Map<Integer, Long> initUpdCntrs;
  
      /** */
+     private AffinityTopologyVersion initTopVer;
+ 
++    /** */
 +    private transient boolean ignoreClassNotFound;
 +
      /**
       * Required by {@link Externalizable}.
       */

http://git-wip-us.apache.org/repos/asf/ignite/blob/68d61302/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/DataStructuresProcessor.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/68d61302/modules/core/src/main/java/org/apache/ignite/internal/processors/service/GridServiceProcessor.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/68d61302/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteKernalSelfTestSuite.java
----------------------------------------------------------------------
diff --cc modules/core/src/test/java/org/apache/ignite/testsuites/IgniteKernalSelfTestSuite.java
index cc7fc21,d9e9b0f..214d375
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteKernalSelfTestSuite.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteKernalSelfTestSuite.java
@@@ -120,7 -122,7 +123,8 @@@ public class IgniteKernalSelfTestSuite 
          suite.addTestSuite(GridServiceClientNodeTest.class);
          suite.addTestSuite(GridServiceProcessorStopSelfTest.class);
          suite.addTestSuite(ServicePredicateAccessCacheTest.class);
+         suite.addTestSuite(GridServicePackagePrivateSelfTest.class);
 +        suite.addTestSuite(GridServiceSerializationSelfTest.class);
  
          return suite;
      }