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

[07/11] ignite git commit: Merge branch 'ignite-3477-master' of https://github.com/gridgain/apache-ignite into ignite-3477-master

Merge branch 'ignite-3477-master' of https://github.com/gridgain/apache-ignite into ignite-3477-master


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

Branch: refs/heads/ignite-3477-master
Commit: f701c6af2198ea22ef59f57063e053db7536f3cd
Parents: 5cf3f05 3f49b18
Author: Ilya Lantukh <il...@gridgain.com>
Authored: Fri Mar 31 15:36:30 2017 +0300
Committer: Ilya Lantukh <il...@gridgain.com>
Committed: Fri Mar 31 15:36:30 2017 +0300

----------------------------------------------------------------------
 .../computegrid/ComputeAsyncExample.java        |   8 +-
 .../ComputeFibonacciContinuationExample.java    |  13 +-
 .../examples/datagrid/CacheAsyncApiExample.java |  17 +-
 .../datastructures/IgniteLockExample.java       |   4 +-
 .../datastructures/IgniteSemaphoreExample.java  |   4 +-
 .../examples/ScalarContinuationExample.scala    |  10 +-
 .../singlesplit/SingleSplitsLoadTest.java       |   8 +-
 .../tcp/ipfinder/s3/TcpDiscoveryS3IpFinder.java |   6 +-
 ...3IpFinderAwsCredentialsProviderSelfTest.java |   2 +-
 .../ignite/tests/utils/TestTransaction.java     |  11 +
 modules/clients/pom.xml                         |   7 +
 .../src/test/config/jdbc-config-cache-store.xml | 124 +++
 .../internal/client/ClientStartNodeTask.java    |  10 +-
 .../jdbc2/JdbcAbstractDmlStatementSelfTest.java |   3 +
 .../internal/jdbc2/JdbcConnectionSelfTest.java  |  28 +-
 .../internal/jdbc2/JdbcSpringSelfTest.java      | 125 +++
 .../JettyRestProcessorAbstractSelfTest.java     |   3 +-
 .../jdbc/AbstractJdbcPojoQuerySelfTest.java     | 169 ++++
 .../jdbc/JdbcPojoLegacyQuerySelfTest.java       |  44 +
 .../ignite/jdbc/JdbcPojoQuerySelfTest.java      |  56 ++
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java   |   5 +
 .../java/org/apache/ignite/IgniteCache.java     | 611 +++++++++++-
 .../java/org/apache/ignite/IgniteCluster.java   | 126 +++
 .../java/org/apache/ignite/IgniteCompute.java   | 262 ++++-
 .../java/org/apache/ignite/IgniteEvents.java    | 128 ++-
 .../org/apache/ignite/IgniteFileSystem.java     |  76 ++
 .../java/org/apache/ignite/IgniteMessaging.java |  27 +
 .../java/org/apache/ignite/IgniteServices.java  | 221 ++++-
 .../ignite/binary/BinaryObjectBuilder.java      |  10 -
 .../store/jdbc/CacheAbstractJdbcStore.java      |  24 +-
 .../cache/store/jdbc/CacheJdbcPojoStore.java    |  18 +-
 .../configuration/CacheConfiguration.java       |  25 +
 .../configuration/MemoryConfiguration.java      | 104 +-
 .../MemoryPolicyConfiguration.java              |  80 ++
 .../apache/ignite/internal/GridComponent.java   |   5 +-
 .../ignite/internal/GridJobCancelRequest.java   |   2 +-
 .../ignite/internal/GridJobExecuteRequest.java  |   2 +-
 .../ignite/internal/GridJobExecuteResponse.java |   2 +-
 .../ignite/internal/GridJobSiblingsRequest.java |   2 +-
 .../internal/GridJobSiblingsResponse.java       |   2 +-
 .../ignite/internal/GridTaskCancelRequest.java  |   2 +-
 .../ignite/internal/GridTaskSessionRequest.java |   2 +-
 .../org/apache/ignite/internal/GridTopic.java   |   5 +-
 .../ignite/internal/IgniteComputeImpl.java      | 546 +++++++++--
 .../ignite/internal/IgniteEventsImpl.java       |  79 ++
 .../apache/ignite/internal/IgniteKernal.java    |  50 +-
 .../ignite/internal/IgniteMessagingImpl.java    |  65 +-
 .../ignite/internal/IgniteServicesImpl.java     | 108 +++
 .../ignite/internal/MarshallerContextImpl.java  |   4 +-
 .../binary/BinaryCachingMetadataHandler.java    |   6 +
 .../internal/binary/BinaryClassDescriptor.java  |  33 +-
 .../ignite/internal/binary/BinaryContext.java   |  29 +-
 .../internal/binary/BinaryEnumObjectImpl.java   |   2 +-
 .../internal/binary/BinaryFieldMetadata.java    | 127 +++
 .../ignite/internal/binary/BinaryMetadata.java  |  49 +-
 .../binary/BinaryMetadataCollector.java         |  17 +-
 .../internal/binary/BinaryMetadataHandler.java  |  18 +-
 .../binary/BinaryNoopMetadataHandler.java       |   5 +
 .../internal/binary/BinaryObjectExImpl.java     |   4 -
 .../internal/binary/BinaryObjectImpl.java       |   2 +-
 .../binary/BinaryObjectOffheapImpl.java         |   2 +-
 .../internal/binary/BinaryReaderExImpl.java     |   2 +-
 .../ignite/internal/binary/BinaryUtils.java     |  21 +-
 .../internal/binary/BinaryWriterExImpl.java     |  45 +-
 .../binary/builder/BinaryObjectBuilderImpl.java |  34 +-
 .../internal/cluster/ClusterGroupAdapter.java   |   2 +-
 .../cluster/IgniteClusterAsyncImpl.java         |  28 +-
 .../internal/cluster/IgniteClusterImpl.java     |  24 +-
 .../internal/direct/DirectMessageWriter.java    |   4 +-
 .../stream/v1/DirectByteBufferStreamImplV1.java |   8 +-
 .../stream/v2/DirectByteBufferStreamImplV2.java |   9 +-
 .../ignite/internal/jdbc2/JdbcConnection.java   |  19 +-
 .../ignite/internal/jdbc2/JdbcQueryTask.java    |   2 +-
 .../ignite/internal/jdbc2/JdbcQueryTaskV2.java  |   2 +-
 .../checkpoint/GridCheckpointRequest.java       |   2 +-
 .../managers/communication/GridIoMessage.java   |   2 +-
 .../communication/GridIoMessageFactory.java     |  23 +-
 .../communication/GridIoUserMessage.java        |   2 +-
 .../communication/IgniteIoTestMessage.java      |   2 +-
 .../deployment/GridDeploymentInfoBean.java      |   2 +-
 .../deployment/GridDeploymentRequest.java       |   2 +-
 .../deployment/GridDeploymentResponse.java      |   2 +-
 .../discovery/DiscoveryCustomMessage.java       |  48 +
 .../discovery/GridDiscoveryManager.java         |  38 +-
 .../eventstorage/GridEventStorageManager.java   |   6 +-
 .../eventstorage/GridEventStorageMessage.java   |   2 +-
 .../snapshot/SnapshotFinishedMessage.java       |   2 +-
 .../snapshot/SnapshotProgressMessage.java       |   2 +-
 .../affinity/AffinityTopologyVersion.java       |   2 +-
 .../cache/CacheAffinitySharedManager.java       |   4 -
 .../cache/CacheEntryInfoCollection.java         |   2 +-
 .../cache/CacheEntryPredicateAdapter.java       |   2 +-
 .../cache/CacheEntryPredicateContainsValue.java |   2 +-
 .../cache/CacheEntrySerializablePredicate.java  |   2 +-
 .../processors/cache/CacheEvictionEntry.java    |   2 +-
 .../cache/CacheInvokeDirectResult.java          |   2 +-
 .../cache/CacheObjectByteArrayImpl.java         |   2 +-
 .../processors/cache/CacheObjectImpl.java       |   2 +-
 .../processors/cache/GridCacheAdapter.java      | 187 +---
 .../processors/cache/GridCacheContext.java      |  43 +
 .../processors/cache/GridCacheEntryInfo.java    |   2 +-
 .../cache/GridCacheEvictionRequest.java         |   2 +-
 .../cache/GridCacheEvictionResponse.java        |   2 +-
 .../GridCachePartitionExchangeManager.java      |  12 +-
 .../processors/cache/GridCacheProcessor.java    |  21 +-
 .../processors/cache/GridCacheReturn.java       |   2 +-
 .../processors/cache/GridCacheUtils.java        |   4 -
 .../GridChangeGlobalStateMessageResponse.java   |   2 +-
 .../cache/IgniteCacheOffheapManagerImpl.java    |  37 +-
 .../processors/cache/IgniteCacheProxy.java      | 580 ++++++++++-
 .../processors/cache/KeyCacheObjectImpl.java    |   2 +-
 .../cache/binary/BinaryMetadataHolder.java      |  73 ++
 .../cache/binary/BinaryMetadataTransport.java   | 641 ++++++++++++
 .../binary/BinaryMetadataUpdatedListener.java   |  29 +
 .../binary/CacheObjectBinaryProcessor.java      |  12 +-
 .../binary/CacheObjectBinaryProcessorImpl.java  | 504 +++-------
 .../binary/ClientMetadataRequestFuture.java     | 161 ++++
 .../cache/binary/MetadataRequestMessage.java    | 122 +++
 .../cache/binary/MetadataResponseMessage.java   | 195 ++++
 .../binary/MetadataUpdateAcceptedMessage.java   |  96 ++
 .../binary/MetadataUpdateProposedMessage.java   | 224 +++++
 .../cache/binary/MetadataUpdateResult.java      |  96 ++
 .../cache/database/CacheDataRowAdapter.java     |   4 +-
 .../IgniteCacheDatabaseSharedManager.java       | 354 ++++++-
 .../processors/cache/database/MemoryPolicy.java |  53 +
 .../processors/cache/database/RowStore.java     |   2 +-
 .../distributed/GridCacheTtlUpdateRequest.java  |   2 +-
 .../distributed/GridCacheTxRecoveryRequest.java |   2 +-
 .../GridCacheTxRecoveryResponse.java            |   2 +-
 .../distributed/GridDistributedLockRequest.java |   2 +-
 .../GridDistributedLockResponse.java            |   2 +-
 .../GridDistributedTxFinishRequest.java         |   2 +-
 .../GridDistributedTxFinishResponse.java        |   2 +-
 .../GridDistributedTxPrepareRequest.java        |   2 +-
 .../GridDistributedTxPrepareResponse.java       |   2 +-
 .../GridDistributedUnlockRequest.java           |   2 +-
 .../dht/GridClientPartitionTopology.java        |  46 +-
 .../dht/GridDhtAffinityAssignmentRequest.java   |   2 +-
 .../dht/GridDhtAffinityAssignmentResponse.java  | 103 +-
 .../distributed/dht/GridDhtLockRequest.java     |   2 +-
 .../distributed/dht/GridDhtLockResponse.java    |   2 +-
 .../dht/GridDhtPartitionTopology.java           |  12 +-
 .../dht/GridDhtPartitionTopologyImpl.java       |  54 +-
 .../distributed/dht/GridDhtTxFinishRequest.java |   2 +-
 .../dht/GridDhtTxFinishResponse.java            |   2 +-
 .../dht/GridDhtTxOnePhaseCommitAckRequest.java  |   2 +-
 .../dht/GridDhtTxPrepareRequest.java            |   2 +-
 .../dht/GridDhtTxPrepareResponse.java           |   2 +-
 .../distributed/dht/GridDhtUnlockRequest.java   |   2 +-
 .../dht/GridPartitionedGetFuture.java           |   8 +-
 .../dht/GridPartitionedSingleGetFuture.java     |  56 +-
 .../dht/atomic/GridDhtAtomicCache.java          |   5 +
 .../GridDhtAtomicDeferredUpdateResponse.java    |   2 +-
 .../dht/atomic/GridDhtAtomicNearResponse.java   |   2 +-
 .../GridDhtAtomicSingleUpdateRequest.java       |   2 +-
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |   2 +-
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |   2 +-
 .../GridNearAtomicCheckUpdateRequest.java       |   2 +-
 .../atomic/GridNearAtomicFullUpdateRequest.java |   2 +-
 ...GridNearAtomicSingleUpdateFilterRequest.java |   2 +-
 ...GridNearAtomicSingleUpdateInvokeRequest.java |   2 +-
 .../GridNearAtomicSingleUpdateRequest.java      |   2 +-
 .../atomic/GridNearAtomicUpdateResponse.java    |   2 +-
 .../dht/atomic/NearCacheUpdates.java            |   2 +-
 .../distributed/dht/atomic/UpdateErrors.java    |   2 +-
 .../dht/preloader/GridDhtForceKeysRequest.java  |   2 +-
 .../dht/preloader/GridDhtForceKeysResponse.java |   2 +-
 .../GridDhtPartitionDemandMessage.java          |   2 +-
 .../dht/preloader/GridDhtPartitionDemander.java | 501 +---------
 .../preloader/GridDhtPartitionExchangeId.java   |   2 +-
 .../dht/preloader/GridDhtPartitionFullMap.java  |  22 +-
 .../dht/preloader/GridDhtPartitionMap.java      | 325 +++++++
 .../dht/preloader/GridDhtPartitionMap2.java     | 327 -------
 .../GridDhtPartitionSupplyMessage.java          |   2 +-
 .../GridDhtPartitionSupplyMessageV2.java        |   2 +-
 .../GridDhtPartitionsAbstractMessage.java       |   4 -
 .../GridDhtPartitionsExchangeFuture.java        |   2 +-
 .../preloader/GridDhtPartitionsFullMessage.java |   8 +-
 .../GridDhtPartitionsSingleMessage.java         |  12 +-
 .../GridDhtPartitionsSingleRequest.java         |   2 +-
 .../dht/preloader/GridDhtPreloader.java         |  18 +-
 .../distributed/near/CacheVersionedValue.java   |   2 +-
 .../distributed/near/GridNearGetRequest.java    |   2 +-
 .../distributed/near/GridNearGetResponse.java   |   2 +-
 .../distributed/near/GridNearLockRequest.java   |   2 +-
 .../distributed/near/GridNearLockResponse.java  |   2 +-
 .../near/GridNearSingleGetRequest.java          |   2 +-
 .../near/GridNearSingleGetResponse.java         |   2 +-
 .../near/GridNearTxFinishRequest.java           |   2 +-
 .../near/GridNearTxFinishResponse.java          |   2 +-
 .../cache/distributed/near/GridNearTxLocal.java |   1 -
 .../near/GridNearTxPrepareRequest.java          |   2 +-
 .../near/GridNearTxPrepareResponse.java         |   2 +-
 .../distributed/near/GridNearUnlockRequest.java |   2 +-
 .../query/GridCacheDistributedQueryManager.java |   7 +-
 .../cache/query/GridCacheLocalQueryFuture.java  |   3 +-
 .../cache/query/GridCacheQueryManager.java      |   3 +-
 .../cache/query/GridCacheQueryRequest.java      |   2 +-
 .../cache/query/GridCacheQueryResponse.java     |   2 +-
 .../cache/query/GridCacheSqlQuery.java          |   2 +-
 .../CacheContinuousQueryBatchAck.java           |   6 +-
 .../continuous/CacheContinuousQueryEntry.java   |   2 +-
 .../continuous/CacheContinuousQueryHandler.java |   6 +-
 .../continuous/CacheContinuousQueryManager.java |  87 +-
 .../query/jdbc/GridCacheQueryJdbcTask.java      |   4 +-
 .../store/GridCacheStoreManagerAdapter.java     |  35 +-
 .../cache/transactions/IgniteTxEntry.java       |   2 +-
 .../cache/transactions/IgniteTxKey.java         |   2 +-
 .../cache/transactions/IgniteTxManager.java     |   2 +
 .../transactions/TransactionProxyImpl.java      |  39 +-
 .../cache/transactions/TxEntryValueHolder.java  |   2 +-
 .../processors/cache/transactions/TxLock.java   |   2 +-
 .../cache/transactions/TxLockList.java          |   2 +-
 .../cache/transactions/TxLocksRequest.java      |   2 +-
 .../cache/transactions/TxLocksResponse.java     |   2 +-
 .../version/GridCacheRawVersionedEntry.java     |   2 +-
 .../cache/version/GridCacheVersion.java         |   2 +-
 .../cache/version/GridCacheVersionEx.java       |   2 +-
 .../clock/GridClockDeltaSnapshotMessage.java    |   2 +-
 .../processors/clock/GridClockDeltaVersion.java |   2 +-
 .../closure/GridClosureProcessor.java           | 398 +-------
 .../continuous/GridContinuousMessage.java       |   2 +-
 .../continuous/GridContinuousProcessor.java     |   3 -
 .../datastreamer/DataStreamerEntry.java         |   2 +-
 .../datastreamer/DataStreamerRequest.java       |   2 +-
 .../datastreamer/DataStreamerResponse.java      |   2 +-
 .../internal/processors/hadoop/HadoopJobId.java |   2 +-
 .../shuffle/HadoopDirectShuffleMessage.java     |   2 +-
 .../hadoop/shuffle/HadoopShuffleAck.java        |   2 +-
 .../shuffle/HadoopShuffleFinishRequest.java     |   2 +-
 .../shuffle/HadoopShuffleFinishResponse.java    |   2 +-
 .../hadoop/shuffle/HadoopShuffleMessage.java    |   2 +-
 .../processors/igfs/IgfsAckMessage.java         |   2 +-
 .../internal/processors/igfs/IgfsAsyncImpl.java |  43 +-
 .../internal/processors/igfs/IgfsBlockKey.java  |   3 +-
 .../processors/igfs/IgfsBlocksMessage.java      |   2 +-
 .../processors/igfs/IgfsDeleteMessage.java      |   2 +-
 .../processors/igfs/IgfsFileAffinityRange.java  |   2 +-
 .../igfs/IgfsFragmentizerRequest.java           |   2 +-
 .../igfs/IgfsFragmentizerResponse.java          |   2 +-
 .../internal/processors/igfs/IgfsImpl.java      |  62 +-
 .../processors/igfs/IgfsSyncMessage.java        |   2 +-
 .../GridMarshallerMappingProcessor.java         |   6 +-
 .../MissingMappingRequestMessage.java           |   2 +-
 .../MissingMappingResponseMessage.java          |   2 +-
 .../platform/PlatformAbstractTarget.java        |  24 +-
 .../platform/PlatformAsyncTarget.java           |  44 -
 .../platform/PlatformContextImpl.java           |  82 +-
 .../platform/PlatformTargetProxy.java           |  22 -
 .../platform/PlatformTargetProxyImpl.java       |  36 +-
 .../platform/cache/PlatformCache.java           | 218 +++--
 .../platform/compute/PlatformCompute.java       |  14 +-
 .../dotnet/PlatformDotNetCacheStore.java        |  12 +-
 ...formDotNetEntityFrameworkCacheExtension.java |   8 +-
 .../platform/events/PlatformEvents.java         |  70 +-
 .../memory/PlatformOutputStreamImpl.java        |   8 +-
 .../platform/messaging/PlatformMessaging.java   |  35 +-
 .../platform/services/PlatformServices.java     |  95 +-
 .../transactions/PlatformTransactions.java      |   9 +-
 .../utils/PlatformConfigurationUtils.java       |   2 +
 .../processors/query/GridQueryProcessor.java    |  10 +-
 .../query/QueryTypeDescriptorImpl.java          |  17 -
 .../messages/GridQueryCancelRequest.java        |   2 +-
 .../twostep/messages/GridQueryFailResponse.java |   2 +-
 .../messages/GridQueryNextPageRequest.java      |   2 +-
 .../messages/GridQueryNextPageResponse.java     |   2 +-
 .../h2/twostep/messages/GridQueryRequest.java   | 368 -------
 .../handlers/task/GridTaskResultRequest.java    |   2 +-
 .../handlers/task/GridTaskResultResponse.java   |   2 +-
 .../service/GridServiceProcessor.java           | 139 +--
 .../processors/task/GridTaskProcessor.java      |   9 +-
 .../ignite/internal/util/GridByteArrayList.java |   2 +-
 .../ignite/internal/util/GridLongList.java      |   2 +-
 .../internal/util/GridMessageCollection.java    |   2 +-
 .../ignite/internal/util/IgniteUtils.java       |  10 -
 .../internal/util/UUIDCollectionMessage.java    |   2 +-
 .../internal/util/nio/GridDirectParser.java     |  12 +-
 .../ignite/internal/visor/cache/VisorCache.java |  13 +-
 .../visor/cache/VisorCacheClearTask.java        |  14 +-
 .../visor/compute/VisorGatewayTask.java         |   6 +-
 .../visor/node/VisorGridConfiguration.java      |   2 +-
 .../visor/node/VisorMemoryConfiguration.java    |  55 +-
 .../node/VisorMemoryPolicyConfiguration.java    |  72 ++
 .../visor/node/VisorNodeDataCollectorJob.java   |  15 +-
 .../internal/visor/query/VisorQueryArg.java     |  27 +-
 .../internal/visor/query/VisorQueryJob.java     |   6 +-
 .../apache/ignite/lang/IgniteAsyncSupport.java  |  52 +-
 .../ignite/lang/IgniteAsyncSupported.java       |   4 +-
 .../extensions/communication/Message.java       |   5 +-
 .../communication/MessageFactory.java           |   2 +-
 .../extensions/communication/MessageWriter.java |   5 +-
 .../org/apache/ignite/spi/IgniteSpiAdapter.java |   2 +-
 .../jobstealing/JobStealingRequest.java         |   2 +-
 .../communication/tcp/TcpCommunicationSpi.java  | 148 +--
 .../ignite/spi/discovery/tcp/ServerImpl.java    | 104 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |   9 -
 .../messages/TcpDiscoveryClientAckResponse.java |   4 -
 .../apache/ignite/transactions/Transaction.java |  22 +
 .../resources/META-INF/classnames.properties    | 142 +--
 .../ignite/cache/LargeEntryUpdateTest.java      |   1 -
 .../IgniteCacheExpiryStoreLoadSelfTest.java     |  18 +-
 .../internal/ClusterGroupAbstractTest.java      |  73 +-
 .../ComputeJobCancelWithServiceSelfTest.java    |   7 +-
 .../internal/GridAffinityNoCacheSelfTest.java   |   2 +-
 .../internal/GridCancelOnGridStopSelfTest.java  |   2 +-
 .../GridCancelledJobsMetricsSelfTest.java       |  11 +-
 .../internal/GridContinuousTaskSelfTest.java    |  21 +-
 .../GridEventStorageCheckAllEventsSelfTest.java |  12 +-
 .../GridFailoverCustomTopologySelfTest.java     |   7 +-
 .../GridJobMasterLeaveAwareSelfTest.java        |  93 +-
 .../internal/GridMultipleJobsSelfTest.java      |   8 +-
 .../ignite/internal/GridReduceSelfTest.java     |   9 +-
 .../GridTaskCancelSingleNodeSelfTest.java       |   7 +-
 .../internal/GridTaskExecutionSelfTest.java     |  58 +-
 ...xecutionWithoutPeerClassLoadingSelfTest.java |  31 +
 .../GridTaskFailoverAffinityRunTest.java        |   7 +-
 .../GridTaskInstanceExecutionSelfTest.java      |   7 +-
 .../internal/GridTaskJobRejectSelfTest.java     |   7 +-
 .../IgniteClientReconnectApiExceptionTest.java  |  10 +-
 .../IgniteComputeEmptyClusterGroupTest.java     |  26 +-
 .../binary/BinaryMarshallerSelfTest.java        |   4 -
 .../BinaryObjectBuilderAdditionalSelfTest.java  |   9 +-
 ...naryObjectBuilderDefaultMappersSelfTest.java | 127 +--
 .../binary/BinaryObjectExceptionSelfTest.java   | 209 ----
 .../binary/TestCachingMetadataHandler.java      |   5 +
 ...ByteBufferStreamImplV2ByteOrderSelfTest.java |   2 +-
 ...GridManagerLocalMessageListenerSelfTest.java |   2 +-
 .../GridCommunicationSendMessageSelfTest.java   |  79 +-
 .../communication/GridIoManagerSelfTest.java    |   2 +-
 .../cache/CacheConcurrentReadThroughTest.java   |   8 +-
 .../cache/CacheConfigurationLeakTest.java       |   8 +-
 ...CacheExchangeMessageDuplicatedStateTest.java |  12 +-
 .../cache/CacheFutureExceptionSelfTest.java     |   6 +-
 .../CacheMemoryPolicyConfigurationTest.java     | 164 ++++
 .../CachePutEventListenerErrorSelfTest.java     |   7 +-
 .../GridCacheAbstractFailoverSelfTest.java      |  10 +-
 ...cheAbstractFullApiMultithreadedSelfTest.java | 105 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java | 876 ++++++++++++++---
 .../cache/GridCacheAbstractMetricsSelfTest.java |  52 +-
 .../GridCacheAsyncOperationsLimitSelfTest.java  |   9 +-
 .../GridCacheConcurrentTxMultiNodeTest.java     |  10 +-
 .../GridCacheConditionalDeploymentSelfTest.java |   4 +-
 .../GridCacheInterceptorAbstractSelfTest.java   |  31 +-
 .../GridCacheMissingCommitVersionSelfTest.java  |   6 +-
 .../cache/GridCachePutAllFailoverSelfTest.java  |  16 +-
 .../GridCacheReferenceCleanupSelfTest.java      |  15 +-
 ...ridCacheStoreManagerDeserializationTest.java |   1 -
 .../cache/GridCacheUtilsSelfTest.java           |   4 -
 ...calCacheStoreManagerDeserializationTest.java |   2 +-
 .../IgniteCacheAbstractStopBusySelfTest.java    |   7 +-
 .../IgniteCacheBinaryObjectsScanSelfTest.java   |   2 +-
 .../IgniteCacheConfigVariationsFullApiTest.java | 965 +++++++++++++++++--
 .../cache/IgniteCacheInvokeAbstractTest.java    |  20 +-
 .../IgniteCacheManyAsyncOperationsTest.java     |   6 +-
 .../cache/IgniteCachePeekModesAbstractTest.java |  34 +-
 .../IgniteIncompleteCacheObjectSelfTest.java    |   2 +-
 .../cache/MemoryPolicyConfigValidationTest.java | 241 +++++
 .../cache/WithKeepBinaryCacheFullApiTest.java   | 228 ++---
 .../binary/BinaryMetadataUpdatesFlowTest.java   | 592 ++++++++++++
 .../CacheKeepBinaryWithInterceptorTest.java     |  16 +-
 ...naryObjectMetadataExchangeMultinodeTest.java | 463 +++++++++
 .../GridCacheBinaryObjectsAbstractSelfTest.java | 111 +--
 ...eAbstractDataStructuresFailoverSelfTest.java |   7 +-
 ...ridCacheQueueJoinedNodeSelfAbstractTest.java |  12 +-
 .../IgniteCountDownLatchAbstractSelfTest.java   |   7 +-
 .../IgniteLockAbstractSelfTest.java             |   7 +-
 .../IgniteSemaphoreAbstractSelfTest.java        |   7 +-
 ...acheAsyncOperationsFailoverAbstractTest.java |  12 +-
 .../distributed/CacheAsyncOperationsTest.java   |  32 +-
 .../CachePutAllFailoverAbstractTest.java        |   8 +-
 .../GridCacheAbstractJobExecutionTest.java      |  15 +-
 .../GridCacheBasicOpAbstractTest.java           |  38 +-
 .../distributed/GridCacheEventAbstractTest.java |  80 +-
 .../GridCacheMultiNodeAbstractTest.java         |  25 +-
 ...yMetadataUpdateChangingTopologySelfTest.java |  13 +-
 .../IgniteCacheConnectionRecoveryTest.java      |  10 +-
 ...eCacheMessageRecoveryIdleConnectionTest.java |   6 +-
 ...cOriginatingNodeFailureAbstractSelfTest.java |   6 +-
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java |  12 +-
 .../dht/GridCacheDhtPreloadSelfTest.java        |   4 +-
 .../dht/GridCacheGlobalLoadTest.java            |  21 +-
 .../dht/GridCacheTxNodeFailureSelfTest.java     |  12 +-
 .../IgniteCachePutRetryAbstractSelfTest.java    |  26 +-
 .../atomic/IgniteCacheAtomicProtocolTest.java   |  34 +-
 ...idCacheNearOnlyMultiNodeFullApiSelfTest.java |  11 +-
 .../GridCachePartitionedLoadCacheSelfTest.java  |   9 +-
 .../GridCacheRebalancingSyncSelfTest.java       |   7 +-
 .../GridCacheEmptyEntriesAbstractSelfTest.java  |  21 +-
 .../cache/query/IndexingSpiQuerySelfTest.java   |   3 +
 .../CacheContinuousQueryVariationsTest.java     |   5 +
 .../GridCacheContinuousQueryConcurrentTest.java |   5 +-
 .../closure/GridClosureProcessorSelfTest.java   |  74 +-
 ...ComputeJobExecutionErrorToLogManualTest.java |  10 +-
 ...gniteComputeConfigVariationsFullApiTest.java | 533 +++++++++-
 .../continuous/GridEventConsumeSelfTest.java    | 196 +++-
 .../database/FreeListImplSelfTest.java          |   2 +-
 .../database/IgniteDbAbstractTest.java          |   2 -
 .../database/IgniteDbDynamicCacheSelfTest.java  |   9 +-
 .../IgniteDbMemoryLeakAbstractTest.java         |  10 +-
 .../internal/processors/igfs/IgfsMock.java      |  41 +
 .../processors/igfs/IgfsTaskSelfTest.java       |  19 +
 ...niteMessagingConfigVariationFullApiTest.java |  93 +-
 .../GridServiceProcessorAbstractSelfTest.java   | 291 +++++-
 .../GridServiceProcessorMultiNodeSelfTest.java  |  18 +-
 .../GridServiceProcessorStopSelfTest.java       |   7 +-
 .../nio/IgniteExceptionInNioWorkerSelfTest.java |   2 +-
 .../loadtest/GridSingleExecutionTest.java       |  10 +-
 .../loadtests/colocation/GridTestMain.java      |   7 +-
 .../communication/GridTestMessage.java          |   2 +-
 .../multisplit/GridMultiSplitsLoadTest.java     |   7 +-
 ...ridSingleSplitsNewNodesAbstractLoadTest.java |   8 +-
 .../ignite/loadtests/dsi/GridDsiClient.java     |  12 +-
 .../loadtests/hashmap/GridCacheTestContext.java |   3 +
 ...GridJobExecutionLoadTestClientSemaphore.java |   9 +-
 ...JobExecutionSingleNodeSemaphoreLoadTest.java |  10 +-
 .../loadtests/job/GridJobLoadTestSubmitter.java |   7 +-
 .../mergesort/GridMergeSortLoadTask.java        |   7 +-
 .../marshaller/MarshallerContextSelfTest.java   |  10 +-
 .../ignite/messaging/GridMessagingSelfTest.java |  73 +-
 .../messaging/IgniteMessagingSendAsyncTest.java |  83 +-
 ...idSessionFutureWaitJobAttributeSelfTest.java |   7 +-
 ...GridSessionSetJobAttributeOrderSelfTest.java |   8 +-
 ...sionSetJobAttributeWaitListenerSelfTest.java |   7 +-
 .../GridSessionSetTaskAttributeSelfTest.java    |   7 +-
 ...GridSessionTaskWaitJobAttributeSelfTest.java |   7 +-
 .../GridSessionWaitAttributeSelfTest.java       |   9 +-
 .../communication/GridCacheMessageSelfTest.java |  20 +-
 .../spi/communication/GridTestMessage.java      |   4 +-
 .../TcpDiscoverySpiFailureTimeoutSelfTest.java  |  60 --
 .../ignite/testframework/GridTestUtils.java     |  60 ++
 .../testframework/junits/GridAbstractTest.java  |  68 +-
 .../cache/GridAbstractCacheStoreSelfTest.java   |  11 +
 .../junits/common/GridCommonAbstractTest.java   |  30 +-
 .../multijvm/IgniteCacheProcessProxy.java       | 172 ++++
 .../multijvm/IgniteClusterProcessProxy.java     |  13 +
 .../multijvm/IgniteEventsProcessProxy.java      |  31 +
 .../IgniteBinaryObjectsTestSuite.java           |   6 +-
 .../testsuites/IgniteCacheTestSuite2.java       |   4 +
 .../testsuites/IgniteComputeGridTestSuite.java  |   2 +
 .../ignite/util/GridMessageCollectionTest.java  |   5 +-
 .../query/h2/DmlStatementsProcessor.java        |  35 -
 .../processors/query/h2/IgniteH2Indexing.java   |  18 +-
 .../query/h2/database/H2TreeIndex.java          |   5 +-
 .../processors/query/h2/opt/GridH2Table.java    |  16 +-
 .../query/h2/opt/GridH2TreeIndex.java           |  16 +-
 .../query/h2/twostep/GridMapQueryExecutor.java  |  39 -
 .../h2/twostep/GridReduceQueryExecutor.java     |  60 +-
 .../query/h2/twostep/msg/GridH2Array.java       |   2 +-
 .../query/h2/twostep/msg/GridH2Boolean.java     |   2 +-
 .../query/h2/twostep/msg/GridH2Byte.java        |   2 +-
 .../query/h2/twostep/msg/GridH2Bytes.java       |   2 +-
 .../query/h2/twostep/msg/GridH2CacheObject.java |   2 +-
 .../query/h2/twostep/msg/GridH2Date.java        |   2 +-
 .../query/h2/twostep/msg/GridH2Decimal.java     |   2 +-
 .../query/h2/twostep/msg/GridH2Double.java      |   2 +-
 .../query/h2/twostep/msg/GridH2Float.java       |   2 +-
 .../query/h2/twostep/msg/GridH2Geometry.java    |   2 +-
 .../h2/twostep/msg/GridH2IndexRangeRequest.java |   2 +-
 .../twostep/msg/GridH2IndexRangeResponse.java   |   2 +-
 .../query/h2/twostep/msg/GridH2Integer.java     |   2 +-
 .../query/h2/twostep/msg/GridH2JavaObject.java  |   2 +-
 .../query/h2/twostep/msg/GridH2Long.java        |   2 +-
 .../query/h2/twostep/msg/GridH2Null.java        |   2 +-
 .../h2/twostep/msg/GridH2QueryRequest.java      |   2 +-
 .../query/h2/twostep/msg/GridH2RowMessage.java  |   2 +-
 .../query/h2/twostep/msg/GridH2RowRange.java    |   2 +-
 .../h2/twostep/msg/GridH2RowRangeBounds.java    |   2 +-
 .../query/h2/twostep/msg/GridH2Short.java       |   2 +-
 .../query/h2/twostep/msg/GridH2String.java      |   2 +-
 .../query/h2/twostep/msg/GridH2Time.java        |   2 +-
 .../query/h2/twostep/msg/GridH2Timestamp.java   |   2 +-
 .../query/h2/twostep/msg/GridH2Uuid.java        |   2 +-
 .../twostep/msg/GridH2ValueMessageFactory.java  |   2 +-
 .../IgniteCacheInsertSqlQuerySelfTest.java      |   4 +
 ...niteCacheLockPartitionOnAffinityRunTest.java |   6 +-
 .../cache/IgniteCacheMergeSqlQuerySelfTest.java |   4 +
 .../cache/IgniteCacheQueryLoadSelfTest.java     |  20 +-
 .../cache/IncorrectCacheTypeMetadataTest.java   |   8 +-
 .../cache/IncorrectQueryEntityTest.java         |   8 +-
 .../query/IgniteQueryDedicatedPoolTest.java     | 223 +++++
 .../query/IgniteSqlQueryDedicatedPoolTest.java  | 110 ---
 .../query/IgniteSqlSegmentedIndexSelfTest.java  |  26 +-
 .../h2/GridIndexingSpiAbstractSelfTest.java     | 198 ++--
 .../query/h2/opt/GridH2TableSelfTest.java       |   3 +-
 .../query/h2/sql/GridQueryParsingTest.java      | 112 +--
 .../query/h2/sql/H2CompareBigQueryTest.java     |   2 +-
 .../IgniteCacheQuerySelfTestSuite.java          |   4 +-
 modules/platforms/cpp/binary/Makefile.am        |   2 +-
 .../platforms/cpp/binary/include/Makefile.am    |   1 +
 .../include/ignite/binary/binary_object.h       |  75 +-
 .../ignite/impl/binary/binary_field_meta.h      | 110 +++
 .../ignite/impl/binary/binary_id_resolver.h     |  96 +-
 .../ignite/impl/binary/binary_object_header.h   |  13 +
 .../ignite/impl/binary/binary_object_impl.h     | 124 ++-
 .../include/ignite/impl/binary/binary_schema.h  |  10 +-
 .../ignite/impl/binary/binary_type_handler.h    |  47 +-
 .../ignite/impl/binary/binary_type_manager.h    |  48 +-
 .../ignite/impl/binary/binary_type_snapshot.h   |  82 +-
 .../ignite/impl/binary/binary_type_updater.h    |  19 +-
 .../ignite/impl/binary/binary_writer_impl.h     |  17 +-
 .../cpp/binary/project/vs/binary.vcxproj        |   3 +-
 .../binary/project/vs/binary.vcxproj.filters    |   9 +-
 .../src/impl/binary/binary_field_meta.cpp       |  42 +
 .../src/impl/binary/binary_object_impl.cpp      | 139 ++-
 .../src/impl/binary/binary_type_handler.cpp     |  45 +-
 .../src/impl/binary/binary_type_manager.cpp     | 187 ++--
 .../src/impl/binary/binary_type_snapshot.cpp    |  50 +-
 .../src/impl/binary/binary_type_updater.cpp     |  32 -
 .../cpp/core-test/config/cache-identity.xml     |  33 +
 .../cpp/core-test/config/cache-query-32.xml     |  50 +
 .../config/cache-query-continuous-32.xml        |  46 +
 .../config/cache-query-continuous-default.xml   |  87 ++
 .../core-test/config/cache-query-continuous.xml |  61 +-
 .../core-test/config/cache-query-default.xml    | 131 +++
 .../cpp/core-test/config/cache-query.xml        | 114 +--
 .../cpp/core-test/config/cache-test-32.xml      |  50 +
 .../cpp/core-test/config/cache-test-default.xml | 135 +++
 .../cpp/core-test/config/cache-test.xml         | 105 +-
 .../core-test/include/ignite/binary_test_defs.h |   5 +
 .../cpp/core-test/project/vs/core-test.vcxproj  |   7 +
 .../project/vs/core-test.vcxproj.filters        |  21 +
 .../src/binary_identity_resolver_test.cpp       |  91 +-
 .../cpp/core-test/src/binary_object_test.cpp    | 220 ++++-
 .../cpp/core-test/src/cache_invoke_test.cpp     |   2 +
 .../cpp/core-test/src/cache_query_test.cpp      |   4 +
 .../platforms/cpp/core-test/src/cache_test.cpp  |   5 +
 .../cpp/core-test/src/cluster_test.cpp          |   5 +-
 .../cpp/core-test/src/continuous_query_test.cpp |   4 +
 .../cpp/core-test/src/ignition_test.cpp         |   4 +
 .../cpp/core-test/src/interop_test.cpp          |   4 +
 .../cpp/core-test/src/transactions_test.cpp     |   4 +
 .../impl/binary/binary_type_updater_impl.h      |   6 +-
 .../cpp/core/include/ignite/impl/ignite_impl.h  |  11 +
 .../ignite/impl/interop/interop_target.h        |   2 +-
 .../impl/binary/binary_type_updater_impl.cpp    | 101 +-
 .../cpp/core/src/impl/ignite_environment.cpp    |   4 +-
 .../core/src/impl/interop/interop_target.cpp    |   2 +-
 .../cpp/jni/include/ignite/jni/exports.h        |   2 -
 .../platforms/cpp/jni/include/ignite/jni/java.h |   4 -
 modules/platforms/cpp/jni/project/vs/module.def |   2 -
 modules/platforms/cpp/jni/src/exports.cpp       |   8 -
 modules/platforms/cpp/jni/src/java.cpp          |  20 -
 .../cpp/odbc-test/config/queries-test-32.xml    |  47 +
 .../odbc-test/config/queries-test-default.xml   |  38 +
 .../odbc-test/config/queries-test-noodbc-32.xml |  47 +
 .../cpp/odbc-test/config/queries-test.xml       |  11 +-
 .../cpp/odbc-test/project/vs/odbc-test.vcxproj  |   3 +
 .../project/vs/odbc-test.vcxproj.filters        |   6 +
 .../cpp/odbc-test/src/api_robustness_test.cpp   |  20 +-
 .../cpp/odbc-test/src/queries_test.cpp          |   8 +
 .../odbc-test/src/sql_test_suite_fixture.cpp    |   6 +-
 .../cpp/odbc/install/install_amd64.cmd          |   4 +-
 .../platforms/cpp/odbc/install/install_x86.cmd  |   2 +-
 .../Apache.Ignite.Core.Tests.csproj             |   1 -
 .../Binary/BinaryBuilderSelfTest.cs             | 151 +--
 .../BinaryBuilderSelfTestArrayIdentity.cs       |  34 -
 .../Binary/BinarySelfTest.cs                    |   8 -
 .../Cache/CacheConfigurationTest.cs             |   4 +-
 .../Cache/Query/CacheDmlQueriesTest.cs          |   5 +-
 .../Cache/Query/CacheLinqTest.cs                | 129 +--
 .../Query/CacheQueriesCodeConfigurationTest.cs  |   7 +
 .../Cache/Store/CacheStoreAdapterTest.cs        |  14 +-
 .../Cache/Store/CacheStoreSessionTest.cs        |   2 +-
 .../Cache/Store/CacheTestParallelLoadStore.cs   |  16 +-
 .../Cache/Store/CacheTestStore.cs               |  13 +-
 .../Apache.Ignite.Core.Tests/EventsTest.cs      |   1 -
 .../IgniteConfigurationSerializerTest.cs        |   6 +-
 .../Apache.Ignite.Core.csproj                   |   8 +-
 .../Binary/BinaryArrayEqualityComparer.cs       |   8 +
 .../Binary/IBinaryObjectBuilder.cs              |  10 -
 .../Cache/Affinity/AffinityFunctionBase.cs      | 139 +++
 .../Cache/Affinity/Fair/FairAffinityFunction.cs |   1 -
 .../Rendezvous/RendezvousAffinityFunction.cs    |   1 -
 .../Cache/Configuration/CacheConfiguration.cs   |   2 +-
 .../Cache/Configuration/QueryEntity.cs          |   8 +
 .../dotnet/Apache.Ignite.Core/Cache/ICache.cs   |  12 +-
 .../Store/CacheParallelLoadStoreAdapter.cs      |  38 +-
 .../Cache/Store/CacheStoreAdapter.cs            |  30 +-
 .../Cache/Store/ICacheStore.cs                  |  39 +-
 .../Cache/Store/ICacheStoreSession.cs           |   2 +-
 .../Datastream/IDataStreamer.cs                 |   2 +-
 .../Apache.Ignite.Core/Events/CacheEvent.cs     |   8 -
 .../IgniteConfigurationSection.xsd              |   7 +
 .../Impl/Binary/BinaryObject.cs                 |  72 +-
 .../Impl/Binary/BinaryObjectBuilder.cs          |  67 +-
 .../Impl/Binary/BinaryProcessor.cs              |   3 +-
 .../Impl/Binary/BinaryUtils.cs                  |  10 +
 .../Impl/Binary/BinaryWriter.cs                 |  10 +-
 .../Impl/Binary/IBinaryEqualityComparer.cs      |  10 +
 .../Impl/Binary/Io/IBinaryStream.cs             |   3 +-
 .../Impl/Binary/Io/IBinaryStreamProcessor.cs    |   5 +-
 .../Impl/Binary/Marshaller.cs                   |   6 +-
 .../Impl/Binary/Metadata/BinaryField.cs         |  72 ++
 .../Impl/Binary/Metadata/BinaryType.cs          |  38 +-
 .../Binary/Metadata/BinaryTypeHashsetHandler.cs |  10 +-
 .../Impl/Binary/Metadata/BinaryTypeHolder.cs    |   9 +-
 .../Impl/Binary/Metadata/IBinaryTypeHandler.cs  |   4 +-
 .../Impl/Cache/Affinity/AffinityFunctionBase.cs | 140 ---
 .../Impl/Cache/Store/CacheStore.cs              | 233 +----
 .../Impl/Cache/Store/CacheStoreInternal.cs      | 285 ++++++
 .../Impl/Cache/Store/ICacheStoreInternal.cs     |  43 +
 .../Impl/Collections/MultiValueDictionary.cs    |   2 +-
 .../Apache.Ignite.Core/Impl/Common/Future.cs    |   3 +-
 .../Impl/Common/IFutureConverter.cs             |   4 +-
 .../Impl/Common/IFutureInternal.cs              |   3 +-
 .../Impl/Common/LoadedAssembliesResolver.cs     |   2 +-
 .../Apache.Ignite.Core/Impl/Handle/Handle.cs    |   2 +-
 .../Impl/Handle/HandleRegistry.cs               |   2 +-
 .../Apache.Ignite.Core/Impl/Handle/IHandle.cs   |   2 +-
 .../Impl/Memory/IPlatformMemory.cs              |   5 +-
 .../Impl/Memory/PlatformMemory.cs               |   3 +-
 .../Impl/Memory/PlatformMemoryManager.cs        |   4 +-
 .../Impl/Memory/PlatformMemoryPool.cs           |   3 +-
 .../Impl/Memory/PlatformMemoryStream.cs         |   3 +-
 .../Impl/Memory/PlatformRawMemory.cs            |  96 --
 .../Apache.Ignite.Linq.csproj                   |   1 -
 .../dotnet/Apache.Ignite.Linq/CompiledQuery.cs  | 112 ++-
 .../dotnet/Apache.Ignite.Linq/CompiledQuery2.cs | 257 -----
 .../Impl/CacheFieldsQueryProvider.cs            |  10 +-
 .../Datagrid/LinqExample.cs                     |   2 +-
 .../Datagrid/StoreExample.cs                    |   1 +
 .../Datagrid/EmployeeStore.cs                   |  27 +-
 .../scalar/pimps/ScalarProjectionPimp.scala     |  24 +-
 ...gniteProjectionStartStopRestartSelfTest.java |   6 +-
 .../commands/tasks/VisorTasksCommandSpec.scala  |  22 +-
 .../clusters/general/discovery/s3.pug           |   2 +-
 .../cache/IgniteBinaryIdentityBenchmark.java    |  21 -
 .../IgniteLegacyBinaryIdentityGetBenchmark.java |  30 -
 .../IgniteLegacyBinaryIdentityPutBenchmark.java |  30 -
 .../cache/WaitMapExchangeFinishCallable.java    |   4 +-
 .../IgniteAtomicInvokeRetryBenchmark.java       |  12 +-
 .../failover/IgniteAtomicRetriesBenchmark.java  |  12 +-
 .../IgniteFailoverAbstractBenchmark.java        |  22 +-
 ...IgniteTransactionalInvokeRetryBenchmark.java |  10 +-
 ...IgniteTransactionalWriteInvokeBenchmark.java |  16 +-
 .../IgniteTransactionalWriteReadBenchmark.java  |  12 +-
 .../apache/ignite/yarn/ClusterProperties.java   |   1 +
 .../yarn/IgniteApplicationMasterSelfTest.java   |  13 +
 scripts/git-remoteless-branches.sh              |  16 +
 639 files changed, 16780 insertions(+), 8551 deletions(-)
----------------------------------------------------------------------


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