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:04 UTC

[4/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/Cache/CacheAbstractTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheAbstractTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheAbstractTest.cs
index 6af877e..ae00c91 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheAbstractTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheAbstractTest.cs
@@ -349,7 +349,7 @@ namespace Apache.Ignite.Core.Tests.Cache
             {
                 var cache = Cache(i);
 
-                if (!cache.IsEmpty)
+                if (!cache.IsEmpty())
                 {
                     var entries = Enumerable.Range(0, 2000)
                         .Select(x => new KeyValuePair<int, int>(x, cache.LocalPeek(x)))
@@ -374,7 +374,7 @@ namespace Apache.Ignite.Core.Tests.Cache
         }
 
         public ICache<TK, TV> Cache<TK, TV>(int idx) {
-            return GetIgnite(idx).Cache<TK, TV>(CacheName());
+            return GetIgnite(idx).GetCache<TK, TV>(CacheName());
         }
 
         public ICache<int, int> Cache()
@@ -389,12 +389,12 @@ namespace Apache.Ignite.Core.Tests.Cache
 
         public ICacheAffinity Affinity()
         {
-            return GetIgnite(0).Affinity(CacheName());
+            return GetIgnite(0).GetAffinity(CacheName());
         }
 
         public ITransactions Transactions
         {
-            get { return GetIgnite(0).Transactions; }
+            get { return GetIgnite(0).GetTransactions(); }
         }
 
         [Test]
@@ -431,7 +431,7 @@ namespace Apache.Ignite.Core.Tests.Cache
             {
                 var cache = Cache(i);
 
-                Assert.IsTrue(cache.IsEmpty);
+                Assert.IsTrue(cache.IsEmpty());
             }
 
             for (int i = 0; i < GridCount(); i++)
@@ -445,7 +445,7 @@ namespace Apache.Ignite.Core.Tests.Cache
             {
                 var cache = Cache(i);
 
-                Assert.IsFalse(cache.IsEmpty);
+                Assert.IsFalse(cache.IsEmpty());
             }
         }
 
@@ -1015,13 +1015,13 @@ namespace Apache.Ignite.Core.Tests.Cache
 
             cache.LocalEvict(new[] {key});
 
-            Assert.AreEqual(0, cache.LocalSize(CachePeekMode.Onheap));
+            Assert.AreEqual(0, cache.GetLocalSize(CachePeekMode.Onheap));
 
             Assert.AreEqual(0, PeekInt(cache, key));
 
             Assert.AreEqual(1, cache.Get(key));
 
-            Assert.AreEqual(1, cache.LocalSize(CachePeekMode.Onheap));
+            Assert.AreEqual(1, cache.GetLocalSize(CachePeekMode.Onheap));
 
             Assert.AreEqual(1, PeekInt(cache, key));
         }
@@ -1043,7 +1043,7 @@ namespace Apache.Ignite.Core.Tests.Cache
 
             cache.LocalEvict(new List<int> { -1, keys[0], keys[1] });
 
-            Assert.AreEqual(1, cache.LocalSize(CachePeekMode.Onheap));
+            Assert.AreEqual(1, cache.GetLocalSize(CachePeekMode.Onheap));
 
             Assert.AreEqual(0, PeekInt(cache, keys[0]));
             Assert.AreEqual(0, PeekInt(cache, keys[1]));
@@ -1052,7 +1052,7 @@ namespace Apache.Ignite.Core.Tests.Cache
             Assert.AreEqual(1, cache.Get(keys[0]));
             Assert.AreEqual(2, cache.Get(keys[1]));
 
-            Assert.AreEqual(3, cache.LocalSize());
+            Assert.AreEqual(3, cache.GetLocalSize());
 
             Assert.AreEqual(1, PeekInt(cache, keys[0]));
             Assert.AreEqual(2, PeekInt(cache, keys[1]));
@@ -1068,13 +1068,13 @@ namespace Apache.Ignite.Core.Tests.Cache
 
                 cache.Put(PrimaryKeyForCache(cache, 500), 1);
 
-                Assert.IsFalse(cache.IsEmpty);
+                Assert.IsFalse(cache.IsEmpty());
             }
 
             Cache().Clear();
 
             for (int i = 0; i < GridCount(); i++)
-                Assert.IsTrue(Cache(i).IsEmpty);
+                Assert.IsTrue(Cache(i).IsEmpty());
         }
 
         [Test]
@@ -1086,7 +1086,7 @@ namespace Apache.Ignite.Core.Tests.Cache
             foreach (var key in keys)
                 cache.Put(key, 3);
 
-            var i = cache.Size();
+            var i = cache.GetSize();
 
             foreach (var key in keys)
             {
@@ -1094,9 +1094,9 @@ namespace Apache.Ignite.Core.Tests.Cache
 
                 Assert.AreEqual(0, cache.Get(key));
 
-                Assert.Less(cache.Size(), i);
+                Assert.Less(cache.GetSize(), i);
 
-                i = cache.Size();
+                i = cache.GetSize();
             }
         }
 
@@ -1124,7 +1124,7 @@ namespace Apache.Ignite.Core.Tests.Cache
             foreach (var key in keys)
                 cache.Put(key, 3);
 
-            var i = cache.Size();
+            var i = cache.GetSize();
 
             foreach (var key in keys)
             {
@@ -1132,9 +1132,9 @@ namespace Apache.Ignite.Core.Tests.Cache
 
                 Assert.AreEqual(0, cache.LocalPeek(key));
 
-                Assert.Less(cache.Size(), i);
+                Assert.Less(cache.GetSize(), i);
 
-                i = cache.Size();
+                i = cache.GetSize();
             }
 
             cache.Clear();
@@ -1168,7 +1168,7 @@ namespace Apache.Ignite.Core.Tests.Cache
 
             Assert.AreEqual(true, cache.Remove(1));
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             Assert.AreEqual(0, cache.Get(1));
 
@@ -1179,7 +1179,7 @@ namespace Apache.Ignite.Core.Tests.Cache
             Assert.IsFalse(cache.Remove(1, -1));
             Assert.IsTrue(cache.Remove(1, 1));
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             Assert.AreEqual(0, cache.Get(1));
         }
@@ -1195,7 +1195,7 @@ namespace Apache.Ignite.Core.Tests.Cache
 
             Assert.AreEqual(1, cache.GetAndRemove(1));
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             Assert.AreEqual(0, cache.Get(1));
 
@@ -1206,7 +1206,7 @@ namespace Apache.Ignite.Core.Tests.Cache
             Assert.IsFalse(cache.Remove(1, -1));
             Assert.IsTrue(cache.Remove(1, 1));
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             Assert.AreEqual(0, cache.Get(1));
         }
@@ -1223,7 +1223,7 @@ namespace Apache.Ignite.Core.Tests.Cache
             Assert.IsFalse(cache.Remove(-1));
             Assert.IsTrue(cache.Remove(1));
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             Assert.AreEqual(0, cache.Get(1));
         }
@@ -1240,7 +1240,7 @@ namespace Apache.Ignite.Core.Tests.Cache
             Assert.IsFalse(cache.Remove(-1));
             Assert.IsTrue(cache.Remove(1));
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             Assert.AreEqual(0, cache.Get(1));
         }
@@ -1260,7 +1260,7 @@ namespace Apache.Ignite.Core.Tests.Cache
 
             cache.RemoveAll();
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             Assert.AreEqual(0, cache.Get(keys[0]));
             Assert.AreEqual(0, cache.Get(keys[1]));
@@ -1281,7 +1281,7 @@ namespace Apache.Ignite.Core.Tests.Cache
 
             cache.RemoveAll();
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             Assert.AreEqual(0, cache.Get(keys[0]));
             Assert.AreEqual(0, cache.Get(keys[1]));
@@ -1292,7 +1292,7 @@ namespace Apache.Ignite.Core.Tests.Cache
         {
             var cache = Cache();
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             cache.Put(1, 1);
             cache.Put(2, 2);
@@ -1304,7 +1304,7 @@ namespace Apache.Ignite.Core.Tests.Cache
 
             cache.RemoveAll(new List<int> { 0, 1, 2 });
 
-            Assert.AreEqual(1, cache.Size(CachePeekMode.Primary));
+            Assert.AreEqual(1, cache.GetSize(CachePeekMode.Primary));
 
             Assert.AreEqual(0, cache.Get(1));
             Assert.AreEqual(0, cache.Get(2));
@@ -1316,7 +1316,7 @@ namespace Apache.Ignite.Core.Tests.Cache
         {
             var cache = Cache().WithAsync().WrapAsync();
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             cache.Put(1, 1);
             cache.Put(2, 2);
@@ -1328,7 +1328,7 @@ namespace Apache.Ignite.Core.Tests.Cache
 
             cache.RemoveAll(new List<int> { 0, 1, 2 });
 
-            Assert.AreEqual(1, cache.Size(CachePeekMode.Primary));
+            Assert.AreEqual(1, cache.GetSize(CachePeekMode.Primary));
 
             Assert.AreEqual(0, cache.Get(1));
             Assert.AreEqual(0, cache.Get(2));
@@ -1347,13 +1347,13 @@ namespace Apache.Ignite.Core.Tests.Cache
                 foreach (int key in keys)
                     cache.Put(key, 1);
 
-                Assert.IsTrue(cache.Size() >= 2);
-                Assert.AreEqual(2, cache.LocalSize(CachePeekMode.Primary));
+                Assert.IsTrue(cache.GetSize() >= 2);
+                Assert.AreEqual(2, cache.GetLocalSize(CachePeekMode.Primary));
             }
 
             ICache<int, int> cache0 = Cache();
 
-            Assert.AreEqual(GridCount() * 2, cache0.Size(CachePeekMode.Primary));
+            Assert.AreEqual(GridCount() * 2, cache0.GetSize(CachePeekMode.Primary));
 
             if (!LocalCache() && !ReplicatedCache())
             {
@@ -1361,7 +1361,7 @@ namespace Apache.Ignite.Core.Tests.Cache
 
                 cache0.Put(nearKey, 1);
 
-                Assert.AreEqual(NearEnabled() ? 1 : 0, cache0.Size(CachePeekMode.Near));
+                Assert.AreEqual(NearEnabled() ? 1 : 0, cache0.GetSize(CachePeekMode.Near));
             }
         }
 
@@ -1374,16 +1374,16 @@ namespace Apache.Ignite.Core.Tests.Cache
             cache.Put(keys[0], 1);
             cache.Put(keys[1], 2);
 
-            var localSize = cache.LocalSize();
+            var localSize = cache.GetLocalSize();
 
             cache.LocalEvict(keys.Take(2).ToArray());
 
-            Assert.AreEqual(0, cache.LocalSize(CachePeekMode.Onheap));
-            Assert.AreEqual(localSize, cache.LocalSize(CachePeekMode.All));
+            Assert.AreEqual(0, cache.GetLocalSize(CachePeekMode.Onheap));
+            Assert.AreEqual(localSize, cache.GetLocalSize(CachePeekMode.All));
 
             cache.Put(keys[2], 3);
 
-            Assert.AreEqual(localSize + 1, cache.LocalSize(CachePeekMode.All));
+            Assert.AreEqual(localSize + 1, cache.GetLocalSize(CachePeekMode.All));
 
             cache.RemoveAll(keys.Take(2).ToArray());
         }
@@ -1495,13 +1495,13 @@ namespace Apache.Ignite.Core.Tests.Cache
 
             cache.LocalEvict(new[] {key});
 
-            Assert.AreEqual(0, cache.LocalSize(CachePeekMode.Onheap));
+            Assert.AreEqual(0, cache.GetLocalSize(CachePeekMode.Onheap));
 
             Assert.AreEqual(0, PeekInt(cache, key));
 
             cache.LocalPromote(new[] { key });
 
-            Assert.AreEqual(1, cache.LocalSize(CachePeekMode.Onheap));
+            Assert.AreEqual(1, cache.GetLocalSize(CachePeekMode.Onheap));
 
             Assert.AreEqual(1, PeekInt(cache, key));
         }
@@ -1523,7 +1523,7 @@ namespace Apache.Ignite.Core.Tests.Cache
 
             cache.LocalEvict(new List<int> { -1, keys[0], keys[1] });
 
-            Assert.AreEqual(1, cache.LocalSize(CachePeekMode.Onheap));
+            Assert.AreEqual(1, cache.GetLocalSize(CachePeekMode.Onheap));
 
             Assert.AreEqual(0, PeekInt(cache, keys[0]));
             Assert.AreEqual(0, PeekInt(cache, keys[1]));
@@ -1531,7 +1531,7 @@ namespace Apache.Ignite.Core.Tests.Cache
 
             cache.LocalPromote(new[] {keys[0], keys[1]});
 
-            Assert.AreEqual(3, cache.LocalSize(CachePeekMode.Onheap));
+            Assert.AreEqual(3, cache.GetLocalSize(CachePeekMode.Onheap));
 
             Assert.AreEqual(1, PeekInt(cache, keys[0]));
             Assert.AreEqual(2, PeekInt(cache, keys[1]));
@@ -1812,8 +1812,8 @@ namespace Apache.Ignite.Core.Tests.Cache
                     IPortableObject p = portCache.Get(new CacheTestKey(key));
 
                     Assert.IsNotNull(p);
-                    Assert.AreEqual(key, p.Field<int>("age"));
-                    Assert.AreEqual("Person-" + key, p.Field<string>("name"));
+                    Assert.AreEqual(key, p.GetField<int>("age"));
+                    Assert.AreEqual("Person-" + key, p.GetField<string>("name"));
                 }
             }
 
@@ -1843,8 +1843,8 @@ namespace Apache.Ignite.Core.Tests.Cache
                     var p = fut.Get();
 
                     Assert.IsNotNull(p);
-                    Assert.AreEqual(key, p.Field<int>("age"));
-                    Assert.AreEqual("Person-" + key, p.Field<string>("name"));
+                    Assert.AreEqual(key, p.GetField<int>("age"));
+                    Assert.AreEqual("Person-" + key, p.GetField<string>("name"));
                 }
             }, threads);
 
@@ -2206,7 +2206,7 @@ namespace Apache.Ignite.Core.Tests.Cache
             Assert.AreEqual(2500, tx.Timeout.TotalMilliseconds);
             Assert.AreEqual(TransactionState.Active, tx.State);
             Assert.IsTrue(tx.StartTime.Ticks > 0);
-            Assert.AreEqual(tx.NodeId, GetIgnite(0).Cluster.LocalNode.Id);
+            Assert.AreEqual(tx.NodeId, GetIgnite(0).GetCluster().GetLocalNode().Id);
 
             DateTime startTime1 = tx.StartTime;
 
@@ -2515,7 +2515,7 @@ namespace Apache.Ignite.Core.Tests.Cache
                 ISet<int> parts = new HashSet<int>();
 
                 for (int i = 0; i < 1000; i++)
-                    parts.Add(aff.Partition(i));
+                    parts.Add(aff.GetPartition(i));
 
                 if (LocalCache())
                     Assert.AreEqual(1, parts.Count);
@@ -2527,7 +2527,7 @@ namespace Apache.Ignite.Core.Tests.Cache
                 ISet<int> parts = new HashSet<int>();
 
                 for (int i = 0; i < 1000; i++)
-                    parts.Add(aff.Partition("key" + i));
+                    parts.Add(aff.GetPartition("key" + i));
 
                 if (LocalCache())
                     Assert.AreEqual(1, parts.Count);
@@ -2541,7 +2541,7 @@ namespace Apache.Ignite.Core.Tests.Cache
         {
             ICacheAffinity aff = Affinity();
 
-            ICollection<IClusterNode> nodes = GetIgnite(0).Cluster.Nodes();
+            ICollection<IClusterNode> nodes = GetIgnite(0).GetCluster().GetNodes();
 
             Assert.IsTrue(nodes.Count > 0);
 
@@ -2593,7 +2593,7 @@ namespace Apache.Ignite.Core.Tests.Cache
         {
             ICacheAffinity aff = Affinity();
 
-            ICollection<IClusterNode> nodes = GetIgnite(0).Cluster.Nodes();
+            ICollection<IClusterNode> nodes = GetIgnite(0).GetCluster().GetNodes();
 
             Assert.IsTrue(nodes.Count > 0);
 
@@ -2601,11 +2601,11 @@ namespace Apache.Ignite.Core.Tests.Cache
             {
                 IClusterNode node = nodes.First();
 
-                int[] parts = aff.BackupPartitions(node);
+                int[] parts = aff.GetBackupPartitions(node);
 
                 Assert.AreEqual(0, parts.Length);
 
-                parts = aff.AllPartitions(node);
+                parts = aff.GetAllPartitions(node);
 
                 Assert.AreEqual(CachePartitions(), parts.Length);
             }
@@ -2616,17 +2616,17 @@ namespace Apache.Ignite.Core.Tests.Cache
                 IList<int> allParts = new List<int>();
 
                 foreach(IClusterNode node in nodes) {
-                    int[] parts = aff.PrimaryPartitions(node);
+                    int[] parts = aff.GetPrimaryPartitions(node);
 
                     foreach (int part in parts)
                         allPrimaryParts.Add(part);
 
-                    parts = aff.BackupPartitions(node);
+                    parts = aff.GetBackupPartitions(node);
 
                     foreach (int part in parts)
                         allBackupParts.Add(part);
 
-                    parts = aff.AllPartitions(node);
+                    parts = aff.GetAllPartitions(node);
 
                     foreach (int part in parts)
                         allParts.Add(part);
@@ -2643,9 +2643,9 @@ namespace Apache.Ignite.Core.Tests.Cache
         {
             ICacheAffinity aff = Affinity();
 
-            Assert.AreEqual(10, aff.AffinityKey<int, int>(10));
+            Assert.AreEqual(10, aff.GetAffinityKey<int, int>(10));
 
-            Assert.AreEqual("string", aff.AffinityKey<string, string>("string"));
+            Assert.AreEqual("string", aff.GetAffinityKey<string, string>("string"));
         }
 
         [Test]
@@ -2659,7 +2659,7 @@ namespace Apache.Ignite.Core.Tests.Cache
 
             Assert.IsNotNull(node);
 
-            Assert.IsTrue(GetIgnite(0).Cluster.Nodes().Contains(node));
+            Assert.IsTrue(GetIgnite(0).GetCluster().GetNodes().Contains(node));
 
             Assert.IsTrue(aff.IsPrimary(node, key));
 
@@ -2667,7 +2667,7 @@ namespace Apache.Ignite.Core.Tests.Cache
 
             Assert.IsFalse(aff.IsBackup(node, key));
 
-            int part = aff.Partition(key);
+            int part = aff.GetPartition(key);
 
             IClusterNode partNode = aff.MapPartitionToNode(part);
 
@@ -2693,7 +2693,7 @@ namespace Apache.Ignite.Core.Tests.Cache
                     Assert.IsTrue(aff.IsBackup(nodes[i], key));
             }
 
-            int part = aff.Partition(key);
+            int part = aff.GetPartition(key);
 
             IList<IClusterNode> partNodes = aff.MapPartitionToPrimaryAndBackups(part);
 
@@ -2738,7 +2738,7 @@ namespace Apache.Ignite.Core.Tests.Cache
 
                 Assert.AreEqual(parts.Count, map.Count);
 
-                Assert.AreEqual(GetIgnite(0).Cluster.LocalNode, map[0]);
+                Assert.AreEqual(GetIgnite(0).GetCluster().GetLocalNode(), map[0]);
             }
             else
             {
@@ -2780,8 +2780,8 @@ namespace Apache.Ignite.Core.Tests.Cache
             const int count = 20;
 
             var cache = Cache();
-            var aff = cache.Ignite.Affinity(cache.Name);
-            var node = cache.Ignite.Cluster.LocalNode;
+            var aff = cache.Ignite.GetAffinity(cache.Name);
+            var node = cache.Ignite.GetCluster().GetLocalNode();
 
             for (int i = 0; i < count; i++)
                 cache.Put(i, -i - 1);
@@ -3004,7 +3004,7 @@ namespace Apache.Ignite.Core.Tests.Cache
             Assert.AreSame(cacheSkipStore1, cacheSkipStore2);
 
             // Ensure other flags are preserved.
-            Assert.IsTrue(((CacheProxyImpl<int, int>)cache.WithKeepPortable<int, int>().WithSkipStore()).KeepPortable);
+            Assert.IsTrue(((CacheProxyImpl<int, int>)cache.WithKeepPortable<int, int>().WithSkipStore()).IsKeepPortable);
             Assert.IsTrue(cache.WithAsync().WithSkipStore().IsAsync);
         }
 
@@ -3019,7 +3019,7 @@ namespace Apache.Ignite.Core.Tests.Cache
 
             Assert.AreEqual(cache.Name, m.CacheName);
 
-            Assert.AreEqual(cache.Size(), m.Size);
+            Assert.AreEqual(cache.GetSize(), m.Size);
         }
 
         [Test]
@@ -3039,7 +3039,7 @@ namespace Apache.Ignite.Core.Tests.Cache
             var randomName = "template" + Guid.NewGuid();
 
             // Can't get non-existent cache with Cache method
-            Assert.Throws<ArgumentException>(() => GetIgnite(0).Cache<int, int>(randomName));
+            Assert.Throws<ArgumentException>(() => GetIgnite(0).GetCache<int, int>(randomName));
 
             var cache = GetIgnite(0).CreateCache<int, int>(randomName);
 
@@ -3050,7 +3050,7 @@ namespace Apache.Ignite.Core.Tests.Cache
             // Can't create again
             Assert.Throws<IgniteException>(() => GetIgnite(0).CreateCache<int, int>(randomName));
 
-            var cache0 = GetIgnite(0).Cache<int, int>(randomName);
+            var cache0 = GetIgnite(0).GetCache<int, int>(randomName);
 
             Assert.AreEqual(10, cache0.Get(1));
         }
@@ -3062,7 +3062,7 @@ namespace Apache.Ignite.Core.Tests.Cache
             var randomName = "template" + Guid.NewGuid();
 
             // Can't get non-existent cache with Cache method
-            Assert.Throws<ArgumentException>(() => GetIgnite(0).Cache<int, int>(randomName));
+            Assert.Throws<ArgumentException>(() => GetIgnite(0).GetCache<int, int>(randomName));
 
             var cache = GetIgnite(0).GetOrCreateCache<int, int>(randomName);
 
@@ -3074,7 +3074,7 @@ namespace Apache.Ignite.Core.Tests.Cache
 
             Assert.AreEqual(10, cache0.Get(1));
 
-            var cache1 = GetIgnite(0).Cache<int, int>(randomName);
+            var cache1 = GetIgnite(0).GetCache<int, int>(randomName);
 
             Assert.AreEqual(10, cache1.Get(1));
         }
@@ -3138,8 +3138,8 @@ namespace Apache.Ignite.Core.Tests.Cache
 
         private void CheckPersonData(IPortableObject obj, string expName, int expAge)
         {
-            Assert.AreEqual(expName, obj.Field<string>("name"));
-            Assert.AreEqual(expAge, obj.Field<int>("age"));
+            Assert.AreEqual(expName, obj.GetField<string>("name"));
+            Assert.AreEqual(expAge, obj.GetField<int>("age"));
 
             PortablePerson person = obj.Deserialize<PortablePerson>();
 
@@ -3164,18 +3164,18 @@ namespace Apache.Ignite.Core.Tests.Cache
 
         protected static IEnumerable<int> PrimaryKeysForCache(ICache<int, int> cache, int cnt, int startFrom)
         {
-            IClusterNode node = cache.Ignite.Cluster.LocalNode;
+            IClusterNode node = cache.Ignite.GetCluster().GetLocalNode();
 
-            ICacheAffinity aff = cache.Ignite.Affinity(cache.Name);
+            ICacheAffinity aff = cache.Ignite.GetAffinity(cache.Name);
 
             return Enumerable.Range(startFrom, int.MaxValue - startFrom).Where(x => aff.IsPrimary(node, x));
         }
 
         protected static int NearKeyForCache(ICache<int, int> cache)
         {
-            IClusterNode node = cache.Ignite.Cluster.LocalNode;
+            IClusterNode node = cache.Ignite.GetCluster().GetLocalNode();
 
-            ICacheAffinity aff = cache.Ignite.Affinity(cache.Name);
+            ICacheAffinity aff = cache.Ignite.GetAffinity(cache.Name);
 
             for (int i = 0; i < 100000; i++)
             {
@@ -3190,10 +3190,10 @@ namespace Apache.Ignite.Core.Tests.Cache
 
         protected static string GetKeyAffinity(ICache<int, int> cache, int key)
         {
-            if (cache.Ignite.Affinity(cache.Name).IsPrimary(cache.Ignite.Cluster.LocalNode, key))
+            if (cache.Ignite.GetAffinity(cache.Name).IsPrimary(cache.Ignite.GetCluster().GetLocalNode(), key))
                 return "primary";
 
-            if (cache.Ignite.Affinity(cache.Name).IsBackup(cache.Ignite.Cluster.LocalNode, key))
+            if (cache.Ignite.GetAffinity(cache.Name).IsBackup(cache.Ignite.GetCluster().GetLocalNode(), key))
                 return "backup";
 
             return "near";

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheAffinityTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheAffinityTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheAffinityTest.cs
index beb2c0f..469887d 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheAffinityTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheAffinityTest.cs
@@ -68,7 +68,7 @@ namespace Apache.Ignite.Core.Tests.Cache
         {
             IIgnite g = Ignition.GetIgnite("grid-0");
 
-            ICacheAffinity aff = g.Affinity(null);
+            ICacheAffinity aff = g.GetAffinity(null);
 
             IClusterNode node = aff.MapKeyToNode(new AffinityTestKey(0, 1));
 
@@ -84,16 +84,16 @@ namespace Apache.Ignite.Core.Tests.Cache
         {
             IIgnite g = Ignition.GetIgnite("grid-0");
 
-            ICacheAffinity aff = g.Affinity(null);  
+            ICacheAffinity aff = g.GetAffinity(null);  
 
-            IPortableObject affKey = g.Portables().ToPortable<IPortableObject>(new AffinityTestKey(0, 1));
+            IPortableObject affKey = g.GetPortables().ToPortable<IPortableObject>(new AffinityTestKey(0, 1));
 
             IClusterNode node = aff.MapKeyToNode(affKey);
 
             for (int i = 0; i < 10; i++)
             {
                 IPortableObject otherAffKey =
-                    g.Portables().ToPortable<IPortableObject>(new AffinityTestKey(i, 1));
+                    g.GetPortables().ToPortable<IPortableObject>(new AffinityTestKey(i, 1));
 
                 Assert.AreEqual(node.Id, aff.MapKeyToNode(otherAffKey).Id);
             }

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheDynamicStartTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheDynamicStartTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheDynamicStartTest.cs
index 210d80c..abef473 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheDynamicStartTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheDynamicStartTest.cs
@@ -108,17 +108,17 @@ namespace Apache.Ignite.Core.Tests.Cache
         {
             Assert.Throws<ArgumentException>(() =>
             {
-                Ignition.GetIgnite(GridData).Cache<CacheTestKey, PortablePerson>(CacheDummy);
+                Ignition.GetIgnite(GridData).GetCache<CacheTestKey, PortablePerson>(CacheDummy);
             });
 
             Assert.Throws<ArgumentException>(() =>
             {
-                Ignition.GetIgnite(GridDataNoCfg).Cache<CacheTestKey, PortablePerson>(CacheDummy);
+                Ignition.GetIgnite(GridDataNoCfg).GetCache<CacheTestKey, PortablePerson>(CacheDummy);
             });
 
             Assert.Throws<ArgumentException>(() =>
             {
-                Ignition.GetIgnite(GridClient).Cache<CacheTestKey, PortablePerson>(CacheDummy);
+                Ignition.GetIgnite(GridClient).GetCache<CacheTestKey, PortablePerson>(CacheDummy);
             });
         }
 
@@ -147,13 +147,13 @@ namespace Apache.Ignite.Core.Tests.Cache
         private void Check(string cacheName)
         {
             ICache<DynamicTestKey, DynamicTestValue> cacheData =
-                Ignition.GetIgnite(GridData).Cache<DynamicTestKey, DynamicTestValue>(cacheName);
+                Ignition.GetIgnite(GridData).GetCache<DynamicTestKey, DynamicTestValue>(cacheName);
 
             ICache<DynamicTestKey, DynamicTestValue> cacheDataNoCfg =
-                Ignition.GetIgnite(GridDataNoCfg).Cache<DynamicTestKey, DynamicTestValue>(cacheName);
+                Ignition.GetIgnite(GridDataNoCfg).GetCache<DynamicTestKey, DynamicTestValue>(cacheName);
 
             ICache<DynamicTestKey, DynamicTestValue> cacheClient =
-                Ignition.GetIgnite(GridClient).Cache<DynamicTestKey, DynamicTestValue>(cacheName);
+                Ignition.GetIgnite(GridClient).GetCache<DynamicTestKey, DynamicTestValue>(cacheName);
 
             DynamicTestKey key1 = new DynamicTestKey(1);
             DynamicTestKey key2 = new DynamicTestKey(2);
@@ -181,7 +181,7 @@ namespace Apache.Ignite.Core.Tests.Cache
             for (int i = 0; i < 10000; i++)
                 cacheClient.Put(new DynamicTestKey(i), new DynamicTestValue(1));
 
-            int sizeClient = cacheClient.LocalSize();
+            int sizeClient = cacheClient.GetLocalSize();
 
             Assert.AreEqual(0, sizeClient);
         }

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheForkedTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheForkedTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheForkedTest.cs
index 2f3e0d0..46c54e6 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheForkedTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheForkedTest.cs
@@ -75,7 +75,7 @@ namespace Apache.Ignite.Core.Tests.Cache
         [Test]
         public void TestClearCache()
         {
-            _grid.Cache<object, object>(null).Clear();
+            _grid.GetCache<object, object>(null).Clear();
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheTestAsyncWrapper.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheTestAsyncWrapper.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheTestAsyncWrapper.cs
index 93f5973..52a856a 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheTestAsyncWrapper.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/CacheTestAsyncWrapper.cs
@@ -83,15 +83,16 @@ namespace Apache.Ignite.Core.Tests.Cache
         }
 
         /** <inheritDoc /> */
-        public bool IsEmpty
+
+        public bool IsEmpty()
         {
-            get { return _cache.IsEmpty; }
+            return _cache.IsEmpty();
         }
 
         /** <inheritDoc /> */
-        public bool KeepPortable
+        public bool IsKeepPortable
         {
-            get { return _cache.KeepPortable; }
+            get { return _cache.IsKeepPortable; }
         }
 
         /** <inheritDoc /> */
@@ -290,15 +291,15 @@ namespace Apache.Ignite.Core.Tests.Cache
         }
 
         /** <inheritDoc /> */
-        public int LocalSize(params CachePeekMode[] modes)
+        public int GetLocalSize(params CachePeekMode[] modes)
         {
-            return _cache.LocalSize(modes);
+            return _cache.GetLocalSize(modes);
         }
 
         /** <inheritDoc /> */
-        public int Size(params CachePeekMode[] modes)
+        public int GetSize(params CachePeekMode[] modes)
         {
-            _cache.Size(modes);
+            _cache.GetSize(modes);
             return GetResult<int>();
         }
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Query/CacheQueriesTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Query/CacheQueriesTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Query/CacheQueriesTest.cs
index 85227b6..18f04ef 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Query/CacheQueriesTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Query/CacheQueriesTest.cs
@@ -112,7 +112,7 @@ namespace Apache.Ignite.Core.Tests.Cache.Query
                 for (int j = 0; j < MaxItemCnt; j++)
                     cache.Remove(j);
 
-                Assert.IsTrue(cache.IsEmpty);
+                Assert.IsTrue(cache.IsEmpty());
             }
 
             Console.WriteLine("Test finished: " + TestContext.CurrentContext.Test.Name);
@@ -135,7 +135,7 @@ namespace Apache.Ignite.Core.Tests.Cache.Query
         /// <returns></returns>
         public ICache<int, QueryPerson> Cache(int idx)
         {
-            return GetIgnite(idx).Cache<int, QueryPerson>(CacheName);
+            return GetIgnite(idx).GetCache<int, QueryPerson>(CacheName);
         }
 
         /// <summary>
@@ -654,7 +654,7 @@ namespace Apache.Ignite.Core.Tests.Cache.Query
 
             var cache = Cache();
 
-            var aff = cache.Ignite.Affinity(CacheName);
+            var aff = cache.Ignite.GetAffinity(CacheName);
             var exp = PopulateCache(cache, loc, cnt, x => true);  // populate outside the loop (slow)
 
             for (var part = 0; part < aff.Partitions; part++)
@@ -662,7 +662,7 @@ namespace Apache.Ignite.Core.Tests.Cache.Query
                 //var exp0 = new HashSet<int>(exp.Where(x => aff.Partition(x) == part)); // filter expected keys
                 var exp0 = new HashSet<int>();
                 foreach (var x in exp)
-                    if (aff.Partition(x) == part)
+                    if (aff.GetPartition(x) == part)
                         exp0.Add(x);
 
                 var qry = new ScanQuery<int, TV> { Partition = part };
@@ -679,7 +679,7 @@ namespace Apache.Ignite.Core.Tests.Cache.Query
                 //var exp0 = new HashSet<int>(exp.Where(x => aff.Partition(x) == part)); // filter expected keys
                 var exp0 = new HashSet<int>();
                 foreach (var x in exp)
-                    if (aff.Partition(x) == part)
+                    if (aff.GetPartition(x) == part)
                         exp0.Add(x);
 
                 var qry = new ScanQuery<int, TV>(new ScanQueryFilter<TV>()) { Partition = part };
@@ -713,8 +713,8 @@ namespace Apache.Ignite.Core.Tests.Cache.Query
                     {
                         all.Add(entry);
 
-                        Assert.AreEqual(entry.Key.ToString(), entry.Value.Field<string>("name"));
-                        Assert.AreEqual(entry.Key, entry.Value.Field<int>("age"));
+                        Assert.AreEqual(entry.Key.ToString(), entry.Value.GetField<string>("name"));
+                        Assert.AreEqual(entry.Key, entry.Value.GetField<int>("age"));
 
                         exp0.Remove(entry.Key);
                     }
@@ -731,8 +731,8 @@ namespace Apache.Ignite.Core.Tests.Cache.Query
                     {
                         all.Add(entry);
 
-                        Assert.AreEqual(entry.Key.ToString(), entry.Value.Field<string>("name"));
-                        Assert.AreEqual(entry.Key, entry.Value.Field<int>("age"));
+                        Assert.AreEqual(entry.Key.ToString(), entry.Value.GetField<string>("name"));
+                        Assert.AreEqual(entry.Key, entry.Value.GetField<int>("age"));
 
                         exp0.Remove(entry.Key);
                     }
@@ -790,11 +790,11 @@ namespace Apache.Ignite.Core.Tests.Cache.Query
                 return;
 
             var sb = new StringBuilder();
-            var aff = cache.Ignite.Affinity(cache.Name);
+            var aff = cache.Ignite.GetAffinity(cache.Name);
 
             foreach (var key in exp)
             {
-                var part = aff.Partition(key);
+                var part = aff.GetPartition(key);
                 sb.AppendFormat(
                     "Query did not return expected key '{0}' (exists: {1}), partition '{2}', partition nodes: ", 
                     key, cache.Get(key) != null, part);
@@ -838,8 +838,8 @@ namespace Apache.Ignite.Core.Tests.Cache.Query
 
                 cache.Put(val, new QueryPerson(val.ToString(), val));
 
-                if (expectedEntryFilter(val) && (!loc || cache.Ignite.Affinity(cache.Name)
-                    .IsPrimary(cache.Ignite.Cluster.LocalNode, val)))
+                if (expectedEntryFilter(val) && (!loc || cache.Ignite.GetAffinity(cache.Name)
+                    .IsPrimary(cache.Ignite.GetCluster().GetLocalNode(), val)))
                     exp.Add(val);
             }
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Query/Continuous/ContinuousQueryAbstractTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Query/Continuous/ContinuousQueryAbstractTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Query/Continuous/ContinuousQueryAbstractTest.cs
index 55bc76c..e0dcdaa 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Query/Continuous/ContinuousQueryAbstractTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Query/Continuous/ContinuousQueryAbstractTest.cs
@@ -114,11 +114,11 @@ namespace Apache.Ignite.Core.Tests.Cache.Query.Continuous
 
             cfg.GridName = "grid-1";
             grid1 = Ignition.Start(cfg);
-            cache1 = grid1.Cache<int, PortableEntry>(cacheName);
+            cache1 = grid1.GetCache<int, PortableEntry>(cacheName);
 
             cfg.GridName = "grid-2";
             grid2 = Ignition.Start(cfg);
-            cache2 = grid2.Cache<int, PortableEntry>(cacheName);
+            cache2 = grid2.GetCache<int, PortableEntry>(cacheName);
         }
 
         /// <summary>
@@ -147,8 +147,8 @@ namespace Apache.Ignite.Core.Tests.Cache.Query.Continuous
             cache1.Remove(PrimaryKey(cache1));
             cache1.Remove(PrimaryKey(cache2));
 
-            Assert.AreEqual(0, cache1.Size());
-            Assert.AreEqual(0, cache2.Size());
+            Assert.AreEqual(0, cache1.GetSize());
+            Assert.AreEqual(0, cache2.GetSize());
 
             Console.WriteLine("Test started: " + TestContext.CurrentContext.Test.Name);
         }
@@ -923,9 +923,9 @@ namespace Apache.Ignite.Core.Tests.Cache.Query.Continuous
         /// <returns></returns>
         private static List<int> PrimaryKeys<T>(ICache<int, T> cache, int cnt, int startFrom = 0)
         {
-            IClusterNode node = cache.Ignite.Cluster.LocalNode;
+            IClusterNode node = cache.Ignite.GetCluster().GetLocalNode();
 
-            ICacheAffinity aff = cache.Ignite.Affinity(cache.Name);
+            ICacheAffinity aff = cache.Ignite.GetAffinity(cache.Name);
 
             List<int> keys = new List<int>(cnt);
 
@@ -1114,7 +1114,7 @@ namespace Apache.Ignite.Core.Tests.Cache.Query.Continuous
                 {
                     IPortableObject val = evt.Value;
 
-                    IPortableMetadata meta = val.Metadata();
+                    IPortableMetadata meta = val.GetMetadata();
 
                     Assert.AreEqual(typeof(PortableEntry).Name, meta.TypeName);
                 }

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Store/CacheParallelLoadStoreTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Store/CacheParallelLoadStoreTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Store/CacheParallelLoadStoreTest.cs
index 33eec7b..a7d9adb 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Store/CacheParallelLoadStoreTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Store/CacheParallelLoadStoreTest.cs
@@ -77,7 +77,7 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
         {
             var cache = GetCache();
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             const int minId = 113;
             const int expectedItemCount = CacheTestParallelLoadStore.InputDataLength - minId;
@@ -86,7 +86,7 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
 
             cache.LocalLoadCache(null, minId);
 
-            Assert.AreEqual(expectedItemCount, cache.Size());
+            Assert.AreEqual(expectedItemCount, cache.GetSize());
 
             // check items presence; increment by 100 to speed up the test
             for (var i = minId; i < expectedItemCount; i += 100)
@@ -104,7 +104,7 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
         /// </summary>
         private static ICache<int, CacheTestParallelLoadStore.Record> GetCache()
         {
-            return Ignition.GetIgnite().Cache<int, CacheTestParallelLoadStore.Record>(ObjectStoreCacheName);
+            return Ignition.GetIgnite().GetCache<int, CacheTestParallelLoadStore.Record>(ObjectStoreCacheName);
         }
     }
 }

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Store/CacheStoreSessionTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Store/CacheStoreSessionTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Store/CacheStoreSessionTest.cs
index bc55901..137215e 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Store/CacheStoreSessionTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Store/CacheStoreSessionTest.cs
@@ -86,11 +86,11 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
 
             var ignite = Ignition.GetIgnite(IgniteName);
 
-            var cache1 = Ignition.GetIgnite(IgniteName).Cache<int, int>(Cache1);
-            var cache2 = Ignition.GetIgnite(IgniteName).Cache<int, int>(Cache2);
+            var cache1 = Ignition.GetIgnite(IgniteName).GetCache<int, int>(Cache1);
+            var cache2 = Ignition.GetIgnite(IgniteName).GetCache<int, int>(Cache2);
 
             // 1. Test rollback.
-            using (var tx = ignite.Transactions.TxStart())
+            using (var tx = ignite.GetTransactions().TxStart())
             {
                 cache1.Put(1, 1);
                 cache2.Put(2, 2);
@@ -107,7 +107,7 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
             _dumps = new ConcurrentBag<ICollection<Operation>>();
 
             // 2. Test puts.
-            using (var tx = ignite.Transactions.TxStart())
+            using (var tx = ignite.GetTransactions().TxStart())
             {
                 cache1.Put(1, 1);
                 cache2.Put(2, 2);
@@ -126,7 +126,7 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
             _dumps = new ConcurrentBag<ICollection<Operation>>();
 
             // 3. Test removes.
-            using (var tx = ignite.Transactions.TxStart())
+            using (var tx = ignite.GetTransactions().TxStart())
             {
                 cache1.Remove(1);
                 cache2.Remove(2);

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Store/CacheStoreTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Store/CacheStoreTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Store/CacheStoreTest.cs
index 4e5e050..bfafcf4 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Store/CacheStoreTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Cache/Store/CacheStoreTest.cs
@@ -162,7 +162,7 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
 
             cache.Clear();
 
-            Assert.IsTrue(cache.IsEmpty, "Cache is not empty: " + cache.Size());
+            Assert.IsTrue(cache.IsEmpty(), "Cache is not empty: " + cache.GetSize());
 
             CacheTestStore.Reset();
 
@@ -174,11 +174,11 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
         {
             var cache = Cache();
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             cache.LoadCache(new CacheEntryFilter(), 100, 10);
 
-            Assert.AreEqual(5, cache.Size());
+            Assert.AreEqual(5, cache.GetSize());
 
             for (int i = 105; i < 110; i++)
                 Assert.AreEqual("val_" + i, cache.Get(i));
@@ -189,11 +189,11 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
         {
             var cache = Cache();
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             cache.LocalLoadCache(new CacheEntryFilter(), 100, 10);
 
-            Assert.AreEqual(5, cache.Size());
+            Assert.AreEqual(5, cache.GetSize());
 
             for (int i = 105; i < 110; i++)
                 Assert.AreEqual("val_" + i, cache.Get(i));
@@ -206,13 +206,13 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
 
             var cache = Cache();
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             cache.LocalLoadCache(null, 0, 3);
 
-            Assert.AreEqual(3, cache.Size());
+            Assert.AreEqual(3, cache.GetSize());
 
-            var meta = cache.WithKeepPortable<Key, IPortableObject>().Get(new Key(0)).Metadata();
+            var meta = cache.WithKeepPortable<Key, IPortableObject>().Get(new Key(0)).GetMetadata();
 
             Assert.NotNull(meta);
 
@@ -224,7 +224,7 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
         {
             var cache = Cache().WithAsync();
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             cache.LocalLoadCache(new CacheEntryFilter(), 100, 10);
 
@@ -234,7 +234,7 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
 
             Assert.IsTrue(fut.IsDone);
 
-            cache.Size();
+            cache.GetSize();
             Assert.AreEqual(5, cache.GetFuture<int>().ToTask().Result);
 
             for (int i = 105; i < 110; i++)
@@ -258,11 +258,11 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
 
             cache.LocalEvict(new[] { 1 });
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             Assert.AreEqual("val", cache.Get(1));
 
-            Assert.AreEqual(1, cache.Size());
+            Assert.AreEqual(1, cache.GetSize());
         }
 
         [Test]
@@ -278,15 +278,15 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
 
             IPortableObject v = (IPortableObject)map[1];
 
-            Assert.AreEqual(1, v.Field<int>("_idx"));
+            Assert.AreEqual(1, v.GetField<int>("_idx"));
 
             cache.LocalEvict(new[] { 1 });
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             Assert.AreEqual(1, cache.Get(1).Index());
 
-            Assert.AreEqual(1, cache.Size());
+            Assert.AreEqual(1, cache.GetSize());
         }
 
         [Test]
@@ -306,11 +306,11 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
 
             cache.LocalEvict(new[] { 1 });
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             Assert.AreEqual(1, cache.Get(1).Index());
 
-            Assert.AreEqual(1, cache.Size());
+            Assert.AreEqual(1, cache.GetSize());
         }
 
         [Test]
@@ -334,7 +334,7 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
 
             cache.Clear();
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             ICollection<int> keys = new List<int>();
 
@@ -348,7 +348,7 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
             for (int i = 0; i < 10; i++)
                 Assert.AreEqual("val_" + i, loaded[i]);
 
-            Assert.AreEqual(10, cache.Size());
+            Assert.AreEqual(10, cache.GetSize());
         }
 
         [Test]
@@ -397,7 +397,7 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
         {
             var cache = Cache();
 
-            using (var tx = cache.Ignite.Transactions.TxStart())
+            using (var tx = cache.Ignite.GetTransactions().TxStart())
             {
                 CacheTestStore.ExpCommit = true;
 
@@ -422,11 +422,11 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
 
             var cache = Cache();
 
-            Assert.AreEqual(0, cache.Size());
+            Assert.AreEqual(0, cache.GetSize());
 
             cache.LocalLoadCache(null, 0, null);
 
-            Assert.AreEqual(1000, cache.Size());
+            Assert.AreEqual(1000, cache.GetSize());
 
             for (int i = 0; i < 1000; i++)
                 Assert.AreEqual("val_" + i, cache.Get(i));
@@ -475,17 +475,17 @@ namespace Apache.Ignite.Core.Tests.Cache.Store
 
         private ICache<TK, TV> PortableStoreCache<TK, TV>()
         {
-            return Ignition.GetIgnite(GridName()).Cache<TK, TV>(PortableStoreCacheName);
+            return Ignition.GetIgnite(GridName()).GetCache<TK, TV>(PortableStoreCacheName);
         }
 
         private ICache<TK, TV> ObjectStoreCache<TK, TV>()
         {
-            return Ignition.GetIgnite(GridName()).Cache<TK, TV>(ObjectStoreCacheName);
+            return Ignition.GetIgnite(GridName()).GetCache<TK, TV>(ObjectStoreCacheName);
         }
 
         private ICache<int, string> CustomStoreCache()
         {
-            return Ignition.GetIgnite(GridName()).Cache<int, string>(CustomStoreCacheName);
+            return Ignition.GetIgnite(GridName()).GetCache<int, string>(CustomStoreCacheName);
         }
 
         private ICache<int, string> TemplateStoreCache()

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Compute/AbstractTaskTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Compute/AbstractTaskTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Compute/AbstractTaskTest.cs
index f370740..12c9992 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Compute/AbstractTaskTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Compute/AbstractTaskTest.cs
@@ -92,7 +92,7 @@ namespace Apache.Ignite.Core.Tests.Compute
                     if (!_proc2.Alive)
                         throw new Exception("Process 2 died unexpectedly: " + _proc2.Join());
 
-                    if (Grid1.Cluster.Nodes().Count < 2)
+                    if (Grid1.GetCluster().GetNodes().Count < 2)
                         Thread.Sleep(100);
                     else
                         break;
@@ -105,7 +105,7 @@ namespace Apache.Ignite.Core.Tests.Compute
                     if (!_proc3.Alive)
                         throw new Exception("Process 3 died unexpectedly: " + _proc3.Join());
 
-                    if (Grid1.Cluster.Nodes().Count < 3)
+                    if (Grid1.GetCluster().GetNodes().Count < 3)
                         Thread.Sleep(100);
                     else
                         break;

http://git-wip-us.apache.org/repos/asf/ignite/blob/c5fd4a5b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Compute/ClosureTaskTest.cs
----------------------------------------------------------------------
diff --git a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Compute/ClosureTaskTest.cs b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Compute/ClosureTaskTest.cs
index 047e46b..8664413 100644
--- a/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Compute/ClosureTaskTest.cs
+++ b/modules/platform/src/test/dotnet/Apache.Ignite.Core.Tests/Compute/ClosureTaskTest.cs
@@ -45,7 +45,7 @@ namespace Apache.Ignite.Core.Tests.Compute
         [Test]
         public void TestExecuteSingle()
         {
-            var res = Grid1.Compute().Call(OutFunc(false));
+            var res = Grid1.GetCompute().Call(OutFunc(false));
 
             CheckResult(res);
         }
@@ -58,7 +58,7 @@ namespace Apache.Ignite.Core.Tests.Compute
         {
             try
             {
-                Grid1.Compute().Call(OutFunc(true));
+                Grid1.GetCompute().Call(OutFunc(true));
 
                 Assert.Fail();
             }
@@ -79,7 +79,7 @@ namespace Apache.Ignite.Core.Tests.Compute
             for (int i = 0; i < MultiCloCnt; i++)
                 clos.Add(OutFunc(false));
 
-            ICollection<object> ress = Grid1.Compute().Call(clos);
+            ICollection<object> ress = Grid1.GetCompute().Call(clos);
 
             foreach (object res in ress)
                 CheckResult(res);
@@ -96,7 +96,7 @@ namespace Apache.Ignite.Core.Tests.Compute
             for (int i = 0; i < MultiCloCnt; i++)
                 clos.Add(OutFunc(false));
 
-            ICollection<object> ress = Grid1.Compute().Call(clos, new Reducer(false));
+            ICollection<object> ress = Grid1.GetCompute().Call(clos, new Reducer(false));
 
             foreach (object res in ress)
                 CheckResult(res);
@@ -115,7 +115,7 @@ namespace Apache.Ignite.Core.Tests.Compute
 
             try
             {
-                Grid1.Compute().Call(clos);
+                Grid1.GetCompute().Call(clos);
 
                 Assert.Fail();
             }
@@ -131,7 +131,7 @@ namespace Apache.Ignite.Core.Tests.Compute
         [Test]
         public void TestBroadcastOut()
         {
-            ICollection<object> ress = Grid1.Compute().Broadcast(OutFunc(false));
+            ICollection<object> ress = Grid1.GetCompute().Broadcast(OutFunc(false));
 
             foreach (object res in ress)
                 CheckResult(res);
@@ -145,7 +145,7 @@ namespace Apache.Ignite.Core.Tests.Compute
         {
             try
             {
-                Grid1.Compute().Broadcast(OutFunc(true));
+                Grid1.GetCompute().Broadcast(OutFunc(true));
 
                 Assert.Fail();
             }
@@ -161,7 +161,7 @@ namespace Apache.Ignite.Core.Tests.Compute
         [Test]
         public void TestBroadcastInOut()
         {
-            ICollection<object> ress = Grid1.Compute().Broadcast(Func(false), 1);
+            ICollection<object> ress = Grid1.GetCompute().Broadcast(Func(false), 1);
 
             foreach (object res in ress)
                 CheckResult(res);
@@ -175,7 +175,7 @@ namespace Apache.Ignite.Core.Tests.Compute
         {
             try
             {
-                Grid1.Compute().Broadcast(Func(true), 1);
+                Grid1.GetCompute().Broadcast(Func(true), 1);
 
                 Assert.Fail();
             }
@@ -191,7 +191,7 @@ namespace Apache.Ignite.Core.Tests.Compute
         [Test]
         public void TestApply()
         {
-            object res = Grid1.Compute().Apply(Func(false), 1);
+            object res = Grid1.GetCompute().Apply(Func(false), 1);
 
             CheckResult(res);
         }
@@ -204,7 +204,7 @@ namespace Apache.Ignite.Core.Tests.Compute
         {
             try
             {
-                Grid1.Compute().Apply(Func(true), 1);
+                Grid1.GetCompute().Apply(Func(true), 1);
 
                 Assert.Fail();
             }
@@ -227,7 +227,7 @@ namespace Apache.Ignite.Core.Tests.Compute
 
             Console.WriteLine("START TASK");
 
-            var ress = Grid1.Compute().Apply(Func(false), args);
+            var ress = Grid1.GetCompute().Apply(Func(false), args);
 
             Console.WriteLine("END TASK.");
 
@@ -248,7 +248,7 @@ namespace Apache.Ignite.Core.Tests.Compute
 
             try
             {
-                Grid1.Compute().Apply(Func(true), args);
+                Grid1.GetCompute().Apply(Func(true), args);
 
                 Assert.Fail();
             }
@@ -270,7 +270,7 @@ namespace Apache.Ignite.Core.Tests.Compute
                 args.Add(1);
 
             ICollection<object> ress =
-                Grid1.Compute().Apply(Func(false), args, new Reducer(false));
+                Grid1.GetCompute().Apply(Func(false), args, new Reducer(false));
 
             foreach (object res in ress)
                 CheckResult(res);
@@ -289,7 +289,7 @@ namespace Apache.Ignite.Core.Tests.Compute
 
             try
             {
-                Grid1.Compute().Apply(Func(true), args, new Reducer(false));
+                Grid1.GetCompute().Apply(Func(true), args, new Reducer(false));
 
                 Assert.Fail();
             }
@@ -312,7 +312,7 @@ namespace Apache.Ignite.Core.Tests.Compute
 
             try
             {
-                Grid1.Compute().Apply(Func(false), args, new Reducer(true));
+                Grid1.GetCompute().Apply(Func(false), args, new Reducer(true));
 
                 Assert.Fail();
             }