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

[48/50] [abbrv] ignite git commit: Merge branch 'ignite-1.7.3'

Merge branch 'ignite-1.7.3'

# Conflicts:
#	modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheGetEntryAbstractTest.java
#	modules/platforms/dotnet/Apache.Ignite.Core.Tests/Cache/CacheAbstractTest.cs
#	modules/platforms/dotnet/Apache.Ignite.Core.Tests/ProjectFilesTest.cs
#	modules/platforms/dotnet/Apache.Ignite.Core/Impl/Unmanaged/UnmanagedCallbacks.cs
#	modules/platforms/dotnet/Apache.Ignite.NLog/packages.config
#	modules/platforms/dotnet/Apache.Ignite.sln.DotSettings


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

Branch: refs/heads/master
Commit: 173e2b83d2059e7f70e357387b860f4d0c9cd14f
Parents: 3d9f892 b1c7c9b
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Wed Nov 9 11:13:27 2016 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Wed Nov 9 11:13:27 2016 +0300

----------------------------------------------------------------------
 .../internal/jdbc2/JdbcResultSetSelfTest.java   |   91 +-
 .../java/org/apache/ignite/IgniteScheduler.java |   13 +
 .../rendezvous/RendezvousAffinityFunction.java  |    2 +-
 .../cache/query/QueryCancelledException.java    |   35 +
 .../apache/ignite/cache/query/QueryCursor.java  |    8 +-
 .../org/apache/ignite/cache/query/SpiQuery.java |    8 +-
 .../ignite/cache/query/SqlFieldsQuery.java      |   26 +
 .../org/apache/ignite/cache/query/SqlQuery.java |   25 +
 .../cache/store/jdbc/CacheJdbcBlobStore.java    |    4 +-
 .../configuration/CacheConfiguration.java       |   13 +-
 .../configuration/IgniteConfiguration.java      |   18 +-
 .../local/LocalIgfsSecondaryFileSystem.java     |   90 +-
 .../internal/GridEventConsumeHandler.java       |    8 +-
 .../internal/GridJobSiblingsResponse.java       |    3 +-
 .../ignite/internal/GridKernalContext.java      |   23 +
 .../ignite/internal/GridKernalContextImpl.java  |   40 +-
 .../internal/GridMessageListenHandler.java      |    8 +-
 .../apache/ignite/internal/IgniteKernal.java    |   13 +-
 .../ignite/internal/IgniteSchedulerImpl.java    |   18 +
 .../org/apache/ignite/internal/IgnitionEx.java  |  125 +-
 .../ignite/internal/MarshallerContextImpl.java  |    5 +-
 .../internal/binary/BinaryEnumObjectImpl.java   |    3 +-
 .../internal/binary/BinaryMarshaller.java       |    2 +-
 .../internal/binary/BinaryWriterExImpl.java     |    3 +-
 .../GridClientOptimizedMarshaller.java          |    5 +-
 .../GridClientZipOptimizedMarshaller.java       |    5 +-
 .../apache/ignite/internal/jdbc/JdbcUtils.java  |    4 +-
 .../checkpoint/GridCheckpointManager.java       |    6 +-
 .../managers/communication/GridIoManager.java   |  190 +-
 .../deployment/GridDeploymentCommunication.java |    4 +-
 .../eventstorage/GridEventStorageManager.java   |   16 +-
 .../swapspace/GridSwapSpaceManager.java         |   13 +-
 .../processors/affinity/GridAffinityUtils.java  |    4 +-
 .../cache/CacheEntrySerializablePredicate.java  |    4 +-
 .../cache/CacheInvokeDirectResult.java          |    4 +-
 .../processors/cache/GridCacheMapEntry.java     |   13 +-
 .../processors/cache/GridCacheMessage.java      |    4 +-
 .../processors/cache/GridCacheProcessor.java    |   13 +-
 .../processors/cache/GridCacheUtils.java        |    2 +-
 .../processors/cache/IgniteCacheProxy.java      |   34 +-
 .../processors/cache/QueryCursorImpl.java       |   92 +-
 .../GridDistributedLockResponse.java            |    4 +-
 .../GridDistributedTxPrepareRequest.java        |    4 +-
 .../GridDistributedTxPrepareResponse.java       |    4 +-
 .../dht/GridDhtAffinityAssignmentRequest.java   |    2 +-
 .../dht/GridDhtAffinityAssignmentResponse.java  |   12 +-
 .../dht/GridDhtTxFinishResponse.java            |    4 +-
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |    4 +-
 .../dht/atomic/GridNearAtomicUpdateRequest.java |    2 +-
 .../atomic/GridNearAtomicUpdateResponse.java    |    4 +-
 .../colocated/GridDhtDetachedCacheEntry.java    |    5 +
 .../dht/preloader/GridDhtForceKeysResponse.java |    4 +-
 .../GridDhtPartitionDemandMessage.java          |    4 +-
 .../preloader/GridDhtPartitionsFullMessage.java |    8 +-
 .../GridDhtPartitionsSingleMessage.java         |    8 +-
 .../distributed/near/GridNearGetResponse.java   |    4 +-
 .../near/GridNearSingleGetResponse.java         |    4 +-
 .../near/GridNearTxFinishResponse.java          |    4 +-
 .../cache/distributed/near/GridNearTxLocal.java |    2 +-
 .../cache/query/GridCacheLocalQueryFuture.java  |    4 +-
 .../cache/query/GridCacheQueryManager.java      |    2 +-
 .../cache/query/GridCacheQueryRequest.java      |   12 +-
 .../cache/query/GridCacheQueryResponse.java     |    4 +-
 .../cache/query/GridCacheSqlQuery.java          |    4 +-
 .../continuous/CacheContinuousQueryHandler.java |   12 +-
 .../jdbc/GridCacheQueryJdbcMetadataTask.java    |    4 +-
 .../query/jdbc/GridCacheQueryJdbcTask.java      |    6 +-
 .../cache/transactions/IgniteTxEntry.java       |    5 +-
 .../transactions/IgniteTxLocalAdapter.java      |   62 +-
 .../version/GridCacheRawVersionedEntry.java     |    8 +-
 .../IgniteCacheObjectProcessorImpl.java         |    3 +-
 .../closure/GridClosureProcessor.java           |   77 +-
 .../processors/cluster/ClusterProcessor.java    |    2 +-
 .../processors/cluster/GridUpdateNotifier.java  |  108 +-
 .../continuous/GridContinuousProcessor.java     |   12 +-
 .../processors/continuous/StartRequestData.java |    4 +-
 .../datastreamer/DataStreamProcessor.java       |    8 +-
 .../datastreamer/DataStreamerImpl.java          |    6 +-
 .../processors/hadoop/HadoopHelper.java         |    7 +
 .../internal/processors/hadoop/HadoopJob.java   |    5 +
 .../hadoop/HadoopMapReducePlanner.java          |    1 +
 .../processors/hadoop/HadoopNoopHelper.java     |    5 +
 .../processors/igfs/IgfsAckMessage.java         |    5 +-
 .../processors/igfs/IgfsDeleteMessage.java      |    5 +-
 .../internal/processors/igfs/IgfsImpl.java      |   11 +-
 .../processors/igfs/IgfsMetaManager.java        |    1 -
 .../internal/processors/igfs/IgfsPaths.java     |    4 +-
 .../internal/processors/igfs/IgfsServer.java    |    5 +-
 .../processors/igfs/IgfsThreadFactory.java      |   61 +
 .../local/LocalFileSystemIgfsFile.java          |    9 +-
 .../secondary/local/LocalFileSystemUtils.java   |  142 +
 .../processors/job/GridJobProcessor.java        |   18 +-
 .../internal/processors/job/GridJobWorker.java  |   16 +-
 .../offheap/GridOffHeapProcessor.java           |    4 +-
 .../platform/PlatformAbstractTarget.java        |  177 +-
 .../processors/platform/PlatformTarget.java     |   44 +-
 .../platform/cache/PlatformCache.java           |  661 +++-
 .../cache/affinity/PlatformAffinity.java        |   14 +-
 .../query/PlatformAbstractQueryCursor.java      |   42 +-
 .../query/PlatformContinuousQueryProxy.java     |   53 +
 .../cache/store/PlatformCacheStoreCallback.java |   61 -
 .../callback/PlatformCallbackGateway.java       |    5 +-
 .../callback/PlatformCallbackUtils.java         |    3 +-
 .../platform/cluster/PlatformClusterGroup.java  |  124 +-
 .../platform/compute/PlatformCompute.java       |  106 +-
 .../cpp/PlatformCppConfigurationClosure.java    |   13 +-
 .../datastreamer/PlatformDataStreamer.java      |  112 +-
 .../datastructures/PlatformAtomicLong.java      |  179 +-
 .../datastructures/PlatformAtomicReference.java |   38 +-
 .../datastructures/PlatformAtomicSequence.java  |  131 +-
 .../dotnet/PlatformDotNetCacheStore.java        |  117 +-
 .../PlatformDotNetConfigurationClosure.java     |   13 +-
 .../platform/events/PlatformEvents.java         |  194 +-
 .../platform/messaging/PlatformMessaging.java   |   83 +-
 .../platform/services/PlatformServices.java     |  223 +-
 .../transactions/PlatformTransactions.java      |  225 +-
 .../platform/utils/PlatformUtils.java           |    8 +-
 .../internal/processors/pool/PoolProcessor.java |  154 +
 .../processors/query/GridQueryCancel.java       |   83 +
 .../processors/query/GridQueryFieldsResult.java |    3 +-
 .../query/GridQueryFieldsResultAdapter.java     |    3 +-
 .../processors/query/GridQueryIndexing.java     |   11 +-
 .../processors/query/GridQueryProcessor.java    |  176 +-
 .../twostep/messages/GridQueryFailResponse.java |   36 +-
 .../h2/twostep/messages/GridQueryRequest.java   |   31 +-
 .../handlers/task/GridTaskCommandHandler.java   |   10 +-
 .../rest/protocols/tcp/GridTcpRestParser.java   |    4 +-
 .../service/GridServiceProcessor.java           |   70 +-
 .../processors/task/GridTaskProcessor.java      |    8 +-
 .../processors/task/GridTaskWorker.java         |   14 +-
 .../ignite/internal/util/IgniteUtils.java       |  291 +-
 .../internal/util/SerializableTransient.java    |   58 +
 .../shmem/IpcSharedMemoryServerEndpoint.java    |   15 +-
 .../util/nio/GridNioSessionMetaKey.java         |    7 +-
 .../util/nio/ssl/BlockingSslHandler.java        |   61 +-
 .../internal/util/nio/ssl/GridNioSslFilter.java |   63 +-
 .../util/nio/ssl/GridNioSslHandler.java         |   17 +-
 .../internal/util/nio/ssl/GridSslMeta.java      |   94 +
 .../visor/cache/VisorCacheTypeMetadata.java     |   70 +-
 .../apache/ignite/logger/java/JavaLogger.java   |   14 +-
 .../logger/java/JavaLoggerFileHandler.java      |   10 +-
 .../ignite/marshaller/MarshallerUtils.java      |   22 +
 .../ignite/marshaller/jdk/JdkMarshaller.java    |    8 +-
 .../optimized/OptimizedClassDescriptor.java     |   90 +-
 .../optimized/OptimizedMarshaller.java          |   14 +-
 .../sharedfs/SharedFsCheckpointSpi.java         |    3 +-
 .../spi/checkpoint/sharedfs/SharedFsUtils.java  |    4 +-
 .../communication/tcp/TcpCommunicationSpi.java  |   53 +-
 .../ignite/spi/discovery/tcp/ClientImpl.java    |    8 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |   24 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |    8 +-
 .../TcpDiscoveryMulticastIpFinder.java          |    4 +-
 .../sharedfs/TcpDiscoverySharedFsIpFinder.java  |    2 +-
 .../TcpDiscoveryCustomEventMessage.java         |    3 +-
 .../RoundRobinGlobalLoadBalancer.java           |   16 +-
 .../spi/swapspace/file/FileSwapSpaceSpi.java    |    4 +-
 .../ignite/stream/socket/SocketStreamer.java    |    3 +-
 ...RoundRobinErrorAfterClientReconnectTest.java |   99 +
 .../MarshallerContextLockingSelfTest.java       |    2 +-
 .../managers/GridManagerStopSelfTest.java       |    2 +
 .../cache/CacheGetEntryAbstractTest.java        |    3 +-
 .../processors/cache/CachePutIfAbsentTest.java  |  161 +
 .../CacheSerializableTransactionsTest.java      |   70 +-
 .../processors/cache/CacheTxFastFinishTest.java |    2 +-
 .../GridCacheTtlManagerEvictionSelfTest.java    |  160 +
 .../MarshallerCacheJobRunNodeRestartTest.java   |    2 +-
 .../cache/query/IndexingSpiQuerySelfTest.java   |  218 ++
 .../cache/query/IndexingSpiQueryTxSelfTest.java |  162 +
 ...eContinuousQueryAsyncFailoverTxSelfTest.java |    5 +
 ...ContinuousQueryFailoverAbstractSelfTest.java |  225 +-
 .../CacheContinuousQueryFailoverTxSelfTest.java |    5 +
 ...eEntryProcessorExternalizableFailedTest.java |  588 +++
 .../igfs/IgfsAbstractBaseSelfTest.java          |   19 +
 .../processors/igfs/IgfsAbstractSelfTest.java   |  146 +-
 .../igfs/IgfsDualAbstractSelfTest.java          |   42 +-
 ...SecondaryFileSystemDualAbstractSelfTest.java |   26 +-
 ...fsLocalSecondaryFileSystemProxySelfTest.java |    5 -
 ...IgfsLocalSecondaryFileSystemTestAdapter.java |   27 +-
 .../igfs/benchmark/IgfsBenchmark.java           |  561 +++
 .../handlers/log/GridLogCommandHandlerTest.java |    5 +-
 ...artupWithSpecifiedWorkDirectorySelfTest.java |  166 -
 .../util/future/GridFutureAdapterSelfTest.java  |    3 +
 .../ipc/shmem/IgfsSharedMemoryTestServer.java   |    4 +-
 .../IpcSharedMemoryCrashDetectionSelfTest.java  |    9 +-
 .../IpcSharedMemoryBenchmarkReader.java         |    2 +-
 .../ignite/logger/java/JavaLoggerTest.java      |    3 +-
 .../OptimizedMarshallerNodeFailoverTest.java    |    4 -
 ...heckpointSpiMultipleDirectoriesSelfTest.java |    6 +-
 .../GridAbstractCommunicationSelfTest.java      |    2 -
 ...mmunicationSpiConcurrentConnectSelfTest.java |   14 +
 ...nicationSpiConcurrentConnectSslSelfTest.java |   35 +
 ...cpCommunicationSpiMultithreadedSelfTest.java |    2 -
 ...GridTcpCommunicationSpiRecoverySelfTest.java |   14 +
 ...dTcpCommunicationSpiRecoverySslSelfTest.java |   35 +
 ...CommunicationSpiSslSmallBuffersSelfTest.java |   43 +
 .../tcp/IgniteCacheSslStartStopSelfTest.java    |    1 -
 .../tcp/TcpDiscoverySnapshotHistoryTest.java    |   14 +-
 .../GridSwapSpaceSpiAbstractSelfTest.java       |    2 -
 .../ignite/testframework/GridTestUtils.java     |   37 +
 .../ignite/testframework/IgniteTestSuite.java   |   18 +-
 .../testframework/junits/GridAbstractTest.java  |    2 +-
 .../junits/GridTestKernalContext.java           |    2 +
 .../ignite/testframework/junits/IgniteMock.java |   10 +
 .../junits/IgniteTestResources.java             |    2 -
 .../junits/spi/GridSpiAbstractTest.java         |    2 -
 .../testsuites/IgniteBinaryBasicTestSuite.java  |    2 -
 .../ignite/testsuites/IgniteCacheTestSuite.java |    4 +
 .../testsuites/IgniteCacheTestSuite4.java       |    2 +
 .../testsuites/IgniteComputeGridTestSuite.java  |    2 +
 .../testsuites/IgniteKernalSelfTestSuite.java   |    2 -
 .../IgniteSpiCommunicationSelfTestSuite.java    |   11 +-
 .../CacheNoValueClassOnServerTestClient.java    |    2 -
 .../CacheConfigurationP2PTestClient.java        |    2 -
 .../IgniteHadoopClientProtocolProvider.java     |   53 +-
 .../processors/hadoop/HadoopExternalSplit.java  |    8 +
 .../processors/hadoop/HadoopHelperImpl.java     |   13 +
 .../processors/hadoop/HadoopSplitWrapper.java   |    9 +
 .../processors/hadoop/impl/HadoopUtils.java     |   11 +-
 .../HadoopBasicFileSystemFactoryDelegate.java   |   16 +-
 ...doopIgfsSecondaryFileSystemDelegateImpl.java |    3 +-
 ...HadoopKerberosFileSystemFactoryDelegate.java |    7 +-
 .../hadoop/impl/igfs/HadoopIgfsProperties.java  |    3 +
 .../processors/hadoop/impl/v2/HadoopV2Job.java  |   13 +-
 .../hadoop/impl/v2/HadoopV2TaskContext.java     |    4 +-
 .../hadoop/jobtracker/HadoopJobTracker.java     |   61 +
 .../external/HadoopExternalTaskExecutor.java    |   13 +-
 .../child/HadoopExternalProcessStarter.java     |   10 +-
 .../HadoopExternalCommunication.java            |   10 +-
 .../communication/HadoopMarshallerFilter.java   |   13 +-
 .../hadoop/impl/HadoopAbstractSelfTest.java     |    4 +-
 .../hadoop/impl/HadoopPlannerMockJob.java       |    7 +
 ...opClientProtocolMultipleServersSelfTest.java |  324 ++
 .../impl/igfs/Hadoop1DualAbstractTest.java      |   12 +-
 ...oopSecondaryFileSystemConfigurationTest.java |   12 +
 .../HadoopExternalCommunicationSelfTest.java    |    2 +-
 .../testsuites/IgniteHadoopTestSuite.java       |    2 +
 .../hibernate/CacheHibernateBlobStore.java      |    4 +-
 modules/ignored-tests/pom.xml                   |    8 +
 ...gniteIgnoredBinarySimpleMapperTestSuite.java |   41 +
 .../IgniteIgnoredBinaryTestSuite.java           |   42 +
 .../testsuites/IgniteIgnoredTestSuite.java      |    4 +
 .../processors/query/h2/IgniteH2Indexing.java   |  164 +-
 .../query/h2/twostep/GridMapQueryExecutor.java  |   66 +-
 .../query/h2/twostep/GridMergeIndex.java        |   12 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |  127 +-
 .../h2/twostep/msg/GridH2QueryRequest.java      |   42 +-
 .../cache/CacheConfigurationP2PTestServer.java  |    2 -
 ...niteCacheDistributedQueryCancelSelfTest.java |  176 +
 ...butedQueryStopOnCancelOrTimeoutSelfTest.java |  253 ++
 ...cheQueryAbstractDistributedJoinSelfTest.java |  290 ++
 ...QueryNodeRestartDistributedJoinSelfTest.java |  262 +-
 .../IgniteCacheQueryNodeRestartSelfTest2.java   |  125 +-
 ...nCancelOrTimeoutDistributedJoinSelfTest.java |  138 +
 .../IgniteCacheReplicatedQuerySelfTest.java     |    2 +
 ...eCacheLocalQueryCancelOrTimeoutSelfTest.java |  158 +
 .../query/IgniteSqlSplitterSelfTest.java        |    2 +
 .../h2/GridIndexingSpiAbstractSelfTest.java     |   13 +-
 .../query/h2/sql/BaseH2CompareQueryTest.java    |    3 +-
 ...narySimpleNameMapperCacheQueryTestSuite.java |    2 -
 .../IgniteCacheQuerySelfTestSuite.java          |   12 +-
 .../IgniteCacheQuerySelfTestSuite2.java         |   13 +-
 .../serialization/CacheEventDeserializer.java   |    3 +-
 .../serialization/CacheEventSerializer.java     |    3 +-
 modules/platforms/cpp/common/Makefile.am        |    4 +-
 .../common/include/ignite/common/concurrent.h   |    5 +-
 .../cpp/common/include/ignite/ignite_error.h    |    4 +-
 .../platforms/cpp/common/src/ignite_error.cpp   |    4 +-
 modules/platforms/cpp/core-test/Makefile.am     |   10 +-
 .../cpp/core-test/config/cache-query.xml        |   12 +-
 .../cpp/core-test/src/cache_query_test.cpp      |    2 +-
 .../cpp/core-test/src/decimal_test.cpp          |    2 +-
 .../cpp/core-test/src/interop_memory_test.cpp   |    5 +-
 .../cpp/core/include/ignite/cache/cache.h       |   15 +-
 .../core/include/ignite/impl/cache/cache_impl.h |   41 +-
 .../ignite/impl/interop/interop_target.h        |   18 +
 .../cpp/core/src/impl/cache/cache_impl.cpp      |   48 +-
 .../core/src/impl/cache/query/query_impl.cpp    |   15 +-
 .../core/src/impl/interop/interop_target.cpp    |   25 +
 .../src/impl/transactions/transactions_impl.cpp |  135 +-
 .../cpp/jni/include/ignite/jni/exports.h        |  106 +-
 .../platforms/cpp/jni/include/ignite/jni/java.h |  229 +-
 modules/platforms/cpp/jni/project/vs/module.def |   88 +-
 modules/platforms/cpp/jni/src/exports.cpp       |  359 +-
 modules/platforms/cpp/jni/src/java.cpp          | 1405 +------
 modules/platforms/cpp/odbc-test/Makefile.am     |    4 +-
 .../cpp/odbc-test/src/queries_test.cpp          |    4 +-
 .../cpp/odbc/src/config/configuration.cpp       |    2 +-
 modules/platforms/cpp/odbc/src/odbc.cpp         |    4 +-
 .../Cache/CacheAbstractTest.cs                  |    2 +-
 .../IgniteConfigurationTest.cs                  |   24 +-
 .../Services/ServicesTest.cs                    |    2 +
 .../Apache.Ignite.Core.csproj                   |    3 +-
 .../Impl/Cache/CacheAffinityImpl.cs             |    5 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |  484 ++-
 .../Apache.Ignite.Core/Impl/Cache/CacheLock.cs  |   24 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheOp.cs    |   43 +-
 .../Impl/Cache/ICacheLockInternal.cs            |   47 +
 .../Impl/Cache/Query/AbstractQueryCursor.cs     |   10 +-
 .../Continuous/ContinuousQueryHandleImpl.cs     |  117 +-
 .../Impl/Cache/Store/CacheStore.cs              |  108 +-
 .../Impl/Cluster/ClusterGroupImpl.cs            |   64 +-
 .../Apache.Ignite.Core/Impl/Common/Future.cs    |   30 +-
 .../Impl/Compute/ComputeImpl.cs                 |   46 +-
 .../Impl/DataStructures/AtomicLong.cs           |   34 +-
 .../Impl/DataStructures/AtomicReference.cs      |    8 +-
 .../Impl/DataStructures/AtomicSequence.cs       |   26 +-
 .../Impl/Datastream/DataStreamerImpl.cs         |   49 +-
 .../Apache.Ignite.Core/Impl/Events/Events.cs    |  180 +-
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs    |    4 +-
 .../Apache.Ignite.Core/Impl/IgniteUtils.cs      |    2 +-
 .../Impl/Messaging/Messaging.cs                 |  113 +-
 .../Apache.Ignite.Core/Impl/PlatformTarget.cs   |  233 +-
 .../Impl/Services/Services.cs                   |  146 +-
 .../Impl/Transactions/TransactionsImpl.cs       |   64 +-
 .../Impl/Unmanaged/IgniteJniNativeMethods.cs    |  272 +-
 .../Impl/Unmanaged/UnmanagedCallbacks.cs        |   41 +-
 .../Impl/Unmanaged/UnmanagedUtils.cs            |  553 +--
 .../dotnet/Apache.Ignite.sln.DotSettings        |    3 +-
 .../Apache.Ignite.sln.TeamCity.DotSettings      |    1 +
 .../spi/deployment/uri/UriDeploymentSpi.java    |    2 +-
 .../scala/org/apache/ignite/visor/visor.scala   |    2 +-
 modules/web-console/DEVNOTES.txt                |    2 +-
 modules/web-console/backend/app/agent.js        |   26 +-
 modules/web-console/backend/app/browser.js      |   14 +-
 modules/web-console/backend/app/mongo.js        |  207 +-
 .../backend/routes/demo/domains.json            |   15 +-
 modules/web-console/backend/services/agents.js  |    1 +
 modules/web-console/backend/services/auth.js    |    8 +-
 modules/web-console/backend/services/caches.js  |   14 +-
 .../web-console/backend/services/clusters.js    |   19 +-
 modules/web-console/backend/services/domains.js |   12 +-
 modules/web-console/backend/services/igfss.js   |   12 +-
 .../backend/test/unit/AuthService.test.js       |    4 +-
 .../backend/test/unit/CacheService.test.js      |  135 +-
 .../backend/test/unit/ClusterService.test.js    |  132 +-
 .../backend/test/unit/DomainService.test.js     |  144 +-
 .../backend/test/unit/IgfsService.test.js       |  122 +-
 modules/web-console/frontend/.eslintrc          |    6 +-
 modules/web-console/frontend/app/app.config.js  |   10 +
 modules/web-console/frontend/app/app.js         |   37 +-
 .../web-console/frontend/app/data/dialects.json |    9 +
 .../frontend/app/data/java-classes.json         |    4 +-
 .../frontend/app/decorator/tooltip.js           |   13 +-
 .../app/directives/on-focus-out.directive.js    |   37 +
 .../directives/restore-input-focus.directive.js |   24 +
 .../ui-ace-java/ui-ace-java.controller.js       |   78 +-
 .../ui-ace-java/ui-ace-java.directive.js        |  100 +-
 .../ui-ace-pojos/ui-ace-pojos.controller.js     |    2 +-
 .../ui-ace-pom/ui-ace-pom.controller.js         |    2 +-
 .../ui-ace-sharp/ui-ace-sharp.controller.js     |   32 +
 .../ui-ace-sharp/ui-ace-sharp.directive.js      |  133 +
 .../directives/ui-ace-sharp/ui-ace-sharp.jade   |   22 +
 .../ui-ace-spring/ui-ace-spring.controller.js   |   88 +
 .../ui-ace-spring/ui-ace-spring.directive.js    |   66 +
 .../directives/ui-ace-spring/ui-ace-spring.jade |   17 +
 .../ui-ace-xml/ui-ace-xml.controller.js         |   27 -
 .../ui-ace-xml/ui-ace-xml.directive.js          |  147 -
 .../app/directives/ui-ace-xml/ui-ace-xml.jade   |   17 -
 .../ui-grid-settings/ui-grid-settings.jade      |   33 +
 .../ui-grid-settings/ui-grid-settings.scss      |   38 +
 .../frontend/app/filters/default-name.filter.js |   21 +
 .../frontend/app/filters/hasPojo.filter.js      |    5 +-
 .../helpers/jade/form/form-field-feedback.jade  |    5 +-
 .../frontend/app/helpers/jade/mixins.jade       |  219 +-
 .../frontend/app/modules/agent/agent.module.js  |   10 +-
 .../modules/configuration/Version.service.js    |   82 +-
 .../configuration/configuration.module.js       |   30 +-
 .../generator/AbstractTransformer.js            |  341 ++
 .../modules/configuration/generator/Beans.js    |  379 ++
 .../generator/ConfigurationGenerator.js         | 1785 +++++++++
 .../configuration/generator/Java.service.js     |   21 -
 .../generator/JavaTransformer.service.js        | 1721 +++++++++
 .../generator/PlatformGenerator.js              |  522 +++
 .../configuration/generator/Pom.service.js      |  173 +-
 .../generator/Properties.service.js             |   74 +
 .../configuration/generator/Readme.service.js   |   79 +
 .../generator/SharpTransformer.service.js       |  243 ++
 .../generator/SpringTransformer.service.js      |  325 ++
 .../configuration/generator/StringBuilder.js    |   76 +
 .../configuration/generator/Xml.service.js      |   21 -
 .../defaults/cache.platform.provider.js         |   60 +
 .../generator/defaults/cache.provider.js        |  129 +
 .../defaults/cluster.platform.provider.js       |   49 +
 .../generator/defaults/cluster.provider.js      |  293 ++
 .../generator/defaults/igfs.provider.js         |   68 +
 .../configuration/generator/generator-common.js |  625 +++
 .../configuration/generator/generator-java.js   | 3617 ++++++++++++++++++
 .../generator/generator-optional.js             |   25 +
 .../configuration/generator/generator-spring.js | 2111 ++++++++++
 .../app/modules/form/field/input/select.scss    |   21 -
 .../app/modules/form/field/input/text.scss      |    1 -
 .../frontend/app/modules/form/form.module.js    |   10 +-
 .../app/modules/form/panel/revert.directive.js  |    4 +-
 .../modules/form/services/FormGUID.service.js   |   22 +
 .../validator/java-built-in-class.directive.js  |    6 +-
 .../form/validator/java-identifier.directive.js |    6 +-
 .../form/validator/java-keywords.directive.js   |   15 +-
 .../java-package-specified.directive.js         |    6 +-
 .../frontend/app/modules/nodes/Nodes.service.js |   69 +
 .../modules/nodes/nodes-dialog.controller.js    |   68 +
 .../app/modules/nodes/nodes-dialog.jade         |   35 +
 .../app/modules/nodes/nodes-dialog.scss         |   37 +
 .../frontend/app/modules/nodes/nodes.module.js  |   27 +
 .../frontend/app/modules/sql/sql.controller.js  |  269 +-
 .../app/modules/states/configuration.state.js   |    2 +-
 .../configuration/caches/client-near-cache.jade |   50 +
 .../states/configuration/caches/general.jade    |    3 +
 .../states/configuration/caches/memory.jade     |   14 +-
 .../configuration/caches/near-cache-client.jade |   51 +
 .../configuration/caches/near-cache-server.jade |   52 +
 .../configuration/caches/node-filter.jade       |   49 -
 .../states/configuration/caches/query.jade      |   30 +-
 .../states/configuration/caches/rebalance.jade  |    3 +-
 .../configuration/caches/server-near-cache.jade |   51 -
 .../states/configuration/caches/store.jade      |   84 +-
 .../states/configuration/clusters/atomic.jade   |    3 +-
 .../configuration/clusters/attributes.jade      |    4 +-
 .../states/configuration/clusters/binary.jade   |   28 +-
 .../configuration/clusters/cache-key-cfg.jade   |    9 +-
 .../configuration/clusters/checkpoint.jade      |   85 +
 .../configuration/clusters/checkpoint/fs.jade   |   66 +
 .../configuration/clusters/checkpoint/jdbc.jade |   45 +
 .../configuration/clusters/checkpoint/s3.jade   |  174 +
 .../configuration/clusters/collision.jade       |   13 +-
 .../clusters/collision/job-stealing.jade        |    2 +-
 .../configuration/clusters/communication.jade   |    3 +-
 .../configuration/clusters/connector.jade       |    3 +-
 .../configuration/clusters/deployment.jade      |    3 +-
 .../configuration/clusters/discovery.jade       |    3 +-
 .../states/configuration/clusters/events.jade   |   37 +-
 .../states/configuration/clusters/failover.jade |   19 +-
 .../states/configuration/clusters/general.jade  |    3 +
 .../clusters/general/discovery/zookeeper.jade   |    2 +
 .../states/configuration/clusters/igfs.jade     |    3 +-
 .../configuration/clusters/load-balancing.jade  |  104 +
 .../configuration/clusters/marshaller.jade      |    3 +-
 .../states/configuration/clusters/odbc.jade     |    3 +-
 .../states/configuration/clusters/ssl.jade      |    7 +-
 .../states/configuration/clusters/swap.jade     |    3 +-
 .../configuration/clusters/transactions.jade    |    6 +-
 .../states/configuration/domains/general.jade   |   12 +-
 .../states/configuration/domains/query.jade     |   40 +-
 .../states/configuration/domains/store.jade     |   15 +-
 .../states/configuration/igfs/general.jade      |    3 +
 .../modules/states/configuration/igfs/ipc.jade  |    2 +-
 .../modules/states/configuration/igfs/misc.jade |    4 +-
 .../states/configuration/igfs/secondary.jade    |    3 +-
 .../configuration/summary/summary.controller.js |  106 +-
 .../app/services/ErrorPopover.service.js        |    2 +-
 .../frontend/app/services/FormUtils.service.js  |    6 +-
 .../frontend/app/services/JavaTypes.service.js  |   70 +-
 .../app/services/LegacyTable.service.js         |   24 +-
 .../app/services/LegacyUtils.service.js         |  128 +-
 .../frontend/app/services/SqlTypes.service.js   |    6 +-
 modules/web-console/frontend/app/vendor.js      |    3 +-
 .../frontend/controllers/caches-controller.js   |  121 +-
 .../frontend/controllers/clusters-controller.js |  177 +-
 .../frontend/controllers/domains-controller.js  |  148 +-
 .../frontend/controllers/igfs-controller.js     |    6 +-
 .../frontend/generator/generator-common.js      |  625 ---
 .../frontend/generator/generator-java.js        | 3611 -----------------
 .../frontend/generator/generator-optional.js    |   25 -
 .../frontend/generator/generator-properties.js  |  175 -
 .../frontend/generator/generator-readme.js      |   85 -
 .../frontend/generator/generator-xml.js         | 2108 ----------
 .../frontend/gulpfile.babel.js/paths.js         |   31 +-
 .../frontend/gulpfile.babel.js/tasks/jade.js    |   21 +-
 .../frontend/gulpfile.babel.js/tasks/watch.js   |    6 +-
 .../gulpfile.babel.js/webpack/common.js         |    2 +-
 .../webpack/environments/development.js         |   17 +-
 .../webpack/environments/test.js                |   52 +
 .../frontend/gulpfile.babel.js/webpack/index.js |    4 +-
 modules/web-console/frontend/package.json       |   16 +-
 .../frontend/public/stylesheets/style.scss      |   75 +-
 .../frontend/test/karma.conf.babel.js           |   91 +
 modules/web-console/frontend/test/karma.conf.js |   98 +-
 .../frontend/test/unit/JavaTransformer.test.js  |   57 +
 .../frontend/test/unit/JavaTypes.test.js        |   23 +-
 .../frontend/test/unit/SharpTransformer.test.js |   55 +
 .../test/unit/SpringTransformer.test.js         |   57 +
 .../frontend/test/unit/SqlTypes.test.js         |   17 -
 .../frontend/test/unit/Version.test.js          |   82 +
 .../test/unit/defaultName.filter.test.js        |   38 +
 .../frontend/views/configuration/caches.jade    |    3 +-
 .../frontend/views/configuration/clusters.jade  |    3 +-
 .../views/configuration/domains-import.jade     |   14 +-
 .../summary-project-structure.jade              |    2 +-
 .../frontend/views/configuration/summary.jade   |   57 +-
 .../frontend/views/sql/cache-metadata.jade      |    2 +-
 .../frontend/views/sql/notebook-new.jade        |    4 +-
 modules/web-console/frontend/views/sql/sql.jade |   80 +-
 .../views/templates/agent-download.jade         |    6 +-
 .../frontend/views/templates/batch-confirm.jade |    4 +-
 .../frontend/views/templates/clone.jade         |    4 +-
 .../frontend/views/templates/confirm.jade       |    4 +-
 .../frontend/views/templates/demo-info.jade     |    4 +-
 .../views/templates/getting-started.jade        |    4 +-
 .../frontend/views/templates/message.jade       |    4 +-
 .../frontend/views/templates/select.jade        |    2 +-
 .../ignite/console/demo/AgentClusterDemo.java   |    2 +-
 .../ignite/cache/websession/WebSessionV2.java   |   26 +-
 501 files changed, 26906 insertions(+), 14876 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcResultSetSelfTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/core/src/main/java/org/apache/ignite/cache/affinity/rendezvous/RendezvousAffinityFunction.java
----------------------------------------------------------------------

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

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

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

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/core/src/main/java/org/apache/ignite/internal/processors/igfs/IgfsImpl.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/core/src/main/java/org/apache/ignite/internal/processors/offheap/GridOffHeapProcessor.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/core/src/main/java/org/apache/ignite/internal/processors/task/GridTaskWorker.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/core/src/main/java/org/apache/ignite/internal/util/IgniteUtils.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/core/src/main/java/org/apache/ignite/internal/util/ipc/shmem/IpcSharedMemoryServerEndpoint.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationSpi.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ClientImpl.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpi.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ipfinder/multicast/TcpDiscoveryMulticastIpFinder.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/core/src/main/java/org/apache/ignite/spi/swapspace/file/FileSwapSpaceSpi.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/core/src/test/java/org/apache/ignite/testframework/GridTestUtils.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/core/src/test/java/org/apache/ignite/testframework/junits/GridAbstractTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheTestSuite.java
----------------------------------------------------------------------
diff --cc modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheTestSuite.java
index 711453c,fd13e98..435fcfb
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheTestSuite.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheTestSuite.java
@@@ -81,9 -81,9 +81,10 @@@ import org.apache.ignite.internal.proce
  import org.apache.ignite.internal.processors.cache.GridCacheStopSelfTest;
  import org.apache.ignite.internal.processors.cache.GridCacheStorePutxSelfTest;
  import org.apache.ignite.internal.processors.cache.GridCacheStoreValueBytesSelfTest;
 +import org.apache.ignite.internal.processors.cache.GridCacheSwapCleanupTest;
  import org.apache.ignite.internal.processors.cache.GridCacheSwapPreloadSelfTest;
  import org.apache.ignite.internal.processors.cache.GridCacheSwapReloadSelfTest;
+ import org.apache.ignite.internal.processors.cache.GridCacheTtlManagerEvictionSelfTest;
  import org.apache.ignite.internal.processors.cache.GridCacheTtlManagerSelfTest;
  import org.apache.ignite.internal.processors.cache.GridCacheTxPartitionedLocalStoreSelfTest;
  import org.apache.ignite.internal.processors.cache.IgniteCacheAtomicInvokeTest;

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/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 145a896,d9cc8c0..2d06f3a
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteKernalSelfTestSuite.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteKernalSelfTestSuite.java
@@@ -66,10 -66,8 +66,9 @@@ import org.apache.ignite.internal.proce
  import org.apache.ignite.internal.processors.service.IgniteServiceDeploymentClassLoadingDefaultMarshallerTest;
  import org.apache.ignite.internal.processors.service.IgniteServiceDeploymentClassLoadingJdkMarshallerTest;
  import org.apache.ignite.internal.processors.service.IgniteServiceDeploymentClassLoadingOptimizedMarshallerTest;
 +import org.apache.ignite.internal.processors.service.IgniteServiceDynamicCachesSelfTest;
  import org.apache.ignite.internal.processors.service.IgniteServiceReassignmentTest;
  import org.apache.ignite.internal.processors.service.ServicePredicateAccessCacheTest;
- import org.apache.ignite.internal.util.GridStartupWithSpecifiedWorkDirectorySelfTest;
  import org.apache.ignite.internal.util.GridStartupWithUndefinedIgniteHomeSelfTest;
  import org.apache.ignite.spi.communication.GridCacheMessageSelfTest;
  import org.apache.ignite.testframework.GridTestUtils;

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/taskexecutor/external/communication/HadoopExternalCommunication.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/IgniteH2Indexing.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/twostep/GridMapQueryExecutor.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/twostep/GridReduceQueryExecutor.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/distributed/replicated/IgniteCacheReplicatedQuerySelfTest.java
----------------------------------------------------------------------
diff --cc modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/distributed/replicated/IgniteCacheReplicatedQuerySelfTest.java
index 048bc8c,a673a73..6d9cbb1
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/distributed/replicated/IgniteCacheReplicatedQuerySelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/distributed/replicated/IgniteCacheReplicatedQuerySelfTest.java
@@@ -44,9 -48,14 +44,10 @@@ import org.apache.ignite.internal.proce
  import org.apache.ignite.internal.util.typedef.X;
  import org.apache.ignite.internal.util.typedef.internal.S;
  import org.apache.ignite.internal.util.typedef.internal.U;
 -import org.apache.ignite.lang.IgniteBiTuple;
  import org.apache.ignite.lang.IgnitePredicate;
  import org.apache.ignite.testframework.GridTestUtils;
+ import org.apache.ignite.testsuites.IgniteIgnore;
  import org.apache.ignite.transactions.Transaction;
 -import org.springframework.util.ReflectionUtils;
  
  import static org.apache.ignite.cache.CacheMode.REPLICATED;
  import static org.apache.ignite.cache.CachePeekMode.ALL;

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/GridIndexingSpiAbstractSelfTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/indexing/src/test/java/org/apache/ignite/testsuites/IgniteCacheQuerySelfTestSuite2.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Cache/CacheAbstractTest.cs
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/platforms/dotnet/Apache.Ignite.Core/Apache.Ignite.Core.csproj
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/platforms/dotnet/Apache.Ignite.Core/Impl/Events/Events.cs
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/platforms/dotnet/Apache.Ignite.Core/Impl/IgniteUtils.cs
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/platforms/dotnet/Apache.Ignite.Core/Impl/PlatformTarget.cs
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/platforms/dotnet/Apache.Ignite.Core/Impl/Unmanaged/UnmanagedCallbacks.cs
----------------------------------------------------------------------
diff --cc modules/platforms/dotnet/Apache.Ignite.Core/Impl/Unmanaged/UnmanagedCallbacks.cs
index e623969,fcc1652..9dc5b1e
--- a/modules/platforms/dotnet/Apache.Ignite.Core/Impl/Unmanaged/UnmanagedCallbacks.cs
+++ b/modules/platforms/dotnet/Apache.Ignite.Core/Impl/Unmanaged/UnmanagedCallbacks.cs
@@@ -1,19 -1,19 +1,19 @@@
 -\ufeff\ufeff/*
 +\ufeff/*
- * 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.
- */
+  * 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.
+  */
  
  namespace Apache.Ignite.Core.Impl.Unmanaged
  {

http://git-wip-us.apache.org/repos/asf/ignite/blob/173e2b83/modules/platforms/dotnet/Apache.Ignite.sln.DotSettings
----------------------------------------------------------------------
diff --cc modules/platforms/dotnet/Apache.Ignite.sln.DotSettings
index 688a924,72ce015..078e9fb
--- a/modules/platforms/dotnet/Apache.Ignite.sln.DotSettings
+++ b/modules/platforms/dotnet/Apache.Ignite.sln.DotSettings
@@@ -1,9 -1,6 +1,10 @@@
  \ufeff<wpf:ResourceDictionary xml:space="preserve" xmlns:x="http://schemas.microsoft.com/winfx/2006/xaml" xmlns:s="clr-namespace:System;assembly=mscorlib" xmlns:ss="urn:shemas-jetbrains-com:settings-storage-xaml" xmlns:wpf="http://schemas.microsoft.com/winfx/2006/xaml/presentation">
  	<s:String x:Key="/Default/CodeInspection/CSharpLanguageProject/LanguageLevel/@EntryValue">CSharp50</s:String>
 +	<s:String x:Key="/Default/CodeStyle/CodeCleanup/Profiles/=silent/@EntryIndexedValue">&lt;?xml version="1.0" encoding="utf-16"?&gt;&lt;Profile name="silent"&gt;&lt;CSReorderTypeMembers&gt;True&lt;/CSReorderTypeMembers&gt;&lt;CSCodeStyleAttributes ArrangeTypeAccessModifier="True" ArrangeTypeMemberAccessModifier="True" SortModifiers="True" RemoveRedundantParentheses="False" AddMissingParentheses="False" ArrangeBraces="False" ArrangeAttributes="False" ArrangeArgumentsStyle="False" /&gt;&lt;RemoveCodeRedundancies&gt;True&lt;/RemoveCodeRedundancies&gt;&lt;CSArrangeQualifiers&gt;True&lt;/CSArrangeQualifiers&gt;&lt;CSOptimizeUsings&gt;&lt;OptimizeUsings&gt;True&lt;/OptimizeUsings&gt;&lt;EmbraceInRegion&gt;False&lt;/EmbraceInRegion&gt;&lt;RegionName&gt;&lt;/RegionName&gt;&lt;/CSOptimizeUsings&gt;&lt;CSShortenReferences&gt;True&lt;/CSShortenReferences&gt;&lt;CSReformatCode&gt;True&lt;/CSReformatCode&gt;&lt;/Profile&gt;</s:String>
 +	<s:String x:Key="/Default/CodeStyle/CodeCleanup/SilentCleanupProfile/@EntryValue">silent</s:String>
 +	<s:String x:Key="/Default/CodeStyle/CodeFormatting/XmlDocFormatter/IndentSubtags/@EntryValue">DoNotTouch</s:String>
 +	<s:String x:Key="/Default/CodeStyle/CodeFormatting/XmlDocFormatter/IndentTagContent/@EntryValue">DoNotTouch</s:String>
- 	<s:Boolean x:Key="/Default/CodeStyle/CSharpUsing/AddImportsToDeepestScope/@EntryValue">True</s:Boolean>	
+ 	<s:Boolean x:Key="/Default/CodeStyle/CSharpUsing/AddImportsToDeepestScope/@EntryValue">True</s:Boolean>
  	<s:Boolean x:Key="/Default/CodeStyle/CSharpUsing/QualifiedUsingAtNestedScope/@EntryValue">True</s:Boolean>
+ 	<s:String x:Key="/Default/CodeInspection/Highlighting/InspectionSeverities/=ConvertClosureToMethodGroup/@EntryIndexedValue">DO_NOT_SHOW</s:String>
  </wpf:ResourceDictionary>