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 2015/11/05 13:18:22 UTC

[38/38] ignite git commit: Merge branch 'ignite-1.5' into ignite-1282

Merge branch 'ignite-1.5' into ignite-1282

Conflicts:
	modules/core/src/main/java/org/apache/ignite/internal/processors/cache/portable/CacheObjectPortableProcessorImpl.java
	modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java


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

Branch: refs/heads/ignite-1282
Commit: 76b65b21af62f7a67752fab5a14c733455eba471
Parents: c1a6ff7 7573003
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Thu Nov 5 15:17:36 2015 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Thu Nov 5 15:17:36 2015 +0300

----------------------------------------------------------------------
 .../java8/messaging/MessagingExample.java       |   7 +-
 .../src/main/java/org/apache/ignite/Ignite.java |  12 +-
 .../apache/ignite/IgniteSystemProperties.java   |   3 +
 .../apache/ignite/internal/IgniteKernal.java    |  47 +-
 .../affinity/GridAffinityAssignmentCache.java   |  13 +
 .../cache/GridCacheAffinityManager.java         |  28 +-
 .../GridCachePartitionExchangeManager.java      |  24 +
 .../processors/cache/GridCachePreloader.java    |   5 +
 .../cache/GridCachePreloaderAdapter.java        |   5 +
 .../processors/cache/GridCacheProcessor.java    |  96 +++-
 .../distributed/GridCacheTxRecoveryFuture.java  |  13 +-
 .../distributed/dht/GridDhtLocalPartition.java  |   8 +
 .../distributed/dht/GridDhtTxPrepareFuture.java |  44 +-
 .../dht/preloader/GridDhtForceKeysFuture.java   |  14 +
 .../GridDhtPartitionsExchangeFuture.java        |   6 +
 .../dht/preloader/GridDhtPreloader.java         |  21 +-
 ...arOptimisticSerializableTxPrepareFuture.java |  12 +-
 .../CacheObjectPortableProcessorImpl.java       |   9 +
 .../cache/transactions/IgniteTxManager.java     |   4 +-
 .../processors/job/GridJobProcessor.java        |  96 ++--
 .../service/GridServiceProcessor.java           |  31 +-
 .../util/nio/GridNioRecoveryDescriptor.java     |  11 +-
 .../ignite/internal/visor/cache/VisorCache.java |   5 +-
 .../communication/tcp/TcpCommunicationSpi.java  |  40 +-
 .../ignite/spi/discovery/tcp/ClientImpl.java    | 205 ++++---
 .../ignite/spi/discovery/tcp/ServerImpl.java    | 220 +++++---
 .../messages/TcpDiscoveryAbstractMessage.java   |  11 +
 .../TcpDiscoveryClientReconnectMessage.java     |   1 +
 .../messages/TcpDiscoveryDiscardMessage.java    |   1 +
 .../messages/TcpDiscoveryNodeAddedMessage.java  |  39 ++
 .../GridTaskFailoverAffinityRunTest.java        |   3 +
 .../IgniteClientReconnectCacheTest.java         |  33 ++
 .../processors/cache/CacheNamesSelfTest.java    |  69 +++
 .../cache/CacheNearReaderUpdateTest.java        |   2 +
 .../CacheSerializableTransactionsTest.java      | 313 +++++++----
 .../cache/GridCacheAbstractFullApiSelfTest.java |   5 +
 .../GridCacheAbstractRemoveFailureTest.java     |   4 +-
 .../cache/IgniteCachePutAllRestartTest.java     |   3 +
 .../cache/IgniteCacheTxNearPeekModesTest.java   |   7 +-
 .../cache/IgniteCacheTxPeekModesTest.java       |   5 +
 .../CacheGetFutureHangsSelfTest.java            |  11 +-
 ...niteCacheClientNodeChangingTopologyTest.java |   6 +-
 .../IgniteCacheClientReconnectTest.java         |   2 +
 .../distributed/IgniteCacheManyClientsTest.java |  14 +-
 .../IgniteCacheCrossCacheTxFailoverTest.java    |   4 +-
 .../IgniteCachePutRetryAbstractSelfTest.java    |   4 +-
 ...ledFairAffinityMultiNodeFullApiSelfTest.java |   5 -
 ...omicNearEnabledMultiNodeFullApiSelfTest.java |   5 -
 ...icOffHeapTieredMultiNodeFullApiSelfTest.java |   5 -
 .../near/GridCacheNearTxExceptionSelfTest.java  |  15 +
 .../GridServiceProcessorStopSelfTest.java       | 103 ++++
 ...gniteClientReconnectMassiveShutdownTest.java | 329 +++++++++++
 .../tcp/TcpDiscoveryMultiThreadedTest.java      | 288 +++++++---
 .../ignite/testframework/GridTestUtils.java     |   4 +-
 .../ignite/testframework/junits/IgniteMock.java |   7 +-
 .../junits/multijvm/IgniteProcessProxy.java     |   7 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |   2 +
 .../testsuites/IgniteKernalSelfTestSuite.java   |   2 +
 .../processors/query/h2/IgniteH2Indexing.java   |   2 +-
 .../cache/SqlFieldsQuerySelfTest.java           |   2 -
 .../ignite/logger/log4j2/Log4J2Logger.java~     | 542 -------------------
 .../ignite/logger/log4j2/Log4j2FileAware.java~  |  33 --
 .../ignite/logger/log4j2/Log4jFileAware.java~   |  13 -
 modules/rest-http/pom.xml                       |   6 +
 .../http/jetty/GridJettyRestProtocol.java       |   4 +-
 .../scala/org/apache/ignite/spark/Entity.scala  |   2 +-
 .../org/apache/ignite/spark/IgniteRDDSpec.scala | 249 +++++++++
 .../org/apache/ignite/spark/IgniteRddSpec.scala | 249 ---------
 .../org/apache/ignite/IgniteSpringBean.java     |  10 +-
 modules/ssh/pom.xml                             |   2 +-
 .../config/benchmark-client-mode.properties     |   4 +-
 .../config/benchmark-failover.properties        | 107 ++++
 .../config/benchmark-multicast.properties       |  71 ++-
 .../yardstick/config/benchmark-store.properties |   4 +-
 modules/yardstick/config/benchmark.properties   |   4 +-
 .../config/ignite-failover-base-config.xml      | 126 +++++
 .../config/ignite-failover-localhost-config.xml |  56 ++
 modules/yardstick/pom.xml                       |   3 +-
 .../yardstick/IgniteAbstractBenchmark.java      |   2 +-
 .../yardstick/IgniteBenchmarkArguments.java     |  66 ++-
 .../cache/IgniteCacheAbstractBenchmark.java     |   8 +-
 .../yardstick/cache/IgniteGetBenchmark.java     |   4 +-
 .../cache/IgniteJdbcSqlQueryBenchmark.java      |   4 +-
 .../yardstick/cache/IgnitePutAllBenchmark.java  |   4 +-
 .../cache/IgnitePutAllTxBenchmark.java          |   4 +-
 .../yardstick/cache/IgnitePutBenchmark.java     |   4 +-
 .../yardstick/cache/IgnitePutGetBenchmark.java  |   4 +-
 .../cache/IgnitePutGetTxBenchmark.java          |   4 +-
 .../cache/IgnitePutIndexedValue1Benchmark.java  |   4 +-
 .../cache/IgnitePutIndexedValue2Benchmark.java  |   4 +-
 .../cache/IgnitePutIndexedValue8Benchmark.java  |   4 +-
 .../yardstick/cache/IgnitePutTxBenchmark.java   |   4 +-
 .../cache/IgniteSqlQueryBenchmark.java          |   4 +-
 .../cache/IgniteSqlQueryJoinBenchmark.java      |   4 +-
 .../cache/IgniteSqlQueryPutBenchmark.java       |   4 +-
 .../IgniteAtomicInvokeRetryBenchmark.java       | 214 ++++++++
 ...IgniteAtomicOffHeapInvokeRetryBenchmark.java |  31 ++
 .../IgniteAtomicOffHeapRetriesBenchmark.java    |  31 ++
 .../failover/IgniteAtomicRetriesBenchmark.java  |  89 +++
 .../IgniteFailoverAbstractBenchmark.java        | 320 +++++++++++
 .../cache/failover/IgniteFailoverNode.java      |  60 ++
 ...IgniteTransactionalInvokeRetryBenchmark.java | 212 ++++++++
 ...ransactionalOffHeapInvokeRetryBenchmark.java |  33 ++
 ...ransactionalOffHeapWriteInvokeBenchmark.java |  37 ++
 ...eTransactionalOffHeapWriteReadBenchmark.java |  32 ++
 ...IgniteTransactionalWriteInvokeBenchmark.java | 182 +++++++
 .../IgniteTransactionalWriteReadBenchmark.java  | 141 +++++
 107 files changed, 3879 insertions(+), 1412 deletions(-)
----------------------------------------------------------------------


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

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

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

http://git-wip-us.apache.org/repos/asf/ignite/blob/76b65b21/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/portable/CacheObjectPortableProcessorImpl.java
----------------------------------------------------------------------
diff --cc modules/core/src/main/java/org/apache/ignite/internal/processors/cache/portable/CacheObjectPortableProcessorImpl.java
index 083fec9,f0319aa..b687666
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/portable/CacheObjectPortableProcessorImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/portable/CacheObjectPortableProcessorImpl.java
@@@ -39,7 -39,9 +39,9 @@@ import javax.cache.processor.EntryProce
  import javax.cache.processor.MutableEntry;
  import org.apache.ignite.IgniteCheckedException;
  import org.apache.ignite.IgniteException;
 +import org.apache.ignite.IgnitePortables;
+ import org.apache.ignite.cluster.ClusterTopologyException;
+ import org.apache.ignite.internal.cluster.ClusterTopologyCheckedException;
 -import org.apache.ignite.internal.portable.api.IgnitePortables;
  import org.apache.ignite.cache.CacheEntryEventSerializableFilter;
  import org.apache.ignite.cluster.ClusterNode;
  import org.apache.ignite.configuration.CacheConfiguration;

http://git-wip-us.apache.org/repos/asf/ignite/blob/76b65b21/modules/core/src/test/java/org/apache/ignite/testframework/junits/IgniteMock.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/76b65b21/modules/core/src/test/java/org/apache/ignite/testframework/junits/multijvm/IgniteProcessProxy.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/76b65b21/modules/spring/src/main/java/org/apache/ignite/IgniteSpringBean.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/76b65b21/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java
----------------------------------------------------------------------
diff --cc modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java
index b09d478,1c258a4..db44fac
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java
@@@ -30,13 -29,7 +30,13 @@@ import org.yardstickframework.Benchmark
  /**
   * Ignite benchmark that performs put and query operations.
   */
- public class IgniteSqlQueryPutBenchmark extends IgniteCacheAbstractBenchmark {
+ public class IgniteSqlQueryPutBenchmark extends IgniteCacheAbstractBenchmark<Integer, Object> {
 +    /** */
 +    private LongAdder8 resCnt = new LongAdder8();
 +
 +    /** */
 +    private LongAdder8 cnt = new LongAdder8();
 +
      /** {@inheritDoc} */
      @Override public void setUp(BenchmarkConfiguration cfg) throws Exception {
          super.setUp(cfg);