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/09/17 15:27:02 UTC

[2/5] ignite git commit: IGNITE-1499: Correct method naming conventions on public API.

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Compute/TaskResultTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Compute/TaskResultTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Compute/TaskResultTest.cs
index b67e854..e7c5ac9 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Compute/TaskResultTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Compute/TaskResultTest.cs
@@ -52,11 +52,11 @@ namespace Apache.Ignite.Core.Tests.Compute
         {
             TestTask<int> task = new TestTask<int>();
 
-            int res = Grid1.Compute().Execute(task, new Tuple<bool, int>(true, 10));
+            int res = Grid1.GetCompute().Execute(task, new Tuple<bool, int>(true, 10));
 
             Assert.AreEqual(10, res);
 
-            res = Grid1.Compute().Execute(task, new Tuple<bool, int>(false, 11));
+            res = Grid1.GetCompute().Execute(task, new Tuple<bool, int>(false, 11));
 
             Assert.AreEqual(11, res);
         }
@@ -69,11 +69,11 @@ namespace Apache.Ignite.Core.Tests.Compute
         {
             TestTask<long> task = new TestTask<long>();
 
-            long res = Grid1.Compute().Execute(task, new Tuple<bool, long>(true, 10000000000));
+            long res = Grid1.GetCompute().Execute(task, new Tuple<bool, long>(true, 10000000000));
 
             Assert.AreEqual(10000000000, res);
 
-            res = Grid1.Compute().Execute(task, new Tuple<bool, long>(false, 10000000001));
+            res = Grid1.GetCompute().Execute(task, new Tuple<bool, long>(false, 10000000001));
 
             Assert.AreEqual(10000000001, res);
         }
@@ -86,11 +86,11 @@ namespace Apache.Ignite.Core.Tests.Compute
         {
             TestTask<float> task = new TestTask<float>();
 
-            float res = Grid1.Compute().Execute(task, new Tuple<bool, float>(true, 1.1f));
+            float res = Grid1.GetCompute().Execute(task, new Tuple<bool, float>(true, 1.1f));
 
             Assert.AreEqual(1.1f, res);
 
-            res = Grid1.Compute().Execute(task, new Tuple<bool, float>(false, -1.1f));
+            res = Grid1.GetCompute().Execute(task, new Tuple<bool, float>(false, -1.1f));
 
             Assert.AreEqual(-1.1f, res);
         }
@@ -105,13 +105,13 @@ namespace Apache.Ignite.Core.Tests.Compute
 
             PortableResult val = new PortableResult(100);
 
-            PortableResult res = Grid1.Compute().Execute(task, new Tuple<bool, PortableResult>(true, val));
+            PortableResult res = Grid1.GetCompute().Execute(task, new Tuple<bool, PortableResult>(true, val));
 
             Assert.AreEqual(val.Val, res.Val);
 
             val.Val = 101;
 
-            res = Grid1.Compute().Execute(task, new Tuple<bool, PortableResult>(false, val));
+            res = Grid1.GetCompute().Execute(task, new Tuple<bool, PortableResult>(false, val));
 
             Assert.AreEqual(val.Val, res.Val);
         }
@@ -126,13 +126,13 @@ namespace Apache.Ignite.Core.Tests.Compute
 
             SerializableResult val = new SerializableResult(100);
 
-            SerializableResult res = Grid1.Compute().Execute(task, new Tuple<bool, SerializableResult>(true, val));
+            SerializableResult res = Grid1.GetCompute().Execute(task, new Tuple<bool, SerializableResult>(true, val));
 
             Assert.AreEqual(val.Val, res.Val);
 
             val.Val = 101;
 
-            res = Grid1.Compute().Execute(task, new Tuple<bool, SerializableResult>(false, val));
+            res = Grid1.GetCompute().Execute(task, new Tuple<bool, SerializableResult>(false, val));
 
             Assert.AreEqual(val.Val, res.Val);
         }
@@ -145,12 +145,12 @@ namespace Apache.Ignite.Core.Tests.Compute
         {
             TestTask<byte[]> task = new TestTask<byte[]>();
 
-            byte[] res = Grid1.Compute().Execute(task,
+            byte[] res = Grid1.GetCompute().Execute(task,
                 new Tuple<bool, byte[]>(true, new byte[100 * 1024]));
 
             Assert.AreEqual(100 * 1024, res.Length);
 
-            res = Grid1.Compute().Execute(task, new Tuple<bool, byte[]>(false, new byte[101 * 1024]));
+            res = Grid1.GetCompute().Execute(task, new Tuple<bool, byte[]>(false, new byte[101 * 1024]));
 
             Assert.AreEqual(101 * 1024, res.Length);
         }
@@ -167,7 +167,7 @@ namespace Apache.Ignite.Core.Tests.Compute
         [Test]
         public void TestOutFuncResultPrimitive1()
         {
-            ICollection<int> res = Grid1.Compute().Broadcast(new PortableOutFunc());
+            ICollection<int> res = Grid1.GetCompute().Broadcast(new PortableOutFunc());
 
             Assert.AreEqual(3, res.Count);
 
@@ -178,7 +178,7 @@ namespace Apache.Ignite.Core.Tests.Compute
         [Test]
         public void TestOutFuncResultPrimitive2()
         {
-            ICollection<int> res = Grid1.Compute().Broadcast(new SerializableOutFunc());
+            ICollection<int> res = Grid1.GetCompute().Broadcast(new SerializableOutFunc());
 
             Assert.AreEqual(3, res.Count);
 
@@ -189,7 +189,7 @@ namespace Apache.Ignite.Core.Tests.Compute
         [Test]
         public void TestFuncResultPrimitive1()
         {
-            ICollection<int> res = Grid1.Compute().Broadcast(new PortableFunc(), 10);
+            ICollection<int> res = Grid1.GetCompute().Broadcast(new PortableFunc(), 10);
 
             Assert.AreEqual(3, res.Count);
 
@@ -200,7 +200,7 @@ namespace Apache.Ignite.Core.Tests.Compute
         [Test]
         public void TestFuncResultPrimitive2()
         {
-            ICollection<int> res = Grid1.Compute().Broadcast(new SerializableFunc(), 10);
+            ICollection<int> res = Grid1.GetCompute().Broadcast(new SerializableFunc(), 10);
 
             Assert.AreEqual(3, res.Count);
 
@@ -351,11 +351,11 @@ namespace Apache.Ignite.Core.Tests.Compute
         private static Guid GridId(string gridName)
         {
             if (gridName.Equals(Grid1Name))
-                return Ignition.GetIgnite(Grid1Name).Cluster.LocalNode.Id;
+                return Ignition.GetIgnite(Grid1Name).GetCluster().GetLocalNode().Id;
             if (gridName.Equals(Grid2Name))
-                return Ignition.GetIgnite(Grid2Name).Cluster.LocalNode.Id;
+                return Ignition.GetIgnite(Grid2Name).GetCluster().GetLocalNode().Id;
             if (gridName.Equals(Grid3Name))
-                return Ignition.GetIgnite(Grid3Name).Cluster.LocalNode.Id;
+                return Ignition.GetIgnite(Grid3Name).GetCluster().GetLocalNode().Id;
 
             Assert.Fail("Failed to find grid " + gridName);
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Dataload/DataStreamerTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Dataload/DataStreamerTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Dataload/DataStreamerTest.cs
index 3c1619b..245ed5f 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Dataload/DataStreamerTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Dataload/DataStreamerTest.cs
@@ -56,7 +56,7 @@ namespace Apache.Ignite.Core.Tests.Dataload
 
             Ignition.Start(GetIgniteConfiguration(GridName + "_1"));
 
-            _cache = _grid.Cache<int, int?>(CacheName);
+            _cache = _grid.GetCache<int, int?>(CacheName);
         }
 
         /// <summary>
@@ -92,7 +92,7 @@ namespace Apache.Ignite.Core.Tests.Dataload
         [Test]
         public void TestPropertyPropagation()
         {
-            using (IDataStreamer<int, int> ldr = _grid.DataStreamer<int, int>(CacheName))
+            using (IDataStreamer<int, int> ldr = _grid.GetDataStreamer<int, int>(CacheName))
             {
                 ldr.AllowOverwrite = true;
                 Assert.IsTrue(ldr.AllowOverwrite);
@@ -122,7 +122,7 @@ namespace Apache.Ignite.Core.Tests.Dataload
         [Test]        
         public void TestAddRemove()
         {
-            using (IDataStreamer<int, int> ldr = _grid.DataStreamer<int, int>(CacheName))
+            using (IDataStreamer<int, int> ldr = _grid.GetDataStreamer<int, int>(CacheName))
             {
                 ldr.AllowOverwrite = true;
 
@@ -172,7 +172,7 @@ namespace Apache.Ignite.Core.Tests.Dataload
         [Test]
         public void TestTryFlush()
         {
-            using (IDataStreamer<int, int> ldr = _grid.DataStreamer<int, int>(CacheName))
+            using (IDataStreamer<int, int> ldr = _grid.GetDataStreamer<int, int>(CacheName))
             {
                 var fut = ldr.AddData(1, 1);
 
@@ -190,7 +190,7 @@ namespace Apache.Ignite.Core.Tests.Dataload
         [Test]
         public void TestBufferSize()
         {
-            using (IDataStreamer<int, int> ldr = _grid.DataStreamer<int, int>(CacheName))
+            using (IDataStreamer<int, int> ldr = _grid.GetDataStreamer<int, int>(CacheName))
             {
                 var fut = ldr.AddData(1, 1);
 
@@ -231,7 +231,7 @@ namespace Apache.Ignite.Core.Tests.Dataload
         [Test]
         public void TestClose()
         {
-            using (IDataStreamer<int, int> ldr = _grid.DataStreamer<int, int>(CacheName))
+            using (IDataStreamer<int, int> ldr = _grid.GetDataStreamer<int, int>(CacheName))
             {
                 var fut = ldr.AddData(1, 1);
 
@@ -249,7 +249,7 @@ namespace Apache.Ignite.Core.Tests.Dataload
         [Test]
         public void TestCancel()
         {
-            using (IDataStreamer<int, int> ldr = _grid.DataStreamer<int, int>(CacheName))
+            using (IDataStreamer<int, int> ldr = _grid.GetDataStreamer<int, int>(CacheName))
             {
                 var fut = ldr.AddData(1, 1);
 
@@ -267,7 +267,7 @@ namespace Apache.Ignite.Core.Tests.Dataload
         [Test]
         public void TestFinalizer()
         {
-            var streamer = _grid.DataStreamer<int, int>(CacheName);
+            var streamer = _grid.GetDataStreamer<int, int>(CacheName);
             var streamerRef = new WeakReference(streamer);
 
             Assert.IsNotNull(streamerRef.Target);
@@ -287,7 +287,7 @@ namespace Apache.Ignite.Core.Tests.Dataload
         [Test]
         public void TestAutoFlush()
         {
-            using (IDataStreamer<int, int> ldr = _grid.DataStreamer<int, int>(CacheName))
+            using (IDataStreamer<int, int> ldr = _grid.GetDataStreamer<int, int>(CacheName))
             {
                 // Test auto flush turning on.
                 var fut = ldr.AddData(1, 1);
@@ -338,13 +338,13 @@ namespace Apache.Ignite.Core.Tests.Dataload
             {
                 _cache.Clear();
 
-                Assert.AreEqual(0, _cache.Size());
+                Assert.AreEqual(0, _cache.GetSize());
 
                 Stopwatch watch = new Stopwatch();
 
                 watch.Start();
 
-                using (IDataStreamer<int, int> ldr = _grid.DataStreamer<int, int>(CacheName))
+                using (IDataStreamer<int, int> ldr = _grid.GetDataStreamer<int, int>(CacheName))
                 {
                     ldr.PerNodeBufferSize = 1024;
 
@@ -411,7 +411,7 @@ namespace Apache.Ignite.Core.Tests.Dataload
         /// </summary>
         private void TestStreamReceiver(IStreamReceiver<int, int> receiver)
         {
-            using (var ldr = _grid.DataStreamer<int, int>(CacheName))
+            using (var ldr = _grid.GetDataStreamer<int, int>(CacheName))
             {
                 ldr.AllowOverwrite = true;
 
@@ -438,9 +438,9 @@ namespace Apache.Ignite.Core.Tests.Dataload
         public void TestStreamReceiverKeepPortable()
         {
             // ReSharper disable once LocalVariableHidesMember
-            var cache = _grid.Cache<int, PortableEntry>(CacheName);
+            var cache = _grid.GetCache<int, PortableEntry>(CacheName);
 
-            using (var ldr0 = _grid.DataStreamer<int, int>(CacheName))
+            using (var ldr0 = _grid.GetDataStreamer<int, int>(CacheName))
             using (var ldr = ldr0.WithKeepPortable<int, IPortableObject>())
             {
                 ldr.Receiver = new StreamReceiverKeepPortable();
@@ -448,7 +448,7 @@ namespace Apache.Ignite.Core.Tests.Dataload
                 ldr.AllowOverwrite = true;
 
                 for (var i = 0; i < 100; i++)
-                    ldr.AddData(i, _grid.Portables().ToPortable<IPortableObject>(new PortableEntry {Val = i}));
+                    ldr.AddData(i, _grid.GetPortables().ToPortable<IPortableObject>(new PortableEntry {Val = i}));
 
                 ldr.Flush();
 
@@ -517,7 +517,7 @@ namespace Apache.Ignite.Core.Tests.Dataload
             /** <inheritdoc /> */
             public void Receive(ICache<int, IPortableObject> cache, ICollection<ICacheEntry<int, IPortableObject>> entries)
             {
-                var portables = cache.Ignite.Portables();
+                var portables = cache.Ignite.GetPortables();
 
                 cache.PutAll(entries.ToDictionary(x => x.Key, x =>
                     portables.ToPortable<IPortableObject>(new PortableEntry

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/EventsTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/EventsTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/EventsTest.cs
index 39b6b24..aa103d4 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/EventsTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/EventsTest.cs
@@ -100,7 +100,7 @@ namespace Apache.Ignite.Core.Tests
         [Test]
         public void TestEnableDisable()
         {
-            var events = _grid1.Events();
+            var events = _grid1.GetEvents();
 
             Assert.AreEqual(0, events.GetEnabledEvents().Length);
 
@@ -125,7 +125,7 @@ namespace Apache.Ignite.Core.Tests
         [Test]
         public void TestLocalListen()
         {
-            var events = _grid1.Events();
+            var events = _grid1.GetEvents();
             var listener = EventsTestHelper.GetListener();
             var eventType = EventType.EvtsTaskExecution;
 
@@ -164,7 +164,7 @@ namespace Apache.Ignite.Core.Tests
         [Ignore("IGNITE-879")]
         public void TestLocalListenRepeatedSubscription()
         {
-            var events = _grid1.Events();
+            var events = _grid1.GetEvents();
             var listener = EventsTestHelper.GetListener();
             var eventType = EventType.EvtsTaskExecution;
 
@@ -198,7 +198,7 @@ namespace Apache.Ignite.Core.Tests
         [Test, TestCaseSource("TestCases")]
         public void TestEventTypes(EventTestCase testCase)
         {
-            var events = _grid1.Events();
+            var events = _grid1.GetEvents();
 
             events.EnableLocal(testCase.EventType);
 
@@ -236,7 +236,7 @@ namespace Apache.Ignite.Core.Tests
                 {
                     EventType = EventType.EvtsCache,
                     EventObjectType = typeof (CacheEvent),
-                    GenerateEvent = g => g.Cache<int, int>(null).Put(1, 1),
+                    GenerateEvent = g => g.GetCache<int, int>(null).Put(1, 1),
                     VerifyEvents = (e, g) => VerifyCacheEvents(e, g),
                     EventCount = 1
                 };
@@ -282,7 +282,7 @@ namespace Apache.Ignite.Core.Tests
         [Test]
         public void TestLocalQuery()
         {
-            var events = _grid1.Events();
+            var events = _grid1.GetEvents();
 
             var eventType = EventType.EvtsTaskExecution;
 
@@ -304,7 +304,7 @@ namespace Apache.Ignite.Core.Tests
         [Test]
         public void TestWaitForLocal([Values(true, false)] bool async)
         {
-            var events = _grid1.Events();
+            var events = _grid1.GetEvents();
 
             var timeout = TimeSpan.FromSeconds(3);
 
@@ -374,11 +374,11 @@ namespace Apache.Ignite.Core.Tests
         {
             foreach (var g in _grids)
             {
-                g.Events().EnableLocal(EventType.EvtsJobExecution);
-                g.Events().EnableLocal(EventType.EvtsTaskExecution);
+                g.GetEvents().EnableLocal(EventType.EvtsJobExecution);
+                g.GetEvents().EnableLocal(EventType.EvtsTaskExecution);
             }
 
-            var events = _grid1.Events();
+            var events = _grid1.GetEvents();
 
             var expectedType = EventType.EvtJobStarted;
 
@@ -399,7 +399,7 @@ namespace Apache.Ignite.Core.Tests
 
             CheckSend(3, typeof(JobEvent), expectedType);
 
-            _grid3.Events().DisableLocal(EventType.EvtsJobExecution);
+            _grid3.GetEvents().DisableLocal(EventType.EvtsJobExecution);
 
             CheckSend(2, typeof(JobEvent), expectedType);
 
@@ -433,9 +433,9 @@ namespace Apache.Ignite.Core.Tests
         public void TestRemoteQuery([Values(true, false)] bool async)
         {
             foreach (var g in _grids)
-                g.Events().EnableLocal(EventType.EvtsJobExecution);
+                g.GetEvents().EnableLocal(EventType.EvtsJobExecution);
 
-            var events = _grid1.Events();
+            var events = _grid1.GetEvents();
 
             var eventFilter = new RemoteEventFilter(EventType.EvtJobStarted);
 
@@ -469,8 +469,8 @@ namespace Apache.Ignite.Core.Tests
         public void TestSerialization()
         {
             var grid = (Ignite) _grid1;
-            var comp = (Impl.Compute.Compute) grid.Cluster.ForLocal().Compute();
-            var locNode = grid.Cluster.LocalNode;
+            var comp = (Impl.Compute.Compute) grid.GetCluster().ForLocal().GetCompute();
+            var locNode = grid.GetCluster().GetLocalNode();
 
             var expectedGuid = Guid.Parse("00000000-0000-0001-0000-000000000002");
             var expectedGridGuid = new IgniteGuid(expectedGuid, 3);
@@ -540,7 +540,7 @@ namespace Apache.Ignite.Core.Tests
                 var discoEvent = EventReader.Read<DiscoveryEvent>(reader);
                 CheckEventBase(discoEvent);
                 Assert.AreEqual(grid.TopologyVersion, discoEvent.TopologyVersion);
-                Assert.AreEqual(grid.Nodes(), discoEvent.TopologyNodes);
+                Assert.AreEqual(grid.GetNodes(), discoEvent.TopologyNodes);
 
                 var jobEvent = EventReader.Read<JobEvent>(reader);
                 CheckEventBase(jobEvent);
@@ -571,7 +571,7 @@ namespace Apache.Ignite.Core.Tests
         /// <param name="evt">The evt.</param>
         private void CheckEventBase(IEvent evt)
         {
-            var locNode = _grid1.Cluster.LocalNode;
+            var locNode = _grid1.GetCluster().GetLocalNode();
 
             Assert.AreEqual(locNode, evt.Node);
             Assert.AreEqual("msg", evt.Message);
@@ -637,7 +637,7 @@ namespace Apache.Ignite.Core.Tests
         /// </summary>
         private void GenerateTaskEvent(IIgnite grid = null)
         {
-            (grid ?? _grid1).Compute().Broadcast(new ComputeAction());
+            (grid ?? _grid1).GetCompute().Broadcast(new ComputeAction());
         }
 
         /// <summary>
@@ -658,7 +658,7 @@ namespace Apache.Ignite.Core.Tests
         /// </summary>
         private static void GenerateCacheQueryEvent(IIgnite g)
         {
-            var cache = g.Cache<int, int>(null);
+            var cache = g.GetCache<int, int>(null);
 
             cache.Clear();
 
@@ -679,8 +679,8 @@ namespace Apache.Ignite.Core.Tests
                 Assert.AreEqual(null, cacheEvent.CacheName);
                 Assert.AreEqual(null, cacheEvent.ClosureClassName);
                 Assert.AreEqual(null, cacheEvent.TaskName);
-                Assert.AreEqual(grid.Cluster.LocalNode, cacheEvent.EventNode);
-                Assert.AreEqual(grid.Cluster.LocalNode, cacheEvent.Node);
+                Assert.AreEqual(grid.GetCluster().GetLocalNode(), cacheEvent.EventNode);
+                Assert.AreEqual(grid.GetCluster().GetLocalNode(), cacheEvent.Node);
 
                 Assert.AreEqual(false, cacheEvent.HasOldValue);
                 Assert.AreEqual(null, cacheEvent.OldValue);

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/ExceptionsTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/ExceptionsTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/ExceptionsTest.cs
index d90067f..7a5a725 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/ExceptionsTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/ExceptionsTest.cs
@@ -62,7 +62,7 @@ namespace Apache.Ignite.Core.Tests
 
             try
             {
-                grid.Cache<object, object>("invalidCacheName");
+                grid.GetCache<object, object>("invalidCacheName");
 
                 Assert.Fail();
             }
@@ -73,7 +73,7 @@ namespace Apache.Ignite.Core.Tests
 
             try
             {
-                grid.Cluster.ForRemotes().Metrics();
+                grid.GetCluster().ForRemotes().GetMetrics();
 
                 Assert.Fail();
             }
@@ -86,7 +86,7 @@ namespace Apache.Ignite.Core.Tests
 
             try
             {
-                grid.Cache<object, object>("cache1");
+                grid.GetCache<object, object>("cache1");
 
                 Assert.Fail();
             }
@@ -118,7 +118,7 @@ namespace Apache.Ignite.Core.Tests
         public void TestPartialUpdateExceptionPortable()
         {
             // User type
-            TestPartialUpdateException(false, (x, g) => g.Portables().ToPortable<IPortableObject>(new PortableEntry(x)));
+            TestPartialUpdateException(false, (x, g) => g.GetPortables().ToPortable<IPortableObject>(new PortableEntry(x)));
         }
 
         /// <summary>
@@ -205,7 +205,7 @@ namespace Apache.Ignite.Core.Tests
         [Category(TestUtils.CategoryIntensive)]
         public void TestPartialUpdateExceptionAsyncPortable()
         {
-            TestPartialUpdateException(true, (x, g) => g.Portables().ToPortable<IPortableObject>(new PortableEntry(x)));
+            TestPartialUpdateException(true, (x, g) => g.GetPortables().ToPortable<IPortableObject>(new PortableEntry(x)));
         }
 
         /// <summary>
@@ -215,7 +215,7 @@ namespace Apache.Ignite.Core.Tests
         {
             using (var grid = StartGrid())
             {
-                var cache = grid.Cache<TK, int>("partitioned_atomic").WithNoRetries();
+                var cache = grid.GetCache<TK, int>("partitioned_atomic").WithNoRetries();
 
                 if (async)
                     cache = cache.WithAsync();

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/ExecutableTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/ExecutableTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/ExecutableTest.cs
index e4530cb..abb296c 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/ExecutableTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/ExecutableTest.cs
@@ -175,10 +175,10 @@ namespace Apache.Ignite.Core.Tests
 
             Assert.IsTrue(_grid.WaitTopology(2, 30000));
 
-            var minMem = _grid.Cluster.ForRemotes().Compute().ExecuteJavaTask<long>(MinMemTask, null);
+            var minMem = _grid.GetCluster().ForRemotes().GetCompute().ExecuteJavaTask<long>(MinMemTask, null);
             Assert.AreEqual((long) 506*1024*1024, minMem);
 
-            var maxMem = _grid.Cluster.ForRemotes().Compute().ExecuteJavaTask<long>(MaxMemTask, null);
+            var maxMem = _grid.GetCluster().ForRemotes().GetCompute().ExecuteJavaTask<long>(MaxMemTask, null);
             AssertJvmMaxMemory((long) 607*1024*1024, maxMem);
         }
 
@@ -197,10 +197,10 @@ namespace Apache.Ignite.Core.Tests
 
             Assert.IsTrue(_grid.WaitTopology(2, 30000));
 
-            var minMem = _grid.Cluster.ForRemotes().Compute().ExecuteJavaTask<long>(MinMemTask, null);
+            var minMem = _grid.GetCluster().ForRemotes().GetCompute().ExecuteJavaTask<long>(MinMemTask, null);
             Assert.AreEqual((long) 615*1024*1024, minMem);
 
-            var maxMem = _grid.Cluster.ForRemotes().Compute().ExecuteJavaTask<long>(MaxMemTask, null);
+            var maxMem = _grid.GetCluster().ForRemotes().GetCompute().ExecuteJavaTask<long>(MaxMemTask, null);
             AssertJvmMaxMemory((long) 863*1024*1024, maxMem);
         }
 
@@ -219,10 +219,10 @@ namespace Apache.Ignite.Core.Tests
 
             Assert.IsTrue(_grid.WaitTopology(2, 30000));
 
-            var minMem = _grid.Cluster.ForRemotes().Compute().ExecuteJavaTask<long>(MinMemTask, null);
+            var minMem = _grid.GetCluster().ForRemotes().GetCompute().ExecuteJavaTask<long>(MinMemTask, null);
             Assert.AreEqual((long) 601*1024*1024, minMem);
 
-            var maxMem = _grid.Cluster.ForRemotes().Compute().ExecuteJavaTask<long>(MaxMemTask, null);
+            var maxMem = _grid.GetCluster().ForRemotes().GetCompute().ExecuteJavaTask<long>(MaxMemTask, null);
             AssertJvmMaxMemory((long) 702*1024*1024, maxMem);
 
             proc.Kill();
@@ -236,10 +236,10 @@ namespace Apache.Ignite.Core.Tests
 
             Assert.IsTrue(_grid.WaitTopology(2, 30000));
 
-            minMem = _grid.Cluster.ForRemotes().Compute().ExecuteJavaTask<long>(MinMemTask, null);
+            minMem = _grid.GetCluster().ForRemotes().GetCompute().ExecuteJavaTask<long>(MinMemTask, null);
             Assert.AreEqual((long) 605*1024*1024, minMem);
 
-            maxMem = _grid.Cluster.ForRemotes().Compute().ExecuteJavaTask<long>(MaxMemTask, null);
+            maxMem = _grid.GetCluster().ForRemotes().GetCompute().ExecuteJavaTask<long>(MaxMemTask, null);
             AssertJvmMaxMemory((long) 706*1024*1024, maxMem);
         }
 
@@ -261,10 +261,10 @@ namespace Apache.Ignite.Core.Tests
             Assert.IsTrue(_grid.WaitTopology(2, 30000));
 
             // Raw JVM options (Xms/Xmx) should override custom options
-            var minMem = _grid.Cluster.ForRemotes().Compute().ExecuteJavaTask<long>(MinMemTask, null);
+            var minMem = _grid.GetCluster().ForRemotes().GetCompute().ExecuteJavaTask<long>(MinMemTask, null);
             Assert.AreEqual((long) 555*1024*1024, minMem);
 
-            var maxMem = _grid.Cluster.ForRemotes().Compute().ExecuteJavaTask<long>(MaxMemTask, null);
+            var maxMem = _grid.GetCluster().ForRemotes().GetCompute().ExecuteJavaTask<long>(MaxMemTask, null);
             AssertJvmMaxMemory((long) 666*1024*1024, maxMem);
         }
 
@@ -274,7 +274,7 @@ namespace Apache.Ignite.Core.Tests
         /// <returns>Configuration.</returns>
         private RemoteConfiguration RemoteConfig()
         {
-            return _grid.Cluster.ForRemotes().Compute().Call(new RemoteConfigurationClosure());
+            return _grid.GetCluster().ForRemotes().GetCompute().Call(new RemoteConfigurationClosure());
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/FutureTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/FutureTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/FutureTest.cs
index c2815db..993c604 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/FutureTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/FutureTest.cs
@@ -57,9 +57,9 @@ namespace Apache.Ignite.Core.Tests
                 }
             });
 
-            _cache = grid.Cache<object, object>(null).WithAsync();
+            _cache = grid.GetCache<object, object>(null).WithAsync();
 
-            _compute = grid.Compute().WithAsync();
+            _compute = grid.GetCompute().WithAsync();
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/IgniteStartStopTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/IgniteStartStopTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/IgniteStartStopTest.cs
index 2db1781..bd776ce 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/IgniteStartStopTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/IgniteStartStopTest.cs
@@ -64,7 +64,7 @@ namespace Apache.Ignite.Core.Tests
 
             Assert.IsNotNull(grid);
 
-            Assert.AreEqual(1, grid.Cluster.Nodes().Count);
+            Assert.AreEqual(1, grid.GetCluster().GetNodes().Count);
         }
 
         /// <summary>
@@ -83,7 +83,7 @@ namespace Apache.Ignite.Core.Tests
 
             Assert.IsNotNull(grid);
 
-            Assert.AreEqual(1, grid.Cluster.Nodes().Count);
+            Assert.AreEqual(1, grid.GetCluster().GetNodes().Count);
         }
 
         /// <summary>
@@ -235,13 +235,13 @@ namespace Apache.Ignite.Core.Tests
 
             var grid = Ignition.Start(cfg);
 
-            Assert.IsNotNull(grid.Cache<int, int>("cache1"));
+            Assert.IsNotNull(grid.GetCache<int, int>("cache1"));
 
             grid.Dispose();
 
             try
             {
-                grid.Cache<int, int>("cache1");
+                grid.GetCache<int, int>("cache1");
 
                 Assert.Fail();
             }
@@ -334,18 +334,18 @@ namespace Apache.Ignite.Core.Tests
         private static void UseIgnite(IIgnite ignite)
         {
             // Create objects holding references to java objects.
-            var comp = ignite.Compute();
+            var comp = ignite.GetCompute();
 
             // ReSharper disable once RedundantAssignment
             comp = comp.WithKeepPortable();
 
-            var prj = ignite.Cluster.ForOldest();
+            var prj = ignite.GetCluster().ForOldest();
 
-            Assert.IsTrue(prj.Nodes().Count > 0);
+            Assert.IsTrue(prj.GetNodes().Count > 0);
 
-            Assert.IsNotNull(prj.Compute());
+            Assert.IsNotNull(prj.GetCompute());
 
-            var cache = ignite.Cache<int, int>("cache1");
+            var cache = ignite.GetCache<int, int>("cache1");
 
             Assert.IsNotNull(cache);
 
@@ -388,9 +388,9 @@ namespace Apache.Ignite.Core.Tests
 
                 while (!token.IsCancellationRequested)
                 {
-                    var listenId = grid.Message().RemoteListen(filter);
+                    var listenId = grid.GetMessaging().RemoteListen(filter);
 
-                    grid.Message().StopRemoteListen(listenId);
+                    grid.GetMessaging().StopRemoteListen(listenId);
                 }
                 // ReSharper disable once FunctionNeverReturns
             });

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/LifecycleTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/LifecycleTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/LifecycleTest.cs
index 3c38ef9..84f446c 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/LifecycleTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/LifecycleTest.cs
@@ -128,7 +128,7 @@ namespace Apache.Ignite.Core.Tests
             CheckEvent(AfterStartEvts[3], grid, grid, 0, null);
 
             // 2. Test Java start events.
-            IList<int> res = grid.Compute().ExecuteJavaTask<IList<int>>(
+            IList<int> res = grid.GetCompute().ExecuteJavaTask<IList<int>>(
                 "org.apache.ignite.platform.lifecycle.PlatformJavaLifecycleTask", null);
 
             Assert.AreEqual(2, res.Count);

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/MessagingTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/MessagingTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/MessagingTest.cs
index abb8e2f..95e48d3 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/MessagingTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/MessagingTest.cs
@@ -94,7 +94,7 @@ namespace Apache.Ignite.Core.Tests
         [SuppressMessage("ReSharper", "AccessToModifiedClosure")]
         public void TestLocalListen(object topic)
         {
-            var messaging = _grid1.Message();
+            var messaging = _grid1.GetMessaging();
             var listener = MessagingTestHelper.GetListener();
             messaging.LocalListen(listener, topic);
 
@@ -161,9 +161,9 @@ namespace Apache.Ignite.Core.Tests
                 return true;
             });
 
-            _grid3.Message().LocalListen(grid3Listener, topic);
+            _grid3.GetMessaging().LocalListen(grid3Listener, topic);
 
-            var clusterMessaging = _grid1.Cluster.ForNodes(_grid1.Cluster.LocalNode, _grid2.Cluster.LocalNode).Message();
+            var clusterMessaging = _grid1.GetCluster().ForNodes(_grid1.GetCluster().GetLocalNode(), _grid2.GetCluster().GetLocalNode()).GetMessaging();
             var clusterListener = MessagingTestHelper.GetListener();
             clusterMessaging.LocalListen(clusterListener, topic);
 
@@ -174,7 +174,7 @@ namespace Apache.Ignite.Core.Tests
             Assert.IsFalse(grid3GotMessage, "Grid3 should not get messages");
 
             clusterMessaging.StopLocalListen(clusterListener, topic);
-            _grid3.Message().StopLocalListen(grid3Listener, topic);
+            _grid3.GetMessaging().StopLocalListen(grid3Listener, topic);
         }
 
         /// <summary>
@@ -188,7 +188,7 @@ namespace Apache.Ignite.Core.Tests
             const int threadCnt = 20;
             const int runSeconds = 20;
 
-            var messaging = _grid1.Message();
+            var messaging = _grid1.GetMessaging();
 
             var senders = Task.Factory.StartNew(() => TestUtils.RunMultiThreaded(() =>
             {
@@ -287,7 +287,7 @@ namespace Apache.Ignite.Core.Tests
         /// </summary>
         public void TestRemoteListen(object topic, bool async = false)
         {
-            var messaging = async ? _grid1.Message().WithAsync() : _grid1.Message();
+            var messaging = async ? _grid1.GetMessaging().WithAsync() : _grid1.GetMessaging();
 
             var listener = MessagingTestHelper.GetListener();
             var listenId = messaging.RemoteListen(listener, topic);
@@ -345,7 +345,7 @@ namespace Apache.Ignite.Core.Tests
         /// </summary>
         private void TestRemoteListenProjection(object topic)
         {
-            var clusterMessaging = _grid1.Cluster.ForNodes(_grid1.Cluster.LocalNode, _grid2.Cluster.LocalNode).Message();
+            var clusterMessaging = _grid1.GetCluster().ForNodes(_grid1.GetCluster().GetLocalNode(), _grid2.GetCluster().GetLocalNode()).GetMessaging();
             var clusterListener = MessagingTestHelper.GetListener();
             var listenId = clusterMessaging.RemoteListen(clusterListener, topic);
 
@@ -366,7 +366,7 @@ namespace Apache.Ignite.Core.Tests
             const int threadCnt = 20;
             const int runSeconds = 20;
 
-            var messaging = _grid1.Message();
+            var messaging = _grid1.GetMessaging();
 
             var senders = Task.Factory.StartNew(() => TestUtils.RunMultiThreaded(() =>
             {
@@ -428,12 +428,12 @@ namespace Apache.Ignite.Core.Tests
             else
             {
                 grid = grid ?? _grid1;
-                msg = grid.Message();
-                cluster = grid.Cluster.ForLocal();
+                msg = grid.GetMessaging();
+                cluster = grid.GetCluster().ForLocal();
             }
 
             // Messages will repeat due to multiple nodes listening
-            var expectedRepeat = repeatMultiplier * (remoteListen ? cluster.Nodes().Count : 1);
+            var expectedRepeat = repeatMultiplier * (remoteListen ? cluster.GetNodes().Count : 1);
 
             var messages = Enumerable.Range(1, 10).Select(x => NextMessage()).OrderBy(x => x).ToList();
 
@@ -468,7 +468,7 @@ namespace Apache.Ignite.Core.Tests
             // this will result in an exception in case of a message
             MessagingTestHelper.ClearReceived(0);
 
-            (grid ?? _grid1).Message().Send(NextMessage(), topic);
+            (grid ?? _grid1).GetMessaging().Send(NextMessage(), topic);
 
             Thread.Sleep(MessagingTestHelper.MessageTimeout);
 
@@ -559,7 +559,7 @@ namespace Apache.Ignite.Core.Tests
             Assert.AreEqual(expectedMessages, resultFunc(ReceivedMessages));
 
             // check that all messages came from local node.
-            var localNodeId = cluster.Ignite.Cluster.LocalNode.Id;
+            var localNodeId = cluster.Ignite.GetCluster().GetLocalNode().Id;
             Assert.AreEqual(localNodeId, LastNodeIds.Distinct().Single());
             
             AssertFailures();