You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by sb...@apache.org on 2014/12/05 09:44:28 UTC

[01/38] incubator-ignite git commit: # Renaming

Repository: incubator-ignite
Updated Branches:
  refs/heads/master 27c89dec0 -> c6781a1c0


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessor.java
index db1ae2f..3fb43a5 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessor.java
@@ -51,7 +51,7 @@ public class GridServiceProcessor extends GridProcessorAdapter {
     private static final long RETRY_TIMEOUT = 1000;
 
     /** Local service instances. */
-    private final Map<String, Collection<GridServiceContextImpl>> locSvcs = new HashMap<>();
+    private final Map<String, Collection<ManagedServiceContextImpl>> locSvcs = new HashMap<>();
 
     /** Deployment futures. */
     private final ConcurrentMap<String, GridServiceDeploymentFuture> depFuts = new ConcurrentHashMap8<>();
@@ -135,12 +135,12 @@ public class GridServiceProcessor extends GridProcessorAdapter {
                 ctx.cache().context().deploy().ignoreOwnership(false);
         }
 
-        GridServiceConfiguration[] cfgs = ctx.config().getServiceConfiguration();
+        ManagedServiceConfiguration[] cfgs = ctx.config().getServiceConfiguration();
 
         if (cfgs != null) {
             Collection<IgniteFuture<?>> futs = new ArrayList<>();
 
-            for (GridServiceConfiguration c : ctx.config().getServiceConfiguration())
+            for (ManagedServiceConfiguration c : ctx.config().getServiceConfiguration())
                 futs.add(deploy(c));
 
             // Await for services to deploy.
@@ -177,21 +177,21 @@ public class GridServiceProcessor extends GridProcessorAdapter {
             log.error("Failed to unsubscribe service assignment notifications.", e);
         }
 
-        Collection<GridServiceContextImpl> ctxs = new ArrayList<>();
+        Collection<ManagedServiceContextImpl> ctxs = new ArrayList<>();
 
         synchronized (locSvcs) {
-            for (Collection<GridServiceContextImpl> ctxs0 : locSvcs.values())
+            for (Collection<ManagedServiceContextImpl> ctxs0 : locSvcs.values())
                 ctxs.addAll(ctxs0);
         }
 
-        for (GridServiceContextImpl ctx : ctxs) {
+        for (ManagedServiceContextImpl ctx : ctxs) {
             ctx.setCancelled(true);
             ctx.service().cancel(ctx);
 
             ctx.executor().shutdownNow();
         }
 
-        for (GridServiceContextImpl ctx : ctxs) {
+        for (ManagedServiceContextImpl ctx : ctxs) {
             try {
                 if (log.isInfoEnabled() && !ctxs.isEmpty())
                     log.info("Shutting down distributed service [name=" + ctx.name() + ", execId8=" +
@@ -219,7 +219,7 @@ public class GridServiceProcessor extends GridProcessorAdapter {
      * @param c Service configuration.
      * @throws GridRuntimeException If validation failed.
      */
-    private void validate(GridServiceConfiguration c) throws GridRuntimeException {
+    private void validate(ManagedServiceConfiguration c) throws GridRuntimeException {
         IgniteConfiguration cfg = ctx.config();
 
         GridDeploymentMode depMode = cfg.getDeploymentMode();
@@ -253,7 +253,7 @@ public class GridServiceProcessor extends GridProcessorAdapter {
      * @param svc Service.
      * @return Future.
      */
-    public IgniteFuture<?> deployNodeSingleton(ClusterGroup prj, String name, GridService svc) {
+    public IgniteFuture<?> deployNodeSingleton(ClusterGroup prj, String name, ManagedService svc) {
         return deployMultiple(prj, name, svc, 0, 1);
     }
 
@@ -262,7 +262,7 @@ public class GridServiceProcessor extends GridProcessorAdapter {
      * @param svc Service.
      * @return Future.
      */
-    public IgniteFuture<?> deployClusterSingleton(ClusterGroup prj, String name, GridService svc) {
+    public IgniteFuture<?> deployClusterSingleton(ClusterGroup prj, String name, ManagedService svc) {
         return deployMultiple(prj, name, svc, 1, 1);
     }
 
@@ -273,9 +273,9 @@ public class GridServiceProcessor extends GridProcessorAdapter {
      * @param maxPerNodeCnt Max per-node count.
      * @return Future.
      */
-    public IgniteFuture<?> deployMultiple(ClusterGroup prj, String name, GridService svc, int totalCnt,
+    public IgniteFuture<?> deployMultiple(ClusterGroup prj, String name, ManagedService svc, int totalCnt,
         int maxPerNodeCnt) {
-        GridServiceConfiguration cfg = new GridServiceConfiguration();
+        ManagedServiceConfiguration cfg = new ManagedServiceConfiguration();
 
         cfg.setName(name);
         cfg.setService(svc);
@@ -293,10 +293,10 @@ public class GridServiceProcessor extends GridProcessorAdapter {
      * @param  affKey Affinity key.
      * @return Future.
      */
-    public IgniteFuture<?> deployKeyAffinitySingleton(String name, GridService svc, String cacheName, Object affKey) {
+    public IgniteFuture<?> deployKeyAffinitySingleton(String name, ManagedService svc, String cacheName, Object affKey) {
         A.notNull(affKey, "affKey");
 
-        GridServiceConfiguration cfg = new GridServiceConfiguration();
+        ManagedServiceConfiguration cfg = new ManagedServiceConfiguration();
 
         cfg.setName(name);
         cfg.setService(svc);
@@ -312,7 +312,7 @@ public class GridServiceProcessor extends GridProcessorAdapter {
      * @param cfg Service configuration.
      * @return Future for deployment.
      */
-    public IgniteFuture<?> deploy(GridServiceConfiguration cfg) {
+    public IgniteFuture<?> deploy(ManagedServiceConfiguration cfg) {
         A.notNull(cfg, "cfg");
 
         validate(cfg);
@@ -460,8 +460,8 @@ public class GridServiceProcessor extends GridProcessorAdapter {
     /**
      * @return Collection of service descriptors.
      */
-    public Collection<GridServiceDescriptor> deployedServices() {
-        Collection<GridServiceDescriptor> descs = new ArrayList<>();
+    public Collection<ManagedServiceDescriptor> deployedServices() {
+        Collection<ManagedServiceDescriptor> descs = new ArrayList<>();
 
         for (GridCacheEntry<Object, Object> e : cache.entrySetx()) {
             if (!(e.getKey() instanceof GridServiceDeploymentKey))
@@ -469,7 +469,7 @@ public class GridServiceProcessor extends GridProcessorAdapter {
 
             GridServiceDeployment dep = (GridServiceDeployment)e.getValue();
 
-            GridServiceDescriptorImpl desc = new GridServiceDescriptorImpl(dep);
+            ManagedServiceDescriptorImpl desc = new ManagedServiceDescriptorImpl(dep);
 
             try {
                 GridServiceAssignments assigns = (GridServiceAssignments)cache.//flagsOn(GridCacheFlag.GET_PRIMARY).
@@ -497,7 +497,7 @@ public class GridServiceProcessor extends GridProcessorAdapter {
      */
     @SuppressWarnings("unchecked")
     public <T> T service(String name) {
-        Collection<GridServiceContextImpl> ctxs;
+        Collection<ManagedServiceContextImpl> ctxs;
 
         synchronized (locSvcs) {
             ctxs = locSvcs.get(name);
@@ -518,8 +518,8 @@ public class GridServiceProcessor extends GridProcessorAdapter {
      * @param name Service name.
      * @return Service by specified service name.
      */
-    public GridServiceContextImpl serviceContext(String name) {
-        Collection<GridServiceContextImpl> ctxs;
+    public ManagedServiceContextImpl serviceContext(String name) {
+        Collection<ManagedServiceContextImpl> ctxs;
 
         synchronized (locSvcs) {
             ctxs = locSvcs.get(name);
@@ -549,7 +549,7 @@ public class GridServiceProcessor extends GridProcessorAdapter {
         throws GridRuntimeException {
 
         if (hasLocalNode(prj)) {
-            GridServiceContextImpl ctx = serviceContext(name);
+            ManagedServiceContextImpl ctx = serviceContext(name);
 
             if (ctx != null) {
                 if (!svcItf.isAssignableFrom(ctx.service().getClass()))
@@ -583,7 +583,7 @@ public class GridServiceProcessor extends GridProcessorAdapter {
      */
     @SuppressWarnings("unchecked")
     public <T> Collection<T> services(String name) {
-        Collection<GridServiceContextImpl> ctxs;
+        Collection<ManagedServiceContextImpl> ctxs;
 
         synchronized (locSvcs) {
              ctxs = locSvcs.get(name);
@@ -595,7 +595,7 @@ public class GridServiceProcessor extends GridProcessorAdapter {
         synchronized (ctxs) {
             Collection<T> res = new ArrayList<>(ctxs.size());
 
-            for (GridServiceContextImpl ctx : ctxs)
+            for (ManagedServiceContextImpl ctx : ctxs)
                 res.add((T)ctx.service());
 
             return res;
@@ -610,7 +610,7 @@ public class GridServiceProcessor extends GridProcessorAdapter {
      * @throws GridException If failed.
      */
     private void reassign(GridServiceDeployment dep, long topVer) throws GridException {
-        GridServiceConfiguration cfg = dep.configuration();
+        ManagedServiceConfiguration cfg = dep.configuration();
 
         int totalCnt = cfg.getTotalCount();
         int maxPerNodeCnt = cfg.getMaxPerNodeCount();
@@ -748,9 +748,9 @@ public class GridServiceProcessor extends GridProcessorAdapter {
         if (assignCnt == null)
             assignCnt = 0;
 
-        GridService svc = assigns.service();
+        ManagedService svc = assigns.service();
 
-        Collection<GridServiceContextImpl> ctxs;
+        Collection<ManagedServiceContextImpl> ctxs;
 
         synchronized (locSvcs) {
             ctxs = locSvcs.get(svcName);
@@ -769,11 +769,11 @@ public class GridServiceProcessor extends GridProcessorAdapter {
                 int createCnt = assignCnt - ctxs.size();
 
                 for (int i = 0; i < createCnt; i++) {
-                    final GridService cp = copyAndInject(svc);
+                    final ManagedService cp = copyAndInject(svc);
 
                     final ExecutorService exe = Executors.newSingleThreadExecutor(threadFactory);
 
-                    final GridServiceContextImpl svcCtx = new GridServiceContextImpl(assigns.name(),
+                    final ManagedServiceContextImpl svcCtx = new ManagedServiceContextImpl(assigns.name(),
                         UUID.randomUUID(), assigns.cacheName(), assigns.affinityKey(), cp, exe);
 
                     ctxs.add(svcCtx);
@@ -849,13 +849,13 @@ public class GridServiceProcessor extends GridProcessorAdapter {
      * @param svc Service.
      * @return Copy of service.
      */
-    private GridService copyAndInject(GridService svc) {
+    private ManagedService copyAndInject(ManagedService svc) {
         IgniteMarshaller m = ctx.config().getMarshaller();
 
         try {
             byte[] bytes = m.marshal(svc);
 
-            GridService cp = m.unmarshal(bytes, svc.getClass().getClassLoader());
+            ManagedService cp = m.unmarshal(bytes, svc.getClass().getClassLoader());
 
             ctx.resource().inject(cp);
 
@@ -872,9 +872,9 @@ public class GridServiceProcessor extends GridProcessorAdapter {
      * @param ctxs Contexts to cancel.
      * @param cancelCnt Number of contexts to cancel.
      */
-    private void cancel(Iterable<GridServiceContextImpl> ctxs, int cancelCnt) {
-        for (Iterator<GridServiceContextImpl> it = ctxs.iterator(); it.hasNext();) {
-            GridServiceContextImpl ctx = it.next();
+    private void cancel(Iterable<ManagedServiceContextImpl> ctxs, int cancelCnt) {
+        for (Iterator<ManagedServiceContextImpl> it = ctxs.iterator(); it.hasNext();) {
+            ManagedServiceContextImpl ctx = it.next();
 
             // Flip cancelled flag.
             ctx.setCancelled(true);
@@ -940,7 +940,7 @@ public class GridServiceProcessor extends GridProcessorAdapter {
 
                             svcName.set(name);
 
-                            Collection<GridServiceContextImpl> ctxs;
+                            Collection<ManagedServiceContextImpl> ctxs;
 
                             synchronized (locSvcs) {
                                 ctxs = locSvcs.remove(name);
@@ -1228,7 +1228,7 @@ public class GridServiceProcessor extends GridProcessorAdapter {
 
                             svcName.set(name);
 
-                            Collection<GridServiceContextImpl> ctxs;
+                            Collection<ManagedServiceContextImpl> ctxs;
 
                             synchronized (locSvcs) {
                                 ctxs = locSvcs.remove(name);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProxy.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProxy.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProxy.java
index f9e61f2..4bae4d6 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProxy.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProxy.java
@@ -29,7 +29,7 @@ import java.util.concurrent.atomic.*;
 import static org.gridgain.grid.kernal.GridClosureCallMode.*;
 
 /**
- * Wrapper for making {@link GridService} class proxies.
+ * Wrapper for making {@link org.apache.ignite.managed.ManagedService} class proxies.
  */
 class GridServiceProxy<T> implements Serializable {
     /** */
@@ -129,7 +129,7 @@ class GridServiceProxy<T> implements Serializable {
 
                     // If service is deployed locally, then execute locally.
                     if (node.isLocal()) {
-                        GridServiceContextImpl svcCtx = ctx.service().serviceContext(name);
+                        ManagedServiceContextImpl svcCtx = ctx.service().serviceContext(name);
 
                         if (svcCtx != null)
                             return mtd.invoke(svcCtx.service(), args);
@@ -280,7 +280,7 @@ class GridServiceProxy<T> implements Serializable {
          * @return Map of number of service instances per node ID.
          */
         private Map<UUID, Integer> serviceTopology(String name) {
-            for (GridServiceDescriptor desc : ctx.service().deployedServices()) {
+            for (ManagedServiceDescriptor desc : ctx.service().deployedServices()) {
                 if (desc.name().equals(name))
                     return desc.topologySnapshot();
             }
@@ -334,7 +334,7 @@ class GridServiceProxy<T> implements Serializable {
 
         /** {@inheritDoc} */
         @Override public Object call() throws Exception {
-            GridServiceContextImpl svcCtx = ((GridKernal) ignite).context().service().serviceContext(svcName);
+            ManagedServiceContextImpl svcCtx = ((GridKernal) ignite).context().service().serviceContext(svcName);
 
             if (svcCtx == null)
                 throw new GridServiceNotFoundException(svcName);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/ManagedServiceContextImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/ManagedServiceContextImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/ManagedServiceContextImpl.java
new file mode 100644
index 0000000..94b7e1e
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/ManagedServiceContextImpl.java
@@ -0,0 +1,148 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.kernal.processors.service;
+
+import org.apache.ignite.managed.*;
+import org.gridgain.grid.util.tostring.*;
+import org.gridgain.grid.util.typedef.internal.*;
+import org.jetbrains.annotations.*;
+
+import java.lang.reflect.*;
+import java.util.*;
+import java.util.concurrent.*;
+
+/**
+ * Service context implementation.
+ */
+public class ManagedServiceContextImpl implements ManagedServiceContext {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** Null method. */
+    private static final Method NULL_METHOD = ManagedServiceContextImpl.class.getMethods()[0];
+
+    /** Service name. */
+    private final String name;
+
+    /** Execution ID. */
+    private final UUID execId;
+
+    /** Cache name. */
+    private final String cacheName;
+
+    /** Affinity key. */
+    private final Object affKey;
+
+    /** Service. */
+    @GridToStringExclude
+    private final ManagedService svc;
+
+    /** Executor service. */
+    @GridToStringExclude
+    private final ExecutorService exe;
+
+    /** Methods reflection cache. */
+    private final ConcurrentMap<GridServiceMethodReflectKey, Method> mtds = new ConcurrentHashMap<>();
+
+    /** Cancelled flag. */
+    private volatile boolean isCancelled;
+
+
+    /**
+     * @param name Service name.
+     * @param execId Execution ID.
+     * @param cacheName Cache name.
+     * @param affKey Affinity key.
+     * @param svc Service.
+     * @param exe Executor service.
+     */
+    ManagedServiceContextImpl(String name, UUID execId, String cacheName, Object affKey, ManagedService svc,
+                              ExecutorService exe) {
+        this.name = name;
+        this.execId = execId;
+        this.cacheName = cacheName;
+        this.affKey = affKey;
+        this.svc = svc;
+        this.exe = exe;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String name() {
+        return name;
+    }
+
+    /** {@inheritDoc} */
+    @Override public UUID executionId() {
+        return execId;
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean isCancelled() {
+        return isCancelled;
+    }
+
+    /** {@inheritDoc} */
+    @Nullable @Override public String cacheName() {
+        return cacheName;
+    }
+
+    /** {@inheritDoc} */
+    @SuppressWarnings("unchecked")
+    @Nullable @Override public <K> K affinityKey() {
+        return (K)affKey;
+    }
+
+    /**
+     * @return Service instance.
+     */
+    ManagedService service() {
+        return svc;
+    }
+
+    /**
+     * @return Executor service.
+     */
+    ExecutorService executor() {
+        return exe;
+    }
+
+    /**
+     * @param key Method key.
+     * @return Method.
+     */
+    @Nullable Method method(GridServiceMethodReflectKey key) {
+        Method mtd = mtds.get(key);
+
+        if (mtd == null) {
+            try {
+                mtd = svc.getClass().getMethod(key.methodName(), key.argTypes());
+            }
+            catch (NoSuchMethodException e) {
+                mtd = NULL_METHOD;
+            }
+
+            mtds.put(key, mtd);
+        }
+
+        return mtd == NULL_METHOD ? null : mtd;
+    }
+
+    /**
+     * @param isCancelled Cancelled flag.
+     */
+    public void setCancelled(boolean isCancelled) {
+        this.isCancelled = isCancelled;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(ManagedServiceContextImpl.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/ManagedServiceDescriptorImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/ManagedServiceDescriptorImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/ManagedServiceDescriptorImpl.java
new file mode 100644
index 0000000..ff3d26b
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/ManagedServiceDescriptorImpl.java
@@ -0,0 +1,93 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.kernal.processors.service;
+
+import org.apache.ignite.managed.*;
+import org.gridgain.grid.util.tostring.*;
+import org.gridgain.grid.util.typedef.internal.*;
+import org.jetbrains.annotations.*;
+
+import java.util.*;
+
+/**
+ * Service descriptor.
+ */
+public class ManagedServiceDescriptorImpl implements ManagedServiceDescriptor {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** Configuration. */
+    @GridToStringInclude
+    private final GridServiceDeployment dep;
+
+    /** Topology snapshot. */
+    @GridToStringInclude
+    private Map<UUID, Integer> top;
+
+    /**
+     * @param dep Deployment.
+     */
+    public ManagedServiceDescriptorImpl(GridServiceDeployment dep) {
+        this.dep = dep;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String name() {
+        return dep.configuration().getName();
+    }
+
+    /** {@inheritDoc} */
+    @Override public Class<? extends ManagedService> serviceClass() {
+        return dep.configuration().getService().getClass();
+    }
+
+    /** {@inheritDoc} */
+    @Override public int totalCount() {
+        return dep.configuration().getTotalCount();
+    }
+
+    /** {@inheritDoc} */
+    @Override public int maxPerNodeCount() {
+        return dep.configuration().getMaxPerNodeCount();
+    }
+
+    /** {@inheritDoc} */
+    @Nullable @Override public String cacheName() {
+        return dep.configuration().getCacheName();
+    }
+
+    /** {@inheritDoc} */
+    @SuppressWarnings("unchecked")
+    @Nullable @Override public <K> K affinityKey() {
+        return (K)dep.configuration().getAffinityKey();
+    }
+
+    /** {@inheritDoc} */
+    @Override public UUID originNodeId() {
+        return dep.nodeId();
+    }
+
+    /** {@inheritDoc} */
+    @Override public Map<UUID, Integer> topologySnapshot() {
+        return top;
+    }
+
+    /**
+     * @param top Topology snapshot.
+     */
+    void topologySnapshot(Map<UUID, Integer> top) {
+        this.top = top;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(ManagedServiceDescriptorImpl.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/DummyService.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/DummyService.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/DummyService.java
index 88dbb15..c0179d0 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/DummyService.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/DummyService.java
@@ -18,7 +18,7 @@ import java.util.concurrent.atomic.*;
 /**
  * Dummy service.
  */
-public class DummyService implements GridService {
+public class DummyService implements ManagedService {
     /** */
     private static final long serialVersionUID = 0L;
 
@@ -38,7 +38,7 @@ public class DummyService implements GridService {
     private static final ConcurrentMap<String, AtomicInteger> cancelled = new ConcurrentHashMap8<>();
 
     /** {@inheritDoc} */
-    @Override public void cancel(GridServiceContext ctx) {
+    @Override public void cancel(ManagedServiceContext ctx) {
         AtomicInteger cntr = cancelled.get(ctx.name());
 
         if (cntr == null) {
@@ -59,7 +59,7 @@ public class DummyService implements GridService {
     }
 
     /** {@inheritDoc} */
-    @Override public void init(GridServiceContext ctx) throws Exception {
+    @Override public void init(ManagedServiceContext ctx) throws Exception {
         AtomicInteger cntr = inited.get(ctx.name());
 
         if (cntr == null) {
@@ -75,7 +75,7 @@ public class DummyService implements GridService {
     }
 
     /** {@inheritDoc} */
-    @Override public void execute(GridServiceContext ctx) {
+    @Override public void execute(ManagedServiceContext ctx) {
         AtomicInteger cntr = started.get(ctx.name());
 
         if (cntr == null) {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessorAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessorAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessorAbstractSelfTest.java
index e81c186..035ff40 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessorAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessorAbstractSelfTest.java
@@ -54,7 +54,7 @@ public abstract class GridServiceProcessorAbstractSelfTest extends GridCommonAbs
 
         c.setDiscoverySpi(discoSpi);
 
-        GridServiceConfiguration[] svcs = services();
+        ManagedServiceConfiguration[] svcs = services();
 
         if (svcs != null)
             c.setServiceConfiguration(svcs);
@@ -82,7 +82,7 @@ public abstract class GridServiceProcessorAbstractSelfTest extends GridCommonAbs
      *
      * @return Services configuration.
      */
-    protected GridServiceConfiguration[] services() {
+    protected ManagedServiceConfiguration[] services() {
         return null;
     }
 
@@ -470,7 +470,7 @@ public abstract class GridServiceProcessorAbstractSelfTest extends GridCommonAbs
      * @param descs Descriptors.
      * @param cnt Expected count.
      */
-    protected void checkCount(String svcName, Iterable<GridServiceDescriptor> descs, int cnt) {
+    protected void checkCount(String svcName, Iterable<ManagedServiceDescriptor> descs, int cnt) {
         assertEquals(cnt, actualCount(svcName, descs));
     }
 
@@ -479,10 +479,10 @@ public abstract class GridServiceProcessorAbstractSelfTest extends GridCommonAbs
      * @param descs Descriptors.
      * @return Services count.
      */
-    protected int actualCount(String svcName, Iterable<GridServiceDescriptor> descs) {
+    protected int actualCount(String svcName, Iterable<ManagedServiceDescriptor> descs) {
         int sum = 0;
 
-        for (GridServiceDescriptor d : descs) {
+        for (ManagedServiceDescriptor d : descs) {
             if (d.name().equals(svcName)) {
                 for (Integer i : d.topologySnapshot().values())
                     sum += i;
@@ -515,7 +515,7 @@ public abstract class GridServiceProcessorAbstractSelfTest extends GridCommonAbs
     /**
      * Affinity service.
      */
-    protected static class AffinityService implements GridService {
+    protected static class AffinityService implements ManagedService {
         /** */
         private static final long serialVersionUID = 0L;
 
@@ -534,12 +534,12 @@ public abstract class GridServiceProcessorAbstractSelfTest extends GridCommonAbs
         }
 
         /** {@inheritDoc} */
-        @Override public void cancel(GridServiceContext ctx) {
+        @Override public void cancel(ManagedServiceContext ctx) {
             // No-op.
         }
 
         /** {@inheritDoc} */
-        @Override public void init(GridServiceContext ctx) throws Exception {
+        @Override public void init(ManagedServiceContext ctx) throws Exception {
             X.println("Initializing affinity service for key: " + affKey);
 
             ClusterNode n = g.cache(CACHE_NAME).affinity().mapKeyToNode(affKey);
@@ -549,7 +549,7 @@ public abstract class GridServiceProcessorAbstractSelfTest extends GridCommonAbs
         }
 
         /** {@inheritDoc} */
-        @Override public void execute(GridServiceContext ctx) {
+        @Override public void execute(ManagedServiceContext ctx) {
             X.println("Executing affinity service for key: " + affKey);
         }
     }
@@ -557,7 +557,7 @@ public abstract class GridServiceProcessorAbstractSelfTest extends GridCommonAbs
     /**
      * Counter service implementation.
      */
-    protected static class CounterServiceImpl implements CounterService, GridService {
+    protected static class CounterServiceImpl implements CounterService, ManagedService {
         /** Auto-injected grid instance. */
         @IgniteInstanceResource
         private Ignite ignite;
@@ -616,12 +616,12 @@ public abstract class GridServiceProcessorAbstractSelfTest extends GridCommonAbs
         }
 
         /** {@inheritDoc} */
-        @Override public void cancel(GridServiceContext ctx) {
+        @Override public void cancel(ManagedServiceContext ctx) {
             X.println("Stopping counter service: " + ctx.name());
         }
 
         /** {@inheritDoc} */
-        @Override public void init(GridServiceContext ctx) throws Exception {
+        @Override public void init(ManagedServiceContext ctx) throws Exception {
             X.println("Initializing counter service: " + ctx.name());
 
             key = ctx.name();
@@ -630,7 +630,7 @@ public abstract class GridServiceProcessorAbstractSelfTest extends GridCommonAbs
         }
 
         /** {@inheritDoc} */
-        @Override public void execute(GridServiceContext ctx) throws Exception {
+        @Override public void execute(ManagedServiceContext ctx) throws Exception {
             X.println("Executing counter service: " + ctx.name());
         }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessorMultiNodeConfigSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessorMultiNodeConfigSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessorMultiNodeConfigSelfTest.java
index f7be967..c45feb1 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessorMultiNodeConfigSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessorMultiNodeConfigSelfTest.java
@@ -38,10 +38,10 @@ public class GridServiceProcessorMultiNodeConfigSelfTest extends GridServiceProc
     }
 
     /** {@inheritDoc} */
-    @Override protected GridServiceConfiguration[] services() {
-        GridServiceConfiguration[] arr = new GridServiceConfiguration[3];
+    @Override protected ManagedServiceConfiguration[] services() {
+        ManagedServiceConfiguration[] arr = new ManagedServiceConfiguration[3];
 
-        GridServiceConfiguration cfg = new GridServiceConfiguration();
+        ManagedServiceConfiguration cfg = new ManagedServiceConfiguration();
 
         cfg.setName(CLUSTER_SINGLE);
         cfg.setMaxPerNodeCount(1);
@@ -50,7 +50,7 @@ public class GridServiceProcessorMultiNodeConfigSelfTest extends GridServiceProc
 
         arr[0] = cfg;
 
-        cfg = new GridServiceConfiguration();
+        cfg = new ManagedServiceConfiguration();
 
         cfg.setName(NODE_SINGLE);
         cfg.setMaxPerNodeCount(1);
@@ -58,7 +58,7 @@ public class GridServiceProcessorMultiNodeConfigSelfTest extends GridServiceProc
 
         arr[1] = cfg;
 
-        cfg = new GridServiceConfiguration();
+        cfg = new ManagedServiceConfiguration();
 
         cfg.setName(AFFINITY);
         cfg.setCacheName(CACHE_NAME);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessorProxySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessorProxySelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessorProxySelfTest.java
index 3c62027..d3b6efe 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessorProxySelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessorProxySelfTest.java
@@ -186,7 +186,7 @@ public class GridServiceProcessorProxySelfTest extends GridServiceProcessorAbstr
             MapService<Integer, String> svc =  grid(i).managed().serviceProxy(name, MapService.class, false);
 
             // Make sure service is a proxy.
-            assertFalse(svc instanceof GridService);
+            assertFalse(svc instanceof ManagedService);
 
             svc.put(i, Integer.toString(i));
         }
@@ -208,7 +208,7 @@ public class GridServiceProcessorProxySelfTest extends GridServiceProcessorAbstr
             MapService<Integer, String> svc =  grid(i).managed().serviceProxy(name, MapService.class, false);
 
             // Make sure service is a local instance.
-            assertTrue(svc instanceof GridService);
+            assertTrue(svc instanceof ManagedService);
 
             svc.put(i, Integer.toString(i));
         }
@@ -234,7 +234,7 @@ public class GridServiceProcessorProxySelfTest extends GridServiceProcessorAbstr
             serviceProxy(name, MapService.class, false);
 
         // Make sure service is a local instance.
-        assertFalse(svc instanceof GridService);
+        assertFalse(svc instanceof ManagedService);
 
         for (int i = 0; i < nodeCount(); i++)
             svc.put(i, Integer.toString(i));
@@ -246,7 +246,7 @@ public class GridServiceProcessorProxySelfTest extends GridServiceProcessorAbstr
                 serviceProxy(name, MapService.class, false);
 
             // Make sure service is a local instance.
-            assertFalse(map instanceof GridService);
+            assertFalse(map instanceof ManagedService);
 
             size += map.size();
         }
@@ -269,7 +269,7 @@ public class GridServiceProcessorProxySelfTest extends GridServiceProcessorAbstr
             serviceProxy(name, MapService.class, true);
 
         // Make sure service is a local instance.
-        assertFalse(svc instanceof GridService);
+        assertFalse(svc instanceof ManagedService);
 
         for (int i = 0; i < nodeCount(); i++)
             svc.put(i, Integer.toString(i));
@@ -281,7 +281,7 @@ public class GridServiceProcessorProxySelfTest extends GridServiceProcessorAbstr
                 serviceProxy(name, MapService.class, false);
 
             // Make sure service is a local instance.
-            assertFalse(map instanceof GridService);
+            assertFalse(map instanceof ManagedService);
 
             if (map.size() != 0)
                 size += map.size();
@@ -327,7 +327,7 @@ public class GridServiceProcessorProxySelfTest extends GridServiceProcessorAbstr
     /**
      * Cache service implementation.
      */
-    protected static class MapServiceImpl<K, V> implements MapService<K, V>, GridService {
+    protected static class MapServiceImpl<K, V> implements MapService<K, V>, ManagedService {
         /** Underlying cache map. */
         private final Map<K, V> map = new ConcurrentHashMap<>();
 
@@ -351,17 +351,17 @@ public class GridServiceProcessorProxySelfTest extends GridServiceProcessorAbstr
         }
 
         /** {@inheritDoc} */
-        @Override public void cancel(GridServiceContext ctx) {
+        @Override public void cancel(ManagedServiceContext ctx) {
             X.println("Stopping cache service: " + ctx.name());
         }
 
         /** {@inheritDoc} */
-        @Override public void init(GridServiceContext ctx) throws Exception {
+        @Override public void init(ManagedServiceContext ctx) throws Exception {
             X.println("Initializing counter service: " + ctx.name());
         }
 
         /** {@inheritDoc} */
-        @Override public void execute(GridServiceContext ctx) throws Exception {
+        @Override public void execute(ManagedServiceContext ctx) throws Exception {
             X.println("Executing cache service: " + ctx.name());
         }
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/spring/src/test/java/org/gridgain/grid/kernal/processors/resource/GridServiceInjectionSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/spring/src/test/java/org/gridgain/grid/kernal/processors/resource/GridServiceInjectionSelfTest.java b/modules/spring/src/test/java/org/gridgain/grid/kernal/processors/resource/GridServiceInjectionSelfTest.java
index 87c9b20..f1edf8f 100644
--- a/modules/spring/src/test/java/org/gridgain/grid/kernal/processors/resource/GridServiceInjectionSelfTest.java
+++ b/modules/spring/src/test/java/org/gridgain/grid/kernal/processors/resource/GridServiceInjectionSelfTest.java
@@ -61,7 +61,7 @@ public class GridServiceInjectionSelfTest extends GridCommonAbstractTest impleme
 
             @Override public Object call() throws Exception {
                 assertNotNull(svc);
-                assertTrue(svc instanceof GridService);
+                assertTrue(svc instanceof ManagedService);
 
                 svc.noop();
 
@@ -82,7 +82,7 @@ public class GridServiceInjectionSelfTest extends GridCommonAbstractTest impleme
                 assertNotNull(svc);
 
                 // Ensure proxy instance.
-                assertFalse(svc instanceof GridService);
+                assertFalse(svc instanceof ManagedService);
 
                 svc.noop();
 
@@ -103,7 +103,7 @@ public class GridServiceInjectionSelfTest extends GridCommonAbstractTest impleme
                 assertNotNull(svc);
 
                 // Ensure proxy instance.
-                assertTrue(svc instanceof GridService);
+                assertTrue(svc instanceof ManagedService);
 
                 svc.noop();
 
@@ -146,7 +146,7 @@ public class GridServiceInjectionSelfTest extends GridCommonAbstractTest impleme
             private void service(DummyService svc) {
                 assertNotNull(svc);
 
-                assertTrue(svc instanceof GridService);
+                assertTrue(svc instanceof ManagedService);
 
                 this.svc = svc;
             }
@@ -171,7 +171,7 @@ public class GridServiceInjectionSelfTest extends GridCommonAbstractTest impleme
                 assertNotNull(svc);
 
                 // Ensure proxy instance.
-                assertFalse(svc instanceof GridService);
+                assertFalse(svc instanceof ManagedService);
 
                 this.svc = svc;
             }
@@ -196,7 +196,7 @@ public class GridServiceInjectionSelfTest extends GridCommonAbstractTest impleme
                 assertNotNull(svc);
 
                 // Ensure proxy instance.
-                assertTrue(svc instanceof GridService);
+                assertTrue(svc instanceof ManagedService);
 
                 this.svc = svc;
             }
@@ -274,7 +274,7 @@ public class GridServiceInjectionSelfTest extends GridCommonAbstractTest impleme
     /**
      * No-op test service.
      */
-    public static class DummyServiceImpl implements DummyService, GridService {
+    public static class DummyServiceImpl implements DummyService, ManagedService {
         /** */
         private static final long serialVersionUID = 0L;
 
@@ -284,17 +284,17 @@ public class GridServiceInjectionSelfTest extends GridCommonAbstractTest impleme
         }
 
         /** {@inheritDoc} */
-        @Override public void cancel(GridServiceContext ctx) {
+        @Override public void cancel(ManagedServiceContext ctx) {
             System.out.println("Cancelling service: " + ctx.name());
         }
 
         /** {@inheritDoc} */
-        @Override public void init(GridServiceContext ctx) throws Exception {
+        @Override public void init(ManagedServiceContext ctx) throws Exception {
             System.out.println("Initializing service: " + ctx.name());
         }
 
         /** {@inheritDoc} */
-        @Override public void execute(GridServiceContext ctx) {
+        @Override public void execute(ManagedServiceContext ctx) {
             System.out.println("Executing service: " + ctx.name());
         }
     }


[09/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java
index 9a2cd96..b09fc5c 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java
@@ -72,7 +72,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile info(GridGgfsPath path) throws GridException {
+    @Override public GridGgfsFile info(IgniteFsPath path) throws GridException {
         try {
             return ggfs.info(path);
         }
@@ -82,7 +82,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile update(GridGgfsPath path, Map<String, String> props) throws GridException {
+    @Override public GridGgfsFile update(IgniteFsPath path, Map<String, String> props) throws GridException {
         try {
             return ggfs.update(path, props);
         }
@@ -92,7 +92,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     }
 
     /** {@inheritDoc} */
-    @Override public Boolean setTimes(GridGgfsPath path, long accessTime, long modificationTime) throws GridException {
+    @Override public Boolean setTimes(IgniteFsPath path, long accessTime, long modificationTime) throws GridException {
         try {
             ggfs.setTimes(path, accessTime, modificationTime);
 
@@ -105,7 +105,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     }
 
     /** {@inheritDoc} */
-    @Override public Boolean rename(GridGgfsPath src, GridGgfsPath dest) throws GridException {
+    @Override public Boolean rename(IgniteFsPath src, IgniteFsPath dest) throws GridException {
         try {
             ggfs.rename(src, dest);
 
@@ -117,7 +117,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     }
 
     /** {@inheritDoc} */
-    @Override public Boolean delete(GridGgfsPath path, boolean recursive) throws GridException {
+    @Override public Boolean delete(IgniteFsPath path, boolean recursive) throws GridException {
         try {
             return ggfs.delete(path, recursive);
         }
@@ -138,7 +138,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsPath> listPaths(GridGgfsPath path) throws GridException {
+    @Override public Collection<IgniteFsPath> listPaths(IgniteFsPath path) throws GridException {
         try {
             return ggfs.listPaths(path);
         }
@@ -148,7 +148,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsFile> listFiles(GridGgfsPath path) throws GridException {
+    @Override public Collection<GridGgfsFile> listFiles(IgniteFsPath path) throws GridException {
         try {
             return ggfs.listFiles(path);
         }
@@ -158,7 +158,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     }
 
     /** {@inheritDoc} */
-    @Override public Boolean mkdirs(GridGgfsPath path, Map<String, String> props) throws GridException {
+    @Override public Boolean mkdirs(IgniteFsPath path, Map<String, String> props) throws GridException {
         try {
             ggfs.mkdirs(path, props);
 
@@ -171,7 +171,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsPathSummary contentSummary(GridGgfsPath path) throws GridException {
+    @Override public IgniteFsPathSummary contentSummary(IgniteFsPath path) throws GridException {
         try {
             return ggfs.summary(path);
         }
@@ -182,7 +182,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsBlockLocation> affinity(GridGgfsPath path, long start, long len)
+    @Override public Collection<IgniteFsBlockLocation> affinity(IgniteFsPath path, long start, long len)
         throws GridException {
         try {
             return ggfs.affinity(path, start, len);
@@ -193,7 +193,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsHadoopStreamDelegate open(GridGgfsPath path) throws GridException {
+    @Override public GridGgfsHadoopStreamDelegate open(IgniteFsPath path) throws GridException {
         try {
             GridGgfsInputStreamAdapter stream = ggfs.open(path, bufSize);
 
@@ -205,7 +205,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsHadoopStreamDelegate open(GridGgfsPath path, int seqReadsBeforePrefetch)
+    @Override public GridGgfsHadoopStreamDelegate open(IgniteFsPath path, int seqReadsBeforePrefetch)
         throws GridException {
         try {
             GridGgfsInputStreamAdapter stream = ggfs.open(path, bufSize, seqReadsBeforePrefetch);
@@ -218,7 +218,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsHadoopStreamDelegate create(GridGgfsPath path, boolean overwrite, boolean colocate,
+    @Override public GridGgfsHadoopStreamDelegate create(IgniteFsPath path, boolean overwrite, boolean colocate,
         int replication, long blockSize, @Nullable Map<String, String> props) throws GridException {
         try {
             GridGgfsOutputStream stream = ggfs.create(path, bufSize, overwrite,
@@ -232,7 +232,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsHadoopStreamDelegate append(GridGgfsPath path, boolean create,
+    @Override public GridGgfsHadoopStreamDelegate append(IgniteFsPath path, boolean create,
         @Nullable Map<String, String> props) throws GridException {
         try {
             GridGgfsOutputStream stream = ggfs.append(path, bufSize, create, props);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopOutProc.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopOutProc.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopOutProc.java
index c516e5c..194a217 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopOutProc.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopOutProc.java
@@ -54,15 +54,15 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
 
     /** Expected result is {@code GridGgfsFile}. */
     private static final GridPlainClosure<GridPlainFuture<GridGgfsMessage>,
-        Collection<GridGgfsPath>> PATH_COL_RES = createClosure();
+        Collection<IgniteFsPath>> PATH_COL_RES = createClosure();
 
     /** Expected result is {@code GridGgfsPathSummary}. */
-    private static final GridPlainClosure<GridPlainFuture<GridGgfsMessage>, GridGgfsPathSummary> SUMMARY_RES =
+    private static final GridPlainClosure<GridPlainFuture<GridGgfsMessage>, IgniteFsPathSummary> SUMMARY_RES =
         createClosure();
 
     /** Expected result is {@code GridGgfsFile}. */
     private static final GridPlainClosure<GridPlainFuture<GridGgfsMessage>,
-        Collection<GridGgfsBlockLocation>> BLOCK_LOCATION_COL_RES = createClosure();
+        Collection<IgniteFsBlockLocation>> BLOCK_LOCATION_COL_RES = createClosure();
 
     /** Grid name. */
     private final String grid;
@@ -157,7 +157,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile info(GridGgfsPath path) throws GridException {
+    @Override public GridGgfsFile info(IgniteFsPath path) throws GridException {
         final GridGgfsPathControlRequest msg = new GridGgfsPathControlRequest();
 
         msg.command(INFO);
@@ -167,7 +167,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile update(GridGgfsPath path, Map<String, String> props) throws GridException {
+    @Override public GridGgfsFile update(IgniteFsPath path, Map<String, String> props) throws GridException {
         final GridGgfsPathControlRequest msg = new GridGgfsPathControlRequest();
 
         msg.command(UPDATE);
@@ -178,7 +178,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     }
 
     /** {@inheritDoc} */
-    @Override public Boolean setTimes(GridGgfsPath path, long accessTime, long modificationTime) throws GridException {
+    @Override public Boolean setTimes(IgniteFsPath path, long accessTime, long modificationTime) throws GridException {
         final GridGgfsPathControlRequest msg = new GridGgfsPathControlRequest();
 
         msg.command(SET_TIMES);
@@ -190,7 +190,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     }
 
     /** {@inheritDoc} */
-    @Override public Boolean rename(GridGgfsPath src, GridGgfsPath dest) throws GridException {
+    @Override public Boolean rename(IgniteFsPath src, IgniteFsPath dest) throws GridException {
         final GridGgfsPathControlRequest msg = new GridGgfsPathControlRequest();
 
         msg.command(RENAME);
@@ -201,7 +201,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     }
 
     /** {@inheritDoc} */
-    @Override public Boolean delete(GridGgfsPath path, boolean recursive) throws GridException {
+    @Override public Boolean delete(IgniteFsPath path, boolean recursive) throws GridException {
         final GridGgfsPathControlRequest msg = new GridGgfsPathControlRequest();
 
         msg.command(DELETE);
@@ -212,7 +212,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsBlockLocation> affinity(GridGgfsPath path, long start, long len)
+    @Override public Collection<IgniteFsBlockLocation> affinity(IgniteFsPath path, long start, long len)
         throws GridException {
         final GridGgfsPathControlRequest msg = new GridGgfsPathControlRequest();
 
@@ -225,7 +225,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsPathSummary contentSummary(GridGgfsPath path) throws GridException {
+    @Override public IgniteFsPathSummary contentSummary(IgniteFsPath path) throws GridException {
         final GridGgfsPathControlRequest msg = new GridGgfsPathControlRequest();
 
         msg.command(PATH_SUMMARY);
@@ -235,7 +235,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     }
 
     /** {@inheritDoc} */
-    @Override public Boolean mkdirs(GridGgfsPath path, Map<String, String> props) throws GridException {
+    @Override public Boolean mkdirs(IgniteFsPath path, Map<String, String> props) throws GridException {
         final GridGgfsPathControlRequest msg = new GridGgfsPathControlRequest();
 
         msg.command(MAKE_DIRECTORIES);
@@ -246,7 +246,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsFile> listFiles(GridGgfsPath path) throws GridException {
+    @Override public Collection<GridGgfsFile> listFiles(IgniteFsPath path) throws GridException {
         final GridGgfsPathControlRequest msg = new GridGgfsPathControlRequest();
 
         msg.command(LIST_FILES);
@@ -256,7 +256,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsPath> listPaths(GridGgfsPath path) throws GridException {
+    @Override public Collection<IgniteFsPath> listPaths(IgniteFsPath path) throws GridException {
         final GridGgfsPathControlRequest msg = new GridGgfsPathControlRequest();
 
         msg.command(LIST_PATHS);
@@ -271,7 +271,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsHadoopStreamDelegate open(GridGgfsPath path) throws GridException {
+    @Override public GridGgfsHadoopStreamDelegate open(IgniteFsPath path) throws GridException {
         final GridGgfsPathControlRequest msg = new GridGgfsPathControlRequest();
 
         msg.command(OPEN_READ);
@@ -284,7 +284,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsHadoopStreamDelegate open(GridGgfsPath path,
+    @Override public GridGgfsHadoopStreamDelegate open(IgniteFsPath path,
         int seqReadsBeforePrefetch) throws GridException {
         final GridGgfsPathControlRequest msg = new GridGgfsPathControlRequest();
 
@@ -299,7 +299,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsHadoopStreamDelegate create(GridGgfsPath path, boolean overwrite, boolean colocate,
+    @Override public GridGgfsHadoopStreamDelegate create(IgniteFsPath path, boolean overwrite, boolean colocate,
         int replication, long blockSize, @Nullable Map<String, String> props) throws GridException {
         final GridGgfsPathControlRequest msg = new GridGgfsPathControlRequest();
 
@@ -317,7 +317,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsHadoopStreamDelegate append(GridGgfsPath path, boolean create,
+    @Override public GridGgfsHadoopStreamDelegate append(IgniteFsPath path, boolean create,
         @Nullable Map<String, String> props) throws GridException {
         final GridGgfsPathControlRequest msg = new GridGgfsPathControlRequest();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopReader.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopReader.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopReader.java
index efc54c1..4a73fcf 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopReader.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopReader.java
@@ -21,7 +21,7 @@ import java.io.*;
  * <p>
  * The class is expected to be used only from synchronized context and therefore is not tread-safe.
  */
-public class GridGgfsHadoopReader implements GridGgfsReader {
+public class GridGgfsHadoopReader implements IgniteFsReader {
     /** Secondary file system. */
     private final FileSystem fs;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java
index 3e90f80..f54dbfb 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java
@@ -108,7 +108,7 @@ public class GridGgfsHadoopUtils {
             return new ParentNotDirectoryException(path);
         else if (path != null && e instanceof GridGgfsDirectoryNotEmptyException)
             return new PathIsNotEmptyDirectoryException(path);
-        else if (path != null && e instanceof GridGgfsPathAlreadyExistsException)
+        else if (path != null && e instanceof IgniteFsPathAlreadyExistsException)
             return new PathExistsException(path);
         else
             return new IOException(e);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopWrapper.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopWrapper.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopWrapper.java
index 98751ac..4fff807 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopWrapper.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopWrapper.java
@@ -88,7 +88,7 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile info(final GridGgfsPath path) throws IOException {
+    @Override public GridGgfsFile info(final IgniteFsPath path) throws IOException {
         return withReconnectHandling(new FileSystemClosure<GridGgfsFile>() {
             @Override public GridGgfsFile apply(GridGgfsHadoopEx hadoop, GridGgfsHandshakeResponse hndResp)
                 throws GridException, IOException {
@@ -98,7 +98,7 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile update(final GridGgfsPath path, final Map<String, String> props) throws IOException {
+    @Override public GridGgfsFile update(final IgniteFsPath path, final Map<String, String> props) throws IOException {
         return withReconnectHandling(new FileSystemClosure<GridGgfsFile>() {
             @Override public GridGgfsFile apply(GridGgfsHadoopEx hadoop, GridGgfsHandshakeResponse hndResp)
                 throws GridException, IOException {
@@ -108,7 +108,7 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
     }
 
     /** {@inheritDoc} */
-    @Override public Boolean setTimes(final GridGgfsPath path, final long accessTime, final long modificationTime)
+    @Override public Boolean setTimes(final IgniteFsPath path, final long accessTime, final long modificationTime)
         throws IOException {
         return withReconnectHandling(new FileSystemClosure<Boolean>() {
             @Override public Boolean apply(GridGgfsHadoopEx hadoop, GridGgfsHandshakeResponse hndResp)
@@ -119,7 +119,7 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
     }
 
     /** {@inheritDoc} */
-    @Override public Boolean rename(final GridGgfsPath src, final GridGgfsPath dest) throws IOException {
+    @Override public Boolean rename(final IgniteFsPath src, final IgniteFsPath dest) throws IOException {
         return withReconnectHandling(new FileSystemClosure<Boolean>() {
             @Override public Boolean apply(GridGgfsHadoopEx hadoop, GridGgfsHandshakeResponse hndResp)
                 throws GridException, IOException {
@@ -129,7 +129,7 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
     }
 
     /** {@inheritDoc} */
-    @Override public Boolean delete(final GridGgfsPath path, final boolean recursive) throws IOException {
+    @Override public Boolean delete(final IgniteFsPath path, final boolean recursive) throws IOException {
         return withReconnectHandling(new FileSystemClosure<Boolean>() {
             @Override public Boolean apply(GridGgfsHadoopEx hadoop, GridGgfsHandshakeResponse hndResp)
                 throws GridException, IOException {
@@ -139,10 +139,10 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsBlockLocation> affinity(final GridGgfsPath path, final long start,
+    @Override public Collection<IgniteFsBlockLocation> affinity(final IgniteFsPath path, final long start,
         final long len) throws IOException {
-        return withReconnectHandling(new FileSystemClosure<Collection<GridGgfsBlockLocation>>() {
-            @Override public Collection<GridGgfsBlockLocation> apply(GridGgfsHadoopEx hadoop,
+        return withReconnectHandling(new FileSystemClosure<Collection<IgniteFsBlockLocation>>() {
+            @Override public Collection<IgniteFsBlockLocation> apply(GridGgfsHadoopEx hadoop,
                 GridGgfsHandshakeResponse hndResp) throws GridException, IOException {
                 return hadoop.affinity(path, start, len);
             }
@@ -150,9 +150,9 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsPathSummary contentSummary(final GridGgfsPath path) throws IOException {
-        return withReconnectHandling(new FileSystemClosure<GridGgfsPathSummary>() {
-            @Override public GridGgfsPathSummary apply(GridGgfsHadoopEx hadoop, GridGgfsHandshakeResponse hndResp)
+    @Override public IgniteFsPathSummary contentSummary(final IgniteFsPath path) throws IOException {
+        return withReconnectHandling(new FileSystemClosure<IgniteFsPathSummary>() {
+            @Override public IgniteFsPathSummary apply(GridGgfsHadoopEx hadoop, GridGgfsHandshakeResponse hndResp)
                 throws GridException, IOException {
                 return hadoop.contentSummary(path);
             }
@@ -160,7 +160,7 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
     }
 
     /** {@inheritDoc} */
-    @Override public Boolean mkdirs(final GridGgfsPath path, final Map<String, String> props) throws IOException {
+    @Override public Boolean mkdirs(final IgniteFsPath path, final Map<String, String> props) throws IOException {
         return withReconnectHandling(new FileSystemClosure<Boolean>() {
             @Override public Boolean apply(GridGgfsHadoopEx hadoop, GridGgfsHandshakeResponse hndResp)
                 throws GridException, IOException {
@@ -170,7 +170,7 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsFile> listFiles(final GridGgfsPath path) throws IOException {
+    @Override public Collection<GridGgfsFile> listFiles(final IgniteFsPath path) throws IOException {
         return withReconnectHandling(new FileSystemClosure<Collection<GridGgfsFile>>() {
             @Override public Collection<GridGgfsFile> apply(GridGgfsHadoopEx hadoop,
                 GridGgfsHandshakeResponse hndResp) throws GridException, IOException {
@@ -180,9 +180,9 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsPath> listPaths(final GridGgfsPath path) throws IOException {
-        return withReconnectHandling(new FileSystemClosure<Collection<GridGgfsPath>>() {
-            @Override public Collection<GridGgfsPath> apply(GridGgfsHadoopEx hadoop,
+    @Override public Collection<IgniteFsPath> listPaths(final IgniteFsPath path) throws IOException {
+        return withReconnectHandling(new FileSystemClosure<Collection<IgniteFsPath>>() {
+            @Override public Collection<IgniteFsPath> apply(GridGgfsHadoopEx hadoop,
                 GridGgfsHandshakeResponse hndResp) throws GridException, IOException {
                 return hadoop.listPaths(path);
             }
@@ -200,7 +200,7 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsHadoopStreamDelegate open(final GridGgfsPath path) throws IOException {
+    @Override public GridGgfsHadoopStreamDelegate open(final IgniteFsPath path) throws IOException {
         return withReconnectHandling(new FileSystemClosure<GridGgfsHadoopStreamDelegate>() {
             @Override public GridGgfsHadoopStreamDelegate apply(GridGgfsHadoopEx hadoop,
                 GridGgfsHandshakeResponse hndResp) throws GridException, IOException {
@@ -210,7 +210,7 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsHadoopStreamDelegate open(final GridGgfsPath path, final int seqReadsBeforePrefetch)
+    @Override public GridGgfsHadoopStreamDelegate open(final IgniteFsPath path, final int seqReadsBeforePrefetch)
         throws IOException {
         return withReconnectHandling(new FileSystemClosure<GridGgfsHadoopStreamDelegate>() {
             @Override public GridGgfsHadoopStreamDelegate apply(GridGgfsHadoopEx hadoop,
@@ -221,7 +221,7 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsHadoopStreamDelegate create(final GridGgfsPath path, final boolean overwrite,
+    @Override public GridGgfsHadoopStreamDelegate create(final IgniteFsPath path, final boolean overwrite,
         final boolean colocate, final int replication, final long blockSize, @Nullable final Map<String, String> props)
         throws IOException {
         return withReconnectHandling(new FileSystemClosure<GridGgfsHadoopStreamDelegate>() {
@@ -233,7 +233,7 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsHadoopStreamDelegate append(final GridGgfsPath path, final boolean create,
+    @Override public GridGgfsHadoopStreamDelegate append(final IgniteFsPath path, final boolean create,
         @Nullable final Map<String, String> props) throws IOException {
         return withReconnectHandling(new FileSystemClosure<GridGgfsHadoopStreamDelegate>() {
             @Override public GridGgfsHadoopStreamDelegate apply(GridGgfsHadoopEx hadoop,
@@ -262,7 +262,7 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
      * @return Result.
      * @throws IOException If failed.
      */
-    private <T> T withReconnectHandling(final FileSystemClosure<T> clo, @Nullable GridGgfsPath path)
+    private <T> T withReconnectHandling(final FileSystemClosure<T> clo, @Nullable IgniteFsPath path)
         throws IOException {
         Exception err = null;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/planner/GridHadoopDefaultMapReducePlanner.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/planner/GridHadoopDefaultMapReducePlanner.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/planner/GridHadoopDefaultMapReducePlanner.java
index ffd14f6..74e73a8 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/planner/GridHadoopDefaultMapReducePlanner.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/planner/GridHadoopDefaultMapReducePlanner.java
@@ -154,7 +154,7 @@ public class GridHadoopDefaultMapReducePlanner implements GridHadoopMapReducePla
                     ggfs = (GridGgfsEx) ((GridEx) ignite).ggfsx(endpoint.ggfs());
 
                 if (ggfs != null && !ggfs.isProxy(split0.file())) {
-                    Collection<GridGgfsBlockLocation> blocks = ggfs.affinity(new GridGgfsPath(split0.file()),
+                    Collection<IgniteFsBlockLocation> blocks = ggfs.affinity(new IgniteFsPath(split0.file()),
                         split0.start(), split0.length());
 
                     assert blocks != null;
@@ -169,7 +169,7 @@ public class GridHadoopDefaultMapReducePlanner implements GridHadoopMapReducePla
                         List<UUID> bestNodeIds = null;
                         long bestLen = -1L;
 
-                        for (GridGgfsBlockLocation block : blocks) {
+                        for (IgniteFsBlockLocation block : blocks) {
                             for (UUID blockNodeId : block.nodeIds()) {
                                 if (topIds.contains(blockNodeId)) {
                                     Long oldLen = nodeMap.get(blockNodeId);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/test/java/org/gridgain/client/hadoop/GridHadoopClientProtocolSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/client/hadoop/GridHadoopClientProtocolSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/client/hadoop/GridHadoopClientProtocolSelfTest.java
index 7f84e13..dda947f 100644
--- a/modules/hadoop/src/test/java/org/gridgain/client/hadoop/GridHadoopClientProtocolSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/client/hadoop/GridHadoopClientProtocolSelfTest.java
@@ -144,10 +144,10 @@ public class GridHadoopClientProtocolSelfTest extends GridHadoopAbstractSelfTest
     public void testJobCounters() throws Exception {
         IgniteFs ggfs = grid(0).fileSystem(GridHadoopAbstractSelfTest.ggfsName);
 
-        ggfs.mkdirs(new GridGgfsPath(PATH_INPUT));
+        ggfs.mkdirs(new IgniteFsPath(PATH_INPUT));
 
         try (BufferedWriter bw = new BufferedWriter(new OutputStreamWriter(ggfs.create(
-            new GridGgfsPath(PATH_INPUT + "/test.file"), true)))) {
+            new IgniteFsPath(PATH_INPUT + "/test.file"), true)))) {
 
             bw.write(
                 "alpha\n" +
@@ -262,10 +262,10 @@ public class GridHadoopClientProtocolSelfTest extends GridHadoopAbstractSelfTest
     public void checkJobSubmit(boolean noCombiners, boolean noReducers) throws Exception {
         IgniteFs ggfs = grid(0).fileSystem(GridHadoopAbstractSelfTest.ggfsName);
 
-        ggfs.mkdirs(new GridGgfsPath(PATH_INPUT));
+        ggfs.mkdirs(new IgniteFsPath(PATH_INPUT));
 
         try (BufferedWriter bw = new BufferedWriter(new OutputStreamWriter(ggfs.create(
-            new GridGgfsPath(PATH_INPUT + "/test.file"), true)))) {
+            new IgniteFsPath(PATH_INPUT + "/test.file"), true)))) {
 
             bw.write("word");
         }
@@ -381,7 +381,7 @@ public class GridHadoopClientProtocolSelfTest extends GridHadoopAbstractSelfTest
         assert jobStatus.getMapProgress() == 1.0f;
         assert jobStatus.getReduceProgress() == 1.0f;
 
-        dumpGgfs(ggfs, new GridGgfsPath(PATH_OUTPUT));
+        dumpGgfs(ggfs, new IgniteFsPath(PATH_OUTPUT));
     }
 
     /**
@@ -392,7 +392,7 @@ public class GridHadoopClientProtocolSelfTest extends GridHadoopAbstractSelfTest
      * @throws Exception If failed.
      */
     @SuppressWarnings("ConstantConditions")
-    private static void dumpGgfs(IgniteFs ggfs, GridGgfsPath path) throws Exception {
+    private static void dumpGgfs(IgniteFs ggfs, IgniteFsPath path) throws Exception {
         GridGgfsFile file = ggfs.info(path);
 
         assert file != null;
@@ -400,7 +400,7 @@ public class GridHadoopClientProtocolSelfTest extends GridHadoopAbstractSelfTest
         System.out.println(file.path());
 
         if (file.isDirectory()) {
-            for (GridGgfsPath child : ggfs.listPaths(path))
+            for (IgniteFsPath child : ggfs.listPaths(path))
                 dumpGgfs(ggfs, child);
         }
         else {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
index 1fb40fb..8edd67f 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
@@ -1293,15 +1293,15 @@ public abstract class GridGgfsHadoop20FileSystemAbstractSelfTest extends GridGgf
 
             IgniteFs igniteFs = grid(0).fileSystem("ggfs");
 
-            GridGgfsPath filePath = new GridGgfsPath("/someFile");
+            IgniteFsPath filePath = new IgniteFsPath("/someFile");
 
             GridGgfsFile fileInfo = igniteFs.info(filePath);
 
-            Collection<GridGgfsBlockLocation> locations = igniteFs.affinity(filePath, 0, fileInfo.length());
+            Collection<IgniteFsBlockLocation> locations = igniteFs.affinity(filePath, 0, fileInfo.length());
 
             assertEquals(1, locations.size());
 
-            GridGgfsBlockLocation location = F.first(locations);
+            IgniteFsBlockLocation location = F.first(locations);
 
             assertEquals(1, location.nodeIds().size());
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
index 3c90a98..2528cd4 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
@@ -65,13 +65,13 @@ public abstract class GridGgfsHadoopDualAbstractSelfTest extends GridGgfsCommonA
     protected static final String SECONDARY_REST_CFG = "{type:'tcp', port:11500}";
 
     /** Directory. */
-    protected static final GridGgfsPath DIR = new GridGgfsPath("/dir");
+    protected static final IgniteFsPath DIR = new IgniteFsPath("/dir");
 
     /** Sub-directory. */
-    protected static final GridGgfsPath SUBDIR = new GridGgfsPath(DIR, "subdir");
+    protected static final IgniteFsPath SUBDIR = new IgniteFsPath(DIR, "subdir");
 
     /** File. */
-    protected static final GridGgfsPath FILE = new GridGgfsPath(SUBDIR, "file");
+    protected static final IgniteFsPath FILE = new IgniteFsPath(SUBDIR, "file");
 
     /** Default data chunk (128 bytes). */
     protected static byte[] chunk;
@@ -192,7 +192,7 @@ public abstract class GridGgfsHadoopDualAbstractSelfTest extends GridGgfsCommonA
      * @param paths Paths to group.
      * @return Paths as array.
      */
-    protected GridGgfsPath[] paths(GridGgfsPath... paths) {
+    protected IgniteFsPath[] paths(IgniteFsPath... paths) {
         return paths;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
index 4fc262d..9300aaa 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
@@ -1532,15 +1532,15 @@ public abstract class GridGgfsHadoopFileSystemAbstractSelfTest extends GridGgfsC
 
             IgniteFs igniteFs = grid(0).fileSystem("ggfs");
 
-            GridGgfsPath filePath = new GridGgfsPath("/someFile");
+            IgniteFsPath filePath = new IgniteFsPath("/someFile");
 
             GridGgfsFile fileInfo = igniteFs.info(filePath);
 
-            Collection<GridGgfsBlockLocation> locations = igniteFs.affinity(filePath, 0, fileInfo.length());
+            Collection<IgniteFsBlockLocation> locations = igniteFs.affinity(filePath, 0, fileInfo.length());
 
             assertEquals(1, locations.size());
 
-            GridGgfsBlockLocation location = F.first(locations);
+            IgniteFsBlockLocation location = F.first(locations);
 
             assertEquals(1, location.nodeIds().size());
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java
index 2fd3a72..7095ded 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java
@@ -120,7 +120,7 @@ public class GridGgfsHadoopFileSystemClientSelfTest extends GridGgfsCommonAbstra
 
             client.handshake(null);
 
-            GridGgfsPath path = new GridGgfsPath("/test1.file");
+            IgniteFsPath path = new IgniteFsPath("/test1.file");
 
             GridGgfsHadoopStreamDelegate delegate = client.create(path, true, false, 1, 1024, null);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
index f51e85c..560b343 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
@@ -49,7 +49,7 @@ public class GridGgfsHadoopFileSystemHandshakeSelfTest extends GridGgfsCommonAbs
     private static final String GGFS_NAME = "ggfs";
 
     /** GGFS path. */
-    private static final GridGgfsPath PATH = new GridGgfsPath("/path");
+    private static final IgniteFsPath PATH = new IgniteFsPath("/path");
 
     /** {@inheritDoc} */
     @Override protected void afterTest() throws Exception {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java
index 6956bad..8edb6d6 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java
@@ -30,7 +30,7 @@ public class GridGgfsHadoopFileSystemLoggerSelfTest extends GridGgfsCommonAbstra
     private static final String PATH_STR_ESCAPED = PATH_STR.replace(';', '~');
 
     /** Path. */
-    private static final GridGgfsPath PATH = new GridGgfsPath(PATH_STR);
+    private static final IgniteFsPath PATH = new IgniteFsPath(PATH_STR);
 
     /** GGFS name. */
     private static final String GGFS_NAME = "ggfs";
@@ -196,7 +196,7 @@ public class GridGgfsHadoopFileSystemLoggerSelfTest extends GridGgfsCommonAbstra
         String file2 = "/dir3/file1.test";
 
         log.logMakeDirectory(PATH, PRIMARY);
-        log.logRename(PATH, PRIMARY, new GridGgfsPath(newFile));
+        log.logRename(PATH, PRIMARY, new IgniteFsPath(newFile));
         log.logListDirectory(PATH, PRIMARY, new String[] { file1, file2 });
         log.logDelete(PATH, PRIMARY, false);
 
@@ -220,7 +220,7 @@ public class GridGgfsHadoopFileSystemLoggerSelfTest extends GridGgfsCommonAbstra
      * @return GGFS file instance.
      */
     private GridGgfsFile file(String path) {
-        return new GridGgfsFileImpl(new GridGgfsPath(path), new GridGgfsFileInfo(), 64 * 1024 * 1024);
+        return new GridGgfsFileImpl(new IgniteFsPath(path), new GridGgfsFileInfo(), 64 * 1024 * 1024);
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractWordCountTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractWordCountTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractWordCountTest.java
index 11aff60..66e2fd0 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractWordCountTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractWordCountTest.java
@@ -90,7 +90,7 @@ public abstract class GridHadoopAbstractWordCountTest extends GridHadoopAbstract
         }
 
         //Input file preparing
-        PrintWriter testInputFileWriter = new PrintWriter(ggfs.create(new GridGgfsPath(path), true));
+        PrintWriter testInputFileWriter = new PrintWriter(ggfs.create(new IgniteFsPath(path), true));
 
         int j = 0;
 
@@ -114,7 +114,7 @@ public abstract class GridHadoopAbstractWordCountTest extends GridHadoopAbstract
      * @throws Exception If could not read the file.
      */
     protected String readAndSortFile(String fileName) throws Exception {
-        BufferedReader reader = new BufferedReader(new InputStreamReader(ggfs.open(new GridGgfsPath(fileName))));
+        BufferedReader reader = new BufferedReader(new InputStreamReader(ggfs.open(new IgniteFsPath(fileName))));
 
         List<String> list = new ArrayList<>();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopCommandLineTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopCommandLineTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopCommandLineTest.java
index 51eec68..f9c0498 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopCommandLineTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopCommandLineTest.java
@@ -301,17 +301,17 @@ public class GridHadoopCommandLineTest extends GridCommonAbstractTest {
 
         assertEquals(0, executeHadoopCmd("fs", "-put", new File(testWorkDir, "test-data").getAbsolutePath(), "/input"));
 
-        assertTrue(ggfs.exists(new GridGgfsPath("/input/test-data")));
+        assertTrue(ggfs.exists(new IgniteFsPath("/input/test-data")));
 
         assertEquals(0, executeHadoopCmd("jar", examplesJar.getAbsolutePath(), "wordcount", "/input", "/output"));
 
-        GridGgfsPath path = new GridGgfsPath("/users/" + System.getProperty("user.name") + "/");
+        IgniteFsPath path = new IgniteFsPath("/users/" + System.getProperty("user.name") + "/");
 
         assertTrue(ggfs.exists(path));
 
-        GridGgfsPath jobStatPath = null;
+        IgniteFsPath jobStatPath = null;
 
-        for (GridGgfsPath jobPath : ggfs.listPaths(path)) {
+        for (IgniteFsPath jobPath : ggfs.listPaths(path)) {
             assertNull(jobStatPath);
 
             jobStatPath = jobPath;
@@ -325,9 +325,9 @@ public class GridHadoopCommandLineTest extends GridCommonAbstractTest {
 
         assertTrue(evtCnt >= 22); //It's the minimum amount of events for job with combiner.
 
-        assertTrue(ggfs.exists(new GridGgfsPath("/output")));
+        assertTrue(ggfs.exists(new IgniteFsPath("/output")));
 
-        BufferedReader in = new BufferedReader(new InputStreamReader(ggfs.open(new GridGgfsPath("/output/part-r-00000"))));
+        BufferedReader in = new BufferedReader(new InputStreamReader(ggfs.open(new IgniteFsPath("/output/part-r-00000"))));
 
         List<String> res = new ArrayList<>();
 
@@ -358,7 +358,7 @@ public class GridHadoopCommandLineTest extends GridCommonAbstractTest {
             "location '/result' as " + qry
         ));
 
-        GridGgfsInputStreamAdapter in = ggfs.open(new GridGgfsPath("/result/000000_0"));
+        GridGgfsInputStreamAdapter in = ggfs.open(new IgniteFsPath("/result/000000_0"));
 
         byte[] buf = new byte[(int) in.length()];
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
index bbdb5b2..f8a603b 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
@@ -72,7 +72,7 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
     private static final GridHadoopMapReducePlanner PLANNER = new GridHadoopDefaultMapReducePlanner();
 
     /** Block locations. */
-    private static final Map<Block, Collection<GridGgfsBlockLocation>> BLOCK_MAP = new HashMap<>();
+    private static final Map<Block, Collection<IgniteFsBlockLocation>> BLOCK_MAP = new HashMap<>();
 
     /** Proxy map. */
     private static final Map<URI, Boolean> PROXY_MAP = new HashMap<>();
@@ -488,7 +488,7 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
      * @param nodeIds Node IDs.
      * @return Block location.
      */
-    private static GridGgfsBlockLocation location(long start, long len, UUID... nodeIds) {
+    private static IgniteFsBlockLocation location(long start, long len, UUID... nodeIds) {
         assert nodeIds != null && nodeIds.length > 0;
 
         Collection<ClusterNode> nodes = new ArrayList<>(nodeIds.length);
@@ -507,14 +507,14 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
      * @param len Length.
      * @param locations Locations.
      */
-    private static void mapGgfsBlock(URI file, long start, long len, GridGgfsBlockLocation... locations) {
+    private static void mapGgfsBlock(URI file, long start, long len, IgniteFsBlockLocation... locations) {
         assert locations != null && locations.length > 0;
 
-        GridGgfsPath path = new GridGgfsPath(file);
+        IgniteFsPath path = new IgniteFsPath(file);
 
         Block block = new Block(path, start, len);
 
-        Collection<GridGgfsBlockLocation> locationsList = new ArrayList<>();
+        Collection<IgniteFsBlockLocation> locationsList = new ArrayList<>();
 
         Collections.addAll(locationsList, locations);
 
@@ -526,7 +526,7 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
      */
     private static class Block {
         /** */
-        private final GridGgfsPath path;
+        private final IgniteFsPath path;
 
         /** */
         private final long start;
@@ -541,7 +541,7 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
          * @param start Start.
          * @param len Length.
          */
-        private Block(GridGgfsPath path, long start, long len) {
+        private Block(IgniteFsPath path, long start, long len) {
             this.path = path;
             this.start = start;
             this.len = len;
@@ -659,13 +659,13 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
         }
 
         /** {@inheritDoc} */
-        @Override public Collection<GridGgfsBlockLocation> affinity(GridGgfsPath path, long start, long len)
+        @Override public Collection<IgniteFsBlockLocation> affinity(IgniteFsPath path, long start, long len)
             throws GridException {
             return BLOCK_MAP.get(new Block(path, start, len));
         }
 
         /** {@inheritDoc} */
-        @Override public Collection<GridGgfsBlockLocation> affinity(GridGgfsPath path, long start, long len,
+        @Override public Collection<IgniteFsBlockLocation> affinity(IgniteFsPath path, long start, long len,
             long maxLen) throws GridException {
             return null;
         }
@@ -686,18 +686,18 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
         }
 
         /** {@inheritDoc} */
-        @Override public GridGgfsInputStreamAdapter open(GridGgfsPath path, int bufSize, int seqReadsBeforePrefetch)
+        @Override public GridGgfsInputStreamAdapter open(IgniteFsPath path, int bufSize, int seqReadsBeforePrefetch)
             throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Override public GridGgfsInputStreamAdapter open(GridGgfsPath path) throws GridException {
+        @Override public GridGgfsInputStreamAdapter open(IgniteFsPath path) throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Override public GridGgfsInputStreamAdapter open(GridGgfsPath path, int bufSize) throws GridException {
+        @Override public GridGgfsInputStreamAdapter open(IgniteFsPath path, int bufSize) throws GridException {
             return null;
         }
 
@@ -742,7 +742,7 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
         }
 
         /** {@inheritDoc} */
-        @Override public boolean evictExclude(GridGgfsPath path, boolean primary) {
+        @Override public boolean evictExclude(IgniteFsPath path, boolean primary) {
             return false;
         }
 
@@ -757,53 +757,53 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
         }
 
         /** {@inheritDoc} */
-        @Override public boolean exists(GridGgfsPath path) throws GridException {
+        @Override public boolean exists(IgniteFsPath path) throws GridException {
             return false;
         }
 
         /** {@inheritDoc} */
-        @Nullable @Override public GridGgfsFile info(GridGgfsPath path) throws GridException {
+        @Nullable @Override public GridGgfsFile info(IgniteFsPath path) throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Override public GridGgfsPathSummary summary(GridGgfsPath path) throws GridException {
+        @Override public IgniteFsPathSummary summary(IgniteFsPath path) throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Nullable @Override public GridGgfsFile update(GridGgfsPath path, Map<String, String> props)
+        @Nullable @Override public GridGgfsFile update(IgniteFsPath path, Map<String, String> props)
             throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Override public void rename(GridGgfsPath src, GridGgfsPath dest) throws GridException {
+        @Override public void rename(IgniteFsPath src, IgniteFsPath dest) throws GridException {
             // No-op.
         }
 
         /** {@inheritDoc} */
-        @Override public boolean delete(GridGgfsPath path, boolean recursive) throws GridException {
+        @Override public boolean delete(IgniteFsPath path, boolean recursive) throws GridException {
             return false;
         }
 
         /** {@inheritDoc} */
-        @Override public void mkdirs(GridGgfsPath path) throws GridException {
+        @Override public void mkdirs(IgniteFsPath path) throws GridException {
             // No-op.
         }
 
         /** {@inheritDoc} */
-        @Override public void mkdirs(GridGgfsPath path, @Nullable Map<String, String> props) throws GridException {
+        @Override public void mkdirs(IgniteFsPath path, @Nullable Map<String, String> props) throws GridException {
             // No-op.
         }
 
         /** {@inheritDoc} */
-        @Override public Collection<GridGgfsPath> listPaths(GridGgfsPath path) throws GridException {
+        @Override public Collection<IgniteFsPath> listPaths(IgniteFsPath path) throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Override public Collection<GridGgfsFile> listFiles(GridGgfsPath path) throws GridException {
+        @Override public Collection<GridGgfsFile> listFiles(IgniteFsPath path) throws GridException {
             return null;
         }
 
@@ -818,36 +818,36 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
         }
 
         /** {@inheritDoc} */
-        @Override public GridGgfsOutputStream create(GridGgfsPath path, boolean overwrite) throws GridException {
+        @Override public GridGgfsOutputStream create(IgniteFsPath path, boolean overwrite) throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Override public GridGgfsOutputStream create(GridGgfsPath path, int bufSize, boolean overwrite, int replication,
+        @Override public GridGgfsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication,
             long blockSize, @Nullable Map<String, String> props) throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Override public GridGgfsOutputStream create(GridGgfsPath path, int bufSize, boolean overwrite,
+        @Override public GridGgfsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite,
             @Nullable IgniteUuid affKey, int replication, long blockSize, @Nullable Map<String, String> props)
             throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Override public GridGgfsOutputStream append(GridGgfsPath path, boolean create) throws GridException {
+        @Override public GridGgfsOutputStream append(IgniteFsPath path, boolean create) throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Override public GridGgfsOutputStream append(GridGgfsPath path, int bufSize, boolean create,
+        @Override public GridGgfsOutputStream append(IgniteFsPath path, int bufSize, boolean create,
             @Nullable Map<String, String> props) throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Override public void setTimes(GridGgfsPath path, long accessTime, long modificationTime) throws GridException {
+        @Override public void setTimes(IgniteFsPath path, long accessTime, long modificationTime) throws GridException {
             // No-op.
         }
 
@@ -862,7 +862,7 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
         }
 
         /** {@inheritDoc} */
-        @Override public long size(GridGgfsPath path) throws GridException {
+        @Override public long size(IgniteFsPath path) throws GridException {
             return 0;
         }
 
@@ -873,27 +873,27 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
 
         /** {@inheritDoc} */
         @Override public <T, R> R execute(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
-            Collection<GridGgfsPath> paths, @Nullable T arg) throws GridException {
+            Collection<IgniteFsPath> paths, @Nullable T arg) throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
         @Override public <T, R> R execute(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
-            Collection<GridGgfsPath> paths, boolean skipNonExistentFiles, long maxRangeLen, @Nullable T arg)
+            Collection<IgniteFsPath> paths, boolean skipNonExistentFiles, long maxRangeLen, @Nullable T arg)
             throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
         @Override public <T, R> R execute(Class<? extends GridGgfsTask<T, R>> taskCls,
-            @Nullable GridGgfsRecordResolver rslvr, Collection<GridGgfsPath> paths, @Nullable T arg)
+            @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, @Nullable T arg)
             throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
         @Override public <T, R> R execute(Class<? extends GridGgfsTask<T, R>> taskCls,
-            @Nullable GridGgfsRecordResolver rslvr, Collection<GridGgfsPath> paths, boolean skipNonExistentFiles,
+            @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, boolean skipNonExistentFiles,
             long maxRangeLen, @Nullable T arg) throws GridException {
             return null;
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceEmbeddedSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceEmbeddedSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceEmbeddedSelfTest.java
index 128d19b..26b17d0 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceEmbeddedSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceEmbeddedSelfTest.java
@@ -49,11 +49,11 @@ public class GridHadoopMapReduceEmbeddedSelfTest extends GridHadoopMapReduceTest
      * @throws Exception If fails.
      */
     public void testMultiReducerWholeMapReduceExecution() throws Exception {
-        GridGgfsPath inDir = new GridGgfsPath(PATH_INPUT);
+        IgniteFsPath inDir = new IgniteFsPath(PATH_INPUT);
 
         ggfs.mkdirs(inDir);
 
-        GridGgfsPath inFile = new GridGgfsPath(inDir, GridHadoopWordCount2.class.getSimpleName() + "-input");
+        IgniteFsPath inFile = new IgniteFsPath(inDir, GridHadoopWordCount2.class.getSimpleName() + "-input");
 
         generateTestFile(inFile.toString(), "key1", 10000, "key2", 20000, "key3", 15000, "key4", 7000, "key5", 12000,
             "key6", 18000 );
@@ -61,7 +61,7 @@ public class GridHadoopMapReduceEmbeddedSelfTest extends GridHadoopMapReduceTest
         for (int i = 0; i < 2; i++) {
             boolean useNewAPI = i == 1;
 
-            ggfs.delete(new GridGgfsPath(PATH_OUTPUT), true);
+            ggfs.delete(new IgniteFsPath(PATH_OUTPUT), true);
 
             flags.put("serializationWasConfigured", false);
             flags.put("partitionerWasConfigured", false);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceTest.java
index 25504d7..75aefb2 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceTest.java
@@ -44,16 +44,16 @@ public class GridHadoopMapReduceTest extends GridHadoopAbstractWordCountTest {
      * @throws Exception If fails.
      */
     public void testWholeMapReduceExecution() throws Exception {
-        GridGgfsPath inDir = new GridGgfsPath(PATH_INPUT);
+        IgniteFsPath inDir = new IgniteFsPath(PATH_INPUT);
 
         ggfs.mkdirs(inDir);
 
-        GridGgfsPath inFile = new GridGgfsPath(inDir, GridHadoopWordCount2.class.getSimpleName() + "-input");
+        IgniteFsPath inFile = new IgniteFsPath(inDir, GridHadoopWordCount2.class.getSimpleName() + "-input");
 
         generateTestFile(inFile.toString(), "red", 100000, "blue", 200000, "green", 150000, "yellow", 70000 );
 
         for (int i = 0; i < 8; i++) {
-            ggfs.delete(new GridGgfsPath(PATH_OUTPUT), true);
+            ggfs.delete(new IgniteFsPath(PATH_OUTPUT), true);
 
             boolean useNewMapper = (i & 1) == 0;
             boolean useNewCombiner = (i & 2) == 0;
@@ -171,7 +171,7 @@ public class GridHadoopMapReduceTest extends GridHadoopAbstractWordCountTest {
             }
         }
 
-        final GridGgfsPath statPath = new GridGgfsPath("/users/anonymous/" + jobId + "/performance");
+        final IgniteFsPath statPath = new IgniteFsPath("/users/anonymous/" + jobId + "/performance");
 
         GridTestUtils.waitForCondition(new GridAbsPredicate() {
             @Override public boolean apply() {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTaskExecutionSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTaskExecutionSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTaskExecutionSelfTest.java
index d4a75bc..4355101 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTaskExecutionSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTaskExecutionSelfTest.java
@@ -240,7 +240,7 @@ public class GridHadoopTaskExecutionSelfTest extends GridHadoopAbstractSelfTest
     private void prepareFile(String fileName, int lineCnt) throws Exception {
         IgniteFs ggfs = grid(0).fileSystem(ggfsName);
 
-        try (OutputStream os = ggfs.create(new GridGgfsPath(fileName), true)) {
+        try (OutputStream os = ggfs.create(new IgniteFsPath(fileName), true)) {
             PrintWriter w = new PrintWriter(new OutputStreamWriter(os));
 
             for (int i = 0; i < lineCnt; i++)

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTasksAllVersionsTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTasksAllVersionsTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTasksAllVersionsTest.java
index fe134a3..7aa11b8 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTasksAllVersionsTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTasksAllVersionsTest.java
@@ -50,11 +50,11 @@ abstract class GridHadoopTasksAllVersionsTest extends GridHadoopAbstractWordCoun
      */
     @SuppressWarnings("ConstantConditions")
     public void testMapTask() throws Exception {
-        GridGgfsPath inDir = new GridGgfsPath(PATH_INPUT);
+        IgniteFsPath inDir = new IgniteFsPath(PATH_INPUT);
 
         ggfs.mkdirs(inDir);
 
-        GridGgfsPath inFile = new GridGgfsPath(inDir, GridHadoopWordCount2.class.getSimpleName() + "-input");
+        IgniteFsPath inFile = new IgniteFsPath(inDir, GridHadoopWordCount2.class.getSimpleName() + "-input");
 
         URI inFileUri = URI.create(ggfsScheme() + inFile.toString());
 
@@ -203,11 +203,11 @@ abstract class GridHadoopTasksAllVersionsTest extends GridHadoopAbstractWordCoun
      */
     @SuppressWarnings("ConstantConditions")
     public void testAllTasks() throws Exception {
-        GridGgfsPath inDir = new GridGgfsPath(PATH_INPUT);
+        IgniteFsPath inDir = new IgniteFsPath(PATH_INPUT);
 
         ggfs.mkdirs(inDir);
 
-        GridGgfsPath inFile = new GridGgfsPath(inDir, GridHadoopWordCount2.class.getSimpleName() + "-input");
+        IgniteFsPath inFile = new IgniteFsPath(inDir, GridHadoopWordCount2.class.getSimpleName() + "-input");
 
         URI inFileUri = URI.create(ggfsScheme() + inFile.toString());
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/GridHadoopExternalTaskExecutionSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/GridHadoopExternalTaskExecutionSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/GridHadoopExternalTaskExecutionSelfTest.java
index 3697656..fe20f71 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/GridHadoopExternalTaskExecutionSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/GridHadoopExternalTaskExecutionSelfTest.java
@@ -143,7 +143,7 @@ public class GridHadoopExternalTaskExecutionSelfTest extends GridHadoopAbstractS
     private void prepareTestFile(String filePath) throws Exception {
         IgniteFs ggfs = grid(0).fileSystem(ggfsName);
 
-        try (GridGgfsOutputStream out = ggfs.create(new GridGgfsPath(filePath), true)) {
+        try (GridGgfsOutputStream out = ggfs.create(new IgniteFsPath(filePath), true)) {
             PrintWriter wr = new PrintWriter(new OutputStreamWriter(out));
 
             for (int i = 0; i < 1000; i++)


[29/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/task/GridTaskWorker.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/task/GridTaskWorker.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/task/GridTaskWorker.java
index 9bf93e0..38f7007 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/task/GridTaskWorker.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/task/GridTaskWorker.java
@@ -13,11 +13,11 @@ import org.apache.ignite.*;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.compute.*;
 import org.apache.ignite.events.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.marshaller.*;
 import org.apache.ignite.resources.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.managers.deployment.*;
 import org.gridgain.grid.kernal.processors.job.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfs.java b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfs.java
index 9d537de..2bd761b 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfs.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfs.java
@@ -10,8 +10,8 @@
 package org.gridgain.grid.kernal.visor.ggfs;
 
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.util.typedef.internal.*;
 
 import java.io.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsMetrics.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsMetrics.java b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsMetrics.java
index 67ff249..cd93fa5 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsMetrics.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsMetrics.java
@@ -9,13 +9,13 @@
 
 package org.gridgain.grid.kernal.visor.ggfs;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.util.typedef.internal.*;
 
 import java.io.*;
 
 /**
- * Data transfer object for {@link org.gridgain.grid.ggfs.IgniteFsMetrics}.
+ * Data transfer object for {@link org.apache.ignite.fs.IgniteFsMetrics}.
  */
 public class VisorGgfsMetrics implements Serializable {
     /** */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfiler.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfiler.java b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfiler.java
index e1c8c14..34467c2 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfiler.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfiler.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.visor.ggfs;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.util.typedef.*;
 
 import java.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerEntry.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerEntry.java b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerEntry.java
index b027627..84de0be 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerEntry.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerEntry.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.visor.ggfs;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.util.typedef.internal.*;
 
 import java.io.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerTask.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerTask.java b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerTask.java
index c82ebd9..d47ea5b 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerTask.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerTask.java
@@ -9,8 +9,8 @@
 
 package org.gridgain.grid.kernal.visor.ggfs;
 
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.processors.task.*;
 import org.gridgain.grid.kernal.visor.*;
 import org.gridgain.grid.util.typedef.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java
index 2c75301..14f4182 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.visor.node;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.jetbrains.annotations.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/visor/util/VisorTaskUtils.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/util/VisorTaskUtils.java b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/util/VisorTaskUtils.java
index b6989c3..db87151 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/util/VisorTaskUtils.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/util/VisorTaskUtils.java
@@ -37,7 +37,7 @@ import java.util.concurrent.atomic.*;
 
 import static java.lang.System.*;
 import static org.apache.ignite.events.IgniteEventType.*;
-import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
+import static org.apache.ignite.fs.IgniteFsConfiguration.*;
 
 /**
  * Contains utility methods for Visor tasks and jobs.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/config/ggfs-loopback.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/ggfs-loopback.xml b/modules/core/src/test/config/ggfs-loopback.xml
index a6b911d..5cd4588 100644
--- a/modules/core/src/test/config/ggfs-loopback.xml
+++ b/modules/core/src/test/config/ggfs-loopback.xml
@@ -74,7 +74,7 @@
 
         <property name="ggfsConfiguration">
             <list>
-                <bean class="org.gridgain.grid.ggfs.IgniteFsConfiguration">
+                <bean class="org.apache.ignite.fs.IgniteFsConfiguration">
                     <property name="name" value="ggfs"/>
                     <property name="metaCacheName" value="ggfs-meta"/>
                     <property name="dataCacheName" value="ggfs-data"/>
@@ -109,7 +109,7 @@
                     <property name="distributionMode" value="PARTITIONED_ONLY"/>
                     <property name="backups" value="0"/>
                     <property name="affinityMapper">
-                        <bean class="org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper">
+                        <bean class="org.apache.ignite.fs.IgniteFsGroupDataBlocksKeyMapper">
                             <!-- Haw many blocks in row will be stored on the same node. -->
                             <constructor-arg value="512"/>
                         </bean>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/config/ggfs-no-endpoint.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/ggfs-no-endpoint.xml b/modules/core/src/test/config/ggfs-no-endpoint.xml
index cd4fa1e..56d8155 100644
--- a/modules/core/src/test/config/ggfs-no-endpoint.xml
+++ b/modules/core/src/test/config/ggfs-no-endpoint.xml
@@ -75,7 +75,7 @@
 
         <property name="ggfsConfiguration">
             <list>
-                <bean class="org.gridgain.grid.ggfs.IgniteFsConfiguration">
+                <bean class="org.apache.ignite.fs.IgniteFsConfiguration">
                     <property name="name" value="ggfs"/>
                     <property name="metaCacheName" value="ggfs-meta"/>
                     <property name="dataCacheName" value="ggfs-data"/>
@@ -109,7 +109,7 @@
                     <property name="distributionMode" value="PARTITIONED_ONLY"/>
                     <property name="backups" value="0"/>
                     <property name="affinityMapper">
-                        <bean class="org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper">
+                        <bean class="org.apache.ignite.fs.IgniteFsGroupDataBlocksKeyMapper">
                             <!-- Haw many blocks in row will be stored on the same node. -->
                             <constructor-arg value="512"/>
                         </bean>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/config/ggfs-shmem.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/ggfs-shmem.xml b/modules/core/src/test/config/ggfs-shmem.xml
index 84d1f72..f2d4d5e 100644
--- a/modules/core/src/test/config/ggfs-shmem.xml
+++ b/modules/core/src/test/config/ggfs-shmem.xml
@@ -74,7 +74,7 @@
 
         <property name="ggfsConfiguration">
             <list>
-                <bean class="org.gridgain.grid.ggfs.IgniteFsConfiguration">
+                <bean class="org.apache.ignite.fs.IgniteFsConfiguration">
                     <property name="name" value="ggfs"/>
                     <property name="metaCacheName" value="ggfs-meta"/>
                     <property name="dataCacheName" value="ggfs-data"/>
@@ -109,7 +109,7 @@
                     <property name="distributionMode" value="PARTITIONED_ONLY"/>
                     <property name="backups" value="0"/>
                     <property name="affinityMapper">
-                        <bean class="org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper">
+                        <bean class="org.apache.ignite.fs.IgniteFsGroupDataBlocksKeyMapper">
                             <!-- Haw many blocks in row will be stored on the same node. -->
                             <constructor-arg value="512"/>
                         </bean>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
index 44df918..0317c11 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
@@ -12,6 +12,7 @@ package org.gridgain.grid.ggfs;
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
 import org.apache.ignite.events.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java
index 94cfd3c..f97a416 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java
@@ -10,6 +10,7 @@
 package org.gridgain.grid.ggfs;
 
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java
index dfb99d6..4f6bac1 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java
@@ -10,6 +10,7 @@
 package org.gridgain.grid.ggfs;
 
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerTopologySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerTopologySelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerTopologySelfTest.java
index 4d99ac8..324258d 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerTopologySelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerTopologySelfTest.java
@@ -10,6 +10,7 @@
 package org.gridgain.grid.ggfs;
 
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 
 /**
  * Tests coordinator transfer from one node to other.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsPathSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsPathSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsPathSelfTest.java
index 94168d6..8e25e29 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsPathSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsPathSelfTest.java
@@ -9,6 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
+import org.apache.ignite.fs.*;
 import org.apache.ignite.marshaller.*;
 import org.apache.ignite.marshaller.optimized.*;
 import org.gridgain.grid.*;
@@ -23,7 +24,7 @@ import java.util.*;
 import java.util.concurrent.*;
 
 /**
- * {@link IgniteFsPath} self test.
+ * {@link org.apache.ignite.fs.IgniteFsPath} self test.
  */
 public class GridGgfsPathSelfTest extends GridCommonAbstractTest {
     /** Marshaller to test {@link Externalizable} interface. */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
index f0f4965..a21eaff 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
@@ -11,10 +11,10 @@ package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.cache.eviction.ggfs.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.processors.cache.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.vm.*;
@@ -28,7 +28,7 @@ import java.util.concurrent.*;
 
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * Tests for GGFS per-block LR eviction policy.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
index e64b9b3..6f7ece0 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
@@ -11,10 +11,10 @@ package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.vm.*;
@@ -34,7 +34,7 @@ import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMemoryMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
 import static org.apache.ignite.IgniteFs.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * Test fo regular GGFs operations.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributesSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributesSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributesSelfTest.java
index 35cabd4..f66ffb4 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributesSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributesSelfTest.java
@@ -9,13 +9,13 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 
 import java.io.*;
 import java.lang.reflect.*;
 import java.util.*;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * {@link GridGgfsAttributes} test case.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsCacheSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsCacheSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsCacheSelfTest.java
index 71945ee..5629c86 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsCacheSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsCacheSelfTest.java
@@ -11,8 +11,8 @@ package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.vm.*;
 import org.gridgain.testframework.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java
index 605b1c0..414e566 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java
@@ -11,9 +11,9 @@ package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.processors.cache.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
index 99feec6..8873f48 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
@@ -9,9 +9,9 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.GridCache;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.gridgain.grid.util.lang.*;
 import org.gridgain.testframework.GridTestUtils;
@@ -21,7 +21,7 @@ import java.util.*;
 import java.util.concurrent.*;
 
 import static org.apache.ignite.IgniteFs.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * Tests for GGFS working in mode when remote file system exists: DUAL_SYNC, DUAL_ASYNC.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAsyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAsyncSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAsyncSelfTest.java
index 01bc9f2..cb22ac8 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAsyncSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAsyncSelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * Tests for DUAL_ASYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualSyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualSyncSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualSyncSelfTest.java
index c9d5e64..15070e0 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualSyncSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualSyncSelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * Tests for DUAL_SYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsGroupDataBlockKeyMapperHashSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsGroupDataBlockKeyMapperHashSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsGroupDataBlockKeyMapperHashSelfTest.java
index e1140b4..0ec24ed 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsGroupDataBlockKeyMapperHashSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsGroupDataBlockKeyMapperHashSelfTest.java
@@ -9,14 +9,14 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.util.typedef.internal.*;
 
 import java.util.concurrent.*;
 
 /**
- * Tests for {@link org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper} hash.
+ * Tests for {@link org.apache.ignite.fs.IgniteFsGroupDataBlocksKeyMapper} hash.
  */
 public class GridGgfsGroupDataBlockKeyMapperHashSelfTest extends GridGgfsCommonAbstractTest {
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java
index 2d3fa9c..38b9155 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java
@@ -10,9 +10,9 @@
 package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.vm.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
index 42d4cb8..2ebab9e 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
@@ -11,8 +11,8 @@ package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.vm.*;
@@ -24,7 +24,7 @@ import java.util.*;
 
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * Test for GGFS metrics.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolverSelfTest.java
index 1bc63d3..e4481b5 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolverSelfTest.java
@@ -10,12 +10,12 @@
 package org.gridgain.grid.kernal.processors.ggfs;
 
 import junit.framework.*;
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.util.typedef.*;
 
 import java.util.*;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
index bbb9f2c..679bac1 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
@@ -10,10 +10,10 @@
 package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.vm.*;
@@ -25,7 +25,7 @@ import java.util.*;
 
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * GGFS modes self test.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapTieredSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapTieredSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapTieredSelfTest.java
index 302dc4a..b7ee626 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapTieredSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapTieredSelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 import static org.gridgain.grid.cache.GridCacheMemoryMode.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapValuesSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapValuesSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapValuesSelfTest.java
index 86faae8..86b0606 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapValuesSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapValuesSelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 import static org.gridgain.grid.cache.GridCacheMemoryMode.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimarySelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimarySelfTest.java
index f39fe7b..672d407 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimarySelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimarySelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * Tests for PRIMARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
index d13a1c6..057dd6c 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
@@ -12,10 +12,10 @@ package org.gridgain.grid.kernal.processors.ggfs;
 import org.apache.commons.io.*;
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java
index a1991c5..221b593 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java
@@ -10,9 +10,9 @@
 package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.processors.cache.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.*;
@@ -24,13 +24,13 @@ import java.util.*;
 
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * Tests for node validation logic in {@link GridGgfsProcessor}.
  * <p>
  * Tests starting with "testLocal" are checking
- * {@link GridGgfsProcessor#validateLocalGgfsConfigurations(org.gridgain.grid.ggfs.IgniteFsConfiguration[])}.
+ * {@link GridGgfsProcessor#validateLocalGgfsConfigurations(org.apache.ignite.fs.IgniteFsConfiguration[])}.
  * <p>
  * Tests starting with "testRemote" are checking {@link GridGgfsProcessor#checkGgfsOnRemoteNode(org.apache.ignite.cluster.ClusterNode)}.
  */
@@ -474,7 +474,7 @@ public class GridGgfsProcessorValidationSelfTest extends GridGgfsCommonAbstractT
     }
 
     /**
-     * @param grpSize Group size to use in {@link org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper}.
+     * @param grpSize Group size to use in {@link org.apache.ignite.fs.IgniteFsGroupDataBlocksKeyMapper}.
      * @param cacheNames 2 Optional caches names.
      * @return 2 preconfigured data caches.
      */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationAbstractSelfTest.java
index 73a5556..84be991 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationAbstractSelfTest.java
@@ -10,9 +10,9 @@
 package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.processors.port.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
@@ -29,7 +29,7 @@ import java.util.*;
 import java.util.concurrent.atomic.*;
 
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
-import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
+import static org.apache.ignite.fs.IgniteFsConfiguration.*;
 
 /**
  * Base test class for {@link GridGgfsServer} checking IPC endpoint registrations.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationOnLinuxAndMacSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationOnLinuxAndMacSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationOnLinuxAndMacSelfTest.java
index 2b3291d..5295857 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationOnLinuxAndMacSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationOnLinuxAndMacSelfTest.java
@@ -12,7 +12,7 @@ package org.gridgain.grid.kernal.processors.ggfs;
 import org.apache.ignite.configuration.*;
 import org.gridgain.grid.util.typedef.*;
 
-import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
+import static org.apache.ignite.fs.IgniteFsConfiguration.*;
 
 /**
  * Tests for {@link GridGgfsServer} that checks all IPC endpoint registration types

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
index 9dce0df..1ccdc99 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
@@ -13,9 +13,9 @@ import org.apache.ignite.*;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.configuration.*;
 import org.apache.ignite.events.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.processors.cache.*;
 import org.gridgain.grid.spi.discovery.tcp.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
index b79dca0..31736c2 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
@@ -11,10 +11,10 @@ package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.vm.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
index d962109..02aa9ef 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
@@ -12,11 +12,11 @@ package org.gridgain.grid.kernal.processors.ggfs;
 import org.apache.ignite.*;
 import org.apache.ignite.compute.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.resources.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.ggfs.mapreduce.records.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
@@ -32,7 +32,7 @@ import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheDistributionMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
 import static org.gridgain.grid.cache.GridCacheWriteSynchronizationMode.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * Tests for {@link org.gridgain.grid.ggfs.mapreduce.IgniteFsTask}.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
index afa008d..7347f0f 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
@@ -11,8 +11,8 @@ package org.gridgain.grid.kernal.processors.ggfs.split;
 
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.*;
@@ -26,7 +26,7 @@ import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheDistributionMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
 import static org.gridgain.grid.cache.GridCacheWriteSynchronizationMode.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * Base class for all split resolvers

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
index 0c20431..b9f6b8d 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs.split;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.ggfs.mapreduce.records.*;
 import org.gridgain.grid.util.typedef.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
index 98b0abc..e9d3357 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs.split;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.ggfs.mapreduce.records.*;
 import org.gridgain.grid.util.typedef.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
index 4d3aae2..b1efc24 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs.split;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.ggfs.mapreduce.records.*;
 import org.gridgain.grid.util.typedef.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
index 51dbf5f..bea2eff 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs.split;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.ggfs.mapreduce.records.*;
 import org.gridgain.grid.util.typedef.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/test/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryNodeStartup.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryNodeStartup.java b/modules/core/src/test/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryNodeStartup.java
index 96fd35b..fd465ce 100644
--- a/modules/core/src/test/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryNodeStartup.java
+++ b/modules/core/src/test/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryNodeStartup.java
@@ -11,8 +11,8 @@ package org.gridgain.grid.util.ipc.shmem;
 
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.vm.*;
 import org.gridgain.grid.util.typedef.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/GridGgfsHadoopParameters.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/GridGgfsHadoopParameters.java b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/GridGgfsHadoopParameters.java
index bbd2d49..fa51cbc 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/GridGgfsHadoopParameters.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/GridGgfsHadoopParameters.java
@@ -16,7 +16,7 @@ package org.gridgain.grid.ggfs.hadoop;
  * <ul>
  *     <li>
  *         {@code fs.ggfs.[name].open.sequential_reads_before_prefetch} - this parameter overrides
- *         the one specified in {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getSequentialReadsBeforePrefetch()}
+ *         the one specified in {@link org.apache.ignite.fs.IgniteFsConfiguration#getSequentialReadsBeforePrefetch()}
  *         GGFS data node configuration property.
  *     </li>
  *     <li>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
index df55bb3..aeb9267 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
@@ -16,8 +16,8 @@ import org.apache.hadoop.fs.permission.*;
 import org.apache.hadoop.hdfs.*;
 import org.apache.hadoop.mapreduce.*;
 import org.apache.hadoop.util.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.ggfs.common.*;
 import org.gridgain.grid.kernal.ggfs.hadoop.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;
@@ -31,8 +31,8 @@ import java.util.*;
 import java.util.concurrent.atomic.*;
 
 import static org.apache.ignite.IgniteFs.*;
-import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsConfiguration.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 import static org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.*;
 import static org.gridgain.grid.kernal.ggfs.hadoop.GridGgfsHadoopUtils.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
index 31e4ced..0a8e7f7 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
@@ -16,8 +16,8 @@ import org.apache.hadoop.fs.Options;
 import org.apache.hadoop.fs.permission.*;
 import org.apache.hadoop.mapreduce.*;
 import org.apache.hadoop.util.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.ggfs.common.*;
 import org.gridgain.grid.kernal.ggfs.hadoop.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;
@@ -31,8 +31,8 @@ import java.util.*;
 import java.util.concurrent.atomic.*;
 
 import static org.apache.ignite.IgniteFs.*;
-import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsConfiguration.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 import static org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.*;
 import static org.gridgain.grid.kernal.ggfs.hadoop.GridGgfsHadoopUtils.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoop.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoop.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoop.java
index 3b35a95..642efbf 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoop.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoop.java
@@ -9,8 +9,8 @@
 
 package org.gridgain.grid.kernal.ggfs.hadoop;
 
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;
 import org.jetbrains.annotations.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopEndpoint.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopEndpoint.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopEndpoint.java
index c17d26f..dc22086 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopEndpoint.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopEndpoint.java
@@ -19,7 +19,7 @@ import org.jetbrains.annotations.*;
 import java.io.*;
 import java.net.*;
 
-import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
+import static org.apache.ignite.fs.IgniteFsConfiguration.*;
 
 /**
  * GGFS endpoint abstraction.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
index ca08ca1..7f6f540 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
@@ -13,8 +13,8 @@ import org.apache.hadoop.conf.*;
 import org.apache.hadoop.fs.*;
 import org.apache.hadoop.fs.permission.*;
 import org.apache.hadoop.ipc.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 
 import java.io.*;
 import java.net.*;
@@ -26,7 +26,7 @@ import org.gridgain.grid.util.typedef.internal.*;
 import org.jetbrains.annotations.*;
 
 /**
- * Adapter to use any Hadoop file system {@link org.apache.hadoop.fs.FileSystem} as {@link org.gridgain.grid.ggfs.IgniteFsFileSystem}.
+ * Adapter to use any Hadoop file system {@link org.apache.hadoop.fs.FileSystem} as {@link org.apache.ignite.fs.IgniteFsFileSystem}.
  */
 public class GridGgfsHadoopFileSystemWrapper implements IgniteFsFileSystem, AutoCloseable {
     /** Property name for path to Hadoop configuration. */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java
index b77c49a..0729023 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java
@@ -10,8 +10,8 @@
 package org.gridgain.grid.kernal.ggfs.hadoop;
 
 import org.apache.commons.logging.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;
 import org.gridgain.grid.util.lang.*;
 import org.jetbrains.annotations.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopOutProc.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopOutProc.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopOutProc.java
index c32616c..60b1db1 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopOutProc.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopOutProc.java
@@ -10,8 +10,8 @@
 package org.gridgain.grid.kernal.ggfs.hadoop;
 
 import org.apache.commons.logging.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.ggfs.common.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;
 import org.gridgain.grid.util.lang.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopReader.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopReader.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopReader.java
index 4a73fcf..1fedab2 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopReader.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopReader.java
@@ -10,7 +10,7 @@
 package org.gridgain.grid.kernal.ggfs.hadoop;
 
 import org.apache.hadoop.fs.*;
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.util.typedef.internal.*;
 
 import java.io.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java
index 17442fd..e81b17d 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java
@@ -11,8 +11,8 @@ package org.gridgain.grid.kernal.ggfs.hadoop;
 
 import org.apache.hadoop.conf.*;
 import org.apache.hadoop.fs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;
 import org.jetbrains.annotations.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopWrapper.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopWrapper.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopWrapper.java
index cd34dd2..7f2b91a 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopWrapper.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopWrapper.java
@@ -12,8 +12,8 @@ package org.gridgain.grid.kernal.ggfs.hadoop;
 import org.apache.commons.logging.*;
 import org.apache.hadoop.conf.*;
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/fs/GridHadoopDistributedFileSystem.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/fs/GridHadoopDistributedFileSystem.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/fs/GridHadoopDistributedFileSystem.java
index e39153a..171f5ea 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/fs/GridHadoopDistributedFileSystem.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/fs/GridHadoopDistributedFileSystem.java
@@ -17,7 +17,7 @@ import org.apache.hadoop.mapreduce.*;
 import java.io.*;
 import java.net.*;
 
-import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
+import static org.apache.ignite.fs.IgniteFsConfiguration.*;
 
 /**
  * Wrapper of HDFS for support of separated working directory.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/planner/GridHadoopDefaultMapReducePlanner.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/planner/GridHadoopDefaultMapReducePlanner.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/planner/GridHadoopDefaultMapReducePlanner.java
index 74e73a8..2d9358c 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/planner/GridHadoopDefaultMapReducePlanner.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/planner/GridHadoopDefaultMapReducePlanner.java
@@ -11,9 +11,9 @@ package org.gridgain.grid.kernal.processors.hadoop.planner;
 
 import org.apache.ignite.*;
 import org.apache.ignite.cluster.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.resources.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.hadoop.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.ggfs.hadoop.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/client/hadoop/GridHadoopClientProtocolSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/client/hadoop/GridHadoopClientProtocolSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/client/hadoop/GridHadoopClientProtocolSelfTest.java
index 49c4ad9..0576dbb 100644
--- a/modules/hadoop/src/test/java/org/gridgain/client/hadoop/GridHadoopClientProtocolSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/client/hadoop/GridHadoopClientProtocolSelfTest.java
@@ -17,7 +17,7 @@ import org.apache.hadoop.mapreduce.lib.input.*;
 import org.apache.hadoop.mapreduce.lib.output.*;
 import org.apache.hadoop.mapreduce.protocol.*;
 import org.apache.ignite.*;
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.kernal.processors.hadoop.*;
 import org.gridgain.grid.util.lang.*;
 import org.gridgain.grid.util.typedef.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsTestSuite.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsTestSuite.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsTestSuite.java
index b6655ad..78c214f 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsTestSuite.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsTestSuite.java
@@ -12,6 +12,7 @@ package org.gridgain.grid.ggfs;
 import junit.framework.*;
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.ggfs.hadoop.*;
 import org.gridgain.grid.kernal.processors.hadoop.*;
@@ -20,7 +21,7 @@ import org.gridgain.grid.util.ipc.shmem.*;
 import org.gridgain.testframework.*;
 import org.jetbrains.annotations.*;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * Test suite for GGFS event tests.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
index 53fa471..bb683db 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
@@ -15,6 +15,7 @@ import org.apache.hadoop.fs.FileSystem;
 import org.apache.hadoop.fs.permission.*;
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
@@ -41,7 +42,7 @@ import java.util.concurrent.atomic.*;
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
 import static org.apache.ignite.events.IgniteEventType.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * Hadoop 2.x compliant file system.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemLoopbackPrimarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemLoopbackPrimarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemLoopbackPrimarySelfTest.java
index 8040ae2..7da86b0 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemLoopbackPrimarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemLoopbackPrimarySelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 import static org.gridgain.grid.util.ipc.shmem.GridIpcSharedMemoryServerEndpoint.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemShmemPrimarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemShmemPrimarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemShmemPrimarySelfTest.java
index 8b4d071..922702f 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemShmemPrimarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemShmemPrimarySelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 import static org.gridgain.grid.util.ipc.shmem.GridIpcSharedMemoryServerEndpoint.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
index 4952fe7..0a18c5e 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
@@ -13,6 +13,7 @@ import org.apache.hadoop.conf.*;
 import org.apache.hadoop.fs.*;
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.kernal.ggfs.hadoop.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;
@@ -29,7 +30,7 @@ import java.util.concurrent.*;
 
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 import static org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.*;
 import static org.gridgain.grid.kernal.processors.ggfs.GridGgfsAbstractSelfTest.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAsyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAsyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAsyncSelfTest.java
index 88e2977..de224db 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAsyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAsyncSelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * Tests for DUAL_ASYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualSyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualSyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualSyncSelfTest.java
index ede366f..1284a29 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualSyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualSyncSelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * Tests for DUAL_SYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
index d0d7188..4dd3bd3 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
@@ -15,6 +15,7 @@ import org.apache.hadoop.fs.FileSystem;
 import org.apache.hadoop.fs.permission.*;
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
@@ -44,7 +45,7 @@ import java.util.concurrent.atomic.*;
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
 import static org.apache.ignite.events.IgniteEventType.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * Test hadoop file system implementation.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java
index bfb0310..df69163 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java
@@ -11,6 +11,7 @@ package org.gridgain.grid.ggfs;
 
 import org.apache.commons.logging.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.kernal.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
index ce54dfb..981225e 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
@@ -14,6 +14,7 @@ import org.apache.hadoop.fs.FileSystem;
 import org.apache.hadoop.fs.*;
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;
 import org.gridgain.grid.spi.communication.tcp.*;
@@ -31,7 +32,7 @@ import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheDistributionMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
 import static org.gridgain.grid.cache.GridCacheWriteSynchronizationMode.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 import static org.gridgain.grid.kernal.ggfs.hadoop.GridGgfsHadoopUtils.*;
 import static org.gridgain.grid.util.ipc.shmem.GridIpcSharedMemoryServerEndpoint.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemIpcCacheSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemIpcCacheSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemIpcCacheSelfTest.java
index a1a0606..4819bb3 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemIpcCacheSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemIpcCacheSelfTest.java
@@ -12,6 +12,7 @@ package org.gridgain.grid.ggfs;
 import org.apache.hadoop.conf.*;
 import org.apache.hadoop.fs.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.kernal.ggfs.hadoop.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java
index 182dc49..0467d22 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java
@@ -9,6 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.kernal.ggfs.common.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;
 import org.gridgain.grid.util.typedef.internal.*;
@@ -16,7 +17,7 @@ import org.gridgain.grid.util.typedef.internal.*;
 import java.io.*;
 import java.util.*;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 import static org.gridgain.grid.kernal.ggfs.common.GridGgfsLogger.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java
index dabfca9..372150a 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java
@@ -13,6 +13,7 @@ import org.apache.hadoop.conf.*;
 import org.apache.hadoop.fs.FileSystem;
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.ggfs.hadoop.v1.*;
 import org.gridgain.grid.kernal.ggfs.common.*;
@@ -29,7 +30,7 @@ import java.nio.file.*;
 
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 import static org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackAbstractSelfTest.java
index 83cd2b9..17f3fcc 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackAbstractSelfTest.java
@@ -9,6 +9,8 @@
 
 package org.gridgain.grid.ggfs;
 
+import org.apache.ignite.fs.*;
+
 import static org.gridgain.grid.util.ipc.shmem.GridIpcSharedMemoryServerEndpoint.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualAsyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualAsyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualAsyncSelfTest.java
index 2450d73..87d47fd 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualAsyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualAsyncSelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC loopback self test in DUAL_ASYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualSyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualSyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualSyncSelfTest.java
index 76da390..1681ad9 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualSyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualSyncSelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC loopback self test in DUAL_SYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedPrimarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedPrimarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedPrimarySelfTest.java
index 4675501..3bd489f 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedPrimarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedPrimarySelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC loopback self test in PRIMARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedSecondarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedSecondarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedSecondarySelfTest.java
index e914278..cf05e96 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedSecondarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedSecondarySelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC loopback self test in SECONDARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualAsyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualAsyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualAsyncSelfTest.java
index eab8491..eaddfe7 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualAsyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualAsyncSelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC loopback self test in DUAL_ASYNC mode.


[02/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
# Renaming


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

Branch: refs/heads/master
Commit: 2f80979624600eda943cc72d6c423cf1177f9f29
Parents: 27c89de
Author: sboikov <sb...@gridgain.com>
Authored: Fri Dec 5 10:48:13 2014 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Dec 5 10:48:13 2014 +0300

----------------------------------------------------------------------
 .../examples/services/SimpleMapServiceImpl.java |   9 +-
 .../java/org/apache/ignite/IgniteManaged.java   |  36 +--
 .../configuration/IgniteConfiguration.java      |   6 +-
 .../org/apache/ignite/managed/GridService.java  | 115 -------
 .../managed/GridServiceConfiguration.java       | 297 -------------------
 .../ignite/managed/GridServiceContext.java      |  60 ----
 .../ignite/managed/GridServiceDescriptor.java   |  82 -----
 .../apache/ignite/managed/ManagedService.java   | 115 +++++++
 .../managed/ManagedServiceConfiguration.java    | 297 +++++++++++++++++++
 .../ignite/managed/ManagedServiceContext.java   |  60 ++++
 .../managed/ManagedServiceDescriptor.java       |  82 +++++
 .../gridgain/grid/kernal/IgniteManagedImpl.java |  12 +-
 .../resource/GridResourceCustomInjector.java    |   4 +-
 .../resource/GridResourceProcessor.java         |   6 +-
 .../resource/GridResourceServiceInjector.java   |   2 +-
 .../service/GridServiceAssignments.java         |   8 +-
 .../service/GridServiceContextImpl.java         | 148 ---------
 .../service/GridServiceDeployment.java          |   6 +-
 .../service/GridServiceDeploymentFuture.java    |   6 +-
 .../service/GridServiceDescriptorImpl.java      |  93 ------
 .../service/GridServiceProcessor.java           |  72 ++---
 .../processors/service/GridServiceProxy.java    |   8 +-
 .../service/ManagedServiceContextImpl.java      | 148 +++++++++
 .../service/ManagedServiceDescriptorImpl.java   |  93 ++++++
 .../kernal/processors/service/DummyService.java |   8 +-
 .../GridServiceProcessorAbstractSelfTest.java   |  26 +-
 ...ServiceProcessorMultiNodeConfigSelfTest.java |  10 +-
 .../GridServiceProcessorProxySelfTest.java      |  20 +-
 .../resource/GridServiceInjectionSelfTest.java  |  20 +-
 29 files changed, 925 insertions(+), 924 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/examples/src/main/java/org/gridgain/examples/services/SimpleMapServiceImpl.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/gridgain/examples/services/SimpleMapServiceImpl.java b/examples/src/main/java/org/gridgain/examples/services/SimpleMapServiceImpl.java
index dee7512..6427079 100644
--- a/examples/src/main/java/org/gridgain/examples/services/SimpleMapServiceImpl.java
+++ b/examples/src/main/java/org/gridgain/examples/services/SimpleMapServiceImpl.java
@@ -17,7 +17,7 @@ import java.util.concurrent.*;
 /**
  * Simple service which loops infinitely and prints out a counter.
  */
-public class SimpleMapServiceImpl<K, V> implements GridService, SimpleMapService<K, V> {
+public class SimpleMapServiceImpl<K, V> implements ManagedService, SimpleMapService<K, V> {
     /** Serial version UID. */
     private static final long serialVersionUID = 0L;
 
@@ -39,24 +39,25 @@ public class SimpleMapServiceImpl<K, V> implements GridService, SimpleMapService
         map.clear();
     }
 
+    /** {@inheritDoc} */
     @Override public int size() {
         return map.size();
     }
 
     /** {@inheritDoc} */
-    @Override public void cancel(GridServiceContext ctx) {
+    @Override public void cancel(ManagedServiceContext ctx) {
         System.out.println("Service was cancelled: " + ctx.name());
     }
 
     /** {@inheritDoc} */
-    @Override public void init(GridServiceContext ctx) throws Exception {
+    @Override public void init(ManagedServiceContext ctx) throws Exception {
         System.out.println("Service was initialized: " + ctx.name());
 
         map = new ConcurrentHashMap<>();
     }
 
     /** {@inheritDoc} */
-    @Override public void execute(GridServiceContext ctx) throws Exception {
+    @Override public void execute(ManagedServiceContext ctx) throws Exception {
         System.out.println("Executing distributed service: " + ctx.name());
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/apache/ignite/IgniteManaged.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/IgniteManaged.java b/modules/core/src/main/java/org/apache/ignite/IgniteManaged.java
index 61dc6e9..44fe314 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteManaged.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteManaged.java
@@ -135,7 +135,7 @@ public interface IgniteManaged extends IgniteAsyncSupport {
      * when a singleton service instance will be active on more than one node (e.g. crash detection delay).
      * <p>
      * This method is analogous to calling
-     * {@link #deployMultiple(String, org.apache.ignite.managed.GridService, int, int) deployMultiple(name, svc, 1, 1)} method.
+     * {@link #deployMultiple(String, org.apache.ignite.managed.ManagedService, int, int) deployMultiple(name, svc, 1, 1)} method.
      * <p>
      * Supports asynchronous execution (see {@link IgniteAsyncSupport}).
      *
@@ -143,7 +143,7 @@ public interface IgniteManaged extends IgniteAsyncSupport {
      * @param svc Service instance.
      * @throws GridException If failed to deploy service.
      */
-    public void deployClusterSingleton(String name, GridService svc) throws GridException;
+    public void deployClusterSingleton(String name, ManagedService svc) throws GridException;
 
     /**
      * Deploys a per-node singleton service. GridGain will guarantee that there is always
@@ -152,7 +152,7 @@ public interface IgniteManaged extends IgniteAsyncSupport {
      * the service on every new node.
      * <p>
      * This method is analogous to calling
-     * {@link #deployMultiple(String, GridService, int, int) deployMultiple(name, svc, 0, 1)} method.
+     * {@link #deployMultiple(String, org.apache.ignite.managed.ManagedService, int, int) deployMultiple(name, svc, 0, 1)} method.
      * <p>
      * Supports asynchronous execution (see {@link IgniteAsyncSupport}).
      *
@@ -160,7 +160,7 @@ public interface IgniteManaged extends IgniteAsyncSupport {
      * @param svc Service instance.
      * @throws GridException If failed to deploy service.
      */
-    public void deployNodeSingleton(String name, GridService svc) throws GridException;
+    public void deployNodeSingleton(String name, ManagedService svc) throws GridException;
 
     /**
      * Deploys one instance of this service on the primary node for a given affinity key.
@@ -171,7 +171,7 @@ public interface IgniteManaged extends IgniteAsyncSupport {
      * Note that in case of topology changes, due to network delays, there may be a temporary situation
      * when a service instance will be active on more than one node (e.g. crash detection delay).
      * <p>
-     * This method is analogous to the invocation of {@link #deploy(GridServiceConfiguration)} method
+     * This method is analogous to the invocation of {@link #deploy(org.apache.ignite.managed.ManagedServiceConfiguration)} method
      * as follows:
      * <pre name="code" class="java">
      *     GridServiceConfiguration cfg = new GridServiceConfiguration();
@@ -195,7 +195,7 @@ public interface IgniteManaged extends IgniteAsyncSupport {
      * @param affKey Affinity cache key.
      * @throws GridException If failed to deploy service.
      */
-    public void deployKeyAffinitySingleton(String name, GridService svc, @Nullable String cacheName, Object affKey)
+    public void deployKeyAffinitySingleton(String name, ManagedService svc, @Nullable String cacheName, Object affKey)
         throws GridException;
 
     /**
@@ -209,7 +209,7 @@ public interface IgniteManaged extends IgniteAsyncSupport {
      * Note that at least one of {@code 'totalCnt'} or {@code 'maxPerNodeCnt'} parameters must have
      * value greater than {@code 0}.
      * <p>
-     * This method is analogous to the invocation of {@link #deploy(GridServiceConfiguration)} method
+     * This method is analogous to the invocation of {@link #deploy(org.apache.ignite.managed.ManagedServiceConfiguration)} method
      * as follows:
      * <pre name="code" class="java">
      *     GridServiceConfiguration cfg = new GridServiceConfiguration();
@@ -230,22 +230,22 @@ public interface IgniteManaged extends IgniteAsyncSupport {
      * @param maxPerNodeCnt Maximum number of deployed services on each node, {@code 0} for unlimited.
      * @throws GridException If failed to deploy service.
      */
-    public void deployMultiple(String name, GridService svc, int totalCnt, int maxPerNodeCnt) throws GridException;
+    public void deployMultiple(String name, ManagedService svc, int totalCnt, int maxPerNodeCnt) throws GridException;
 
     /**
      * Deploys multiple instances of the service on the grid according to provided
      * configuration. GridGain will deploy a maximum amount of services equal to
-     * {@link GridServiceConfiguration#getTotalCount() cfg.getTotalCount()}  parameter
-     * making sure that there are no more than {@link GridServiceConfiguration#getMaxPerNodeCount() cfg.getMaxPerNodeCount()}
+     * {@link org.apache.ignite.managed.ManagedServiceConfiguration#getTotalCount() cfg.getTotalCount()}  parameter
+     * making sure that there are no more than {@link org.apache.ignite.managed.ManagedServiceConfiguration#getMaxPerNodeCount() cfg.getMaxPerNodeCount()}
      * service instances running on each node. Whenever topology changes, GridGain will automatically rebalance
      * the deployed services within cluster to make sure that each node will end up with
      * about equal number of deployed instances whenever possible.
      * <p>
-     * If {@link GridServiceConfiguration#getAffinityKey() cfg.getAffinityKey()} is not {@code null}, then GridGain
+     * If {@link org.apache.ignite.managed.ManagedServiceConfiguration#getAffinityKey() cfg.getAffinityKey()} is not {@code null}, then GridGain
      * will deploy the service on the primary node for given affinity key. The affinity will be calculated
-     * on the cache with {@link GridServiceConfiguration#getCacheName() cfg.getCacheName()} name.
+     * on the cache with {@link org.apache.ignite.managed.ManagedServiceConfiguration#getCacheName() cfg.getCacheName()} name.
      * <p>
-     * If {@link GridServiceConfiguration#getNodeFilter() cfg.getNodeFilter()} is not {@code null}, then
+     * If {@link org.apache.ignite.managed.ManagedServiceConfiguration#getNodeFilter() cfg.getNodeFilter()} is not {@code null}, then
      * GridGain will deploy service on all grid nodes for which the provided filter evaluates to {@code true}.
      * The node filter will be checked in addition to the underlying grid projection filter, or the
      * whole grid, if the underlying grid projection includes all grid nodes.
@@ -270,14 +270,14 @@ public interface IgniteManaged extends IgniteAsyncSupport {
      * @param cfg Service configuration.
      * @throws GridException If failed to deploy service.
      */
-    public void deploy(GridServiceConfiguration cfg) throws GridException;
+    public void deploy(ManagedServiceConfiguration cfg) throws GridException;
 
     /**
      * Cancels service deployment. If a service with specified name was deployed on the grid,
-     * then {@link GridService#cancel(GridServiceContext)} method will be called on it.
+     * then {@link org.apache.ignite.managed.ManagedService#cancel(org.apache.ignite.managed.ManagedServiceContext)} method will be called on it.
      * <p>
-     * Note that GridGain cannot guarantee that the service exits from {@link GridService#execute(GridServiceContext)}
-     * method whenever {@link GridService#cancel(GridServiceContext)} is called. It is up to the user to
+     * Note that GridGain cannot guarantee that the service exits from {@link org.apache.ignite.managed.ManagedService#execute(org.apache.ignite.managed.ManagedServiceContext)}
+     * method whenever {@link org.apache.ignite.managed.ManagedService#cancel(org.apache.ignite.managed.ManagedServiceContext)} is called. It is up to the user to
      * make sure that the service code properly reacts to cancellations.
      * <p>
      * Supports asynchronous execution (see {@link IgniteAsyncSupport}).
@@ -304,7 +304,7 @@ public interface IgniteManaged extends IgniteAsyncSupport {
      *
      * @return Metadata about all deployed services.
      */
-    public Collection<GridServiceDescriptor> deployedServices();
+    public Collection<ManagedServiceDescriptor> deployedServices();
 
     /**
      * Gets deployed service with specified name.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java b/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
index c8a7a52..1d40d13 100644
--- a/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
@@ -526,7 +526,7 @@ public class IgniteConfiguration {
     private GridSecurityCredentialsProvider securityCred;
 
     /** Service configuration. */
-    private GridServiceConfiguration[] svcCfgs;
+    private ManagedServiceConfiguration[] svcCfgs;
 
     /** Hadoop configuration. */
     private GridHadoopConfiguration hadoopCfg;
@@ -3143,7 +3143,7 @@ public class IgniteConfiguration {
      *
      * @return Configurations for services to be deployed on the grid.
      */
-    public GridServiceConfiguration[] getServiceConfiguration() {
+    public ManagedServiceConfiguration[] getServiceConfiguration() {
         return svcCfgs;
     }
 
@@ -3152,7 +3152,7 @@ public class IgniteConfiguration {
      *
      * @param svcCfgs Configurations for services to be deployed on the grid.
      */
-    public void setServiceConfiguration(GridServiceConfiguration... svcCfgs) {
+    public void setServiceConfiguration(ManagedServiceConfiguration... svcCfgs) {
         this.svcCfgs = svcCfgs;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/apache/ignite/managed/GridService.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/managed/GridService.java b/modules/core/src/main/java/org/apache/ignite/managed/GridService.java
deleted file mode 100644
index fe15233..0000000
--- a/modules/core/src/main/java/org/apache/ignite/managed/GridService.java
+++ /dev/null
@@ -1,115 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.managed;
-
-import java.io.*;
-
-/**
- * An instance of grid-managed service. Grid-managed services may be deployed from
- * {@link org.apache.ignite.IgniteManaged} facade or directly from grid configuration at startup.
- * <h1 class="header">Deployment</h1>
- * Whenever service is deployed, GridGain will automatically calculate how many
- * instances of this service should be deployed on each node within the cluster.
- * Whenever service is deployed on a cluster node, GridGain will call
- * {@link #execute(GridServiceContext)} method on that service. It is up to the user
- * to control whenever the service should exit from the {@code execute} method.
- * For example, user may choose to implement service as follows:
- * <pre name="code" class="java">
- * public class MyGridService implements GridService {
- *      ...
- *      // Example of grid resource injection. All resources are optional.
- *      // You should inject resources only as needed.
- *      &#64;GridInstanceResource
- *      private Grid grid;
- *      ...
- *      &#64;Override public void cancel(GridServiceContext ctx) {
- *          // No-op.
- *      }
- *
- *      &#64;Override public void execute(GridServiceContext ctx) {
- *          // Loop until service is cancelled.
- *          while (!ctx.isCancelled()) {
- *              // Do something.
- *              ...
- *          }
- *      }
- *  }
- * </pre>
- * Consecutively, this service can be deployed as follows:
- * <pre name="code" class="java">
- * ...
- * GridServices svcs = grid.services();
- *
- * GridFuture&lt;?&gt; fut = svcs.deployClusterSingleton("mySingleton", new MyGridService());
- *
- * // Wait for deployment to complete.
- * fut.get();
- * </pre>
- * Or from grid configuration on startup:
- * <pre name="code" class="java">
- * GridConfiguration gridCfg = new GridConfiguration();
- *
- * GridServiceConfiguration svcCfg = new GridServiceConfiguration();
- *
- * // Configuration for cluster-singleton service.
- * svcCfg.setName("mySingleton");
- * svcCfg.setMaxPerNodeCount(1);
- * svcCfg.setTotalCount(1);
- * svcCfg.setService(new MyGridService());
- *
- * gridCfg.setServiceConfiguration(svcCfg);
- * ...
- * GridGain.start(gridCfg);
- * </pre>
- * <h1 class="header">Cancellation</h1>
- * Services can be cancelled by calling any of the {@code cancel} methods on {@link org.apache.ignite.IgniteManaged} API.
- * Whenever a deployed service is cancelled, GridGain will automatically call
- * {@link GridService#cancel(GridServiceContext)} method on that service.
- * <p>
- * Note that GridGain cannot guarantee that the service exits from {@link GridService#execute(GridServiceContext)}
- * method whenever {@link #cancel(GridServiceContext)} is called. It is up to the user to
- * make sure that the service code properly reacts to cancellations.
- */
-public interface GridService extends Serializable {
-    /**
-     * Cancels this service. GridGain will automatically call this method whenever any of the
-     * {@code cancel} methods on {@link org.apache.ignite.IgniteManaged} API are called.
-     * <p>
-     * Note that GridGain cannot guarantee that the service exits from {@link #execute(GridServiceContext)}
-     * method whenever {@code cancel(GridServiceContext)} method is called. It is up to the user to
-     * make sure that the service code properly reacts to cancellations.
-     *
-     * @param ctx Service execution context.
-     */
-    public void cancel(GridServiceContext ctx);
-
-    /**
-     * Pre-initializes service before execution. This method is guaranteed to be called before
-     * service deployment is complete (this guarantees that this method will be called
-     * before method {@link #execute(GridServiceContext)} is called).
-     *
-     * @param ctx Service execution context.
-     * @throws Exception If service initialization failed.
-     */
-    public void init(GridServiceContext ctx) throws Exception;
-
-    /**
-     * Starts execution of this service. This method is automatically invoked whenever an instance of the service
-     * is deployed on a grid node. Note that service is considered deployed even after it exits the {@code execute}
-     * method and can be cancelled (or undeployed) only by calling any of the {@code cancel} methods on
-     * {@link org.apache.ignite.IgniteManaged} API. Also note that service is not required to exit from {@code execute} method until
-     * {@link #cancel(GridServiceContext)} method was called.
-     *
-     * @param ctx Service execution context.
-     * @throws Exception If service execution failed. Not that service will still remain deployed, until
-     *      {@link org.apache.ignite.IgniteManaged#cancel(String)} method will be called.
-     */
-    public void execute(GridServiceContext ctx) throws Exception;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/apache/ignite/managed/GridServiceConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/managed/GridServiceConfiguration.java b/modules/core/src/main/java/org/apache/ignite/managed/GridServiceConfiguration.java
deleted file mode 100644
index 90f1049..0000000
--- a/modules/core/src/main/java/org/apache/ignite/managed/GridServiceConfiguration.java
+++ /dev/null
@@ -1,297 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.managed;
-
-import org.apache.ignite.cluster.*;
-import org.apache.ignite.lang.*;
-import org.gridgain.grid.util.tostring.*;
-import org.gridgain.grid.util.typedef.internal.*;
-
-import java.io.*;
-
-/**
- * Managed service configuration. In addition to deploying managed services by
- * calling any of the provided {@code deploy(...)} methods, managed services
- * can also be automatically deployed on startup by specifying them in {@link org.apache.ignite.configuration.IgniteConfiguration}
- * like so:
- * <pre name="code" class="java">
- * GridConfiguration gridCfg = new GridConfiguration();
- *
- * GridServiceConfiguration svcCfg1 = new GridServiceConfiguration();
- *
- * svcCfg1.setName("myClusterSingletonService");
- * svcCfg1.setMaxPerNodeCount(1);
- * svcCfg1.setTotalCount(1);
- * svcCfg1.setService(new MyClusterSingletonService());
- *
- * GridServiceConfiguration svcCfg2 = new GridServiceConfiguration();
- *
- * svcCfg2.setName("myNodeSingletonService");
- * svcCfg2.setMaxPerNodeCount(1);
- * svcCfg2.setService(new MyNodeSingletonService());
- *
- * gridCfg.setServiceConfiguration(svcCfg1, svcCfg2);
- * ...
- * GridGain.start(gridCfg);
- * </pre>
- * The above configuration can also be specified in a Spring configuration file.
- */
-public class GridServiceConfiguration implements Serializable {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** Service name. */
-    private String name;
-
-    /** Service instance. */
-    @GridToStringExclude
-    private GridService svc;
-
-    /** Total count. */
-    private int totalCnt;
-
-    /** Max per-node count. */
-    private int maxPerNodeCnt;
-
-    /** Cache name. */
-    private String cacheName;
-
-    /** Affinity key. */
-    private Object affKey;
-
-    /** Node filter. */
-    @GridToStringExclude
-    private IgnitePredicate<ClusterNode> nodeFilter;
-
-    /**
-     * Gets service name.
-     * <p>
-     * This parameter is mandatory when deploying a service.
-     *
-     * @return Service name.
-     */
-    public String getName() {
-        return name;
-    }
-
-    /**
-     * Sets service name.
-     * <p>
-     * This parameter is mandatory when deploying a service.
-     *
-     * @param name Service name.
-     */
-    public void setName(String name) {
-        this.name = name;
-    }
-
-    /**
-     * Gets service instance.
-     * <p>
-     * This parameter is mandatory when deploying a service.
-     *
-     * @return Service instance.
-     */
-    public GridService getService() {
-        return svc;
-    }
-
-    /**
-     * Sets service instance.
-     * <p>
-     * This parameter is mandatory when deploying a service.
-     *
-     * @param svc Service instance.
-     */
-    public void setService(GridService svc) {
-        this.svc = svc;
-    }
-
-    /**
-     * Gets total number of deployed service instances in the cluster, {@code 0} for unlimited.
-     * <p>
-     * At least one of {@code getTotalCount()} or {@link #getMaxPerNodeCount()} values must be positive.
-     *
-     * @return Total number of deployed service instances in the cluster, {@code 0} for unlimited.
-     */
-    public int getTotalCount() {
-        return totalCnt;
-    }
-
-    /**
-     * Sets total number of deployed service instances in the cluster, {@code 0} for unlimited.
-     * <p>
-     * At least one of {@code getTotalCount()} or {@link #getMaxPerNodeCount()} values must be positive.
-     *
-     * @param totalCnt Total number of deployed service instances in the cluster, {@code 0} for unlimited.
-     */
-    public void setTotalCount(int totalCnt) {
-        this.totalCnt = totalCnt;
-    }
-
-    /**
-     * Gets maximum number of deployed service instances on each node, {@code 0} for unlimited.
-     * <p>
-     * At least one of {@code getMaxPerNodeCount()} or {@link #getTotalCount()} values must be positive.
-     *
-     * @return Maximum number of deployed service instances on each node, {@code 0} for unlimited.
-     */
-    public int getMaxPerNodeCount() {
-        return maxPerNodeCnt;
-    }
-
-    /**
-     * Sets maximum number of deployed service instances on each node, {@code 0} for unlimited.
-     * <p>
-     * At least one of {@code getMaxPerNodeCount()} or {@link #getTotalCount()} values must be positive.
-     *
-     * @param maxPerNodeCnt Maximum number of deployed service instances on each node, {@code 0} for unlimited.
-     */
-    public void setMaxPerNodeCount(int maxPerNodeCnt) {
-        this.maxPerNodeCnt = maxPerNodeCnt;
-    }
-
-    /**
-     * Gets cache name used for key-to-node affinity calculation.
-     * <p>
-     * This parameter is optional and is set only when deploying service based on key-affinity.
-     *
-     * @return Cache name, possibly {@code null}.
-     */
-    public String getCacheName() {
-        return cacheName;
-    }
-
-    /**
-     * Sets cache name used for key-to-node affinity calculation.
-     * <p>
-     * This parameter is optional and is set only when deploying service based on key-affinity.
-     *
-     * @param cacheName Cache name, possibly {@code null}.
-     */
-    public void setCacheName(String cacheName) {
-        this.cacheName = cacheName;
-    }
-
-    /**
-     * Gets affinity key used for key-to-node affinity calculation.
-     * <p>
-     * This parameter is optional and is set only when deploying service based on key-affinity.
-     *
-     * @return Affinity key, possibly {@code null}.
-     */
-    public Object getAffinityKey() {
-        return affKey;
-    }
-
-    /**
-     * Sets affinity key used for key-to-node affinity calculation.
-     * <p>
-     * This parameter is optional and is set only when deploying service based on key-affinity.
-     *
-     * @param affKey Affinity key, possibly {@code null}.
-     */
-    public void setAffinityKey(Object affKey) {
-        this.affKey = affKey;
-    }
-
-    /**
-     * Gets node filter used to filter nodes on which the service will be deployed.
-     * <p>
-     * This parameter is optional. If not provided service may be deployed on any or all
-     * nodes in the grid, based on configuration.
-     *
-     * @return Node filter used to filter nodes on which the service will be deployed, possibly {@code null}.
-     */
-    public IgnitePredicate<ClusterNode> getNodeFilter() {
-        return nodeFilter;
-    }
-
-    /**
-     * Sets node filter used to filter nodes on which the service will be deployed.
-     * <p>
-     * This parameter is optional. If not provided service may be deployed on any or all
-     * nodes in the grid, based on configuration.
-     *
-     * @param nodeFilter Node filter used to filter nodes on which the service will be deployed, possibly {@code null}.
-     */
-    public void setNodeFilter(IgnitePredicate<ClusterNode> nodeFilter) {
-        this.nodeFilter = nodeFilter;
-    }
-
-    /** {@inheritDoc} */
-    @SuppressWarnings({"RedundantIfStatement", "EqualsWhichDoesntCheckParameterClass"})
-    @Override public boolean equals(Object o) {
-        if (!equalsIgnoreNodeFilter(o))
-            return false;
-
-        GridServiceConfiguration that = (GridServiceConfiguration)o;
-
-        if (nodeFilter != null && that.nodeFilter != null) {
-            if (!nodeFilter.getClass().equals(that.nodeFilter.getClass()))
-                return false;
-        }
-        else if (nodeFilter != null || that.nodeFilter != null)
-            return false;
-
-        return true;
-    }
-
-    /**
-     * Checks if configurations are equal ignoring the node filter. Node filters control on which
-     * nodes the services are deployed and often can be ignored for equality checks.
-     *
-     * @param o Other configuration.
-     * @return {@code True} if configurations are equal, {@code false} otherwise.
-     */
-    @SuppressWarnings("RedundantIfStatement")
-    public boolean equalsIgnoreNodeFilter(Object o) {
-        if (this == o)
-            return true;
-
-        if (o == null || getClass() != o.getClass())
-            return false;
-
-        GridServiceConfiguration that = (GridServiceConfiguration)o;
-
-        if (maxPerNodeCnt != that.maxPerNodeCnt)
-            return false;
-
-        if (totalCnt != that.totalCnt)
-            return false;
-
-        if (affKey != null ? !affKey.equals(that.affKey) : that.affKey != null)
-            return false;
-
-        if (cacheName != null ? !cacheName.equals(that.cacheName) : that.cacheName != null)
-            return false;
-
-        if (name != null ? !name.equals(that.name) : that.name != null)
-            return false;
-
-        if (svc != null ? !svc.getClass().equals(that.svc.getClass()) : that.svc != null)
-            return false;
-
-        return true;
-    }
-
-    /** {@inheritDoc} */
-    @Override public int hashCode() {
-        return name == null ? 0 : name.hashCode();
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        String svcCls = svc == null ? "" : svc.getClass().getSimpleName();
-        String nodeFilterCls = nodeFilter == null ? "" : nodeFilter.getClass().getSimpleName();
-
-        return S.toString(GridServiceConfiguration.class, this, "svcCls", svcCls, "nodeFilterCls", nodeFilterCls);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/apache/ignite/managed/GridServiceContext.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/managed/GridServiceContext.java b/modules/core/src/main/java/org/apache/ignite/managed/GridServiceContext.java
deleted file mode 100644
index 946599d..0000000
--- a/modules/core/src/main/java/org/apache/ignite/managed/GridServiceContext.java
+++ /dev/null
@@ -1,60 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.managed;
-
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-import java.util.*;
-
-/**
- * Service execution context. Execution context is provided into {@link GridService#execute(GridServiceContext)}
- * and {@link GridService#cancel(GridServiceContext)} methods and contains information about specific service
- * execution.
- */
-public interface GridServiceContext extends Serializable {
-    /**
-     * Gets service name.
-     *
-     * @return Service name.
-     */
-    public String name();
-
-    /**
-     * Gets service execution ID. Execution ID is guaranteed to be unique across
-     * all service deployments.
-     *
-     * @return Service execution ID.
-     */
-    public UUID executionId();
-
-    /**
-     * Get flag indicating whether service has been cancelled or not.
-     *
-     * @return Flag indicating whether service has been cancelled or not.
-     */
-    public boolean isCancelled();
-
-    /**
-     * Gets cache name used for key-to-node affinity calculation. This parameter is optional
-     * and is set only when key-affinity service was deployed.
-     *
-     * @return Cache name, possibly {@code null}.
-     */
-    @Nullable public String cacheName();
-
-    /**
-     * Gets affinity key used for key-to-node affinity calculation. This parameter is optional
-     * and is set only when key-affinity service was deployed.
-     *
-     * @return Affinity key, possibly {@code null}.
-     */
-    @Nullable public <K> K affinityKey();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/apache/ignite/managed/GridServiceDescriptor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/managed/GridServiceDescriptor.java b/modules/core/src/main/java/org/apache/ignite/managed/GridServiceDescriptor.java
deleted file mode 100644
index eecf4dc..0000000
--- a/modules/core/src/main/java/org/apache/ignite/managed/GridServiceDescriptor.java
+++ /dev/null
@@ -1,82 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.managed;
-
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-import java.util.*;
-
-/**
- * Service deployment descriptor. Contains all service deployment configuration, and also
- * deployment topology snapshot as well as origin node ID.
- * <p>
- * Service descriptors can be retrieved by calling {@link org.apache.ignite.IgniteManaged#deployedServices()} method.
- */
-public interface GridServiceDescriptor extends Serializable {
-    /**
-     * Gets service name.
-     *
-     * @return Service name.
-     */
-    public String name();
-
-    /**
-     * Gets service class.
-     *
-     * @return Service class.
-     */
-    public Class<? extends GridService> serviceClass();
-
-    /**
-     * Gets maximum allowed total number of deployed services in the grid, {@code 0} for unlimited.
-     *
-     * @return Maximum allowed total number of deployed services in the grid, {@code 0} for unlimited.
-     */
-    public int totalCount();
-
-    /**
-     * Gets maximum allowed number of deployed services on each node, {@code 0} for unlimited.
-     *
-     * @return Maximum allowed total number of deployed services on each node, {@code 0} for unlimited.
-     */
-    public int maxPerNodeCount();
-
-    /**
-     * Gets cache name used for key-to-node affinity calculation. This parameter is optional
-     * and is set only when key-affinity service was deployed.
-     *
-     * @return Cache name, possibly {@code null}.
-     */
-    @Nullable public String cacheName();
-
-    /**
-     * Gets affinity key used for key-to-node affinity calculation. This parameter is optional
-     * and is set only when key-affinity service was deployed.
-     *
-     * @return Affinity key, possibly {@code null}.
-     */
-    @Nullable public <K> K affinityKey();
-
-    /**
-     * Gets ID of grid node that initiated the service deployment.
-     *
-     * @return ID of grid node that initiated the service deployment.
-     */
-    public UUID originNodeId();
-
-    /**
-     * Gets service deployment topology snapshot. Service topology snapshot is represented
-     * by number of service instances deployed on a node mapped to node ID.
-     *
-     * @return Map of number of service instances per node ID.
-     */
-    public Map<UUID, Integer> topologySnapshot();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/apache/ignite/managed/ManagedService.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/managed/ManagedService.java b/modules/core/src/main/java/org/apache/ignite/managed/ManagedService.java
new file mode 100644
index 0000000..110d5f1
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/managed/ManagedService.java
@@ -0,0 +1,115 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.managed;
+
+import java.io.*;
+
+/**
+ * An instance of grid-managed service. Grid-managed services may be deployed from
+ * {@link org.apache.ignite.IgniteManaged} facade or directly from grid configuration at startup.
+ * <h1 class="header">Deployment</h1>
+ * Whenever service is deployed, GridGain will automatically calculate how many
+ * instances of this service should be deployed on each node within the cluster.
+ * Whenever service is deployed on a cluster node, GridGain will call
+ * {@link #execute(ManagedServiceContext)} method on that service. It is up to the user
+ * to control whenever the service should exit from the {@code execute} method.
+ * For example, user may choose to implement service as follows:
+ * <pre name="code" class="java">
+ * public class MyGridService implements GridService {
+ *      ...
+ *      // Example of grid resource injection. All resources are optional.
+ *      // You should inject resources only as needed.
+ *      &#64;GridInstanceResource
+ *      private Grid grid;
+ *      ...
+ *      &#64;Override public void cancel(GridServiceContext ctx) {
+ *          // No-op.
+ *      }
+ *
+ *      &#64;Override public void execute(GridServiceContext ctx) {
+ *          // Loop until service is cancelled.
+ *          while (!ctx.isCancelled()) {
+ *              // Do something.
+ *              ...
+ *          }
+ *      }
+ *  }
+ * </pre>
+ * Consecutively, this service can be deployed as follows:
+ * <pre name="code" class="java">
+ * ...
+ * GridServices svcs = grid.services();
+ *
+ * GridFuture&lt;?&gt; fut = svcs.deployClusterSingleton("mySingleton", new MyGridService());
+ *
+ * // Wait for deployment to complete.
+ * fut.get();
+ * </pre>
+ * Or from grid configuration on startup:
+ * <pre name="code" class="java">
+ * GridConfiguration gridCfg = new GridConfiguration();
+ *
+ * GridServiceConfiguration svcCfg = new GridServiceConfiguration();
+ *
+ * // Configuration for cluster-singleton service.
+ * svcCfg.setName("mySingleton");
+ * svcCfg.setMaxPerNodeCount(1);
+ * svcCfg.setTotalCount(1);
+ * svcCfg.setService(new MyGridService());
+ *
+ * gridCfg.setServiceConfiguration(svcCfg);
+ * ...
+ * GridGain.start(gridCfg);
+ * </pre>
+ * <h1 class="header">Cancellation</h1>
+ * Services can be cancelled by calling any of the {@code cancel} methods on {@link org.apache.ignite.IgniteManaged} API.
+ * Whenever a deployed service is cancelled, GridGain will automatically call
+ * {@link ManagedService#cancel(ManagedServiceContext)} method on that service.
+ * <p>
+ * Note that GridGain cannot guarantee that the service exits from {@link ManagedService#execute(ManagedServiceContext)}
+ * method whenever {@link #cancel(ManagedServiceContext)} is called. It is up to the user to
+ * make sure that the service code properly reacts to cancellations.
+ */
+public interface ManagedService extends Serializable {
+    /**
+     * Cancels this service. GridGain will automatically call this method whenever any of the
+     * {@code cancel} methods on {@link org.apache.ignite.IgniteManaged} API are called.
+     * <p>
+     * Note that GridGain cannot guarantee that the service exits from {@link #execute(ManagedServiceContext)}
+     * method whenever {@code cancel(GridServiceContext)} method is called. It is up to the user to
+     * make sure that the service code properly reacts to cancellations.
+     *
+     * @param ctx Service execution context.
+     */
+    public void cancel(ManagedServiceContext ctx);
+
+    /**
+     * Pre-initializes service before execution. This method is guaranteed to be called before
+     * service deployment is complete (this guarantees that this method will be called
+     * before method {@link #execute(ManagedServiceContext)} is called).
+     *
+     * @param ctx Service execution context.
+     * @throws Exception If service initialization failed.
+     */
+    public void init(ManagedServiceContext ctx) throws Exception;
+
+    /**
+     * Starts execution of this service. This method is automatically invoked whenever an instance of the service
+     * is deployed on a grid node. Note that service is considered deployed even after it exits the {@code execute}
+     * method and can be cancelled (or undeployed) only by calling any of the {@code cancel} methods on
+     * {@link org.apache.ignite.IgniteManaged} API. Also note that service is not required to exit from {@code execute} method until
+     * {@link #cancel(ManagedServiceContext)} method was called.
+     *
+     * @param ctx Service execution context.
+     * @throws Exception If service execution failed. Not that service will still remain deployed, until
+     *      {@link org.apache.ignite.IgniteManaged#cancel(String)} method will be called.
+     */
+    public void execute(ManagedServiceContext ctx) throws Exception;
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/apache/ignite/managed/ManagedServiceConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/managed/ManagedServiceConfiguration.java b/modules/core/src/main/java/org/apache/ignite/managed/ManagedServiceConfiguration.java
new file mode 100644
index 0000000..985bdc5
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/managed/ManagedServiceConfiguration.java
@@ -0,0 +1,297 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.managed;
+
+import org.apache.ignite.cluster.*;
+import org.apache.ignite.lang.*;
+import org.gridgain.grid.util.tostring.*;
+import org.gridgain.grid.util.typedef.internal.*;
+
+import java.io.*;
+
+/**
+ * Managed service configuration. In addition to deploying managed services by
+ * calling any of the provided {@code deploy(...)} methods, managed services
+ * can also be automatically deployed on startup by specifying them in {@link org.apache.ignite.configuration.IgniteConfiguration}
+ * like so:
+ * <pre name="code" class="java">
+ * GridConfiguration gridCfg = new GridConfiguration();
+ *
+ * GridServiceConfiguration svcCfg1 = new GridServiceConfiguration();
+ *
+ * svcCfg1.setName("myClusterSingletonService");
+ * svcCfg1.setMaxPerNodeCount(1);
+ * svcCfg1.setTotalCount(1);
+ * svcCfg1.setService(new MyClusterSingletonService());
+ *
+ * GridServiceConfiguration svcCfg2 = new GridServiceConfiguration();
+ *
+ * svcCfg2.setName("myNodeSingletonService");
+ * svcCfg2.setMaxPerNodeCount(1);
+ * svcCfg2.setService(new MyNodeSingletonService());
+ *
+ * gridCfg.setServiceConfiguration(svcCfg1, svcCfg2);
+ * ...
+ * GridGain.start(gridCfg);
+ * </pre>
+ * The above configuration can also be specified in a Spring configuration file.
+ */
+public class ManagedServiceConfiguration implements Serializable {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** Service name. */
+    private String name;
+
+    /** Service instance. */
+    @GridToStringExclude
+    private ManagedService svc;
+
+    /** Total count. */
+    private int totalCnt;
+
+    /** Max per-node count. */
+    private int maxPerNodeCnt;
+
+    /** Cache name. */
+    private String cacheName;
+
+    /** Affinity key. */
+    private Object affKey;
+
+    /** Node filter. */
+    @GridToStringExclude
+    private IgnitePredicate<ClusterNode> nodeFilter;
+
+    /**
+     * Gets service name.
+     * <p>
+     * This parameter is mandatory when deploying a service.
+     *
+     * @return Service name.
+     */
+    public String getName() {
+        return name;
+    }
+
+    /**
+     * Sets service name.
+     * <p>
+     * This parameter is mandatory when deploying a service.
+     *
+     * @param name Service name.
+     */
+    public void setName(String name) {
+        this.name = name;
+    }
+
+    /**
+     * Gets service instance.
+     * <p>
+     * This parameter is mandatory when deploying a service.
+     *
+     * @return Service instance.
+     */
+    public ManagedService getService() {
+        return svc;
+    }
+
+    /**
+     * Sets service instance.
+     * <p>
+     * This parameter is mandatory when deploying a service.
+     *
+     * @param svc Service instance.
+     */
+    public void setService(ManagedService svc) {
+        this.svc = svc;
+    }
+
+    /**
+     * Gets total number of deployed service instances in the cluster, {@code 0} for unlimited.
+     * <p>
+     * At least one of {@code getTotalCount()} or {@link #getMaxPerNodeCount()} values must be positive.
+     *
+     * @return Total number of deployed service instances in the cluster, {@code 0} for unlimited.
+     */
+    public int getTotalCount() {
+        return totalCnt;
+    }
+
+    /**
+     * Sets total number of deployed service instances in the cluster, {@code 0} for unlimited.
+     * <p>
+     * At least one of {@code getTotalCount()} or {@link #getMaxPerNodeCount()} values must be positive.
+     *
+     * @param totalCnt Total number of deployed service instances in the cluster, {@code 0} for unlimited.
+     */
+    public void setTotalCount(int totalCnt) {
+        this.totalCnt = totalCnt;
+    }
+
+    /**
+     * Gets maximum number of deployed service instances on each node, {@code 0} for unlimited.
+     * <p>
+     * At least one of {@code getMaxPerNodeCount()} or {@link #getTotalCount()} values must be positive.
+     *
+     * @return Maximum number of deployed service instances on each node, {@code 0} for unlimited.
+     */
+    public int getMaxPerNodeCount() {
+        return maxPerNodeCnt;
+    }
+
+    /**
+     * Sets maximum number of deployed service instances on each node, {@code 0} for unlimited.
+     * <p>
+     * At least one of {@code getMaxPerNodeCount()} or {@link #getTotalCount()} values must be positive.
+     *
+     * @param maxPerNodeCnt Maximum number of deployed service instances on each node, {@code 0} for unlimited.
+     */
+    public void setMaxPerNodeCount(int maxPerNodeCnt) {
+        this.maxPerNodeCnt = maxPerNodeCnt;
+    }
+
+    /**
+     * Gets cache name used for key-to-node affinity calculation.
+     * <p>
+     * This parameter is optional and is set only when deploying service based on key-affinity.
+     *
+     * @return Cache name, possibly {@code null}.
+     */
+    public String getCacheName() {
+        return cacheName;
+    }
+
+    /**
+     * Sets cache name used for key-to-node affinity calculation.
+     * <p>
+     * This parameter is optional and is set only when deploying service based on key-affinity.
+     *
+     * @param cacheName Cache name, possibly {@code null}.
+     */
+    public void setCacheName(String cacheName) {
+        this.cacheName = cacheName;
+    }
+
+    /**
+     * Gets affinity key used for key-to-node affinity calculation.
+     * <p>
+     * This parameter is optional and is set only when deploying service based on key-affinity.
+     *
+     * @return Affinity key, possibly {@code null}.
+     */
+    public Object getAffinityKey() {
+        return affKey;
+    }
+
+    /**
+     * Sets affinity key used for key-to-node affinity calculation.
+     * <p>
+     * This parameter is optional and is set only when deploying service based on key-affinity.
+     *
+     * @param affKey Affinity key, possibly {@code null}.
+     */
+    public void setAffinityKey(Object affKey) {
+        this.affKey = affKey;
+    }
+
+    /**
+     * Gets node filter used to filter nodes on which the service will be deployed.
+     * <p>
+     * This parameter is optional. If not provided service may be deployed on any or all
+     * nodes in the grid, based on configuration.
+     *
+     * @return Node filter used to filter nodes on which the service will be deployed, possibly {@code null}.
+     */
+    public IgnitePredicate<ClusterNode> getNodeFilter() {
+        return nodeFilter;
+    }
+
+    /**
+     * Sets node filter used to filter nodes on which the service will be deployed.
+     * <p>
+     * This parameter is optional. If not provided service may be deployed on any or all
+     * nodes in the grid, based on configuration.
+     *
+     * @param nodeFilter Node filter used to filter nodes on which the service will be deployed, possibly {@code null}.
+     */
+    public void setNodeFilter(IgnitePredicate<ClusterNode> nodeFilter) {
+        this.nodeFilter = nodeFilter;
+    }
+
+    /** {@inheritDoc} */
+    @SuppressWarnings({"RedundantIfStatement", "EqualsWhichDoesntCheckParameterClass"})
+    @Override public boolean equals(Object o) {
+        if (!equalsIgnoreNodeFilter(o))
+            return false;
+
+        ManagedServiceConfiguration that = (ManagedServiceConfiguration)o;
+
+        if (nodeFilter != null && that.nodeFilter != null) {
+            if (!nodeFilter.getClass().equals(that.nodeFilter.getClass()))
+                return false;
+        }
+        else if (nodeFilter != null || that.nodeFilter != null)
+            return false;
+
+        return true;
+    }
+
+    /**
+     * Checks if configurations are equal ignoring the node filter. Node filters control on which
+     * nodes the services are deployed and often can be ignored for equality checks.
+     *
+     * @param o Other configuration.
+     * @return {@code True} if configurations are equal, {@code false} otherwise.
+     */
+    @SuppressWarnings("RedundantIfStatement")
+    public boolean equalsIgnoreNodeFilter(Object o) {
+        if (this == o)
+            return true;
+
+        if (o == null || getClass() != o.getClass())
+            return false;
+
+        ManagedServiceConfiguration that = (ManagedServiceConfiguration)o;
+
+        if (maxPerNodeCnt != that.maxPerNodeCnt)
+            return false;
+
+        if (totalCnt != that.totalCnt)
+            return false;
+
+        if (affKey != null ? !affKey.equals(that.affKey) : that.affKey != null)
+            return false;
+
+        if (cacheName != null ? !cacheName.equals(that.cacheName) : that.cacheName != null)
+            return false;
+
+        if (name != null ? !name.equals(that.name) : that.name != null)
+            return false;
+
+        if (svc != null ? !svc.getClass().equals(that.svc.getClass()) : that.svc != null)
+            return false;
+
+        return true;
+    }
+
+    /** {@inheritDoc} */
+    @Override public int hashCode() {
+        return name == null ? 0 : name.hashCode();
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        String svcCls = svc == null ? "" : svc.getClass().getSimpleName();
+        String nodeFilterCls = nodeFilter == null ? "" : nodeFilter.getClass().getSimpleName();
+
+        return S.toString(ManagedServiceConfiguration.class, this, "svcCls", svcCls, "nodeFilterCls", nodeFilterCls);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/apache/ignite/managed/ManagedServiceContext.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/managed/ManagedServiceContext.java b/modules/core/src/main/java/org/apache/ignite/managed/ManagedServiceContext.java
new file mode 100644
index 0000000..61b585e
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/managed/ManagedServiceContext.java
@@ -0,0 +1,60 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.managed;
+
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+import java.util.*;
+
+/**
+ * Service execution context. Execution context is provided into {@link ManagedService#execute(ManagedServiceContext)}
+ * and {@link ManagedService#cancel(ManagedServiceContext)} methods and contains information about specific service
+ * execution.
+ */
+public interface ManagedServiceContext extends Serializable {
+    /**
+     * Gets service name.
+     *
+     * @return Service name.
+     */
+    public String name();
+
+    /**
+     * Gets service execution ID. Execution ID is guaranteed to be unique across
+     * all service deployments.
+     *
+     * @return Service execution ID.
+     */
+    public UUID executionId();
+
+    /**
+     * Get flag indicating whether service has been cancelled or not.
+     *
+     * @return Flag indicating whether service has been cancelled or not.
+     */
+    public boolean isCancelled();
+
+    /**
+     * Gets cache name used for key-to-node affinity calculation. This parameter is optional
+     * and is set only when key-affinity service was deployed.
+     *
+     * @return Cache name, possibly {@code null}.
+     */
+    @Nullable public String cacheName();
+
+    /**
+     * Gets affinity key used for key-to-node affinity calculation. This parameter is optional
+     * and is set only when key-affinity service was deployed.
+     *
+     * @return Affinity key, possibly {@code null}.
+     */
+    @Nullable public <K> K affinityKey();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/apache/ignite/managed/ManagedServiceDescriptor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/managed/ManagedServiceDescriptor.java b/modules/core/src/main/java/org/apache/ignite/managed/ManagedServiceDescriptor.java
new file mode 100644
index 0000000..39d3ca5
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/managed/ManagedServiceDescriptor.java
@@ -0,0 +1,82 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.managed;
+
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+import java.util.*;
+
+/**
+ * Service deployment descriptor. Contains all service deployment configuration, and also
+ * deployment topology snapshot as well as origin node ID.
+ * <p>
+ * Service descriptors can be retrieved by calling {@link org.apache.ignite.IgniteManaged#deployedServices()} method.
+ */
+public interface ManagedServiceDescriptor extends Serializable {
+    /**
+     * Gets service name.
+     *
+     * @return Service name.
+     */
+    public String name();
+
+    /**
+     * Gets service class.
+     *
+     * @return Service class.
+     */
+    public Class<? extends ManagedService> serviceClass();
+
+    /**
+     * Gets maximum allowed total number of deployed services in the grid, {@code 0} for unlimited.
+     *
+     * @return Maximum allowed total number of deployed services in the grid, {@code 0} for unlimited.
+     */
+    public int totalCount();
+
+    /**
+     * Gets maximum allowed number of deployed services on each node, {@code 0} for unlimited.
+     *
+     * @return Maximum allowed total number of deployed services on each node, {@code 0} for unlimited.
+     */
+    public int maxPerNodeCount();
+
+    /**
+     * Gets cache name used for key-to-node affinity calculation. This parameter is optional
+     * and is set only when key-affinity service was deployed.
+     *
+     * @return Cache name, possibly {@code null}.
+     */
+    @Nullable public String cacheName();
+
+    /**
+     * Gets affinity key used for key-to-node affinity calculation. This parameter is optional
+     * and is set only when key-affinity service was deployed.
+     *
+     * @return Affinity key, possibly {@code null}.
+     */
+    @Nullable public <K> K affinityKey();
+
+    /**
+     * Gets ID of grid node that initiated the service deployment.
+     *
+     * @return ID of grid node that initiated the service deployment.
+     */
+    public UUID originNodeId();
+
+    /**
+     * Gets service deployment topology snapshot. Service topology snapshot is represented
+     * by number of service instances deployed on a node mapped to node ID.
+     *
+     * @return Map of number of service instances per node ID.
+     */
+    public Map<UUID, Integer> topologySnapshot();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/gridgain/grid/kernal/IgniteManagedImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/IgniteManagedImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/IgniteManagedImpl.java
index 49bb06e..1ebd44e 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/IgniteManagedImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/IgniteManagedImpl.java
@@ -58,7 +58,7 @@ public class IgniteManagedImpl extends IgniteAsyncSupportAdapter implements Igni
     }
 
     /** {@inheritDoc} */
-    @Override public void deployNodeSingleton(String name, GridService svc) throws GridException {
+    @Override public void deployNodeSingleton(String name, ManagedService svc) throws GridException {
         A.notNull(name, "name");
         A.notNull(svc, "svc");
 
@@ -73,7 +73,7 @@ public class IgniteManagedImpl extends IgniteAsyncSupportAdapter implements Igni
     }
 
     /** {@inheritDoc} */
-    @Override public void deployClusterSingleton(String name, GridService svc) throws GridException {
+    @Override public void deployClusterSingleton(String name, ManagedService svc) throws GridException {
         A.notNull(name, "name");
         A.notNull(svc, "svc");
 
@@ -88,7 +88,7 @@ public class IgniteManagedImpl extends IgniteAsyncSupportAdapter implements Igni
     }
 
     /** {@inheritDoc} */
-    @Override public void deployMultiple(String name, GridService svc, int totalCnt, int maxPerNodeCnt)
+    @Override public void deployMultiple(String name, ManagedService svc, int totalCnt, int maxPerNodeCnt)
         throws GridException {
         A.notNull(name, "name");
         A.notNull(svc, "svc");
@@ -104,7 +104,7 @@ public class IgniteManagedImpl extends IgniteAsyncSupportAdapter implements Igni
     }
 
     /** {@inheritDoc} */
-    @Override public void deployKeyAffinitySingleton(String name, GridService svc, @Nullable String cacheName,
+    @Override public void deployKeyAffinitySingleton(String name, ManagedService svc, @Nullable String cacheName,
         Object affKey) throws GridException {
         A.notNull(name, "name");
         A.notNull(svc, "svc");
@@ -121,7 +121,7 @@ public class IgniteManagedImpl extends IgniteAsyncSupportAdapter implements Igni
     }
 
     /** {@inheritDoc} */
-    @Override public void deploy(GridServiceConfiguration cfg) throws GridException {
+    @Override public void deploy(ManagedServiceConfiguration cfg) throws GridException {
         A.notNull(cfg, "cfg");
 
         guard();
@@ -161,7 +161,7 @@ public class IgniteManagedImpl extends IgniteAsyncSupportAdapter implements Igni
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridServiceDescriptor> deployedServices() {
+    @Override public Collection<ManagedServiceDescriptor> deployedServices() {
         guard();
 
         try {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/gridgain/grid/kernal/processors/resource/GridResourceCustomInjector.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/resource/GridResourceCustomInjector.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/resource/GridResourceCustomInjector.java
index 5805a48..3e3b40a 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/resource/GridResourceCustomInjector.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/resource/GridResourceCustomInjector.java
@@ -71,7 +71,7 @@ class GridResourceCustomInjector implements GridResourceInjector {
     private GridResourceBasicInjector<IgniteLogger> logInjector;
 
     /** Service injector. */
-    private GridResourceBasicInjector<Collection<GridService>> srvcInjector;
+    private GridResourceBasicInjector<Collection<ManagedService>> srvcInjector;
 
     /** Spring bean resources injector. */
     private GridResourceInjector springBeanInjector;
@@ -194,7 +194,7 @@ class GridResourceCustomInjector implements GridResourceInjector {
      *
      * @param srvcInjector Service injector.
      */
-    public void setSrvcInjector(GridResourceBasicInjector<Collection<GridService>> srvcInjector) {
+    public void setSrvcInjector(GridResourceBasicInjector<Collection<ManagedService>> srvcInjector) {
         this.srvcInjector = srvcInjector;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/gridgain/grid/kernal/processors/resource/GridResourceProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/resource/GridResourceProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/resource/GridResourceProcessor.java
index f2dbbde..26a744d 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/resource/GridResourceProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/resource/GridResourceProcessor.java
@@ -102,7 +102,7 @@ public class GridResourceProcessor extends GridProcessorAdapter {
     private GridResourceBasicInjector<IgniteLogger> logInjector;
 
     /** Services injector. */
-    private GridResourceBasicInjector<Collection<GridService>> srvcInjector;
+    private GridResourceBasicInjector<Collection<ManagedService>> srvcInjector;
 
     /** Address resolver injector. */
     private GridResourceBasicInjector<GridAddressResolver> addrsRslvrInjector;
@@ -618,7 +618,7 @@ public class GridResourceProcessor extends GridProcessorAdapter {
      * @param svc Service to inject.
      * @throws GridException If failed.
      */
-    public void inject(GridService svc) throws GridException {
+    public void inject(ManagedService svc) throws GridException {
         if (log.isDebugEnabled())
             log.debug("Injecting resources: " + svc);
 
@@ -647,7 +647,7 @@ public class GridResourceProcessor extends GridProcessorAdapter {
      * @param svc Service.
      * @throws GridException Thrown in case of any errors.
      */
-    public void cleanup(GridService svc) throws GridException {
+    public void cleanup(ManagedService svc) throws GridException {
         if (log.isDebugEnabled())
             log.debug("Cleaning up resources: " + svc);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/gridgain/grid/kernal/processors/resource/GridResourceServiceInjector.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/resource/GridResourceServiceInjector.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/resource/GridResourceServiceInjector.java
index 51290c9..dd4daa0 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/resource/GridResourceServiceInjector.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/resource/GridResourceServiceInjector.java
@@ -20,7 +20,7 @@ import java.util.*;
 /**
  * Grid service injector.
  */
-public class GridResourceServiceInjector extends GridResourceBasicInjector<Collection<GridService>> {
+public class GridResourceServiceInjector extends GridResourceBasicInjector<Collection<ManagedService>> {
     /** */
     private Ignite ignite;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceAssignments.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceAssignments.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceAssignments.java
index b9d89a6..34a942c 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceAssignments.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceAssignments.java
@@ -33,7 +33,7 @@ public class GridServiceAssignments implements Serializable, GridCacheInternal {
     private final long topVer;
 
     /** Service configuration. */
-    private final GridServiceConfiguration cfg;
+    private final ManagedServiceConfiguration cfg;
 
     /** Assignments. */
     @GridToStringInclude
@@ -44,7 +44,7 @@ public class GridServiceAssignments implements Serializable, GridCacheInternal {
      * @param nodeId Node ID.
      * @param topVer Topology version.
      */
-    public GridServiceAssignments(GridServiceConfiguration cfg, UUID nodeId, long topVer) {
+    public GridServiceAssignments(ManagedServiceConfiguration cfg, UUID nodeId, long topVer) {
         this.cfg = cfg;
         this.nodeId = nodeId;
         this.topVer = topVer;
@@ -53,7 +53,7 @@ public class GridServiceAssignments implements Serializable, GridCacheInternal {
     /**
      * @return Configuration.
      */
-    public GridServiceConfiguration configuration() {
+    public ManagedServiceConfiguration configuration() {
         return cfg;
     }
 
@@ -67,7 +67,7 @@ public class GridServiceAssignments implements Serializable, GridCacheInternal {
     /**
      * @return Service.
      */
-    public GridService service() {
+    public ManagedService service() {
         return cfg.getService();
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceContextImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceContextImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceContextImpl.java
deleted file mode 100644
index 91fb26b..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceContextImpl.java
+++ /dev/null
@@ -1,148 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.kernal.processors.service;
-
-import org.apache.ignite.managed.*;
-import org.gridgain.grid.util.tostring.*;
-import org.gridgain.grid.util.typedef.internal.*;
-import org.jetbrains.annotations.*;
-
-import java.lang.reflect.*;
-import java.util.*;
-import java.util.concurrent.*;
-
-/**
- * Service context implementation.
- */
-public class GridServiceContextImpl implements GridServiceContext {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** Null method. */
-    private static final Method NULL_METHOD = GridServiceContextImpl.class.getMethods()[0];
-
-    /** Service name. */
-    private final String name;
-
-    /** Execution ID. */
-    private final UUID execId;
-
-    /** Cache name. */
-    private final String cacheName;
-
-    /** Affinity key. */
-    private final Object affKey;
-
-    /** Service. */
-    @GridToStringExclude
-    private final GridService svc;
-
-    /** Executor service. */
-    @GridToStringExclude
-    private final ExecutorService exe;
-
-    /** Methods reflection cache. */
-    private final ConcurrentMap<GridServiceMethodReflectKey, Method> mtds = new ConcurrentHashMap<>();
-
-    /** Cancelled flag. */
-    private volatile boolean isCancelled;
-
-
-    /**
-     * @param name Service name.
-     * @param execId Execution ID.
-     * @param cacheName Cache name.
-     * @param affKey Affinity key.
-     * @param svc Service.
-     * @param exe Executor service.
-     */
-    GridServiceContextImpl(String name, UUID execId, String cacheName, Object affKey, GridService svc,
-        ExecutorService exe) {
-        this.name = name;
-        this.execId = execId;
-        this.cacheName = cacheName;
-        this.affKey = affKey;
-        this.svc = svc;
-        this.exe = exe;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String name() {
-        return name;
-    }
-
-    /** {@inheritDoc} */
-    @Override public UUID executionId() {
-        return execId;
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean isCancelled() {
-        return isCancelled;
-    }
-
-    /** {@inheritDoc} */
-    @Nullable @Override public String cacheName() {
-        return cacheName;
-    }
-
-    /** {@inheritDoc} */
-    @SuppressWarnings("unchecked")
-    @Nullable @Override public <K> K affinityKey() {
-        return (K)affKey;
-    }
-
-    /**
-     * @return Service instance.
-     */
-    GridService service() {
-        return svc;
-    }
-
-    /**
-     * @return Executor service.
-     */
-    ExecutorService executor() {
-        return exe;
-    }
-
-    /**
-     * @param key Method key.
-     * @return Method.
-     */
-    @Nullable Method method(GridServiceMethodReflectKey key) {
-        Method mtd = mtds.get(key);
-
-        if (mtd == null) {
-            try {
-                mtd = svc.getClass().getMethod(key.methodName(), key.argTypes());
-            }
-            catch (NoSuchMethodException e) {
-                mtd = NULL_METHOD;
-            }
-
-            mtds.put(key, mtd);
-        }
-
-        return mtd == NULL_METHOD ? null : mtd;
-    }
-
-    /**
-     * @param isCancelled Cancelled flag.
-     */
-    public void setCancelled(boolean isCancelled) {
-        this.isCancelled = isCancelled;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridServiceContextImpl.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceDeployment.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceDeployment.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceDeployment.java
index 2ff84e7..62c3fa2 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceDeployment.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceDeployment.java
@@ -27,13 +27,13 @@ public class GridServiceDeployment implements GridCacheInternal, Serializable {
     private UUID nodeId;
 
     /** Service configuration. */
-    private GridServiceConfiguration cfg;
+    private ManagedServiceConfiguration cfg;
 
     /**
      * @param nodeId Node ID.
      * @param cfg Service configuration.
      */
-    public GridServiceDeployment(UUID nodeId, GridServiceConfiguration cfg) {
+    public GridServiceDeployment(UUID nodeId, ManagedServiceConfiguration cfg) {
         this.nodeId = nodeId;
         this.cfg = cfg;
     }
@@ -48,7 +48,7 @@ public class GridServiceDeployment implements GridCacheInternal, Serializable {
     /**
      * @return Service configuration.
      */
-    public GridServiceConfiguration configuration() {
+    public ManagedServiceConfiguration configuration() {
         return cfg;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceDeploymentFuture.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceDeploymentFuture.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceDeploymentFuture.java
index 02e9343..e495909 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceDeploymentFuture.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceDeploymentFuture.java
@@ -22,13 +22,13 @@ public class GridServiceDeploymentFuture extends GridFutureAdapter<Object> {
     private static final long serialVersionUID = 0L;
 
     /** */
-    private final GridServiceConfiguration cfg;
+    private final ManagedServiceConfiguration cfg;
 
     /**
      * @param ctx Context.
      * @param cfg Configuration.
      */
-    public GridServiceDeploymentFuture(GridKernalContext ctx, GridServiceConfiguration cfg) {
+    public GridServiceDeploymentFuture(GridKernalContext ctx, ManagedServiceConfiguration cfg) {
         super(ctx);
 
         this.cfg = cfg;
@@ -37,7 +37,7 @@ public class GridServiceDeploymentFuture extends GridFutureAdapter<Object> {
     /**
      * @return Service configuration.
      */
-    GridServiceConfiguration configuration() {
+    ManagedServiceConfiguration configuration() {
         return cfg;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2f809796/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceDescriptorImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceDescriptorImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceDescriptorImpl.java
deleted file mode 100644
index 1a904ce..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceDescriptorImpl.java
+++ /dev/null
@@ -1,93 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.kernal.processors.service;
-
-import org.apache.ignite.managed.*;
-import org.gridgain.grid.util.tostring.*;
-import org.gridgain.grid.util.typedef.internal.*;
-import org.jetbrains.annotations.*;
-
-import java.util.*;
-
-/**
- * Service descriptor.
- */
-public class GridServiceDescriptorImpl implements GridServiceDescriptor {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** Configuration. */
-    @GridToStringInclude
-    private final GridServiceDeployment dep;
-
-    /** Topology snapshot. */
-    @GridToStringInclude
-    private Map<UUID, Integer> top;
-
-    /**
-     * @param dep Deployment.
-     */
-    public GridServiceDescriptorImpl(GridServiceDeployment dep) {
-        this.dep = dep;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String name() {
-        return dep.configuration().getName();
-    }
-
-    /** {@inheritDoc} */
-    @Override public Class<? extends GridService> serviceClass() {
-        return dep.configuration().getService().getClass();
-    }
-
-    /** {@inheritDoc} */
-    @Override public int totalCount() {
-        return dep.configuration().getTotalCount();
-    }
-
-    /** {@inheritDoc} */
-    @Override public int maxPerNodeCount() {
-        return dep.configuration().getMaxPerNodeCount();
-    }
-
-    /** {@inheritDoc} */
-    @Nullable @Override public String cacheName() {
-        return dep.configuration().getCacheName();
-    }
-
-    /** {@inheritDoc} */
-    @SuppressWarnings("unchecked")
-    @Nullable @Override public <K> K affinityKey() {
-        return (K)dep.configuration().getAffinityKey();
-    }
-
-    /** {@inheritDoc} */
-    @Override public UUID originNodeId() {
-        return dep.nodeId();
-    }
-
-    /** {@inheritDoc} */
-    @Override public Map<UUID, Integer> topologySnapshot() {
-        return top;
-    }
-
-    /**
-     * @param top Topology snapshot.
-     */
-    void topologySnapshot(Map<UUID, Integer> top) {
-        this.top = top;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridServiceDescriptorImpl.class, this);
-    }
-}


[30/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInputStream.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInputStream.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInputStream.java
deleted file mode 100644
index 8fb669e..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInputStream.java
+++ /dev/null
@@ -1,72 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import java.io.*;
-
-/**
- * {@code GGFS} input stream to read data from the file system.
- * It provides several additional methods for asynchronous access.
- */
-public abstract class IgniteFsInputStream extends InputStream implements IgniteFsReader {
-    /**
-     * Gets file length during file open.
-     *
-     * @return File length.
-     */
-    public abstract long length();
-
-    /**
-     * Seek to the specified position.
-     *
-     * @param pos Position to seek to.
-     * @throws IOException In case of IO exception.
-     */
-    public abstract void seek(long pos) throws IOException;
-
-    /**
-     * Get the current position in the input stream.
-     *
-     * @return The current position in the input stream.
-     * @throws IOException In case of IO exception.
-     */
-    public abstract long position() throws IOException;
-
-    /**
-     * Read bytes from the given position in the stream to the given buffer.
-     * Continues to read until passed buffer becomes filled.
-     *
-     * @param pos Position in the input stream to seek.
-     * @param buf Buffer into which data is read.
-     * @throws IOException In case of IO exception.
-     */
-    public abstract void readFully(long pos, byte[] buf) throws IOException;
-
-    /**
-     *
-     * @param pos Position in the input stream to seek.
-     * @param buf Buffer into which data is read.
-     * @param off Offset in the buffer from which stream data should be written.
-     * @param len The number of bytes to read.
-     * @throws IOException In case of IO exception.
-     */
-    public abstract void readFully(long pos, byte[] buf, int off, int len) throws IOException;
-
-    /**
-     *
-     * @param pos Position in the input stream to seek.
-     * @param buf Buffer into which data is read.
-     * @param off Offset in the buffer from which stream data should be written.
-     * @param len The number of bytes to read.
-     * @return Total number of bytes read into the buffer, or -1 if there is no more data (EOF).
-     * @throws IOException In case of IO exception.
-     */
-    @Override public abstract int read(long pos, byte[] buf, int off, int len) throws IOException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInvalidHdfsVersionException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInvalidHdfsVersionException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInvalidHdfsVersionException.java
deleted file mode 100644
index 7004311..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInvalidHdfsVersionException.java
+++ /dev/null
@@ -1,34 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-/**
- * Exception thrown when GridGain detects that remote HDFS version differs from version of HDFS libraries
- * in GridGain classpath.
- */
-public class IgniteFsInvalidHdfsVersionException extends IgniteFsException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * @param msg Error message.
-     */
-    public IgniteFsInvalidHdfsVersionException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * @param msg Error message.
-     * @param cause Error cause.
-     */
-    public IgniteFsInvalidHdfsVersionException(String msg, Throwable cause) {
-        super(msg, cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInvalidPathException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInvalidPathException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInvalidPathException.java
deleted file mode 100644
index 0e7fe00..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInvalidPathException.java
+++ /dev/null
@@ -1,49 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.jetbrains.annotations.*;
-
-/**
- * {@code GGFS} exception indicating that operation target is invalid
- * (e.g. not a file while expecting to be a file).
- */
-public class IgniteFsInvalidPathException extends IgniteFsException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Creates exception with given error message.
-     *
-     * @param msg Error message.
-     */
-    public IgniteFsInvalidPathException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * Creates exception with given exception cause.
-     *
-     * @param cause Exception cause.
-     */
-    public IgniteFsInvalidPathException(Throwable cause) {
-        super(cause);
-    }
-
-    /**
-     * Creates exception with given error message and exception cause.
-     *
-     * @param msg Error message.
-     * @param cause Error cause.
-     */
-    public IgniteFsInvalidPathException(String msg, @Nullable Throwable cause) {
-        super(msg, cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsMetrics.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsMetrics.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsMetrics.java
deleted file mode 100644
index d4f7fc6..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsMetrics.java
+++ /dev/null
@@ -1,151 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-/**
- * {@code GGFS} metrics snapshot for the file system. Note, that some metrics are global and
- * some are local (i.e. per each node).
- */
-public interface IgniteFsMetrics {
-    /**
-     * Gets local used space in bytes. This is the sum of all file chunks stored on local node.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Node used space in bytes.
-     */
-    public long localSpaceSize();
-
-    /**
-     * Gets maximum amount of data that can be stored on local node. This metrics is either
-     * equal to {@link IgniteFsConfiguration#getMaxSpaceSize()}, or, if it is {@code 0}, equal to
-     * {@code 80%} of maximum heap size allocated for JVM.
-     *
-     * @return Maximum GGFS local space size.
-     */
-    public long maxSpaceSize();
-
-    /**
-    * Get used space in bytes used in the secondary file system.
-    * <p>
-    * This is a global metric.
-    *
-    * @return Used space in the secondary file system or {@code 0} in case no secondary file system is configured.
-    */
-    public long secondarySpaceSize();
-
-    /**
-     * Gets number of directories created in file system.
-     * <p>
-     * This is a global metric.
-     *
-     * @return Number of directories.
-     */
-    public int directoriesCount();
-
-    /**
-     * Gets number of files stored in file system.
-     * <p>
-     * This is a global metric.
-     *
-     * @return Number of files.
-     */
-    public int filesCount();
-
-    /**
-     * Gets number of files that are currently opened for reading.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Number of opened files.
-     */
-    public int filesOpenedForRead();
-
-    /**
-     * Gets number of files that are currently opened for writing.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Number of opened files.
-     */
-    public int filesOpenedForWrite();
-
-    /**
-     * Gets total blocks read, local and remote.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Total blocks read.
-     */
-    public long blocksReadTotal();
-
-    /**
-     * Gets total remote blocks read.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Total blocks remote read.
-     */
-    public long blocksReadRemote();
-
-    /**
-     * Gets total blocks written, local and remote.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Total blocks written.
-     */
-    public long blocksWrittenTotal();
-
-    /**
-     * Gets total remote blocks written.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Total blocks written.
-     */
-    public long blocksWrittenRemote();
-
-    /**
-     * Gets total bytes read.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Total bytes read.
-     */
-    public long bytesRead();
-
-    /**
-     * Gets total bytes read time.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Total bytes read time.
-     */
-    public long bytesReadTime();
-
-    /**
-     * Gets total bytes written.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Total bytes written.
-     */
-    public long bytesWritten();
-
-    /**
-     * Gets total bytes write time.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Total bytes write time.
-     */
-    public long bytesWriteTime();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsMode.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsMode.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsMode.java
deleted file mode 100644
index 67f5eef..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsMode.java
+++ /dev/null
@@ -1,72 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.jetbrains.annotations.*;
-
-/**
- * {@code GGFS} mode defining interactions with underlying secondary Hadoop file system.
- * Secondary Hadoop file system is provided for pass-through, write-through, and
- * read-through purposes.
- * <p>
- * This mode is configured via {@link IgniteFsConfiguration#getDefaultMode()}
- * configuration property.
- */
-public enum IgniteFsMode {
-    /**
-     * In this mode GGFS will not delegate to secondary Hadoop file system and will
-     * cache all the files in memory only.
-     */
-    PRIMARY,
-
-    /**
-     * In this mode GGFS will not cache any files in memory and will only pass them
-     * through to secondary Hadoop file system. If this mode is enabled, then
-     * secondary Hadoop file system must be configured.
-     *
-     * @see IgniteFsConfiguration#getSecondaryHadoopFileSystemUri()
-     */
-    PROXY,
-
-    /**
-     * In this mode {@code GGFS} will cache files locally and also <i>synchronously</i>
-     * write them through to secondary Hadoop file system.
-     * <p>
-     * If secondary Hadoop file system is not configured, then this mode behaves like
-     * {@link #PRIMARY} mode.
-     *
-     * @see IgniteFsConfiguration#getSecondaryHadoopFileSystemUri()
-     */
-    DUAL_SYNC,
-
-    /**
-     * In this mode {@code GGFS} will cache files locally and also <i>asynchronously</i>
-     * write them through to secondary Hadoop file system.
-     * <p>
-     * If secondary Hadoop file system is not configured, then this mode behaves like
-     * {@link #PRIMARY} mode.
-     *
-     * @see IgniteFsConfiguration#getSecondaryHadoopFileSystemUri()
-     */
-    DUAL_ASYNC;
-
-    /** Enumerated values. */
-    private static final IgniteFsMode[] VALS = values();
-
-    /**
-     * Efficiently gets enumerated value from its ordinal.
-     *
-     * @param ord Ordinal value.
-     * @return Enumerated value or {@code null} if ordinal out of range.
-     */
-    @Nullable public static IgniteFsMode fromOrdinal(int ord) {
-        return ord >= 0 && ord < VALS.length ? VALS[ord] : null;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsOutOfSpaceException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsOutOfSpaceException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsOutOfSpaceException.java
deleted file mode 100644
index cdfee59..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsOutOfSpaceException.java
+++ /dev/null
@@ -1,50 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.jetbrains.annotations.*;
-
-/**
- * {@code GGFS} exception that is thrown when it detected out-of-space condition.
- * It is thrown when number of writes written to a {@code GGFS} data nodes exceeds
- * its maximum value (that is configured per-node).
- */
-public class IgniteFsOutOfSpaceException extends IgniteFsException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Creates exception with given error message.
-     *
-     * @param msg Error message.
-     */
-    public IgniteFsOutOfSpaceException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * Creates an instance of exception with given exception cause.
-     *
-     * @param cause Exception cause.
-     */
-    public IgniteFsOutOfSpaceException(Throwable cause) {
-        super(cause);
-    }
-
-    /**
-     * Creates an instance of GGFS exception with given error message and given exception cause.
-     *
-     * @param msg Error message.
-     * @param cause Exception cause.
-     */
-    public IgniteFsOutOfSpaceException(String msg, @Nullable Throwable cause) {
-        super(msg, cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsOutputStream.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsOutputStream.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsOutputStream.java
deleted file mode 100644
index 76c6b1f..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsOutputStream.java
+++ /dev/null
@@ -1,27 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import java.io.*;
-
-/**
- * {@code GGFS} output stream to write data into the file system.
- */
-public abstract class IgniteFsOutputStream extends OutputStream {
-    /**
-     * Transfers specified amount of bytes from data input to this output stream.
-     * This method is optimized to avoid unnecessary temporal buffer creation and byte array copy.
-     *
-     * @param in Data input to copy bytes from.
-     * @param len Data length to copy.
-     * @throws IOException If write failed, read from input failed or there is no enough data in data input.
-     */
-    public abstract void transferFrom(DataInput in, int len) throws IOException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsParentNotDirectoryException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsParentNotDirectoryException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsParentNotDirectoryException.java
deleted file mode 100644
index 9cc46b7..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsParentNotDirectoryException.java
+++ /dev/null
@@ -1,42 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.jetbrains.annotations.*;
-
-/**
- * Exception thrown when parent supposed to be a directory is a file.
- */
-public class IgniteFsParentNotDirectoryException extends IgniteFsInvalidPathException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * @param msg Error message.
-     */
-    public IgniteFsParentNotDirectoryException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * @param cause Exception cause.
-     */
-    public IgniteFsParentNotDirectoryException(Throwable cause) {
-        super(cause);
-    }
-
-    /**
-     * @param msg Error message.
-     * @param cause Exception cause.
-     */
-    public IgniteFsParentNotDirectoryException(String msg, @Nullable Throwable cause) {
-        super(msg, cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPath.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPath.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPath.java
deleted file mode 100644
index aa321b3..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPath.java
+++ /dev/null
@@ -1,254 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.gridgain.grid.util.io.*;
-import org.gridgain.grid.util.typedef.*;
-import org.gridgain.grid.util.typedef.internal.*;
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-import java.net.*;
-import java.util.*;
-
-/**
- * {@code GGFS} path to file in the file system. For example, to get information about
- * a file you would use the following code:
- * <pre name="code" class="java">
- *     GridGgfsPath dirPath = new GridGgfsPath("/my/working/dir");
- *     GridGgfsPath filePath = new GridGgfsPath(dirPath, "file.txt");
- *
- *     // Get metadata about file.
- *     GridGgfsFile file = ggfs.info(filePath);
- * </pre>
- */
-public final class IgniteFsPath implements Comparable<IgniteFsPath>, Externalizable {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** The directory separator character. */
-    private static final char SLASH_CHAR = '/';
-
-    /** The directory separator. */
-    private static final String SLASH = "/";
-
-    /** URI representing this path. Should never change after object creation or de-serialization. */
-    private String path;
-
-    /**
-     * Constructs default root path.
-     */
-    public IgniteFsPath() {
-        path = SLASH;
-    }
-
-    /**
-     * Constructs a path from an URI
-     *
-     * @param uri URI to create path from.
-     */
-    public IgniteFsPath(URI uri) {
-        A.notNull(uri, "uri");
-
-        path = normalizePath(uri.getPath());
-    }
-
-    /**
-     * Constructs a path from the URI string.
-     *
-     * @param path URI string.
-     */
-    public IgniteFsPath(String path) {
-        A.ensure(!F.isEmpty(path), "'path' is null or empty");
-
-        this.path = normalizePath(path);
-    }
-
-    /**
-     * Resolve a child path against a parent path.
-     *
-     * @param parentPath Parent path.
-     * @param childPath Child path.
-     */
-    public IgniteFsPath(IgniteFsPath parentPath, String childPath) {
-        A.notNull(parentPath, "parentPath");
-
-        String path = GridFilenameUtils.concat(parentPath.path, childPath);
-
-        if (F.isEmpty(path))
-            throw new IllegalArgumentException("Failed to parse path" +
-                " [parent=" + parentPath + ", childPath=" + childPath + ']');
-
-        this.path = normalizePath(path);
-    }
-
-    /**
-     * Initialize path with (1) not-null, (2) normalized, (3) absolute and (4) unix-format path component.
-     *
-     * @param path Path.
-     * @return Normalized path.
-     */
-    private static String normalizePath(String path) {
-        assert path != null;
-
-        String normalizedPath = GridFilenameUtils.normalizeNoEndSeparator(path, true);
-
-        if (F.isEmpty(normalizedPath))
-            throw new IllegalArgumentException("Failed to normalize path: " + path);
-
-        if (!SLASH.equals(GridFilenameUtils.getPrefix(normalizedPath)))
-            throw new IllegalArgumentException("Path should be absolute: " + path);
-
-        assert !normalizedPath.isEmpty() : "Expects normalized path is not empty.";
-        assert normalizedPath.length() == 1 || !normalizedPath.endsWith(SLASH) :
-            "Expects normalized path is root or don't ends with '/' symbol.";
-
-        return normalizedPath;
-    }
-
-    /**
-     * Returns the final component of this path.
-     *
-     * @return The final component of this path.
-     */
-    public String name() {
-        return GridFilenameUtils.getName(path);
-    }
-
-    /**
-     * Returns a root for this path.
-     *
-     * @return Root for this path.
-     */
-    public IgniteFsPath root() {
-        return new IgniteFsPath();
-    }
-
-    /**
-     * Split full path on components.
-     *
-     * @return Path components.
-     */
-    public List<String> components() {
-        String path = this.path;
-
-        assert path.length() >= 1 : "Path expected to be absolute: " + path;
-
-        // Path is short-living object, so we don't need to cache component's resolution result.
-        return path.length() == 1 ? Collections.<String>emptyList() : Arrays.asList(path.substring(1).split(SLASH));
-    }
-
-    /**
-     * Returns the parent of a path or {@code null} if at root.
-     *
-     * @return The parent of a path or {@code null} if at root.
-     */
-    @Nullable public IgniteFsPath parent() {
-        String path = this.path;
-
-        if (path.length() == 1)
-            return null; // Current path is root.
-
-        path = GridFilenameUtils.getFullPathNoEndSeparator(path);
-
-        return new IgniteFsPath(path);
-    }
-
-    /**
-     * Adds a suffix to the final name in the path.
-     *
-     * @param suffix Suffix.
-     * @return Path with suffix.
-     */
-    public IgniteFsPath suffix(String suffix) {
-        A.ensure(!F.isEmpty(suffix), "'suffix' is null or empty.");
-        A.ensure(!suffix.contains(SLASH), "'suffix' contains file's separator '" + SLASH + "'");
-
-        return new IgniteFsPath(path + suffix);
-    }
-
-    /**
-     * Return the number of elements in this path.
-     *
-     * @return The number of elements in this path, zero depth means root directory.
-     */
-    public int depth() {
-        final String path = this.path;
-        final int size = path.length();
-
-        assert size >= 1 && path.charAt(0) == SLASH_CHAR : "Expects absolute path: " + path;
-
-        if (size == 1)
-            return 0;
-
-        int depth = 1;
-
-        // Ignore the first character.
-        for (int i = 1; i < size; i++)
-            if (path.charAt(i) == SLASH_CHAR)
-                depth++;
-
-        return depth;
-    }
-
-    /**
-     * Checks whether this path is a sub-directory of argument.
-     *
-     * @param path Path to check.
-     * @return {@code True} if argument is same or a sub-directory of this object.
-     */
-    public boolean isSubDirectoryOf(IgniteFsPath path) {
-        A.notNull(path, "path");
-
-        return this.path.startsWith(path.path.endsWith(SLASH) ? path.path : path.path + SLASH);
-    }
-
-    /**
-     * Checks if paths are identical.
-     *
-     * @param path Path to check.
-     * @return {@code True} if paths are identical.
-     */
-    public boolean isSame(IgniteFsPath path) {
-        A.notNull(path, "path");
-
-        return this == path || this.path.equals(path.path);
-    }
-
-    /** {@inheritDoc} */
-    @Override public int compareTo(IgniteFsPath o) {
-        return path.compareTo(o.path);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void writeExternal(ObjectOutput out) throws IOException {
-        U.writeString(out, path);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void readExternal(ObjectInput in) throws IOException {
-        path = U.readString(in);
-    }
-
-    /** {@inheritDoc} */
-    @Override public int hashCode() {
-        return path.hashCode();
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean equals(Object o) {
-        return o == this || o != null && getClass() == o.getClass() && path.equals(((IgniteFsPath)o).path);
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return path;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathAlreadyExistsException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathAlreadyExistsException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathAlreadyExistsException.java
deleted file mode 100644
index 4126657..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathAlreadyExistsException.java
+++ /dev/null
@@ -1,42 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.jetbrains.annotations.*;
-
-/**
- * Exception thrown when target path supposed to be created already exists.
- */
-public class IgniteFsPathAlreadyExistsException extends IgniteFsInvalidPathException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * @param msg Error message.
-     */
-    public IgniteFsPathAlreadyExistsException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * @param cause Exception cause.
-     */
-    public IgniteFsPathAlreadyExistsException(Throwable cause) {
-        super(cause);
-    }
-
-    /**
-     * @param msg Error message.
-     * @param cause Exception cause.
-     */
-    public IgniteFsPathAlreadyExistsException(String msg, @Nullable Throwable cause) {
-        super(msg, cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathSummary.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathSummary.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathSummary.java
deleted file mode 100644
index 706a3cb..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathSummary.java
+++ /dev/null
@@ -1,130 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.gridgain.grid.util.typedef.internal.*;
-
-import java.io.*;
-
-/**
- * Path summary: total files count, total directories count, total length.
- */
-public class IgniteFsPathSummary implements Externalizable {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** Path. */
-    private IgniteFsPath path;
-
-    /** File count. */
-    private int filesCnt;
-
-    /** Directories count. */
-    private int dirCnt;
-
-    /** Length consumed. */
-    private long totalLen;
-
-    /**
-     * Empty constructor required by {@link Externalizable}.
-     */
-    public IgniteFsPathSummary() {
-        // No-op.
-    }
-
-    /**
-     * Construct empty path summary.
-     *
-     * @param path Path.
-     */
-    public IgniteFsPathSummary(IgniteFsPath path) {
-        this.path = path;
-    }
-
-    /**
-     * @return Files count.
-     */
-    public int filesCount() {
-        return filesCnt;
-    }
-
-    /**
-     * @param filesCnt Files count.
-     */
-    public void filesCount(int filesCnt) {
-        this.filesCnt = filesCnt;
-    }
-
-    /**
-     * @return Directories count.
-     */
-    public int directoriesCount() {
-        return dirCnt;
-    }
-
-    /**
-     * @param dirCnt Directories count.
-     */
-    public void directoriesCount(int dirCnt) {
-        this.dirCnt = dirCnt;
-    }
-
-    /**
-     * @return Total length.
-     */
-    public long totalLength() {
-        return totalLen;
-    }
-
-    /**
-     * @param totalLen Total length.
-     */
-    public void totalLength(long totalLen) {
-        this.totalLen = totalLen;
-    }
-
-    /**
-     * @return Path for which summary is obtained.
-     */
-    public IgniteFsPath path() {
-        return path;
-    }
-
-    /**
-     * @param path Path for which summary is obtained.
-     */
-    public void path(IgniteFsPath path) {
-        this.path = path;
-    }
-
-    /** {@inheritDoc} */
-    @Override public void writeExternal(ObjectOutput out) throws IOException {
-        out.writeInt(filesCnt);
-        out.writeInt(dirCnt);
-        out.writeLong(totalLen);
-
-        path.writeExternal(out);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
-        filesCnt = in.readInt();
-        dirCnt = in.readInt();
-        totalLen = in.readLong();
-
-        path = new IgniteFsPath();
-        path.readExternal(in);
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(IgniteFsPathSummary.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsReader.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsReader.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsReader.java
deleted file mode 100644
index dd0635c..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsReader.java
+++ /dev/null
@@ -1,30 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import java.io.*;
-
-/**
- * The simplest data input interface to read from secondary file system in dual modes.
- */
-public interface IgniteFsReader extends Closeable {
-    /**
-     * Read up to the specified number of bytes, from a given position within a file, and return the number of bytes
-     * read.
-     *
-     * @param pos Position in the input stream to seek.
-     * @param buf Buffer into which data is read.
-     * @param off Offset in the buffer from which stream data should be written.
-     * @param len The number of bytes to read.
-     * @return Total number of bytes read into the buffer, or -1 if there is no more data (EOF).
-     * @throws IOException In case of any exception.
-     */
-    public int read(long pos, byte[] buf, int off, int len) throws IOException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsFileRange.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsFileRange.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsFileRange.java
index 1e1f27a..57ca491 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsFileRange.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsFileRange.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.ggfs.mapreduce;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.util.typedef.internal.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java
index 28c0890..0432046 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java
@@ -10,14 +10,14 @@
 package org.gridgain.grid.ggfs.mapreduce;
 
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.util.*;
 
 import java.io.*;
 
 /**
- * Convenient {@link IgniteFsJob} adapter. It limits data returned from {@link org.gridgain.grid.ggfs.IgniteFsInputStream} to bytes within
+ * Convenient {@link IgniteFsJob} adapter. It limits data returned from {@link org.apache.ignite.fs.IgniteFsInputStream} to bytes within
  * the {@link IgniteFsFileRange} assigned to the job.
  * <p>
  * Under the covers it simply puts job's {@code GridGgfsInputStream} position to range start and wraps in into

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java
index cfd69a9..5bcf6b3 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java
@@ -10,8 +10,8 @@
 package org.gridgain.grid.ggfs.mapreduce;
 
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 
 import java.io.*;
 
@@ -19,8 +19,8 @@ import java.io.*;
  * Defines executable unit for {@link IgniteFsTask}. Before this job is executed, it is assigned one of the
  * ranges provided by the {@link IgniteFsRecordResolver} passed to one of the {@code GridGgfs.execute(...)} methods.
  * <p>
- * {@link #execute(org.apache.ignite.IgniteFs, IgniteFsFileRange, org.gridgain.grid.ggfs.IgniteFsInputStream)} method is given {@link IgniteFsFileRange} this
- * job is expected to operate on, and already opened {@link org.gridgain.grid.ggfs.IgniteFsInputStream} for the file this range belongs to.
+ * {@link #execute(org.apache.ignite.IgniteFs, IgniteFsFileRange, org.apache.ignite.fs.IgniteFsInputStream)} method is given {@link IgniteFsFileRange} this
+ * job is expected to operate on, and already opened {@link org.apache.ignite.fs.IgniteFsInputStream} for the file this range belongs to.
  * <p>
  * Note that provided input stream has position already adjusted to range start. However, it will not
  * automatically stop on range end. This is done to provide capability in some cases to look beyond

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRangeInputStream.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRangeInputStream.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRangeInputStream.java
index 8687798..6c123eb 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRangeInputStream.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRangeInputStream.java
@@ -9,14 +9,14 @@
 
 package org.gridgain.grid.ggfs.mapreduce;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.jetbrains.annotations.*;
 
 import java.io.*;
 
 /**
- * Decorator for regular {@link org.gridgain.grid.ggfs.IgniteFsInputStream} which streams only data within the given range.
+ * Decorator for regular {@link org.apache.ignite.fs.IgniteFsInputStream} which streams only data within the given range.
  * This stream is used for {@link IgniteFsInputStreamJobAdapter} convenience adapter to create
  * jobs which will be working only with the assigned range. You can also use it explicitly when
  * working with {@link IgniteFsJob} directly.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java
index e9d254f..697f575 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java
@@ -10,8 +10,8 @@
 package org.gridgain.grid.ggfs.mapreduce;
 
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.jetbrains.annotations.*;
 
 import java.io.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java
index edfdf03..bfde75c 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java
@@ -12,9 +12,9 @@ package org.gridgain.grid.ggfs.mapreduce;
 import org.apache.ignite.*;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.compute.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.resources.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;
 import org.gridgain.grid.util.typedef.internal.*;
@@ -26,11 +26,11 @@ import java.util.*;
  * GGFS task which can be executed on the grid using one of {@code GridGgfs.execute()} methods. Essentially GGFS task
  * is regular {@link org.apache.ignite.compute.ComputeTask} with different map logic. Instead of implementing
  * {@link org.apache.ignite.compute.ComputeTask#map(List, Object)} method to split task into jobs, you must implement
- * {@link IgniteFsTask#createJob(org.gridgain.grid.ggfs.IgniteFsPath, IgniteFsFileRange, IgniteFsTaskArgs)} method.
+ * {@link IgniteFsTask#createJob(org.apache.ignite.fs.IgniteFsPath, IgniteFsFileRange, IgniteFsTaskArgs)} method.
  * <p>
  * Each file participating in GGFS task is split into {@link IgniteFsFileRange}s first. Normally range is a number of
  * consequent bytes located on a single node (see {@code GridGgfsGroupDataBlocksKeyMapper}). In case maximum range size
- * is provided (either through {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()} or {@code GridGgfs.execute()}
+ * is provided (either through {@link org.apache.ignite.fs.IgniteFsConfiguration#getMaximumTaskRangeLength()} or {@code GridGgfs.execute()}
  * argument), then ranges could be further divided into smaller chunks.
  * <p>
  * Once file is split into ranges, each range is passed to {@code GridGgfsTask.createJob()} method in order to create a

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskArgs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskArgs.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskArgs.java
index 4eb7757..d6622ef 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskArgs.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskArgs.java
@@ -9,14 +9,14 @@
 
 package org.gridgain.grid.ggfs.mapreduce;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 
 import java.util.*;
 
 /**
  * GGFS task arguments. When you initiate new GGFS task execution using one of {@code GridGgfs.execute(...)} methods,
  * all passed parameters are encapsulated in a single {@code GridGgfsTaskArgs} object. Later on this object is
- * passed to {@link IgniteFsTask#createJob(org.gridgain.grid.ggfs.IgniteFsPath, IgniteFsFileRange, IgniteFsTaskArgs)} method.
+ * passed to {@link IgniteFsTask#createJob(org.apache.ignite.fs.IgniteFsPath, IgniteFsFileRange, IgniteFsTaskArgs)} method.
  * <p>
  * Task arguments encapsulates the following data:
  * <ul>
@@ -25,7 +25,7 @@ import java.util.*;
  *     <li>{@link IgniteFsRecordResolver} for that task</li>
  *     <li>Flag indicating whether to skip non-existent file paths or throw an exception</li>
  *     <li>User-defined task argument</li>
- *     <li>Maximum file range length for that task (see {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()})</li>
+ *     <li>Maximum file range length for that task (see {@link org.apache.ignite.fs.IgniteFsConfiguration#getMaximumTaskRangeLength()})</li>
  * </ul>
  */
 public interface IgniteFsTaskArgs<T> {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java
index 79f928e..9ca7b54 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java
@@ -10,9 +10,9 @@
 package org.gridgain.grid.ggfs.mapreduce.records;
 
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java
index 6190207..ddfd402 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java
@@ -10,8 +10,8 @@
 package org.gridgain.grid.ggfs.mapreduce.records;
 
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.util.typedef.internal.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/package.html
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/package.html b/modules/core/src/main/java/org/gridgain/grid/ggfs/package.html
deleted file mode 100644
index 7fa7477..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/package.html
+++ /dev/null
@@ -1,15 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
-<!--
-    @html.file.header
-    _________        _____ __________________        _____
-    __  ____/___________(_)______  /__  ____/______ ____(_)_______
-    _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
-    / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
-    \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
--->
-<html>
-<body>
-    <!-- Package description. -->
-    Contains <b>G</b>rid<b>G</b>ain <b>F</b>ile <b>S</b>ystem APIs.
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java b/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java
index a79aa15..703840b 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java
@@ -11,6 +11,7 @@ package org.gridgain.grid.kernal;
 
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.logger.*;
 import org.apache.ignite.logger.java.*;
@@ -21,7 +22,6 @@ import org.apache.ignite.mbean.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.cache.affinity.rendezvous.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.processors.interop.*;
 import org.gridgain.grid.kernal.processors.resource.*;
 import org.gridgain.grid.kernal.processors.spring.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
index 8beb1df..b22e7b8 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
@@ -9,8 +9,8 @@
 
 package org.gridgain.grid.kernal.ggfs.common;
 
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsLogger.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsLogger.java b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsLogger.java
index 2f0af0b..b9fcf3a 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsLogger.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsLogger.java
@@ -9,8 +9,8 @@
 
 package org.gridgain.grid.kernal.ggfs.common;
 
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.jdk8.backport.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsMarshaller.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsMarshaller.java b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsMarshaller.java
index 24a8807..a7dea92 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsMarshaller.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsMarshaller.java
@@ -9,8 +9,8 @@
 
 package org.gridgain.grid.kernal.ggfs.common;
 
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.jetbrains.annotations.*;
 
@@ -316,7 +316,7 @@ public class GridGgfsMarshaller {
     }
 
     /**
-     * Reads GGFS path from data input that was written by {@link #writePath(ObjectOutput, org.gridgain.grid.ggfs.IgniteFsPath)}
+     * Reads GGFS path from data input that was written by {@link #writePath(ObjectOutput, org.apache.ignite.fs.IgniteFsPath)}
      * method.
      *
      * @param in Data input.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsPathControlRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsPathControlRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsPathControlRequest.java
index 00b7718..412cdac 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsPathControlRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsPathControlRequest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.ggfs.common;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.jetbrains.annotations.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
index 4a99bc4..52eebc6 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
@@ -13,6 +13,7 @@ import org.apache.ignite.*;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.compute.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.portables.*;
 import org.apache.ignite.resources.*;
@@ -21,7 +22,6 @@ import org.gridgain.grid.cache.*;
 import org.gridgain.grid.cache.affinity.*;
 import org.gridgain.grid.cache.datastructures.*;
 import org.gridgain.grid.cache.query.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.processors.cache.affinity.*;
 import org.gridgain.grid.kernal.processors.cache.datastructures.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProcessor.java
index b266c57..ee6edee 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProcessor.java
@@ -12,6 +12,7 @@ package org.gridgain.grid.kernal.processors.cache;
 import org.apache.ignite.*;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
@@ -20,7 +21,6 @@ import org.gridgain.grid.cache.affinity.consistenthash.*;
 import org.gridgain.grid.cache.affinity.fair.*;
 import org.gridgain.grid.cache.affinity.rendezvous.*;
 import org.gridgain.grid.cache.store.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.processors.*;
 import org.gridgain.grid.kernal.processors.cache.datastructures.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheUtils.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheUtils.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheUtils.java
index 0a335ee..8f4a19d 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheUtils.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheUtils.java
@@ -12,10 +12,10 @@ package org.gridgain.grid.kernal.processors.cache;
 import org.apache.ignite.*;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.processors.cache.distributed.*;
 import org.gridgain.grid.kernal.processors.cache.distributed.dht.*;
 import org.gridgain.grid.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
index 407249b..0351392 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
@@ -10,9 +10,9 @@
 package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.jetbrains.annotations.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributes.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributes.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributes.java
index 885ca75..ba158c8 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributes.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributes.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.util.typedef.internal.*;
 
 import java.io.*;
@@ -30,7 +30,7 @@ public class GridGgfsAttributes implements Externalizable {
     /** File's data block size (bytes). */
     private int blockSize;
 
-    /** Size of the group figured in {@link org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper}. */
+    /** Size of the group figured in {@link org.apache.ignite.fs.IgniteFsGroupDataBlocksKeyMapper}. */
     private int grpSize;
 
     /** Meta cache name. */
@@ -51,7 +51,7 @@ public class GridGgfsAttributes implements Externalizable {
     /**
      * @param ggfsName GGFS name.
      * @param blockSize File's data block size (bytes).
-     * @param grpSize Size of the group figured in {@link org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper}.
+     * @param grpSize Size of the group figured in {@link org.apache.ignite.fs.IgniteFsGroupDataBlocksKeyMapper}.
      * @param metaCacheName Meta cache name.
      * @param dataCacheName Data cache name.
      * @param dfltMode Default mode.
@@ -91,7 +91,7 @@ public class GridGgfsAttributes implements Externalizable {
     }
 
     /**
-     * @return Size of the group figured in {@link org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper}.
+     * @return Size of the group figured in {@link org.apache.ignite.fs.IgniteFsGroupDataBlocksKeyMapper}.
      */
     public int groupSize() {
         return grpSize;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsBlockLocationImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsBlockLocationImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsBlockLocationImpl.java
index b94e262..6fdf889 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsBlockLocationImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsBlockLocationImpl.java
@@ -10,8 +10,8 @@
 package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.cluster.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.gridgain.grid.util.tostring.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsContext.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsContext.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsContext.java
index a5f105c..c06fafe 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsContext.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsContext.java
@@ -10,8 +10,8 @@
 package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.cluster.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.managers.communication.*;
 import org.gridgain.grid.util.typedef.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
index 0b8fe5f..1e15bbb 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
@@ -12,11 +12,11 @@ package org.gridgain.grid.kernal.processors.ggfs;
 import org.apache.ignite.*;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.events.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.cache.affinity.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.managers.communication.*;
 import org.gridgain.grid.kernal.managers.eventstorage.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDirectoryNotEmptyException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDirectoryNotEmptyException.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDirectoryNotEmptyException.java
index 9850e35..fea9eec 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDirectoryNotEmptyException.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDirectoryNotEmptyException.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 
 /**
  * Exception indicating that directory can not be deleted because it is not empty.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsEx.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsEx.java
index 0738bbc..7ee45f3 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsEx.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsEx.java
@@ -10,9 +10,9 @@
 package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.jetbrains.annotations.*;
 
 import java.net.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileInfo.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileInfo.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileInfo.java
index 2e2bcc3..bcfa82d 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileInfo.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileInfo.java
@@ -9,8 +9,8 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;
@@ -90,7 +90,7 @@ public final class GridGgfsFileInfo implements Externalizable {
     }
 
     /**
-     * Constructs directory or file info with {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#DFLT_BLOCK_SIZE default} block size.
+     * Constructs directory or file info with {@link org.apache.ignite.fs.IgniteFsConfiguration#DFLT_BLOCK_SIZE default} block size.
      *
      * @param isDir Constructs directory info if {@code true} or file info if {@code false}.
      * @param props Meta properties to set.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileWorkerBatch.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileWorkerBatch.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileWorkerBatch.java
index 0d5b7d4..ba9ecc8 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileWorkerBatch.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileWorkerBatch.java
@@ -9,8 +9,8 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.util.typedef.internal.*;
 
 import java.io.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
index 5d4f4ad..a54515c 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
@@ -13,13 +13,13 @@ import org.apache.ignite.*;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.compute.*;
 import org.apache.ignite.events.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.resources.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.cache.eviction.*;
 import org.gridgain.grid.cache.eviction.ggfs.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.managers.communication.*;
@@ -38,7 +38,7 @@ import java.util.*;
 import java.util.concurrent.atomic.*;
 
 import static org.apache.ignite.events.IgniteEventType.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 import static org.gridgain.grid.kernal.GridNodeAttributes.*;
 import static org.gridgain.grid.kernal.GridTopic.*;
 import static org.gridgain.grid.kernal.processors.ggfs.GridGgfsFileInfo.*;
@@ -1708,7 +1708,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
 
     /**
      * Executes GGFS task with overridden maximum range length (see
-     * {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()} for more information).
+     * {@link org.apache.ignite.fs.IgniteFsConfiguration#getMaximumTaskRangeLength()} for more information).
      *
      * @param task Task to execute.
      * @param rslvr Optional resolver to control split boundaries.
@@ -1742,7 +1742,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
 
     /**
      * Executes GGFS task asynchronously with overridden maximum range length (see
-     * {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()} for more information).
+     * {@link org.apache.ignite.fs.IgniteFsConfiguration#getMaximumTaskRangeLength()} for more information).
      *
      * @param taskCls Task class to execute.
      * @param rslvr Optional resolver to control split boundaries.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamAdapter.java
index dea1fc2..36d12f0 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamAdapter.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 
 import java.io.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java
index 91e0b4a..18a81ef 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java
@@ -10,9 +10,9 @@
 package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.jetbrains.annotations.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsIpcHandler.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsIpcHandler.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsIpcHandler.java
index 14d05bd..48f0857 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsIpcHandler.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsIpcHandler.java
@@ -10,9 +10,9 @@
 package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.ggfs.common.*;
 import org.gridgain.grid.kernal.processors.closure.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
index 4869103..bdd8e66 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
@@ -11,9 +11,9 @@ package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.*;
 import org.apache.ignite.compute.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.resources.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.kernal.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
index eb862f2..e3ab3a9 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
@@ -12,10 +12,10 @@ package org.gridgain.grid.kernal.processors.ggfs;
 import org.apache.ignite.*;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.events.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.managers.eventstorage.*;
 import org.gridgain.grid.kernal.processors.cache.*;
 import org.gridgain.grid.kernal.processors.task.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolver.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolver.java
index c0701ef..443fbec 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolver.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolver.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.typedef.*;
 import org.jetbrains.annotations.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPaths.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPaths.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPaths.java
index 5dbb004..a0b0122 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPaths.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPaths.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.jetbrains.annotations.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
index 99f817a..5ba2e40 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
@@ -13,11 +13,11 @@ import org.apache.ignite.*;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.compute.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.cache.affinity.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.processors.cache.*;
@@ -35,7 +35,7 @@ import java.util.concurrent.*;
 import static org.gridgain.grid.GridSystemProperties.*;
 import static org.gridgain.grid.cache.GridCacheMemoryMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 import static org.gridgain.grid.kernal.GridNodeAttributes.*;
 import static org.gridgain.grid.kernal.processors.license.GridLicenseSubsystem.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
index 066cd5c..a3bc423 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
@@ -11,7 +11,7 @@ package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.*;
 import org.apache.ignite.compute.*;
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.processors.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSecondaryInputStreamDescriptor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSecondaryInputStreamDescriptor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSecondaryInputStreamDescriptor.java
index 3a17d38..e955711 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSecondaryInputStreamDescriptor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSecondaryInputStreamDescriptor.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 
 /**
  * Descriptor of an input stream opened to the secondary file system.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java
index b8f17a9..4b2063f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java
@@ -9,9 +9,9 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;
@@ -21,7 +21,7 @@ import org.gridgain.grid.util.worker.*;
 import java.util.*;
 import java.util.concurrent.*;
 
-import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
+import static org.apache.ignite.fs.IgniteFsConfiguration.*;
 
 /**
  * GGFS server manager.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
index e73779a..d1f9d6e 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
@@ -11,7 +11,7 @@ package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.*;
 import org.apache.ignite.compute.*;
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.util.ipc.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsFileImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsFileImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsFileImpl.java
index 28b2cd6..6ececbf 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsFileImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsFileImpl.java
@@ -9,8 +9,8 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.jetbrains.annotations.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsMetricsAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsMetricsAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsMetricsAdapter.java
index 36627f8..c77182e 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsMetricsAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsMetricsAdapter.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.util.typedef.internal.*;
 
 import java.io.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamAdapter.java
index b1cdf1b..7eac170 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamAdapter.java
@@ -9,8 +9,8 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.jetbrains.annotations.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamImpl.java
index 1ea8d91..a9bc393 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamImpl.java
@@ -10,9 +10,9 @@
 package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.processors.task.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.gridgain.grid.util.future.*;
@@ -22,7 +22,7 @@ import java.io.*;
 import java.nio.*;
 import java.util.concurrent.atomic.*;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * Output stream to store data into grid cache with separate blocks.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsTaskArgsImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsTaskArgsImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsTaskArgsImpl.java
index 1edaac8..78ecc7d 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsTaskArgsImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsTaskArgsImpl.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.util.typedef.internal.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/kernal/processors/job/GridJobWorker.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/job/GridJobWorker.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/job/GridJobWorker.java
index 6a932f4..abbd45e 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/job/GridJobWorker.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/job/GridJobWorker.java
@@ -13,10 +13,10 @@ import org.apache.ignite.*;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.compute.*;
 import org.apache.ignite.events.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.marshaller.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.managers.deployment.*;
 import org.gridgain.grid.kernal.processors.task.*;


[26/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
# Renaming


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

Branch: refs/heads/master
Commit: 7cd638fe62ddf8518c8e9a41f2b54ef22cf59dab
Parents: b7479ed
Author: sboikov <sb...@gridgain.com>
Authored: Fri Dec 5 11:24:58 2014 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Dec 5 11:24:58 2014 +0300

----------------------------------------------------------------------
 .../examples/ggfs/GgfsMapReduceExample.java     |   6 +-
 .../main/java/org/apache/ignite/IgniteFs.java   |  12 +-
 .../grid/ggfs/IgniteFsConfiguration.java        |   3 +-
 .../mapreduce/GridGgfsRangeInputStream.java     | 189 -------------------
 .../ggfs/mapreduce/GridGgfsRecordResolver.java  |  50 -----
 .../grid/ggfs/mapreduce/GridGgfsTask.java       | 165 ----------------
 .../grid/ggfs/mapreduce/GridGgfsTaskArgs.java   |   6 +-
 .../mapreduce/GridGgfsTaskNoReduceAdapter.java  |   4 +-
 .../IgniteFsInputStreamJobAdapter.java          |   4 +-
 .../grid/ggfs/mapreduce/IgniteFsJob.java        |   8 +-
 .../mapreduce/IgniteFsRangeInputStream.java     | 189 +++++++++++++++++++
 .../ggfs/mapreduce/IgniteFsRecordResolver.java  |  50 +++++
 .../grid/ggfs/mapreduce/IgniteFsTask.java       | 165 ++++++++++++++++
 .../GridGgfsByteDelimiterRecordResolver.java    |   2 +-
 .../GridGgfsFixedLengthRecordResolver.java      |   2 +-
 .../processors/ggfs/GridGgfsAsyncImpl.java      |  12 +-
 .../kernal/processors/ggfs/GridGgfsImpl.java    |  26 +--
 .../kernal/processors/ggfs/GridGgfsJobImpl.java |   4 +-
 .../processors/ggfs/GridGgfsProcessor.java      |   2 +-
 .../ggfs/GridGgfsProcessorAdapter.java          |   2 +-
 .../processors/ggfs/GridGgfsTaskArgsImpl.java   |   8 +-
 .../processors/ggfs/GridNoopGgfsProcessor.java  |   2 +-
 .../processors/ggfs/GridGgfsTaskSelfTest.java   |   4 +-
 ...idHadoopDefaultMapReducePlannerSelfTest.java |  12 +-
 24 files changed, 463 insertions(+), 464 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
index 85f103d..edd3f70 100644
--- a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
+++ b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
@@ -20,7 +20,7 @@ import java.io.*;
 import java.util.*;
 
 /**
- * Example that shows how to use {@link GridGgfsTask} to find lines matching particular pattern in the file in pretty
+ * Example that shows how to use {@link org.gridgain.grid.ggfs.mapreduce.IgniteFsTask} to find lines matching particular pattern in the file in pretty
  * the same way as {@code grep} command does.
  * <p>
  * Remote nodes should always be started with configuration file which includes
@@ -119,7 +119,7 @@ public class GgfsMapReduceExample {
     /**
      * Grep task.
      */
-    private static class GrepTask extends GridGgfsTask<String, Collection<Line>> {
+    private static class GrepTask extends IgniteFsTask<String, Collection<Line>> {
         /** {@inheritDoc} */
         @Override public IgniteFsJob createJob(IgniteFsPath path, IgniteFsFileRange range,
             GridGgfsTaskArgs<String> args) throws GridException {
@@ -166,7 +166,7 @@ public class GgfsMapReduceExample {
         }
 
         /**  {@inheritDoc} */
-        @Override public Object execute(IgniteFs ggfs, GridGgfsRangeInputStream in) throws GridException, IOException {
+        @Override public Object execute(IgniteFs ggfs, IgniteFsRangeInputStream in) throws GridException, IOException {
             Collection<Line> res = null;
 
             long start = in.startOffset();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
index 241ab3e..fd3c88c 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
@@ -269,7 +269,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @return Task result.
      * @throws GridException If execution failed.
      */
-    public <T, R> R execute(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
+    public <T, R> R execute(IgniteFsTask<T, R> task, @Nullable IgniteFsRecordResolver rslvr,
         Collection<IgniteFsPath> paths, @Nullable T arg) throws GridException;
 
     /**
@@ -289,7 +289,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @return Task result.
      * @throws GridException If execution failed.
      */
-    public <T, R> R execute(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
+    public <T, R> R execute(IgniteFsTask<T, R> task, @Nullable IgniteFsRecordResolver rslvr,
         Collection<IgniteFsPath> paths, boolean skipNonExistentFiles, long maxRangeLen, @Nullable T arg)
         throws GridException;
 
@@ -305,8 +305,8 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @return Task result.
      * @throws GridException If execution failed.
      */
-    public <T, R> R execute(Class<? extends GridGgfsTask<T, R>> taskCls,
-        @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, @Nullable T arg) throws GridException;
+    public <T, R> R execute(Class<? extends IgniteFsTask<T, R>> taskCls,
+        @Nullable IgniteFsRecordResolver rslvr, Collection<IgniteFsPath> paths, @Nullable T arg) throws GridException;
 
     /**
      * Executes GGFS task with overridden maximum range length (see
@@ -324,8 +324,8 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @return Task result.
      * @throws GridException If execution failed.
      */
-    public <T, R> R execute(Class<? extends GridGgfsTask<T, R>> taskCls,
-        @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, boolean skipNonExistentFiles,
+    public <T, R> R execute(Class<? extends IgniteFsTask<T, R>> taskCls,
+        @Nullable IgniteFsRecordResolver rslvr, Collection<IgniteFsPath> paths, boolean skipNonExistentFiles,
         long maxRangeLen, @Nullable T arg) throws GridException;
 
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
index 287e93c..45a009a 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
@@ -9,7 +9,6 @@
 
 package org.gridgain.grid.ggfs;
 
-import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.jetbrains.annotations.*;
 
@@ -762,7 +761,7 @@ public class IgniteFsConfiguration {
      * length is smaller than file block size. In this case maximum task range size will be overridden and set to file
      * block size.
      * <p>
-     * Note that this parameter is applied when task is split into jobs before {@link GridGgfsRecordResolver} is
+     * Note that this parameter is applied when task is split into jobs before {@link org.gridgain.grid.ggfs.mapreduce.IgniteFsRecordResolver} is
      * applied. Therefore, final file ranges being assigned to particular jobs could be greater than value of this
      * parameter depending on file data layout and selected resolver type.
      * <p>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRangeInputStream.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRangeInputStream.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRangeInputStream.java
deleted file mode 100644
index ac96c68..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRangeInputStream.java
+++ /dev/null
@@ -1,189 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-import org.gridgain.grid.ggfs.*;
-import org.gridgain.grid.util.typedef.internal.*;
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-
-/**
- * Decorator for regular {@link org.gridgain.grid.ggfs.IgniteFsInputStream} which streams only data within the given range.
- * This stream is used for {@link IgniteFsInputStreamJobAdapter} convenience adapter to create
- * jobs which will be working only with the assigned range. You can also use it explicitly when
- * working with {@link IgniteFsJob} directly.
- */
-public final class GridGgfsRangeInputStream extends IgniteFsInputStream {
-    /** Base input stream. */
-    private final IgniteFsInputStream is;
-
-    /** Start position. */
-    private final long start;
-
-    /** Maximum stream length. */
-    private final long maxLen;
-
-    /** Current position within the stream. */
-    private long pos;
-
-    /**
-     * Constructor.
-     *
-     * @param is Base input stream.
-     * @param start Start position.
-     * @param maxLen Maximum stream length.
-     * @throws IOException In case of exception.
-     */
-    public GridGgfsRangeInputStream(IgniteFsInputStream is, long start, long maxLen) throws IOException {
-        if (is == null)
-            throw new IllegalArgumentException("Input stream cannot be null.");
-
-        if (start < 0)
-            throw new IllegalArgumentException("Start position cannot be negative.");
-
-        if (start >= is.length())
-            throw new IllegalArgumentException("Start position cannot be greater that file length.");
-
-        if (maxLen < 0)
-            throw new IllegalArgumentException("Length cannot be negative.");
-
-        if (start + maxLen > is.length())
-            throw new IllegalArgumentException("Sum of start position and length cannot be greater than file length.");
-
-        this.is = is;
-        this.start = start;
-        this.maxLen = maxLen;
-
-        is.seek(start);
-    }
-
-    /** {@inheritDoc} */
-    @Override public long length() {
-        return is.length();
-    }
-
-    /**
-     * Constructor.
-     *
-     * @param is Base input stream.
-     * @param range File range.
-     * @throws IOException In case of exception.
-     */
-    public GridGgfsRangeInputStream(IgniteFsInputStream is, IgniteFsFileRange range) throws IOException {
-        this(is, range.start(), range.length());
-    }
-
-    /** {@inheritDoc} */
-    @Override public int read() throws IOException {
-        if (pos < maxLen) {
-            int res = is.read();
-
-            if (res != -1)
-                pos++;
-
-            return res;
-        }
-        else
-            return -1;
-    }
-
-    /** {@inheritDoc} */
-    @Override public int read(@NotNull byte[] b, int off, int len) throws IOException {
-        if (pos < maxLen) {
-            len = (int)Math.min(len, maxLen - pos);
-
-            int res = is.read(b, off, len);
-
-            if (res != -1)
-                pos += res;
-
-            return res;
-        }
-        else
-            return -1;
-    }
-
-    /** {@inheritDoc} */
-    @Override public int read(long pos, byte[] buf, int off, int len) throws IOException {
-        seek(pos);
-
-        return read(buf, off, len);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void readFully(long pos, byte[] buf) throws IOException {
-        readFully(pos, buf, 0, buf.length);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void readFully(long pos, byte[] buf, int off, int len) throws IOException {
-        seek(pos);
-
-        for (int readBytes = 0; readBytes < len;) {
-            int read = read(buf, off + readBytes, len - readBytes);
-
-            if (read == -1)
-                throw new EOFException("Failed to read stream fully (stream ends unexpectedly) [pos=" + pos +
-                    ", buf.length=" + buf.length + ", off=" + off + ", len=" + len + ']');
-
-            readBytes += read;
-        }
-    }
-
-    /** {@inheritDoc} */
-    @Override public void seek(long pos) throws IOException {
-        if (pos < 0)
-            throw new IOException("Seek position cannot be negative: " + pos);
-
-        is.seek(start + pos);
-
-        this.pos = pos;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long position() {
-        return pos;
-    }
-
-    /**
-     * Since range input stream represents a part of larger file stream, there is an offset at which this
-     * range input stream starts in original input stream. This method returns start offset of this input
-     * stream relative to original input stream.
-     *
-     * @return Start offset in original input stream.
-     */
-    public long startOffset() {
-        return start;
-    }
-
-    /** {@inheritDoc} */
-    @Override public int available() {
-        long l = maxLen - pos;
-
-        if (l < 0)
-            return 0;
-
-        if (l > Integer.MAX_VALUE)
-            return Integer.MAX_VALUE;
-
-        return (int)l;
-    }
-
-    /** {@inheritDoc} */
-    @Override public void close() throws IOException {
-        is.close();
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridGgfsRangeInputStream.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRecordResolver.java
deleted file mode 100644
index e128776..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRecordResolver.java
+++ /dev/null
@@ -1,50 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-import org.apache.ignite.*;
-import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
-import org.gridgain.grid.ggfs.mapreduce.records.*;
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-
-/**
- * GGFS record resolver. When {@link GridGgfsTask} is split into {@link IgniteFsJob}s each produced job will obtain
- * {@link IgniteFsFileRange} based on file data location. Record resolver is invoked in each job before actual
- * execution in order to adjust record boundaries in a way consistent with user data.
- * <p>
- * E.g., you may want to split your task into jobs so that each job process zero, one or several lines from that file.
- * But file is split into ranges based on block locations, not new line boundaries. Using convenient record resolver
- * you can adjust job range so that it covers the whole line(s).
- * <p>
- * The following record resolvers are available out of the box:
- * <ul>
- *     <li>{@link GridGgfsFixedLengthRecordResolver}</li>
- *     <li>{@link GridGgfsByteDelimiterRecordResolver}</li>
- *     <li>{@link GridGgfsStringDelimiterRecordResolver}</li>
- *     <li>{@link GridGgfsNewLineRecordResolver}</li>
- * </ul>
- */
-public interface GridGgfsRecordResolver extends Serializable {
-    /**
-     * Adjusts record start offset and length.
-     *
-     * @param ggfs GGFS instance to use.
-     * @param stream Input stream for split file.
-     * @param suggestedRecord Suggested file system record.
-     * @return New adjusted record. If this method returns {@code null}, original record is ignored.
-     * @throws GridException If resolve failed.
-     * @throws IOException If resolve failed.
-     */
-    @Nullable public IgniteFsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
-        IgniteFsFileRange suggestedRecord) throws GridException, IOException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
deleted file mode 100644
index 35e16de..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
+++ /dev/null
@@ -1,165 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-import org.apache.ignite.*;
-import org.apache.ignite.cluster.*;
-import org.apache.ignite.compute.*;
-import org.apache.ignite.resources.*;
-import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
-import org.gridgain.grid.kernal.*;
-import org.gridgain.grid.kernal.processors.ggfs.*;
-import org.gridgain.grid.util.typedef.internal.*;
-import org.jetbrains.annotations.*;
-
-import java.util.*;
-
-/**
- * GGFS task which can be executed on the grid using one of {@code GridGgfs.execute()} methods. Essentially GGFS task
- * is regular {@link org.apache.ignite.compute.ComputeTask} with different map logic. Instead of implementing
- * {@link org.apache.ignite.compute.ComputeTask#map(List, Object)} method to split task into jobs, you must implement
- * {@link GridGgfsTask#createJob(org.gridgain.grid.ggfs.IgniteFsPath, IgniteFsFileRange, GridGgfsTaskArgs)} method.
- * <p>
- * Each file participating in GGFS task is split into {@link IgniteFsFileRange}s first. Normally range is a number of
- * consequent bytes located on a single node (see {@code GridGgfsGroupDataBlocksKeyMapper}). In case maximum range size
- * is provided (either through {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()} or {@code GridGgfs.execute()}
- * argument), then ranges could be further divided into smaller chunks.
- * <p>
- * Once file is split into ranges, each range is passed to {@code GridGgfsTask.createJob()} method in order to create a
- * {@link IgniteFsJob}.
- * <p>
- * Finally all generated jobs are sent to Grid nodes for execution.
- * <p>
- * As with regular {@code GridComputeTask} you can define your own logic for results handling and reduce step.
- * <p>
- * Here is an example of such a task:
- * <pre name="code" class="java">
- * public class WordCountTask extends GridGgfsTask&lt;String, Integer&gt; {
- *     &#64;Override
- *     public GridGgfsJob createJob(GridGgfsPath path, GridGgfsFileRange range, GridGgfsTaskArgs&lt;T&gt; args) throws GridException {
- *         // New job will be created for each range within each file.
- *         // We pass user-provided argument (which is essentially a word to look for) to that job.
- *         return new WordCountJob(args.userArgument());
- *     }
- *
- *     // Aggregate results into one compound result.
- *     public Integer reduce(List&lt;GridComputeJobResult&gt; results) throws GridException {
- *         Integer total = 0;
- *
- *         for (GridComputeJobResult res : results) {
- *             Integer cnt = res.getData();
- *
- *             // Null can be returned for non-existent file in case we decide to ignore such situations.
- *             if (cnt != null)
- *                 total += cnt;
- *         }
- *
- *         return total;
- *     }
- * }
- * </pre>
- */
-public abstract class GridGgfsTask<T, R> extends ComputeTaskAdapter<GridGgfsTaskArgs<T>, R> {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** Injected grid. */
-    @IgniteInstanceResource
-    private Ignite ignite;
-
-    /** {@inheritDoc} */
-    @Nullable @Override public final Map<? extends ComputeJob, ClusterNode> map(List<ClusterNode> subgrid,
-        @Nullable GridGgfsTaskArgs<T> args) throws GridException {
-        assert ignite != null;
-        assert args != null;
-
-        IgniteFs ggfs = ignite.fileSystem(args.ggfsName());
-        GridGgfsProcessorAdapter ggfsProc = ((GridKernal) ignite).context().ggfs();
-
-        Map<ComputeJob, ClusterNode> splitMap = new HashMap<>();
-
-        Map<UUID, ClusterNode> nodes = mapSubgrid(subgrid);
-
-        for (IgniteFsPath path : args.paths()) {
-            IgniteFsFile file = ggfs.info(path);
-
-            if (file == null) {
-                if (args.skipNonExistentFiles())
-                    continue;
-                else
-                    throw new GridException("Failed to process GGFS file because it doesn't exist: " + path);
-            }
-
-            Collection<IgniteFsBlockLocation> aff = ggfs.affinity(path, 0, file.length(), args.maxRangeLength());
-
-            long totalLen = 0;
-
-            for (IgniteFsBlockLocation loc : aff) {
-                ClusterNode node = null;
-
-                for (UUID nodeId : loc.nodeIds()) {
-                    node = nodes.get(nodeId);
-
-                    if (node != null)
-                        break;
-                }
-
-                if (node == null)
-                    throw new GridException("Failed to find any of block affinity nodes in subgrid [loc=" + loc +
-                        ", subgrid=" + subgrid + ']');
-
-                IgniteFsJob job = createJob(path, new IgniteFsFileRange(file.path(), loc.start(), loc.length()), args);
-
-                if (job != null) {
-                    ComputeJob jobImpl = ggfsProc.createJob(job, ggfs.name(), file.path(), loc.start(),
-                        loc.length(), args.recordResolver());
-
-                    splitMap.put(jobImpl, node);
-                }
-
-                totalLen += loc.length();
-            }
-
-            assert totalLen == file.length();
-        }
-
-        return splitMap;
-    }
-
-    /**
-     * Callback invoked during task map procedure to create job that will process specified split
-     * for GGFS file.
-     *
-     * @param path Path.
-     * @param range File range based on consecutive blocks. This range will be further
-     *      realigned to record boundaries on destination node.
-     * @param args Task argument.
-     * @return GGFS job. If {@code null} is returned, the passed in file range will be skipped.
-     * @throws GridException If job creation failed.
-     */
-    @Nullable public abstract IgniteFsJob createJob(IgniteFsPath path, IgniteFsFileRange range,
-        GridGgfsTaskArgs<T> args) throws GridException;
-
-    /**
-     * Maps list by node ID.
-     *
-     * @param subgrid Subgrid.
-     * @return Map.
-     */
-    private Map<UUID, ClusterNode> mapSubgrid(Collection<ClusterNode> subgrid) {
-        Map<UUID, ClusterNode> res = U.newHashMap(subgrid.size());
-
-        for (ClusterNode node : subgrid)
-            res.put(node.id(), node);
-
-        return res;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
index fd36ffe..caa0b44 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
@@ -16,13 +16,13 @@ import java.util.*;
 /**
  * GGFS task arguments. When you initiate new GGFS task execution using one of {@code GridGgfs.execute(...)} methods,
  * all passed parameters are encapsulated in a single {@code GridGgfsTaskArgs} object. Later on this object is
- * passed to {@link GridGgfsTask#createJob(org.gridgain.grid.ggfs.IgniteFsPath, IgniteFsFileRange, GridGgfsTaskArgs)} method.
+ * passed to {@link IgniteFsTask#createJob(org.gridgain.grid.ggfs.IgniteFsPath, IgniteFsFileRange, GridGgfsTaskArgs)} method.
  * <p>
  * Task arguments encapsulates the following data:
  * <ul>
  *     <li>GGFS name</li>
  *     <li>File paths passed to {@code GridGgfs.execute()} method</li>
- *     <li>{@link GridGgfsRecordResolver} for that task</li>
+ *     <li>{@link IgniteFsRecordResolver} for that task</li>
  *     <li>Flag indicating whether to skip non-existent file paths or throw an exception</li>
  *     <li>User-defined task argument</li>
  *     <li>Maximum file range length for that task (see {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()})</li>
@@ -48,7 +48,7 @@ public interface GridGgfsTaskArgs<T> {
      *
      * @return Record resolver.
      */
-    public GridGgfsRecordResolver recordResolver();
+    public IgniteFsRecordResolver recordResolver();
 
     /**
      * Flag indicating whether to fail or simply skip non-existent files.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskNoReduceAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskNoReduceAdapter.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskNoReduceAdapter.java
index 9131b09..802b7a5 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskNoReduceAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskNoReduceAdapter.java
@@ -14,10 +14,10 @@ import org.apache.ignite.compute.*;
 import java.util.*;
 
 /**
- * Convenient {@link GridGgfsTask} adapter with empty reduce step. Use this adapter in case you are not interested in
+ * Convenient {@link IgniteFsTask} adapter with empty reduce step. Use this adapter in case you are not interested in
  * results returned by jobs.
  */
-public abstract class GridGgfsTaskNoReduceAdapter<T, R> extends GridGgfsTask<T, R> {
+public abstract class GridGgfsTaskNoReduceAdapter<T, R> extends IgniteFsTask<T, R> {
     /** */
     private static final long serialVersionUID = 0L;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java
index ddc04b3..28c0890 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java
@@ -29,7 +29,7 @@ public abstract class IgniteFsInputStreamJobAdapter extends IgniteFsJobAdapter {
         throws GridException, IOException {
         in.seek(range.start());
 
-        return execute(ggfs, new GridGgfsRangeInputStream(in, range));
+        return execute(ggfs, new IgniteFsRangeInputStream(in, range));
     }
 
     /**
@@ -41,5 +41,5 @@ public abstract class IgniteFsInputStreamJobAdapter extends IgniteFsJobAdapter {
      * @throws GridException If execution failed.
      * @throws IOException If IO exception encountered while working with stream.
      */
-    public abstract Object execute(IgniteFs ggfs, GridGgfsRangeInputStream in) throws GridException, IOException;
+    public abstract Object execute(IgniteFs ggfs, IgniteFsRangeInputStream in) throws GridException, IOException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java
index 4aa33ec..cfd69a9 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java
@@ -16,8 +16,8 @@ import org.gridgain.grid.ggfs.*;
 import java.io.*;
 
 /**
- * Defines executable unit for {@link GridGgfsTask}. Before this job is executed, it is assigned one of the
- * ranges provided by the {@link GridGgfsRecordResolver} passed to one of the {@code GridGgfs.execute(...)} methods.
+ * Defines executable unit for {@link IgniteFsTask}. Before this job is executed, it is assigned one of the
+ * ranges provided by the {@link IgniteFsRecordResolver} passed to one of the {@code GridGgfs.execute(...)} methods.
  * <p>
  * {@link #execute(org.apache.ignite.IgniteFs, IgniteFsFileRange, org.gridgain.grid.ggfs.IgniteFsInputStream)} method is given {@link IgniteFsFileRange} this
  * job is expected to operate on, and already opened {@link org.gridgain.grid.ggfs.IgniteFsInputStream} for the file this range belongs to.
@@ -28,8 +28,8 @@ import java.io.*;
  * <p>
  * In majority of the cases, when you want to process only provided range, you should explicitly control amount
  * of returned data and stop at range end. You can also use {@link IgniteFsInputStreamJobAdapter}, which operates
- * on {@link GridGgfsRangeInputStream} bounded to range start and end, or manually wrap provided input stream with
- * {@link GridGgfsRangeInputStream}.
+ * on {@link IgniteFsRangeInputStream} bounded to range start and end, or manually wrap provided input stream with
+ * {@link IgniteFsRangeInputStream}.
  * <p>
  * You can inject any resources in concrete implementation, just as with regular {@link org.apache.ignite.compute.ComputeJob} implementations.
  */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRangeInputStream.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRangeInputStream.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRangeInputStream.java
new file mode 100644
index 0000000..8687798
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRangeInputStream.java
@@ -0,0 +1,189 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs.mapreduce;
+
+import org.gridgain.grid.ggfs.*;
+import org.gridgain.grid.util.typedef.internal.*;
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+
+/**
+ * Decorator for regular {@link org.gridgain.grid.ggfs.IgniteFsInputStream} which streams only data within the given range.
+ * This stream is used for {@link IgniteFsInputStreamJobAdapter} convenience adapter to create
+ * jobs which will be working only with the assigned range. You can also use it explicitly when
+ * working with {@link IgniteFsJob} directly.
+ */
+public final class IgniteFsRangeInputStream extends IgniteFsInputStream {
+    /** Base input stream. */
+    private final IgniteFsInputStream is;
+
+    /** Start position. */
+    private final long start;
+
+    /** Maximum stream length. */
+    private final long maxLen;
+
+    /** Current position within the stream. */
+    private long pos;
+
+    /**
+     * Constructor.
+     *
+     * @param is Base input stream.
+     * @param start Start position.
+     * @param maxLen Maximum stream length.
+     * @throws IOException In case of exception.
+     */
+    public IgniteFsRangeInputStream(IgniteFsInputStream is, long start, long maxLen) throws IOException {
+        if (is == null)
+            throw new IllegalArgumentException("Input stream cannot be null.");
+
+        if (start < 0)
+            throw new IllegalArgumentException("Start position cannot be negative.");
+
+        if (start >= is.length())
+            throw new IllegalArgumentException("Start position cannot be greater that file length.");
+
+        if (maxLen < 0)
+            throw new IllegalArgumentException("Length cannot be negative.");
+
+        if (start + maxLen > is.length())
+            throw new IllegalArgumentException("Sum of start position and length cannot be greater than file length.");
+
+        this.is = is;
+        this.start = start;
+        this.maxLen = maxLen;
+
+        is.seek(start);
+    }
+
+    /** {@inheritDoc} */
+    @Override public long length() {
+        return is.length();
+    }
+
+    /**
+     * Constructor.
+     *
+     * @param is Base input stream.
+     * @param range File range.
+     * @throws IOException In case of exception.
+     */
+    public IgniteFsRangeInputStream(IgniteFsInputStream is, IgniteFsFileRange range) throws IOException {
+        this(is, range.start(), range.length());
+    }
+
+    /** {@inheritDoc} */
+    @Override public int read() throws IOException {
+        if (pos < maxLen) {
+            int res = is.read();
+
+            if (res != -1)
+                pos++;
+
+            return res;
+        }
+        else
+            return -1;
+    }
+
+    /** {@inheritDoc} */
+    @Override public int read(@NotNull byte[] b, int off, int len) throws IOException {
+        if (pos < maxLen) {
+            len = (int)Math.min(len, maxLen - pos);
+
+            int res = is.read(b, off, len);
+
+            if (res != -1)
+                pos += res;
+
+            return res;
+        }
+        else
+            return -1;
+    }
+
+    /** {@inheritDoc} */
+    @Override public int read(long pos, byte[] buf, int off, int len) throws IOException {
+        seek(pos);
+
+        return read(buf, off, len);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readFully(long pos, byte[] buf) throws IOException {
+        readFully(pos, buf, 0, buf.length);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readFully(long pos, byte[] buf, int off, int len) throws IOException {
+        seek(pos);
+
+        for (int readBytes = 0; readBytes < len;) {
+            int read = read(buf, off + readBytes, len - readBytes);
+
+            if (read == -1)
+                throw new EOFException("Failed to read stream fully (stream ends unexpectedly) [pos=" + pos +
+                    ", buf.length=" + buf.length + ", off=" + off + ", len=" + len + ']');
+
+            readBytes += read;
+        }
+    }
+
+    /** {@inheritDoc} */
+    @Override public void seek(long pos) throws IOException {
+        if (pos < 0)
+            throw new IOException("Seek position cannot be negative: " + pos);
+
+        is.seek(start + pos);
+
+        this.pos = pos;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long position() {
+        return pos;
+    }
+
+    /**
+     * Since range input stream represents a part of larger file stream, there is an offset at which this
+     * range input stream starts in original input stream. This method returns start offset of this input
+     * stream relative to original input stream.
+     *
+     * @return Start offset in original input stream.
+     */
+    public long startOffset() {
+        return start;
+    }
+
+    /** {@inheritDoc} */
+    @Override public int available() {
+        long l = maxLen - pos;
+
+        if (l < 0)
+            return 0;
+
+        if (l > Integer.MAX_VALUE)
+            return Integer.MAX_VALUE;
+
+        return (int)l;
+    }
+
+    /** {@inheritDoc} */
+    @Override public void close() throws IOException {
+        is.close();
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsRangeInputStream.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java
new file mode 100644
index 0000000..fdddc06
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java
@@ -0,0 +1,50 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs.mapreduce;
+
+import org.apache.ignite.*;
+import org.gridgain.grid.*;
+import org.gridgain.grid.ggfs.*;
+import org.gridgain.grid.ggfs.mapreduce.records.*;
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+
+/**
+ * GGFS record resolver. When {@link IgniteFsTask} is split into {@link IgniteFsJob}s each produced job will obtain
+ * {@link IgniteFsFileRange} based on file data location. Record resolver is invoked in each job before actual
+ * execution in order to adjust record boundaries in a way consistent with user data.
+ * <p>
+ * E.g., you may want to split your task into jobs so that each job process zero, one or several lines from that file.
+ * But file is split into ranges based on block locations, not new line boundaries. Using convenient record resolver
+ * you can adjust job range so that it covers the whole line(s).
+ * <p>
+ * The following record resolvers are available out of the box:
+ * <ul>
+ *     <li>{@link GridGgfsFixedLengthRecordResolver}</li>
+ *     <li>{@link GridGgfsByteDelimiterRecordResolver}</li>
+ *     <li>{@link GridGgfsStringDelimiterRecordResolver}</li>
+ *     <li>{@link GridGgfsNewLineRecordResolver}</li>
+ * </ul>
+ */
+public interface IgniteFsRecordResolver extends Serializable {
+    /**
+     * Adjusts record start offset and length.
+     *
+     * @param ggfs GGFS instance to use.
+     * @param stream Input stream for split file.
+     * @param suggestedRecord Suggested file system record.
+     * @return New adjusted record. If this method returns {@code null}, original record is ignored.
+     * @throws GridException If resolve failed.
+     * @throws IOException If resolve failed.
+     */
+    @Nullable public IgniteFsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
+        IgniteFsFileRange suggestedRecord) throws GridException, IOException;
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java
new file mode 100644
index 0000000..0721d0b
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java
@@ -0,0 +1,165 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs.mapreduce;
+
+import org.apache.ignite.*;
+import org.apache.ignite.cluster.*;
+import org.apache.ignite.compute.*;
+import org.apache.ignite.resources.*;
+import org.gridgain.grid.*;
+import org.gridgain.grid.ggfs.*;
+import org.gridgain.grid.kernal.*;
+import org.gridgain.grid.kernal.processors.ggfs.*;
+import org.gridgain.grid.util.typedef.internal.*;
+import org.jetbrains.annotations.*;
+
+import java.util.*;
+
+/**
+ * GGFS task which can be executed on the grid using one of {@code GridGgfs.execute()} methods. Essentially GGFS task
+ * is regular {@link org.apache.ignite.compute.ComputeTask} with different map logic. Instead of implementing
+ * {@link org.apache.ignite.compute.ComputeTask#map(List, Object)} method to split task into jobs, you must implement
+ * {@link IgniteFsTask#createJob(org.gridgain.grid.ggfs.IgniteFsPath, IgniteFsFileRange, GridGgfsTaskArgs)} method.
+ * <p>
+ * Each file participating in GGFS task is split into {@link IgniteFsFileRange}s first. Normally range is a number of
+ * consequent bytes located on a single node (see {@code GridGgfsGroupDataBlocksKeyMapper}). In case maximum range size
+ * is provided (either through {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()} or {@code GridGgfs.execute()}
+ * argument), then ranges could be further divided into smaller chunks.
+ * <p>
+ * Once file is split into ranges, each range is passed to {@code GridGgfsTask.createJob()} method in order to create a
+ * {@link IgniteFsJob}.
+ * <p>
+ * Finally all generated jobs are sent to Grid nodes for execution.
+ * <p>
+ * As with regular {@code GridComputeTask} you can define your own logic for results handling and reduce step.
+ * <p>
+ * Here is an example of such a task:
+ * <pre name="code" class="java">
+ * public class WordCountTask extends GridGgfsTask&lt;String, Integer&gt; {
+ *     &#64;Override
+ *     public GridGgfsJob createJob(GridGgfsPath path, GridGgfsFileRange range, GridGgfsTaskArgs&lt;T&gt; args) throws GridException {
+ *         // New job will be created for each range within each file.
+ *         // We pass user-provided argument (which is essentially a word to look for) to that job.
+ *         return new WordCountJob(args.userArgument());
+ *     }
+ *
+ *     // Aggregate results into one compound result.
+ *     public Integer reduce(List&lt;GridComputeJobResult&gt; results) throws GridException {
+ *         Integer total = 0;
+ *
+ *         for (GridComputeJobResult res : results) {
+ *             Integer cnt = res.getData();
+ *
+ *             // Null can be returned for non-existent file in case we decide to ignore such situations.
+ *             if (cnt != null)
+ *                 total += cnt;
+ *         }
+ *
+ *         return total;
+ *     }
+ * }
+ * </pre>
+ */
+public abstract class IgniteFsTask<T, R> extends ComputeTaskAdapter<GridGgfsTaskArgs<T>, R> {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** Injected grid. */
+    @IgniteInstanceResource
+    private Ignite ignite;
+
+    /** {@inheritDoc} */
+    @Nullable @Override public final Map<? extends ComputeJob, ClusterNode> map(List<ClusterNode> subgrid,
+        @Nullable GridGgfsTaskArgs<T> args) throws GridException {
+        assert ignite != null;
+        assert args != null;
+
+        IgniteFs ggfs = ignite.fileSystem(args.ggfsName());
+        GridGgfsProcessorAdapter ggfsProc = ((GridKernal) ignite).context().ggfs();
+
+        Map<ComputeJob, ClusterNode> splitMap = new HashMap<>();
+
+        Map<UUID, ClusterNode> nodes = mapSubgrid(subgrid);
+
+        for (IgniteFsPath path : args.paths()) {
+            IgniteFsFile file = ggfs.info(path);
+
+            if (file == null) {
+                if (args.skipNonExistentFiles())
+                    continue;
+                else
+                    throw new GridException("Failed to process GGFS file because it doesn't exist: " + path);
+            }
+
+            Collection<IgniteFsBlockLocation> aff = ggfs.affinity(path, 0, file.length(), args.maxRangeLength());
+
+            long totalLen = 0;
+
+            for (IgniteFsBlockLocation loc : aff) {
+                ClusterNode node = null;
+
+                for (UUID nodeId : loc.nodeIds()) {
+                    node = nodes.get(nodeId);
+
+                    if (node != null)
+                        break;
+                }
+
+                if (node == null)
+                    throw new GridException("Failed to find any of block affinity nodes in subgrid [loc=" + loc +
+                        ", subgrid=" + subgrid + ']');
+
+                IgniteFsJob job = createJob(path, new IgniteFsFileRange(file.path(), loc.start(), loc.length()), args);
+
+                if (job != null) {
+                    ComputeJob jobImpl = ggfsProc.createJob(job, ggfs.name(), file.path(), loc.start(),
+                        loc.length(), args.recordResolver());
+
+                    splitMap.put(jobImpl, node);
+                }
+
+                totalLen += loc.length();
+            }
+
+            assert totalLen == file.length();
+        }
+
+        return splitMap;
+    }
+
+    /**
+     * Callback invoked during task map procedure to create job that will process specified split
+     * for GGFS file.
+     *
+     * @param path Path.
+     * @param range File range based on consecutive blocks. This range will be further
+     *      realigned to record boundaries on destination node.
+     * @param args Task argument.
+     * @return GGFS job. If {@code null} is returned, the passed in file range will be skipped.
+     * @throws GridException If job creation failed.
+     */
+    @Nullable public abstract IgniteFsJob createJob(IgniteFsPath path, IgniteFsFileRange range,
+        GridGgfsTaskArgs<T> args) throws GridException;
+
+    /**
+     * Maps list by node ID.
+     *
+     * @param subgrid Subgrid.
+     * @return Map.
+     */
+    private Map<UUID, ClusterNode> mapSubgrid(Collection<ClusterNode> subgrid) {
+        Map<UUID, ClusterNode> res = U.newHashMap(subgrid.size());
+
+        for (ClusterNode node : subgrid)
+            res.put(node.id(), node);
+
+        return res;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java
index eb9de8d..808092e 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java
@@ -28,7 +28,7 @@ import java.util.*;
  * <p>
  * Note that you can use {@link GridGgfsStringDelimiterRecordResolver} if your delimiter is a plain string.
  */
-public class GridGgfsByteDelimiterRecordResolver implements GridGgfsRecordResolver, Externalizable {
+public class GridGgfsByteDelimiterRecordResolver implements IgniteFsRecordResolver, Externalizable {
     /** */
     private static final long serialVersionUID = 0L;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java
index 3230062..1edeb1a 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java
@@ -21,7 +21,7 @@ import java.io.*;
  * Record resolver which adjusts records to fixed length. That is, start offset of the record is shifted to the
  * nearest position so that {@code newStart % length == 0}.
  */
-public class GridGgfsFixedLengthRecordResolver implements GridGgfsRecordResolver, Externalizable {
+public class GridGgfsFixedLengthRecordResolver implements IgniteFsRecordResolver, Externalizable {
     /** */
     private static final long serialVersionUID = 0L;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
index 6e4ad66..407249b 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
@@ -46,27 +46,27 @@ public class GridGgfsAsyncImpl extends IgniteAsyncSupportAdapter implements Grid
     }
 
     /** {@inheritDoc} */
-    @Override public <T, R> R execute(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
+    @Override public <T, R> R execute(IgniteFsTask<T, R> task, @Nullable IgniteFsRecordResolver rslvr,
         Collection<IgniteFsPath> paths, @Nullable T arg) throws GridException {
         return saveOrGet(ggfs.executeAsync(task, rslvr, paths, arg));
     }
 
     /** {@inheritDoc} */
-    @Override public <T, R> R execute(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
+    @Override public <T, R> R execute(IgniteFsTask<T, R> task, @Nullable IgniteFsRecordResolver rslvr,
         Collection<IgniteFsPath> paths, boolean skipNonExistentFiles, long maxRangeLen, @Nullable T arg)
         throws GridException {
         return saveOrGet(ggfs.executeAsync(task, rslvr, paths, skipNonExistentFiles, maxRangeLen, arg));
     }
 
     /** {@inheritDoc} */
-    @Override public <T, R> R execute(Class<? extends GridGgfsTask<T, R>> taskCls,
-        @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, @Nullable T arg) throws GridException {
+    @Override public <T, R> R execute(Class<? extends IgniteFsTask<T, R>> taskCls,
+        @Nullable IgniteFsRecordResolver rslvr, Collection<IgniteFsPath> paths, @Nullable T arg) throws GridException {
         return saveOrGet(ggfs.executeAsync(taskCls, rslvr, paths, arg));
     }
 
     /** {@inheritDoc} */
-    @Override public <T, R> R execute(Class<? extends GridGgfsTask<T, R>> taskCls,
-        @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, boolean skipNonExistentFiles,
+    @Override public <T, R> R execute(Class<? extends IgniteFsTask<T, R>> taskCls,
+        @Nullable IgniteFsRecordResolver rslvr, Collection<IgniteFsPath> paths, boolean skipNonExistentFiles,
         long maxRangeLen, @Nullable T arg) throws GridException {
         return saveOrGet(ggfs.executeAsync(taskCls, rslvr, paths, skipNonExistentFiles, maxRangeLen, arg));
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
index 5145abd..dff827e 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
@@ -1667,27 +1667,27 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public <T, R> R execute(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
+    @Override public <T, R> R execute(IgniteFsTask<T, R> task, @Nullable IgniteFsRecordResolver rslvr,
         Collection<IgniteFsPath> paths, @Nullable T arg) throws GridException {
         return executeAsync(task, rslvr, paths, arg).get();
     }
 
     /** {@inheritDoc} */
-    @Override public <T, R> R execute(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
+    @Override public <T, R> R execute(IgniteFsTask<T, R> task, @Nullable IgniteFsRecordResolver rslvr,
         Collection<IgniteFsPath> paths, boolean skipNonExistentFiles, long maxRangeLen, @Nullable T arg)
         throws GridException {
         return executeAsync(task, rslvr, paths, skipNonExistentFiles, maxRangeLen, arg).get();
     }
 
     /** {@inheritDoc} */
-    @Override public <T, R> R execute(Class<? extends GridGgfsTask<T, R>> taskCls,
-        @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, @Nullable T arg) throws GridException {
+    @Override public <T, R> R execute(Class<? extends IgniteFsTask<T, R>> taskCls,
+        @Nullable IgniteFsRecordResolver rslvr, Collection<IgniteFsPath> paths, @Nullable T arg) throws GridException {
         return executeAsync(taskCls, rslvr, paths, arg).get();
     }
 
     /** {@inheritDoc} */
-    @Override public <T, R> R execute(Class<? extends GridGgfsTask<T, R>> taskCls,
-        @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, boolean skipNonExistentFiles,
+    @Override public <T, R> R execute(Class<? extends IgniteFsTask<T, R>> taskCls,
+        @Nullable IgniteFsRecordResolver rslvr, Collection<IgniteFsPath> paths, boolean skipNonExistentFiles,
         long maxRangeSize, @Nullable T arg) throws GridException {
         return executeAsync(taskCls, rslvr, paths, skipNonExistentFiles, maxRangeSize, arg).get();
     }
@@ -1701,7 +1701,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
      * @param arg Optional task argument.
      * @return Execution future.
      */
-    <T, R> IgniteFuture<R> executeAsync(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
+    <T, R> IgniteFuture<R> executeAsync(IgniteFsTask<T, R> task, @Nullable IgniteFsRecordResolver rslvr,
         Collection<IgniteFsPath> paths, @Nullable T arg) {
         return executeAsync(task, rslvr, paths, true, cfg.getMaximumTaskRangeLength(), arg);
     }
@@ -1720,7 +1720,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
      * @param arg Optional task argument.
      * @return Execution future.
      */
-    <T, R> IgniteFuture<R> executeAsync(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
+    <T, R> IgniteFuture<R> executeAsync(IgniteFsTask<T, R> task, @Nullable IgniteFsRecordResolver rslvr,
         Collection<IgniteFsPath> paths, boolean skipNonExistentFiles, long maxRangeLen, @Nullable T arg) {
         return ggfsCtx.kernalContext().task().execute(task, new GridGgfsTaskArgsImpl<>(cfg.getName(), paths, rslvr,
             skipNonExistentFiles, maxRangeLen, arg));
@@ -1735,8 +1735,8 @@ public final class GridGgfsImpl implements GridGgfsEx {
      * @param arg Optional task argument.
      * @return Execution future.
      */
-    <T, R> IgniteFuture<R> executeAsync(Class<? extends GridGgfsTask<T, R>> taskCls,
-        @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, @Nullable T arg) {
+    <T, R> IgniteFuture<R> executeAsync(Class<? extends IgniteFsTask<T, R>> taskCls,
+        @Nullable IgniteFsRecordResolver rslvr, Collection<IgniteFsPath> paths, @Nullable T arg) {
         return executeAsync(taskCls, rslvr, paths, true, cfg.getMaximumTaskRangeLength(), arg);
     }
 
@@ -1753,10 +1753,10 @@ public final class GridGgfsImpl implements GridGgfsEx {
      * @param arg Optional task argument.
      * @return Execution future.
      */
-    <T, R> IgniteFuture<R> executeAsync(Class<? extends GridGgfsTask<T, R>> taskCls,
-        @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, boolean skipNonExistentFiles,
+    <T, R> IgniteFuture<R> executeAsync(Class<? extends IgniteFsTask<T, R>> taskCls,
+        @Nullable IgniteFsRecordResolver rslvr, Collection<IgniteFsPath> paths, boolean skipNonExistentFiles,
         long maxRangeLen, @Nullable T arg) {
-        return ggfsCtx.kernalContext().task().execute((Class<GridGgfsTask<T, R>>)taskCls,
+        return ggfsCtx.kernalContext().task().execute((Class<IgniteFsTask<T, R>>)taskCls,
             new GridGgfsTaskArgsImpl<>(cfg.getName(), paths, rslvr, skipNonExistentFiles, maxRangeLen, arg));
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
index 2abbef7..4869103 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
@@ -42,7 +42,7 @@ public class GridGgfsJobImpl implements ComputeJob, GridInternalWrapper<IgniteFs
     private long len;
 
     /** Split resolver. */
-    private GridGgfsRecordResolver rslvr;
+    private IgniteFsRecordResolver rslvr;
 
     /** Injected grid. */
     @IgniteInstanceResource
@@ -61,7 +61,7 @@ public class GridGgfsJobImpl implements ComputeJob, GridInternalWrapper<IgniteFs
      * @param rslvr GGFS split resolver.
      */
     public GridGgfsJobImpl(IgniteFsJob job, String ggfsName, IgniteFsPath path, long start, long len,
-        GridGgfsRecordResolver rslvr) {
+        IgniteFsRecordResolver rslvr) {
         this.job = job;
         this.ggfsName = ggfsName;
         this.path = path;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
index 8a73665..99f817a 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
@@ -223,7 +223,7 @@ public class GridGgfsProcessor extends GridGgfsProcessorAdapter {
 
     /** {@inheritDoc} */
     @Nullable @Override public ComputeJob createJob(IgniteFsJob job, @Nullable String ggfsName, IgniteFsPath path,
-        long start, long length, GridGgfsRecordResolver recRslv) {
+        long start, long length, IgniteFsRecordResolver recRslv) {
         return new GridGgfsJobImpl(job, ggfsName, path, start, length, recRslv);
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
index 85ef324..066cd5c 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
@@ -68,5 +68,5 @@ public abstract class GridGgfsProcessorAdapter extends GridProcessorAdapter {
      * @return Compute job.
      */
     @Nullable public abstract ComputeJob createJob(IgniteFsJob job, @Nullable String ggfsName, IgniteFsPath path,
-        long start, long length, GridGgfsRecordResolver recRslv);
+        long start, long length, IgniteFsRecordResolver recRslv);
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskArgsImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskArgsImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskArgsImpl.java
index 516e5a4..44cac9d 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskArgsImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskArgsImpl.java
@@ -30,7 +30,7 @@ public class GridGgfsTaskArgsImpl<T> implements GridGgfsTaskArgs<T>,  Externaliz
     private Collection<IgniteFsPath> paths;
 
     /** Record resolver. */
-    private GridGgfsRecordResolver recRslvr;
+    private IgniteFsRecordResolver recRslvr;
 
     /** Skip non existent files flag. */
     private boolean skipNonExistentFiles;
@@ -58,7 +58,7 @@ public class GridGgfsTaskArgsImpl<T> implements GridGgfsTaskArgs<T>,  Externaliz
      * @param maxRangeLen Maximum range length.
      * @param usrArg User argument.
      */
-    public GridGgfsTaskArgsImpl(String ggfsName, Collection<IgniteFsPath> paths, GridGgfsRecordResolver recRslvr,
+    public GridGgfsTaskArgsImpl(String ggfsName, Collection<IgniteFsPath> paths, IgniteFsRecordResolver recRslvr,
         boolean skipNonExistentFiles, long maxRangeLen, T usrArg) {
         this.ggfsName = ggfsName;
         this.paths = paths;
@@ -79,7 +79,7 @@ public class GridGgfsTaskArgsImpl<T> implements GridGgfsTaskArgs<T>,  Externaliz
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsRecordResolver recordResolver() {
+    @Override public IgniteFsRecordResolver recordResolver() {
         return recRslvr;
     }
 
@@ -119,7 +119,7 @@ public class GridGgfsTaskArgsImpl<T> implements GridGgfsTaskArgs<T>,  Externaliz
         ggfsName = U.readString(in);
         paths = U.readCollection(in);
 
-        recRslvr = (GridGgfsRecordResolver)in.readObject();
+        recRslvr = (IgniteFsRecordResolver)in.readObject();
         skipNonExistentFiles = in.readBoolean();
         maxRangeLen = in.readLong();
         usrArg = (T)in.readObject();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
index 5654a95..e73779a 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
@@ -57,7 +57,7 @@ public class GridNoopGgfsProcessor extends GridGgfsProcessorAdapter {
 
     /** {@inheritDoc} */
     @Nullable @Override public ComputeJob createJob(IgniteFsJob job, @Nullable String ggfsName, IgniteFsPath path,
-        long start, long length, GridGgfsRecordResolver recRslv) {
+        long start, long length, IgniteFsRecordResolver recRslv) {
         return null;
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
index 9e3838a..9443ee7 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
@@ -35,7 +35,7 @@ import static org.gridgain.grid.cache.GridCacheWriteSynchronizationMode.*;
 import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
- * Tests for {@link GridGgfsTask}.
+ * Tests for {@link org.gridgain.grid.ggfs.mapreduce.IgniteFsTask}.
  */
 public class GridGgfsTaskSelfTest extends GridGgfsCommonAbstractTest {
     /** Predefined words dictionary. */
@@ -228,7 +228,7 @@ public class GridGgfsTaskSelfTest extends GridGgfsCommonAbstractTest {
     /**
      * Task.
      */
-    private static class Task extends GridGgfsTask<String, IgniteBiTuple<Long, Integer>> {
+    private static class Task extends IgniteFsTask<String, IgniteBiTuple<Long, Integer>> {
         /** {@inheritDoc} */
         @Override public IgniteFsJob createJob(IgniteFsPath path, IgniteFsFileRange range,
             GridGgfsTaskArgs<String> args) throws GridException {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cd638fe/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
index b131f20..eca987f 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
@@ -872,28 +872,28 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
         }
 
         /** {@inheritDoc} */
-        @Override public <T, R> R execute(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
+        @Override public <T, R> R execute(IgniteFsTask<T, R> task, @Nullable IgniteFsRecordResolver rslvr,
             Collection<IgniteFsPath> paths, @Nullable T arg) throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Override public <T, R> R execute(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
+        @Override public <T, R> R execute(IgniteFsTask<T, R> task, @Nullable IgniteFsRecordResolver rslvr,
             Collection<IgniteFsPath> paths, boolean skipNonExistentFiles, long maxRangeLen, @Nullable T arg)
             throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Override public <T, R> R execute(Class<? extends GridGgfsTask<T, R>> taskCls,
-            @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, @Nullable T arg)
+        @Override public <T, R> R execute(Class<? extends IgniteFsTask<T, R>> taskCls,
+            @Nullable IgniteFsRecordResolver rslvr, Collection<IgniteFsPath> paths, @Nullable T arg)
             throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Override public <T, R> R execute(Class<? extends GridGgfsTask<T, R>> taskCls,
-            @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, boolean skipNonExistentFiles,
+        @Override public <T, R> R execute(Class<? extends IgniteFsTask<T, R>> taskCls,
+            @Nullable IgniteFsRecordResolver rslvr, Collection<IgniteFsPath> paths, boolean skipNonExistentFiles,
             long maxRangeLen, @Nullable T arg) throws GridException {
             return null;
         }


[04/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/GridPortableWriter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableWriter.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableWriter.java
index 0e91d55..769faa0 100644
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableWriter.java
+++ b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableWriter.java
@@ -16,7 +16,7 @@ import java.util.*;
 import java.util.Date;
 
 /**
- * Writer for portable object used in {@link GridPortableMarshalAware} implementations.
+ * Writer for portable object used in {@link PortableMarshalAware} implementations.
  * Useful for the cases when user wants a fine-grained control over serialization.
  * <p>
  * Note that GridGain never writes full strings for field or type names. Instead,
@@ -24,212 +24,212 @@ import java.util.Date;
  * It has been tested that hash code conflicts for the type names or the field names
  * within the same type are virtually non-existent and, to gain performance, it is safe
  * to work with hash codes. For the cases when hash codes for different types or fields
- * actually do collide, GridGain provides {@link GridPortableIdMapper} which
+ * actually do collide, GridGain provides {@link PortableIdMapper} which
  * allows to override the automatically generated hash code IDs for the type and field names.
  */
 public interface GridPortableWriter {
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeByte(String fieldName, byte val) throws GridPortableException;
+    public void writeByte(String fieldName, byte val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeShort(String fieldName, short val) throws GridPortableException;
+    public void writeShort(String fieldName, short val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeInt(String fieldName, int val) throws GridPortableException;
+    public void writeInt(String fieldName, int val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeLong(String fieldName, long val) throws GridPortableException;
+    public void writeLong(String fieldName, long val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeFloat(String fieldName, float val) throws GridPortableException;
+    public void writeFloat(String fieldName, float val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeDouble(String fieldName, double val) throws GridPortableException;
+    public void writeDouble(String fieldName, double val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeChar(String fieldName, char val) throws GridPortableException;
+    public void writeChar(String fieldName, char val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeBoolean(String fieldName, boolean val) throws GridPortableException;
+    public void writeBoolean(String fieldName, boolean val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeString(String fieldName, @Nullable String val) throws GridPortableException;
+    public void writeString(String fieldName, @Nullable String val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val UUID to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeUuid(String fieldName, @Nullable UUID val) throws GridPortableException;
+    public void writeUuid(String fieldName, @Nullable UUID val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Date to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeDate(String fieldName, @Nullable Date val) throws GridPortableException;
+    public void writeDate(String fieldName, @Nullable Date val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Timestamp to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeTimestamp(String fieldName, @Nullable Timestamp val) throws GridPortableException;
+    public void writeTimestamp(String fieldName, @Nullable Timestamp val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param obj Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeObject(String fieldName, @Nullable Object obj) throws GridPortableException;
+    public void writeObject(String fieldName, @Nullable Object obj) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeByteArray(String fieldName, @Nullable byte[] val) throws GridPortableException;
+    public void writeByteArray(String fieldName, @Nullable byte[] val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeShortArray(String fieldName, @Nullable short[] val) throws GridPortableException;
+    public void writeShortArray(String fieldName, @Nullable short[] val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeIntArray(String fieldName, @Nullable int[] val) throws GridPortableException;
+    public void writeIntArray(String fieldName, @Nullable int[] val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeLongArray(String fieldName, @Nullable long[] val) throws GridPortableException;
+    public void writeLongArray(String fieldName, @Nullable long[] val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeFloatArray(String fieldName, @Nullable float[] val) throws GridPortableException;
+    public void writeFloatArray(String fieldName, @Nullable float[] val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeDoubleArray(String fieldName, @Nullable double[] val) throws GridPortableException;
+    public void writeDoubleArray(String fieldName, @Nullable double[] val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeCharArray(String fieldName, @Nullable char[] val) throws GridPortableException;
+    public void writeCharArray(String fieldName, @Nullable char[] val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeBooleanArray(String fieldName, @Nullable boolean[] val) throws GridPortableException;
+    public void writeBooleanArray(String fieldName, @Nullable boolean[] val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeStringArray(String fieldName, @Nullable String[] val) throws GridPortableException;
+    public void writeStringArray(String fieldName, @Nullable String[] val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeUuidArray(String fieldName, @Nullable UUID[] val) throws GridPortableException;
+    public void writeUuidArray(String fieldName, @Nullable UUID[] val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeDateArray(String fieldName, @Nullable Date[] val) throws GridPortableException;
+    public void writeDateArray(String fieldName, @Nullable Date[] val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeObjectArray(String fieldName, @Nullable Object[] val) throws GridPortableException;
+    public void writeObjectArray(String fieldName, @Nullable Object[] val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param col Collection to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public <T> void writeCollection(String fieldName, @Nullable Collection<T> col) throws GridPortableException;
+    public <T> void writeCollection(String fieldName, @Nullable Collection<T> col) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param map Map to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public <K, V> void writeMap(String fieldName, @Nullable Map<K, V> map) throws GridPortableException;
+    public <K, V> void writeMap(String fieldName, @Nullable Map<K, V> map) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public <T extends Enum<?>> void writeEnum(String fieldName, T val) throws GridPortableException;
+    public <T extends Enum<?>> void writeEnum(String fieldName, T val) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public <T extends Enum<?>> void writeEnumArray(String fieldName, T[] val) throws GridPortableException;
+    public <T extends Enum<?>> void writeEnumArray(String fieldName, T[] val) throws PortableException;
 
     /**
      * Gets raw writer. Raw writer does not write field name hash codes, therefore,

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/PortableBuilder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableBuilder.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableBuilder.java
new file mode 100644
index 0000000..e353d7b
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableBuilder.java
@@ -0,0 +1,129 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.portables;
+
+import org.jetbrains.annotations.*;
+
+/**
+ * Portable object builder. Provides ability to build portable objects dynamically
+ * without having class definitions.
+ * <p>
+ * Here is an example of how a portable object can be built dynamically:
+ * <pre name=code class=java>
+ * GridPortableBuilder builder = GridGain.grid().portables().builder("org.project.MyObject");
+ *
+ * builder.setField("fieldA", "A");
+ * builder.setField("fieldB", "B");
+ *
+ * GridPortableObject portableObj = builder.build();
+ * </pre>
+ *
+ * <p>
+ * Also builder can be initialized by existing portable object. This allows changing some fields without affecting
+ * other fields.
+ * <pre name=code class=java>
+ * GridPortableBuilder builder = GridGain.grid().portables().builder(person);
+ *
+ * builder.setField("name", "John");
+ *
+ * person = builder.build();
+ * </pre>
+ * </p>
+ *
+ * If you need to modify nested portable object you can get builder for nested object using
+ * {@link #getField(String)}, changes made on nested builder will affect parent object,
+ * for example:
+ *
+ * <pre name=code class=java>
+ * GridPortableBuilder personBuilder = grid.portables().createBuilder(personPortableObj);
+ * GridPortableBuilder addressBuilder = personBuilder.setField("address");
+ *
+ * addressBuilder.setField("city", "New York");
+ *
+ * personPortableObj = personBuilder.build();
+ *
+ * // Should be "New York".
+ * String city = personPortableObj.getField("address").getField("city");
+ * </pre>
+ *
+ * @see org.apache.ignite.IgnitePortables#builder(int)
+ * @see org.apache.ignite.IgnitePortables#builder(String)
+ * @see org.apache.ignite.IgnitePortables#builder(GridPortableObject)
+ */
+public interface PortableBuilder {
+    /**
+     * Returns value assigned to the specified field.
+     * If the value is a portable object instance of {@code GridPortableBuilder} will be returned,
+     * which can be modified.
+     * <p>
+     * Collections and maps returned from this method are modifiable.
+     *
+     * @param name Field name.
+     * @return Filed value.
+     */
+    public <T> T getField(String name);
+
+    /**
+     * Sets field value.
+     *
+     * @param name Field name.
+     * @param val Field value (cannot be {@code null}).
+     * @see GridPortableObject#metaData()
+     */
+    public PortableBuilder setField(String name, Object val);
+
+    /**
+     * Sets field value with value type specification.
+     * <p>
+     * Field type is needed for proper metadata update.
+     *
+     * @param name Field name.
+     * @param val Field value.
+     * @param type Field type.
+     * @see GridPortableObject#metaData()
+     */
+    public <T> PortableBuilder setField(String name, @Nullable T val, Class<? super T> type);
+
+    /**
+     * Sets field value.
+     * <p>
+     * This method should be used if field is portable object.
+     *
+     * @param name Field name.
+     * @param builder Builder for object field.
+     */
+    public PortableBuilder setField(String name, @Nullable PortableBuilder builder);
+
+    /**
+     * Removes field from this builder.
+     *
+     * @param fieldName Field name.
+     * @return {@code this} instance for chaining.
+     */
+    public PortableBuilder removeField(String fieldName);
+
+    /**
+     * Sets hash code for resulting portable object returned by {@link #build()} method.
+     * <p>
+     * If not set {@code 0} is used.
+     *
+     * @param hashCode Hash code.
+     * @return {@code this} instance for chaining.
+     */
+    public PortableBuilder hashCode(int hashCode);
+
+    /**
+     * Builds portable object.
+     *
+     * @return Portable object.
+     * @throws PortableException In case of error.
+     */
+    public GridPortableObject build() throws PortableException;
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/PortableConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableConfiguration.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableConfiguration.java
new file mode 100644
index 0000000..573836e
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableConfiguration.java
@@ -0,0 +1,181 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.portables;
+
+import org.gridgain.grid.util.typedef.internal.*;
+
+import java.sql.Timestamp;
+import java.util.*;
+
+/**
+ * Defines configuration for GridGain portable functionality. All configuration
+ * properties defined here can be overridden on per-type level in
+ * {@link GridPortableTypeConfiguration}. Type configurations are provided via
+ * {@link #getTypeConfigurations()} method.
+ */
+public class PortableConfiguration {
+    /** Class names. */
+    private Collection<String> clsNames;
+
+    /** ID mapper. */
+    private PortableIdMapper idMapper;
+
+    /** Serializer. */
+    private GridPortableSerializer serializer;
+
+    /** Types. */
+    private Collection<GridPortableTypeConfiguration> typeCfgs;
+
+    /** Use timestamp flag. */
+    private boolean useTs = true;
+
+    /** Meta data enabled flag. */
+    private boolean metaDataEnabled = true;
+
+    /** Keep deserialized flag. */
+    private boolean keepDeserialized = true;
+
+    /**
+     * Gets class names.
+     *
+     * @return Class names.
+     */
+    public Collection<String> getClassNames() {
+        return clsNames;
+    }
+
+    /**
+     * Sets class names.
+     *
+     * @param clsNames Class names.
+     */
+    public void setClassNames(Collection<String> clsNames) {
+        this.clsNames = clsNames;
+    }
+
+    /**
+     * Gets ID mapper.
+     *
+     * @return ID mapper.
+     */
+    public PortableIdMapper getIdMapper() {
+        return idMapper;
+    }
+
+    /**
+     * Sets ID mapper.
+     *
+     * @param idMapper ID mapper.
+     */
+    public void setIdMapper(PortableIdMapper idMapper) {
+        this.idMapper = idMapper;
+    }
+
+    /**
+     * Gets serializer.
+     *
+     * @return Serializer.
+     */
+    public GridPortableSerializer getSerializer() {
+        return serializer;
+    }
+
+    /**
+     * Sets serializer.
+     *
+     * @param serializer Serializer.
+     */
+    public void setSerializer(GridPortableSerializer serializer) {
+        this.serializer = serializer;
+    }
+
+    /**
+     * Gets types configuration.
+     *
+     * @return Types configuration.
+     */
+    public Collection<GridPortableTypeConfiguration> getTypeConfigurations() {
+        return typeCfgs;
+    }
+
+    /**
+     * Sets type configurations.
+     *
+     * @param typeCfgs Type configurations.
+     */
+    public void setTypeConfigurations(Collection<GridPortableTypeConfiguration> typeCfgs) {
+        this.typeCfgs = typeCfgs;
+    }
+
+    /**
+     * If {@code true} then date values converted to {@link Timestamp} on deserialization.
+     * <p>
+     * Default value is {@code true}.
+     *
+     * @return Flag indicating whether date values converted to {@link Timestamp} during unmarshalling.
+     */
+    public boolean isUseTimestamp() {
+        return useTs;
+    }
+
+    /**
+     * @param useTs Flag indicating whether date values converted to {@link Timestamp} during unmarshalling.
+     */
+    public void setUseTimestamp(boolean useTs) {
+        this.useTs = useTs;
+    }
+
+    /**
+     * If {@code true}, meta data will be collected or all types. If you need to override this behaviour for
+     * some specific type, use {@link GridPortableTypeConfiguration#setMetaDataEnabled(Boolean)} method.
+     * <p>
+     * Default value if {@code true}.
+     *
+     * @return Whether meta data is collected.
+     */
+    public boolean isMetaDataEnabled() {
+        return metaDataEnabled;
+    }
+
+    /**
+     * @param metaDataEnabled Whether meta data is collected.
+     */
+    public void setMetaDataEnabled(boolean metaDataEnabled) {
+        this.metaDataEnabled = metaDataEnabled;
+    }
+
+    /**
+     * If {@code true}, {@link GridPortableObject} will cache deserialized instance after
+     * {@link GridPortableObject#deserialize()} is called. All consequent calls of this
+     * method on the same instance of {@link GridPortableObject} will return that cached
+     * value without actually deserializing portable object. If you need to override this
+     * behaviour for some specific type, use {@link GridPortableTypeConfiguration#setKeepDeserialized(Boolean)}
+     * method.
+     * <p>
+     * Default value if {@code true}.
+     *
+     * @return Whether deserialized value is kept.
+     */
+    public boolean isKeepDeserialized() {
+        return keepDeserialized;
+    }
+
+    /**
+     * @param keepDeserialized Whether deserialized value is kept.
+     */
+    public void setKeepDeserialized(boolean keepDeserialized) {
+        this.keepDeserialized = keepDeserialized;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(PortableConfiguration.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/PortableException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableException.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableException.java
new file mode 100644
index 0000000..a6815c0
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableException.java
@@ -0,0 +1,49 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.portables;
+
+import org.gridgain.grid.*;
+import org.jetbrains.annotations.*;
+
+/**
+ * Exception indicating portable object serialization error.
+ */
+public class PortableException extends GridRuntimeException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Creates portable exception with error message.
+     *
+     * @param msg Error message.
+     */
+    public PortableException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * Creates portable exception with {@link Throwable} as a cause.
+     *
+     * @param cause Cause.
+     */
+    public PortableException(Throwable cause) {
+        super(cause);
+    }
+
+    /**
+     * Creates portable exception with error message and {@link Throwable} as a cause.
+     *
+     * @param msg Error message.
+     * @param cause Cause.
+     */
+    public PortableException(String msg, @Nullable Throwable cause) {
+        super(msg, cause);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/PortableIdMapper.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableIdMapper.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableIdMapper.java
new file mode 100644
index 0000000..dafaca9
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableIdMapper.java
@@ -0,0 +1,47 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.portables;
+
+/**
+ * Type and field ID mapper for portable objects. GridGain never writes full
+ * strings for field or type names. Instead, for performance reasons, GridGain
+ * writes integer hash codes for type and field names. It has been tested that
+ * hash code conflicts for the type names or the field names
+ * within the same type are virtually non-existent and, to gain performance, it is safe
+ * to work with hash codes. For the cases when hash codes for different types or fields
+ * actually do collide {@code GridPortableIdMapper} allows to override the automatically
+ * generated hash code IDs for the type and field names.
+ * <p>
+ * Portable ID mapper can be configured for all portable objects via
+ * {@link PortableConfiguration#getIdMapper()} method, or for a specific
+ * portable type via {@link GridPortableTypeConfiguration#getIdMapper()} method.
+ */
+public interface PortableIdMapper {
+    /**
+     * Gets type ID for provided class name.
+     * <p>
+     * If {@code 0} is returned, hash code of class simple name will be used.
+     *
+     * @param clsName Class name.
+     * @return Type ID.
+     */
+    public int typeId(String clsName);
+
+    /**
+     * Gets ID for provided field.
+     * <p>
+     * If {@code 0} is returned, hash code of field name will be used.
+     *
+     * @param typeId Type ID.
+     * @param fieldName Field name.
+     * @return Field ID.
+     */
+    public int fieldId(int typeId, String fieldName);
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/PortableInvalidClassException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableInvalidClassException.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableInvalidClassException.java
new file mode 100644
index 0000000..5322fa9
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableInvalidClassException.java
@@ -0,0 +1,50 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.portables;
+
+import org.jetbrains.annotations.*;
+
+/**
+ * Exception indicating that class needed for deserialization of portable object does not exist.
+ * <p>
+ * Thrown from {@link GridPortableObject#deserialize()} method.
+ */
+public class PortableInvalidClassException extends PortableException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Creates invalid class exception with error message.
+     *
+     * @param msg Error message.
+     */
+    public PortableInvalidClassException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * Creates invalid class exception with {@link Throwable} as a cause.
+     *
+     * @param cause Cause.
+     */
+    public PortableInvalidClassException(Throwable cause) {
+        super(cause);
+    }
+
+    /**
+     * Creates invalid class exception with error message and {@link Throwable} as a cause.
+     *
+     * @param msg Error message.
+     * @param cause Cause.
+     */
+    public PortableInvalidClassException(String msg, @Nullable Throwable cause) {
+        super(msg, cause);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/PortableMarshalAware.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableMarshalAware.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableMarshalAware.java
new file mode 100644
index 0000000..d0b5bcb
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableMarshalAware.java
@@ -0,0 +1,40 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.portables;
+
+/**
+ * Interface that allows to implement custom serialization
+ * logic for portable objects. Portable objects are not required
+ * to implement this interface, in which case GridGain will automatically
+ * serialize portable objects using reflection.
+ * <p>
+ * This interface, in a way, is analogous to {@link java.io.Externalizable}
+ * interface, which allows users to override default serialization logic,
+ * usually for performance reasons. The only difference here is that portable
+ * serialization is already very fast and implementing custom serialization
+ * logic for portables does not provide significant performance gains.
+ */
+public interface PortableMarshalAware {
+    /**
+     * Writes fields to provided writer.
+     *
+     * @param writer Portable object writer.
+     * @throws PortableException In case of error.
+     */
+    public void writePortable(GridPortableWriter writer) throws PortableException;
+
+    /**
+     * Reads fields from provided reader.
+     *
+     * @param reader Portable object reader.
+     * @throws PortableException In case of error.
+     */
+    public void readPortable(GridPortableReader reader) throws PortableException;
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/client/GridClientConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/client/GridClientConfiguration.java b/modules/core/src/main/java/org/gridgain/client/GridClientConfiguration.java
index 9f30724..12ae587 100644
--- a/modules/core/src/main/java/org/gridgain/client/GridClientConfiguration.java
+++ b/modules/core/src/main/java/org/gridgain/client/GridClientConfiguration.java
@@ -110,7 +110,7 @@ public class GridClientConfiguration {
     private boolean daemon;
 
     /** Portable configuration. */
-    private GridPortableConfiguration portableCfg;
+    private PortableConfiguration portableCfg;
 
     /**
      * Creates default configuration.
@@ -628,7 +628,7 @@ public class GridClientConfiguration {
      *
      * @return Portable configuration.
      */
-    public GridPortableConfiguration getPortableConfiguration() {
+    public PortableConfiguration getPortableConfiguration() {
         return portableCfg;
     }
 
@@ -637,7 +637,7 @@ public class GridClientConfiguration {
      *
      * @param portableCfg Portable configuration.
      */
-    public void setPortableConfiguration(@Nullable GridPortableConfiguration portableCfg) {
+    public void setPortableConfiguration(@Nullable PortableConfiguration portableCfg) {
         this.portableCfg = portableCfg;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetConfiguration.java
index 0cccd46..fcc83ac 100644
--- a/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetConfiguration.java
+++ b/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetConfiguration.java
@@ -17,7 +17,7 @@ import java.util.*;
 /**
  * Mirror of .Net class GridDotNetConfiguration.cs
  */
-public class GridDotNetConfiguration implements GridPortableMarshalAware {
+public class GridDotNetConfiguration implements PortableMarshalAware {
     /** */
     private GridDotNetPortableConfiguration portableCfg;
 
@@ -73,7 +73,7 @@ public class GridDotNetConfiguration implements GridPortableMarshalAware {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         GridPortableRawWriter rawWriter = writer.rawWriter();
 
         rawWriter.writeObject(portableCfg);
@@ -81,7 +81,7 @@ public class GridDotNetConfiguration implements GridPortableMarshalAware {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         GridPortableRawReader rawReader = reader.rawReader();
 
         portableCfg = (GridDotNetPortableConfiguration)rawReader.readObject();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableConfiguration.java
index f20ac76..cbe2348 100644
--- a/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableConfiguration.java
+++ b/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableConfiguration.java
@@ -17,7 +17,7 @@ import java.util.*;
 /**
  * Mirror of .Net class GridDotNetPortableConfiguration.cs
  */
-public class GridDotNetPortableConfiguration implements GridPortableMarshalAware {
+public class GridDotNetPortableConfiguration implements PortableMarshalAware {
     /** */
     private Collection<GridDotNetPortableTypeConfiguration> typesCfg;
 
@@ -167,7 +167,7 @@ public class GridDotNetPortableConfiguration implements GridPortableMarshalAware
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         GridPortableRawWriter rawWriter = writer.rawWriter();
 
         rawWriter.writeCollection(typesCfg);
@@ -186,7 +186,7 @@ public class GridDotNetPortableConfiguration implements GridPortableMarshalAware
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         GridPortableRawReader rawReader = reader.rawReader();
 
         typesCfg = rawReader.readCollection();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableTypeConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableTypeConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableTypeConfiguration.java
index 5fbca5c..a984966 100644
--- a/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableTypeConfiguration.java
+++ b/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableTypeConfiguration.java
@@ -16,7 +16,7 @@ import org.jetbrains.annotations.*;
 /**
  * Mirror of .Net class GridDotNetPortableTypeConfiguration.cs
  */
-public class GridDotNetPortableTypeConfiguration implements GridPortableMarshalAware {
+public class GridDotNetPortableTypeConfiguration implements PortableMarshalAware {
     /** */
     private String assemblyName;
 
@@ -175,7 +175,7 @@ public class GridDotNetPortableTypeConfiguration implements GridPortableMarshalA
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         GridPortableRawWriter rawWriter = writer.rawWriter();
 
         rawWriter.writeString(assemblyName);
@@ -196,7 +196,7 @@ public class GridDotNetPortableTypeConfiguration implements GridPortableMarshalA
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         GridPortableRawReader rawReader = reader.rawReader();
 
         assemblyName = rawReader.readString();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/GridPortablesImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/GridPortablesImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/GridPortablesImpl.java
index bf1c86b..5bdf615 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/GridPortablesImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/GridPortablesImpl.java
@@ -48,7 +48,7 @@ public class GridPortablesImpl implements IgnitePortables {
     }
 
     /** {@inheritDoc} */
-    @Override public <T> T toPortable(@Nullable Object obj) throws GridPortableException {
+    @Override public <T> T toPortable(@Nullable Object obj) throws PortableException {
         guard();
 
         try {
@@ -60,7 +60,7 @@ public class GridPortablesImpl implements IgnitePortables {
     }
 
     /** {@inheritDoc} */
-    @Override public GridPortableBuilder builder(int typeId) {
+    @Override public PortableBuilder builder(int typeId) {
         guard();
 
         try {
@@ -72,7 +72,7 @@ public class GridPortablesImpl implements IgnitePortables {
     }
 
     /** {@inheritDoc} */
-    @Override public GridPortableBuilder builder(String typeName) {
+    @Override public PortableBuilder builder(String typeName) {
         guard();
 
         try {
@@ -84,7 +84,7 @@ public class GridPortablesImpl implements IgnitePortables {
     }
 
     /** {@inheritDoc} */
-    @Override public GridPortableBuilder builder(GridPortableObject portableObj) {
+    @Override public PortableBuilder builder(GridPortableObject portableObj) {
         guard();
 
         try {
@@ -96,7 +96,7 @@ public class GridPortablesImpl implements IgnitePortables {
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public GridPortableMetadata metadata(Class<?> cls) throws GridPortableException {
+    @Nullable @Override public GridPortableMetadata metadata(Class<?> cls) throws PortableException {
         guard();
 
         try {
@@ -108,7 +108,7 @@ public class GridPortablesImpl implements IgnitePortables {
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public GridPortableMetadata metadata(String typeName) throws GridPortableException {
+    @Nullable @Override public GridPortableMetadata metadata(String typeName) throws PortableException {
         guard();
 
         try {
@@ -120,7 +120,7 @@ public class GridPortablesImpl implements IgnitePortables {
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public GridPortableMetadata metadata(int typeId) throws GridPortableException {
+    @Nullable @Override public GridPortableMetadata metadata(int typeId) throws PortableException {
         guard();
 
         try {
@@ -132,7 +132,7 @@ public class GridPortablesImpl implements IgnitePortables {
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridPortableMetadata> metadata() throws GridPortableException {
+    @Override public Collection<GridPortableMetadata> metadata() throws PortableException {
         guard();
 
         try {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/managers/indexing/GridIndexingManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/managers/indexing/GridIndexingManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/managers/indexing/GridIndexingManager.java
index c20a966..02104ee 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/managers/indexing/GridIndexingManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/managers/indexing/GridIndexingManager.java
@@ -1348,7 +1348,7 @@ public class GridIndexingManager extends GridManagerAdapter<GridIndexingSpi> {
             try {
                 return ((GridPortableObject)obj).field(propName);
             }
-            catch (GridPortableException e) {
+            catch (PortableException e) {
                 throw new GridSpiException(e);
             }
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/affinity/GridAffinityAssignmentCache.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/affinity/GridAffinityAssignmentCache.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/affinity/GridAffinityAssignmentCache.java
index 214e4e3..49206d5 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/affinity/GridAffinityAssignmentCache.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/affinity/GridAffinityAssignmentCache.java
@@ -252,7 +252,7 @@ public class GridAffinityAssignmentCache {
             try {
                 key = ctx.marshalToPortable(key);
             }
-            catch (GridPortableException e) {
+            catch (PortableException e) {
                 U.error(log, "Failed to marshal key to portable: " + key, e);
             }
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
index 8b521dc..d10beaa 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
@@ -1287,7 +1287,7 @@ public abstract class GridCacheAdapter<K, V> extends GridMetadataAwareAdapter im
             try {
                 key = (K)ctx.marshalToPortable(key);
             }
-            catch (GridPortableException e) {
+            catch (PortableException e) {
                 throw new GridRuntimeException(e);
             }
         }
@@ -3001,7 +3001,7 @@ public abstract class GridCacheAdapter<K, V> extends GridMetadataAwareAdapter im
                     try {
                         key0 = (K)ctx.marshalToPortable(key);
                     }
-                    catch (GridPortableException e) {
+                    catch (PortableException e) {
                         return new GridFinishedFuture<>(ctx.kernalContext(), e);
                     }
                 }
@@ -3352,7 +3352,7 @@ public abstract class GridCacheAdapter<K, V> extends GridMetadataAwareAdapter im
 
             ctx.store().loadCache(new CIX3<K, V, GridCacheVersion>() {
                 @Override public void applyx(K key, V val, @Nullable GridCacheVersion ver)
-                    throws GridPortableException {
+                    throws PortableException {
                     assert ver == null;
 
                     if (p != null && !p.apply(key, val))
@@ -4132,7 +4132,7 @@ public abstract class GridCacheAdapter<K, V> extends GridMetadataAwareAdapter im
             try {
                 key = (K)ctx.marshalToPortable(key);
             }
-            catch (GridPortableException e) {
+            catch (PortableException e) {
                 throw new GridRuntimeException(e);
             }
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheContext.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheContext.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheContext.java
index c3be292..d893403 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheContext.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheContext.java
@@ -1570,9 +1570,9 @@ public class GridCacheContext<K, V> implements Externalizable {
     /**
      * @param obj Object.
      * @return Portable object.
-     * @throws org.apache.ignite.portables.GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    @Nullable public Object marshalToPortable(@Nullable Object obj) throws GridPortableException {
+    @Nullable public Object marshalToPortable(@Nullable Object obj) throws PortableException {
         assert portableEnabled();
 
         if (obj == null)

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDefaultAffinityKeyMapper.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDefaultAffinityKeyMapper.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDefaultAffinityKeyMapper.java
index 5ec12a9..86dc530 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDefaultAffinityKeyMapper.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDefaultAffinityKeyMapper.java
@@ -91,7 +91,7 @@ public class GridCacheDefaultAffinityKeyMapper implements GridCacheAffinityKeyMa
                         return po.field(affKeyFieldName);
                 }
             }
-            catch (GridPortableException e) {
+            catch (PortableException e) {
                 U.error(log, "Failed to get affinity field from portable object: " + key, e);
             }
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTxLocalAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTxLocalAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTxLocalAdapter.java
index d8b74b4..9e4ff88 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTxLocalAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTxLocalAdapter.java
@@ -2171,7 +2171,7 @@ public abstract class GridCacheTxLocalAdapter<K, V> extends GridCacheTxAdapter<K
                         map0.put(key, val);
                     }
                 }
-                catch (GridPortableException e) {
+                catch (PortableException e) {
                     return new GridFinishedFuture<>(cctx.kernalContext(), e);
                 }
             }
@@ -2188,7 +2188,7 @@ public abstract class GridCacheTxLocalAdapter<K, V> extends GridCacheTxAdapter<K
                         transformMap0.put(key, e.getValue());
                     }
                 }
-                catch (GridPortableException e) {
+                catch (PortableException e) {
                     return new GridFinishedFuture<>(cctx.kernalContext(), e);
                 }
             }
@@ -2375,7 +2375,7 @@ public abstract class GridCacheTxLocalAdapter<K, V> extends GridCacheTxAdapter<K
                 else
                     keys0 = null;
             }
-            catch (GridPortableException e) {
+            catch (PortableException e) {
                 return new GridFinishedFuture<>(cctx.kernalContext(), e);
             }
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/affinity/GridCacheAffinityImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/affinity/GridCacheAffinityImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/affinity/GridCacheAffinityImpl.java
index 2f6988a..db4a771 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/affinity/GridCacheAffinityImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/affinity/GridCacheAffinityImpl.java
@@ -144,7 +144,7 @@ public class GridCacheAffinityImpl<K, V> implements GridCacheAffinity<K> {
             try {
                 key = (K)cctx.marshalToPortable(key);
             }
-            catch (GridPortableException e) {
+            catch (PortableException e) {
                 U.error(log, "Failed to marshal key to portable: " + key, e);
             }
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/GridPortableProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/GridPortableProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/GridPortableProcessor.java
index af9045f..51cfe01 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/GridPortableProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/GridPortableProcessor.java
@@ -31,41 +31,41 @@ public interface GridPortableProcessor extends GridProcessor {
      * @param obj Object to marshal.
      * @param trim If {@code true} trims result byte buffer.
      * @return Object bytes.
-     * @throws GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    public ByteBuffer marshal(@Nullable Object obj, boolean trim) throws GridPortableException;
+    public ByteBuffer marshal(@Nullable Object obj, boolean trim) throws PortableException;
 
     /**
      * @param arr Byte array.
      * @param off Offset.
      * @return Unmarshalled object.
-     * @throws GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    public Object unmarshal(byte[] arr, int off) throws GridPortableException;
+    public Object unmarshal(byte[] arr, int off) throws PortableException;
 
     /**
      * @param ptr Offheap pointer.
      * @param forceHeap If {@code true} creates heap-based object.
      * @return Unmarshalled object.
-     * @throws GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    public Object unmarshal(long ptr, boolean forceHeap) throws GridPortableException;
+    public Object unmarshal(long ptr, boolean forceHeap) throws PortableException;
 
     /**
      * Converts temporary offheap object to heap-based.
      *
      * @param obj Object.
      * @return Heap-based object.
-     * @throws GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    @Nullable public Object unwrapTemporary(@Nullable Object obj) throws GridPortableException;
+    @Nullable public Object unwrapTemporary(@Nullable Object obj) throws PortableException;
 
     /**
      * @param obj Object to marshal.
      * @return Portable object.
-     * @throws GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    public Object marshalToPortable(@Nullable Object obj) throws GridPortableException;
+    public Object marshalToPortable(@Nullable Object obj) throws PortableException;
 
     /**
      * @param obj Object (portable or not).
@@ -88,12 +88,12 @@ public interface GridPortableProcessor extends GridProcessor {
     /**
      * @return Builder.
      */
-    public GridPortableBuilder builder(int typeId);
+    public PortableBuilder builder(int typeId);
 
     /**
      * @return Builder.
      */
-    public GridPortableBuilder builder(String clsName);
+    public PortableBuilder builder(String clsName);
 
     /**
      * Creates builder initialized by existing portable object.
@@ -101,42 +101,42 @@ public interface GridPortableProcessor extends GridProcessor {
      * @param portableObj Portable object to edit.
      * @return Portable builder.
      */
-    public GridPortableBuilder builder(GridPortableObject portableObj);
+    public PortableBuilder builder(GridPortableObject portableObj);
 
     /**
      * @param typeId Type ID.
      * @param newMeta New meta data.
-     * @throws GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    public void addMeta(int typeId, final GridPortableMetadata newMeta) throws GridPortableException;
+    public void addMeta(int typeId, final GridPortableMetadata newMeta) throws PortableException;
 
     /**
      * @param typeId Type ID.
      * @param typeName Type name.
      * @param affKeyFieldName Affinity key field name.
      * @param fieldTypeIds Fields map.
-     * @throws GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
     public void updateMetaData(int typeId, String typeName, @Nullable String affKeyFieldName,
-        Map<String, Integer> fieldTypeIds) throws GridPortableException;
+        Map<String, Integer> fieldTypeIds) throws PortableException;
 
     /**
      * @param typeId Type ID.
      * @return Meta data.
-     * @throws GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    @Nullable public GridPortableMetadata metadata(int typeId) throws GridPortableException;
+    @Nullable public GridPortableMetadata metadata(int typeId) throws PortableException;
 
     /**
      * @param typeIds Type ID.
      * @return Meta data.
-     * @throws GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    public Map<Integer, GridPortableMetadata> metadata(Collection<Integer> typeIds) throws GridPortableException;
+    public Map<Integer, GridPortableMetadata> metadata(Collection<Integer> typeIds) throws PortableException;
 
     /**
      * @return Metadata for all types.
-     * @throws GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    public Collection<GridPortableMetadata> metadata() throws GridPortableException;
+    public Collection<GridPortableMetadata> metadata() throws PortableException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/os/GridOsPortableProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/os/GridOsPortableProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/os/GridOsPortableProcessor.java
index 3587b73..0f2f951 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/os/GridOsPortableProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/os/GridOsPortableProcessor.java
@@ -36,27 +36,27 @@ public class GridOsPortableProcessor extends GridProcessorAdapter implements Gri
     }
 
     /** {@inheritDoc} */
-    @Override public ByteBuffer marshal(@Nullable Object obj, boolean trim) throws GridPortableException {
+    @Override public ByteBuffer marshal(@Nullable Object obj, boolean trim) throws PortableException {
         return null;
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public Object unmarshal(byte[] arr, int off) throws GridPortableException {
+    @Nullable @Override public Object unmarshal(byte[] arr, int off) throws PortableException {
         return null;
     }
 
     /** {@inheritDoc} */
-    @Override public Object unmarshal(long ptr, boolean forceHeap) throws GridPortableException {
+    @Override public Object unmarshal(long ptr, boolean forceHeap) throws PortableException {
         return null;
     }
 
     /** {@inheritDoc} */
-    @Override public Object unwrapTemporary(Object obj) throws GridPortableException {
+    @Override public Object unwrapTemporary(Object obj) throws PortableException {
         return null;
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public Object marshalToPortable(@Nullable Object obj) throws GridPortableException {
+    @Nullable @Override public Object marshalToPortable(@Nullable Object obj) throws PortableException {
         return obj;
     }
 
@@ -76,28 +76,28 @@ public class GridOsPortableProcessor extends GridProcessorAdapter implements Gri
     }
 
     /** {@inheritDoc} */
-    @Override public GridPortableBuilder builder(int typeId) {
+    @Override public PortableBuilder builder(int typeId) {
         return null;
     }
 
     /** {@inheritDoc} */
-    @Override public GridPortableBuilder builder(String clsName) {
+    @Override public PortableBuilder builder(String clsName) {
         return null;
     }
 
     /** {@inheritDoc} */
-    @Override public GridPortableBuilder builder(GridPortableObject portableObj) {
+    @Override public PortableBuilder builder(GridPortableObject portableObj) {
         return null;
     }
 
     /** {@inheritDoc} */
-    @Override public void addMeta(int typeId, GridPortableMetadata newMeta) throws GridPortableException {
+    @Override public void addMeta(int typeId, GridPortableMetadata newMeta) throws PortableException {
         // No-op.
     }
 
     /** {@inheritDoc} */
     @Override public void updateMetaData(int typeId, String typeName, String affKeyFieldName,
-        Map<String, Integer> fieldTypeIds) throws GridPortableException {
+        Map<String, Integer> fieldTypeIds) throws PortableException {
         // No-op.
     }
 
@@ -112,7 +112,7 @@ public class GridOsPortableProcessor extends GridProcessorAdapter implements Gri
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridPortableMetadata> metadata() throws GridPortableException {
+    @Override public Collection<GridPortableMetadata> metadata() throws PortableException {
         return Collections.emptyList();
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAbstractMessage.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAbstractMessage.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAbstractMessage.java
index f47832a..35316dc 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAbstractMessage.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAbstractMessage.java
@@ -17,7 +17,7 @@ import java.util.*;
 /**
  * This class provides implementation for commit message fields and cannot be used directly.
  */
-public abstract class GridClientAbstractMessage implements GridClientMessage, Externalizable, GridPortableMarshalAware {
+public abstract class GridClientAbstractMessage implements GridClientMessage, Externalizable, PortableMarshalAware {
     /** */
     private static final long serialVersionUID = 0L;
 
@@ -88,14 +88,14 @@ public abstract class GridClientAbstractMessage implements GridClientMessage, Ex
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         GridPortableRawWriter raw = writer.rawWriter();
 
         raw.writeByteArray(sesTok);
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         GridPortableRawReader raw = reader.rawReader();
 
         sesTok = raw.readByteArray();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAuthenticationRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAuthenticationRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAuthenticationRequest.java
index 44fc512..d388b53 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAuthenticationRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAuthenticationRequest.java
@@ -53,7 +53,7 @@ public class GridClientAuthenticationRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
         GridPortableRawWriter raw = writer.rawWriter();
@@ -62,7 +62,7 @@ public class GridClientAuthenticationRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         super.readPortable(reader);
 
         GridPortableRawReader raw = reader.rawReader();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheQueryRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheQueryRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheQueryRequest.java
index 9a7034a..e05a92c 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheQueryRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheQueryRequest.java
@@ -316,7 +316,7 @@ public class GridClientCacheQueryRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         super.readPortable(reader);
 
         GridPortableRawReader rawReader = reader.rawReader();
@@ -338,7 +338,7 @@ public class GridClientCacheQueryRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
         GridPortableRawWriter rawWriter = writer.rawWriter();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheRequest.java
index e564e8b..c2c2e83 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheRequest.java
@@ -221,7 +221,7 @@ public class GridClientCacheRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
         GridPortableRawWriterEx raw = (GridPortableRawWriterEx)writer.rawWriter();
@@ -244,7 +244,7 @@ public class GridClientCacheRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         super.readPortable(reader);
 
         GridPortableRawReaderEx raw = (GridPortableRawReaderEx)reader.rawReader();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientGetMetaDataRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientGetMetaDataRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientGetMetaDataRequest.java
index 802d46e..6fd6da0 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientGetMetaDataRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientGetMetaDataRequest.java
@@ -32,7 +32,7 @@ public class GridClientGetMetaDataRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
         GridPortableRawWriter raw = writer.rawWriter();
@@ -41,7 +41,7 @@ public class GridClientGetMetaDataRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         super.readPortable(reader);
 
         GridPortableRawReader raw = reader.rawReader();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientLogRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientLogRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientLogRequest.java
index 3a5bef7..01de166 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientLogRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientLogRequest.java
@@ -73,7 +73,7 @@ public class GridClientLogRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
         GridPortableRawWriter raw = writer.rawWriter();
@@ -84,7 +84,7 @@ public class GridClientLogRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         super.readPortable(reader);
 
         GridPortableRawReader raw = reader.rawReader();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientMetaDataResponse.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientMetaDataResponse.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientMetaDataResponse.java
index 25f6c8a..2cb89ce 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientMetaDataResponse.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientMetaDataResponse.java
@@ -17,7 +17,7 @@ import java.util.*;
 /**
  * Metadata response.
  */
-public class GridClientMetaDataResponse implements GridPortableMarshalAware {
+public class GridClientMetaDataResponse implements PortableMarshalAware {
     /** */
     private Map<Integer, GridPortableMetadata> meta;
 
@@ -29,14 +29,14 @@ public class GridClientMetaDataResponse implements GridPortableMarshalAware {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         GridPortableRawWriter raw = writer.rawWriter();
 
         raw.writeMap(meta);
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         GridPortableRawReader raw = reader.rawReader();
 
         meta = raw.readMap();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeBean.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeBean.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeBean.java
index 7c99074..74fcb6e 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeBean.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeBean.java
@@ -18,7 +18,7 @@ import java.util.*;
 /**
  * Node bean.
  */
-public class GridClientNodeBean implements Externalizable, GridPortableMarshalAware {
+public class GridClientNodeBean implements Externalizable, PortableMarshalAware {
     /** */
     private static final long serialVersionUID = 0L;
 
@@ -247,7 +247,7 @@ public class GridClientNodeBean implements Externalizable, GridPortableMarshalAw
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         GridPortableRawWriter raw = writer.rawWriter();
 
         raw.writeInt(tcpPort);
@@ -263,7 +263,7 @@ public class GridClientNodeBean implements Externalizable, GridPortableMarshalAw
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         GridPortableRawReader raw = reader.rawReader();
 
         tcpPort = raw.readInt();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeMetricsBean.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeMetricsBean.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeMetricsBean.java
index 0c9fdcf..1be72ef 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeMetricsBean.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeMetricsBean.java
@@ -16,7 +16,7 @@ import java.io.*;
 /**
  * Node metrics bean.
  */
-public class GridClientNodeMetricsBean implements Externalizable, GridPortableMarshalAware {
+public class GridClientNodeMetricsBean implements Externalizable, PortableMarshalAware {
     /** */
     private static final long serialVersionUID = 0L;
 
@@ -1341,7 +1341,7 @@ public class GridClientNodeMetricsBean implements Externalizable, GridPortableMa
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         GridPortableRawWriter raw = writer.rawWriter();
 
         raw.writeLong(lastUpdateTime);
@@ -1399,7 +1399,7 @@ public class GridClientNodeMetricsBean implements Externalizable, GridPortableMa
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         GridPortableRawReader raw = reader.rawReader();
 
         lastUpdateTime = raw.readLong();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPortableMetaData.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPortableMetaData.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPortableMetaData.java
index 4b2c34b..a256051 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPortableMetaData.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPortableMetaData.java
@@ -17,7 +17,7 @@ import java.util.*;
 /**
  * Portable meta data sent from client.
  */
-public class GridClientPortableMetaData implements GridPortableMarshalAware {
+public class GridClientPortableMetaData implements PortableMarshalAware {
     /** */
     private int typeId;
 
@@ -59,7 +59,7 @@ public class GridClientPortableMetaData implements GridPortableMarshalAware {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         GridPortableRawWriter raw = writer.rawWriter();
 
         raw.writeInt(typeId);
@@ -69,7 +69,7 @@ public class GridClientPortableMetaData implements GridPortableMarshalAware {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         GridPortableRawReader raw = reader.rawReader();
 
         typeId = raw.readInt();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPutMetaDataRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPutMetaDataRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPutMetaDataRequest.java
index 47557cc..3699913 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPutMetaDataRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPutMetaDataRequest.java
@@ -32,7 +32,7 @@ public class GridClientPutMetaDataRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
         GridPortableRawWriter raw = writer.rawWriter();
@@ -41,7 +41,7 @@ public class GridClientPutMetaDataRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         super.readPortable(reader);
 
         GridPortableRawReader raw = reader.rawReader();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientResponse.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientResponse.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientResponse.java
index f9d9999..6bc1db9 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientResponse.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientResponse.java
@@ -85,7 +85,7 @@ public class GridClientResponse extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
         GridPortableRawWriter raw = writer.rawWriter();
@@ -96,7 +96,7 @@ public class GridClientResponse extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         super.readPortable(reader);
 
         GridPortableRawReader raw = reader.rawReader();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskRequest.java
index acc6b92..e8d452e 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskRequest.java
@@ -94,7 +94,7 @@ public class GridClientTaskRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
         GridPortableRawWriterEx raw = (GridPortableRawWriterEx)writer.rawWriter();
@@ -109,7 +109,7 @@ public class GridClientTaskRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         super.readPortable(reader);
 
         GridPortableRawReaderEx raw = (GridPortableRawReaderEx)reader.rawReader();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskResultBean.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskResultBean.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskResultBean.java
index 0079ad1..666a0dc 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskResultBean.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskResultBean.java
@@ -18,7 +18,7 @@ import java.io.*;
 /**
  * Task result.
  */
-public class GridClientTaskResultBean implements Externalizable, GridPortableMarshalAware {
+public class GridClientTaskResultBean implements Externalizable, PortableMarshalAware {
     /** */
     private static final long serialVersionUID = 0L;
 
@@ -92,7 +92,7 @@ public class GridClientTaskResultBean implements Externalizable, GridPortableMar
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         GridPortableRawWriterEx raw = (GridPortableRawWriterEx)writer.rawWriter();
 
         raw.writeString(id);
@@ -104,7 +104,7 @@ public class GridClientTaskResultBean implements Externalizable, GridPortableMar
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         GridPortableRawReaderEx raw = (GridPortableRawReaderEx)reader.rawReader();
 
         id = raw.readString();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTopologyRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTopologyRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTopologyRequest.java
index 8ebb677..761bcbd 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTopologyRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTopologyRequest.java
@@ -111,7 +111,7 @@ public class GridClientTopologyRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
         GridPortableRawWriter raw = writer.rawWriter();
@@ -123,7 +123,7 @@ public class GridClientTopologyRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         super.readPortable(reader);
 
         GridPortableRawReader raw = reader.rawReader();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/cache/GridCacheClientQueryResult.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/cache/GridCacheClientQueryResult.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/cache/GridCacheClientQueryResult.java
index dddb1a5..1200d97 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/cache/GridCacheClientQueryResult.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/cache/GridCacheClientQueryResult.java
@@ -17,7 +17,7 @@ import java.util.*;
 /**
  * Client query result.
  */
-public class GridCacheClientQueryResult implements GridPortableMarshalAware, Serializable {
+public class GridCacheClientQueryResult implements PortableMarshalAware, Serializable {
     /** */
     private static final long serialVersionUID = 0L;
 
@@ -90,7 +90,7 @@ public class GridCacheClientQueryResult implements GridPortableMarshalAware, Ser
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         GridPortableRawWriter rawWriter = writer.rawWriter();
 
         rawWriter.writeBoolean(last);
@@ -100,7 +100,7 @@ public class GridCacheClientQueryResult implements GridPortableMarshalAware, Ser
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         GridPortableRawReader rawReader = reader.rawReader();
 
         last = rawReader.readBoolean();


[24/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
# Renaming


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

Branch: refs/heads/master
Commit: 5e4cd4d883518be712f44f569fa4e7692e86e913
Parents: 1d26f5f
Author: sboikov <sb...@gridgain.com>
Authored: Fri Dec 5 11:22:40 2014 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Dec 5 11:22:41 2014 +0300

----------------------------------------------------------------------
 .../examples/ggfs/GgfsMapReduceExample.java     |   2 +-
 .../main/java/org/apache/ignite/IgniteFs.java   |  10 +-
 .../org/gridgain/grid/ggfs/GridGgfsMode.java    |  72 ---
 .../grid/ggfs/GridGgfsOutOfSpaceException.java  |  50 --
 .../grid/ggfs/GridGgfsOutputStream.java         |  27 -
 .../GridGgfsParentNotDirectoryException.java    |  42 --
 .../grid/ggfs/IgniteFsConfiguration.java        |  20 +-
 .../org/gridgain/grid/ggfs/IgniteFsMode.java    |  72 +++
 .../grid/ggfs/IgniteFsOutOfSpaceException.java  |  50 ++
 .../grid/ggfs/IgniteFsOutputStream.java         |  27 +
 .../IgniteFsParentNotDirectoryException.java    |  42 ++
 .../ggfs/common/GridGgfsControlResponse.java    |   4 +-
 .../grid/kernal/ggfs/common/GridGgfsLogger.java |  18 +-
 .../processors/ggfs/GridGgfsAsyncImpl.java      |  10 +-
 .../processors/ggfs/GridGgfsAttributes.java     |  16 +-
 .../processors/ggfs/GridGgfsDataManager.java    |   8 +-
 .../kernal/processors/ggfs/GridGgfsImpl.java    |  72 +--
 .../processors/ggfs/GridGgfsIpcHandler.java     |   4 +-
 .../processors/ggfs/GridGgfsModeResolver.java   |  36 +-
 .../ggfs/GridGgfsOutputStreamAdapter.java       | 255 ----------
 .../ggfs/GridGgfsOutputStreamImpl.java          | 497 -------------------
 .../kernal/processors/ggfs/GridGgfsPaths.java   |  18 +-
 .../processors/ggfs/GridGgfsProcessor.java      |   4 +-
 .../ggfs/IgniteFsOutputStreamAdapter.java       | 255 ++++++++++
 .../ggfs/IgniteFsOutputStreamImpl.java          | 497 +++++++++++++++++++
 .../kernal/processors/job/GridJobWorker.java    |   2 +-
 .../kernal/processors/task/GridTaskWorker.java  |   4 +-
 .../grid/kernal/visor/ggfs/VisorGgfs.java       |   6 +-
 .../kernal/visor/ggfs/VisorGgfsProfiler.java    |   2 +-
 .../visor/ggfs/VisorGgfsProfilerEntry.java      |   6 +-
 .../visor/ggfs/VisorGgfsProfilerTask.java       |  10 +-
 .../visor/node/VisorGgfsConfiguration.java      |  12 +-
 .../ggfs/GridGgfsEventsAbstractSelfTest.java    |   2 +-
 .../grid/ggfs/GridGgfsFragmentizerSelfTest.java |   8 +-
 .../GridGgfsFragmentizerTopologySelfTest.java   |   2 +-
 ...heGgfsPerBlockLruEvictionPolicySelfTest.java |   6 +-
 .../ggfs/GridGgfsAbstractSelfTest.java          |  56 +--
 .../ggfs/GridGgfsAttributesSelfTest.java        |   4 +-
 .../ggfs/GridGgfsDualAbstractSelfTest.java      |   8 +-
 .../ggfs/GridGgfsDualAsyncSelfTest.java         |   2 +-
 .../ggfs/GridGgfsDualSyncSelfTest.java          |   2 +-
 .../ggfs/GridGgfsMetricsSelfTest.java           |  18 +-
 .../ggfs/GridGgfsModeResolverSelfTest.java      |  18 +-
 .../processors/ggfs/GridGgfsModesSelfTest.java  |  16 +-
 .../GridGgfsPrimaryOffheapTieredSelfTest.java   |   2 +-
 .../GridGgfsPrimaryOffheapValuesSelfTest.java   |   2 +-
 .../ggfs/GridGgfsPrimarySelfTest.java           |   2 +-
 .../ggfs/GridGgfsProcessorSelfTest.java         |  12 +-
 .../GridGgfsProcessorValidationSelfTest.java    |   2 +-
 .../processors/ggfs/GridGgfsSizeSelfTest.java   |  10 +-
 .../ggfs/GridGgfsStreamsSelfTest.java           |   8 +-
 .../processors/ggfs/GridGgfsTaskSelfTest.java   |   2 +-
 .../GridGgfsAbstractRecordResolverSelfTest.java |   4 +-
 .../hadoop/v1/GridGgfsHadoopFileSystem.java     |  24 +-
 .../hadoop/v2/GridGgfsHadoopFileSystem.java     |  22 +-
 .../hadoop/GridGgfsHadoopFileSystemWrapper.java |   2 +-
 .../ggfs/hadoop/GridGgfsHadoopInProc.java       |   8 +-
 .../kernal/ggfs/hadoop/GridGgfsHadoopUtils.java |   2 +-
 .../grid/ggfs/GridGgfsEventsTestSuite.java      |   2 +-
 ...dGgfsHadoop20FileSystemAbstractSelfTest.java |   6 +-
 ...doop20FileSystemLoopbackPrimarySelfTest.java |   2 +-
 ...sHadoop20FileSystemShmemPrimarySelfTest.java |   2 +-
 .../GridGgfsHadoopDualAbstractSelfTest.java     |  10 +-
 .../ggfs/GridGgfsHadoopDualAsyncSelfTest.java   |   2 +-
 .../ggfs/GridGgfsHadoopDualSyncSelfTest.java    |   2 +-
 ...ridGgfsHadoopFileSystemAbstractSelfTest.java |   6 +-
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |   2 +-
 .../GridGgfsHadoopFileSystemLoggerSelfTest.java |   2 +-
 ...GgfsHadoopFileSystemLoggerStateSelfTest.java |   2 +-
 ...adoopFileSystemLoopbackAbstractSelfTest.java |   2 +-
 ...SystemLoopbackEmbeddedDualAsyncSelfTest.java |   2 +-
 ...eSystemLoopbackEmbeddedDualSyncSelfTest.java |   2 +-
 ...leSystemLoopbackEmbeddedPrimarySelfTest.java |   2 +-
 ...SystemLoopbackEmbeddedSecondarySelfTest.java |   2 +-
 ...SystemLoopbackExternalDualAsyncSelfTest.java |   2 +-
 ...eSystemLoopbackExternalDualSyncSelfTest.java |   2 +-
 ...leSystemLoopbackExternalPrimarySelfTest.java |   2 +-
 ...SystemLoopbackExternalSecondarySelfTest.java |   2 +-
 ...fsHadoopFileSystemSecondaryModeSelfTest.java |  10 +-
 ...fsHadoopFileSystemShmemAbstractSelfTest.java |   2 +-
 ...ileSystemShmemEmbeddedDualAsyncSelfTest.java |   2 +-
 ...FileSystemShmemEmbeddedDualSyncSelfTest.java |   2 +-
 ...pFileSystemShmemEmbeddedPrimarySelfTest.java |   2 +-
 ...ileSystemShmemEmbeddedSecondarySelfTest.java |   2 +-
 ...ileSystemShmemExternalDualAsyncSelfTest.java |   2 +-
 ...FileSystemShmemExternalDualSyncSelfTest.java |   2 +-
 ...pFileSystemShmemExternalPrimarySelfTest.java |   2 +-
 ...ileSystemShmemExternalSecondarySelfTest.java |   2 +-
 ...idHadoopDefaultMapReducePlannerSelfTest.java |  10 +-
 ...GridHadoopExternalTaskExecutionSelfTest.java |   2 +-
 90 files changed, 1245 insertions(+), 1245 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
index 89dbbe8..c006641 100644
--- a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
+++ b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
@@ -92,7 +92,7 @@ public class GgfsMapReduceExample {
         System.out.println("Copying file to GGFS: " + file);
 
         try (
-            GridGgfsOutputStream os = fs.create(fsPath, true);
+            IgniteFsOutputStream os = fs.create(fsPath, true);
             FileInputStream fis = new FileInputStream(file)
         ) {
             byte[] buf = new byte[2048];

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
index cf9f9a6..241ab3e 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
@@ -121,7 +121,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @return File output stream to write data to.
      * @throws GridException In case of error.
      */
-    @Override public GridGgfsOutputStream create(IgniteFsPath path, boolean overwrite) throws GridException;
+    @Override public IgniteFsOutputStream create(IgniteFsPath path, boolean overwrite) throws GridException;
 
     /**
      * Creates a file and opens it for writing.
@@ -135,7 +135,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @return File output stream to write data to.
      * @throws GridException In case of error.
      */
-    @Override public GridGgfsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication,
+    @Override public IgniteFsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication,
         long blockSize, @Nullable Map<String, String> props) throws GridException;
 
     /**
@@ -152,7 +152,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @return File output stream to write data to.
      * @throws GridException In case of error.
      */
-    public GridGgfsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite,
+    public IgniteFsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite,
         @Nullable IgniteUuid affKey, int replication, long blockSize, @Nullable Map<String, String> props)
         throws GridException;
 
@@ -165,7 +165,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @throws GridException In case of error.
      * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist and create flag is {@code false}.
      */
-    public GridGgfsOutputStream append(IgniteFsPath path, boolean create) throws GridException;
+    public IgniteFsOutputStream append(IgniteFsPath path, boolean create) throws GridException;
 
     /**
      * Opens an output stream to an existing file for appending data.
@@ -178,7 +178,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @throws GridException In case of error.
      * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist and create flag is {@code false}.
      */
-    @Override public GridGgfsOutputStream append(IgniteFsPath path, int bufSize, boolean create,
+    @Override public IgniteFsOutputStream append(IgniteFsPath path, int bufSize, boolean create,
         @Nullable Map<String, String> props) throws GridException;
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMode.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMode.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMode.java
deleted file mode 100644
index 8bca1e5..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMode.java
+++ /dev/null
@@ -1,72 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.jetbrains.annotations.*;
-
-/**
- * {@code GGFS} mode defining interactions with underlying secondary Hadoop file system.
- * Secondary Hadoop file system is provided for pass-through, write-through, and
- * read-through purposes.
- * <p>
- * This mode is configured via {@link IgniteFsConfiguration#getDefaultMode()}
- * configuration property.
- */
-public enum GridGgfsMode {
-    /**
-     * In this mode GGFS will not delegate to secondary Hadoop file system and will
-     * cache all the files in memory only.
-     */
-    PRIMARY,
-
-    /**
-     * In this mode GGFS will not cache any files in memory and will only pass them
-     * through to secondary Hadoop file system. If this mode is enabled, then
-     * secondary Hadoop file system must be configured.
-     *
-     * @see IgniteFsConfiguration#getSecondaryHadoopFileSystemUri()
-     */
-    PROXY,
-
-    /**
-     * In this mode {@code GGFS} will cache files locally and also <i>synchronously</i>
-     * write them through to secondary Hadoop file system.
-     * <p>
-     * If secondary Hadoop file system is not configured, then this mode behaves like
-     * {@link #PRIMARY} mode.
-     *
-     * @see IgniteFsConfiguration#getSecondaryHadoopFileSystemUri()
-     */
-    DUAL_SYNC,
-
-    /**
-     * In this mode {@code GGFS} will cache files locally and also <i>asynchronously</i>
-     * write them through to secondary Hadoop file system.
-     * <p>
-     * If secondary Hadoop file system is not configured, then this mode behaves like
-     * {@link #PRIMARY} mode.
-     *
-     * @see IgniteFsConfiguration#getSecondaryHadoopFileSystemUri()
-     */
-    DUAL_ASYNC;
-
-    /** Enumerated values. */
-    private static final GridGgfsMode[] VALS = values();
-
-    /**
-     * Efficiently gets enumerated value from its ordinal.
-     *
-     * @param ord Ordinal value.
-     * @return Enumerated value or {@code null} if ordinal out of range.
-     */
-    @Nullable public static GridGgfsMode fromOrdinal(int ord) {
-        return ord >= 0 && ord < VALS.length ? VALS[ord] : null;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsOutOfSpaceException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsOutOfSpaceException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsOutOfSpaceException.java
deleted file mode 100644
index ce5ef3d..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsOutOfSpaceException.java
+++ /dev/null
@@ -1,50 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.jetbrains.annotations.*;
-
-/**
- * {@code GGFS} exception that is thrown when it detected out-of-space condition.
- * It is thrown when number of writes written to a {@code GGFS} data nodes exceeds
- * its maximum value (that is configured per-node).
- */
-public class GridGgfsOutOfSpaceException extends IgniteFsException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Creates exception with given error message.
-     *
-     * @param msg Error message.
-     */
-    public GridGgfsOutOfSpaceException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * Creates an instance of exception with given exception cause.
-     *
-     * @param cause Exception cause.
-     */
-    public GridGgfsOutOfSpaceException(Throwable cause) {
-        super(cause);
-    }
-
-    /**
-     * Creates an instance of GGFS exception with given error message and given exception cause.
-     *
-     * @param msg Error message.
-     * @param cause Exception cause.
-     */
-    public GridGgfsOutOfSpaceException(String msg, @Nullable Throwable cause) {
-        super(msg, cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsOutputStream.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsOutputStream.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsOutputStream.java
deleted file mode 100644
index 887075c..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsOutputStream.java
+++ /dev/null
@@ -1,27 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import java.io.*;
-
-/**
- * {@code GGFS} output stream to write data into the file system.
- */
-public abstract class GridGgfsOutputStream extends OutputStream {
-    /**
-     * Transfers specified amount of bytes from data input to this output stream.
-     * This method is optimized to avoid unnecessary temporal buffer creation and byte array copy.
-     *
-     * @param in Data input to copy bytes from.
-     * @param len Data length to copy.
-     * @throws IOException If write failed, read from input failed or there is no enough data in data input.
-     */
-    public abstract void transferFrom(DataInput in, int len) throws IOException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsParentNotDirectoryException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsParentNotDirectoryException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsParentNotDirectoryException.java
deleted file mode 100644
index dc71dd2..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsParentNotDirectoryException.java
+++ /dev/null
@@ -1,42 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.jetbrains.annotations.*;
-
-/**
- * Exception thrown when parent supposed to be a directory is a file.
- */
-public class GridGgfsParentNotDirectoryException extends IgniteFsInvalidPathException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * @param msg Error message.
-     */
-    public GridGgfsParentNotDirectoryException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * @param cause Exception cause.
-     */
-    public GridGgfsParentNotDirectoryException(Throwable cause) {
-        super(cause);
-    }
-
-    /**
-     * @param msg Error message.
-     * @param cause Exception cause.
-     */
-    public GridGgfsParentNotDirectoryException(String msg, @Nullable Throwable cause) {
-        super(msg, cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
index 8b43058..d86049d 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
@@ -16,7 +16,7 @@ import org.jetbrains.annotations.*;
 import java.util.*;
 import java.util.concurrent.*;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * {@code GGFS} configuration. More than one file system can be configured within grid.
@@ -61,7 +61,7 @@ public class IgniteFsConfiguration {
     public static final int DFLT_PER_NODE_PARALLEL_BATCH_CNT = 8;
 
     /** Default GGFS mode. */
-    public static final GridGgfsMode DFLT_MODE = DUAL_ASYNC;
+    public static final IgniteFsMode DFLT_MODE = DUAL_ASYNC;
 
     /** Default file's data block size (bytes). */
     public static final int DFLT_BLOCK_SIZE = 1 << 16;
@@ -118,7 +118,7 @@ public class IgniteFsConfiguration {
     private IgniteFsFileSystem secondaryFs;
 
     /** GGFS mode. */
-    private GridGgfsMode dfltMode = DFLT_MODE;
+    private IgniteFsMode dfltMode = DFLT_MODE;
 
     /** Fragmentizer throttling block length. */
     private long fragmentizerThrottlingBlockLen = DFLT_FRAGMENTIZER_THROTTLING_BLOCK_LENGTH;
@@ -136,7 +136,7 @@ public class IgniteFsConfiguration {
     private boolean fragmentizerEnabled = DFLT_FRAGMENTIZER_ENABLED;
 
     /** Path modes. */
-    private Map<String, GridGgfsMode> pathModes;
+    private Map<String, IgniteFsMode> pathModes;
 
     /** Maximum space. */
     private long maxSpace;
@@ -485,12 +485,12 @@ public class IgniteFsConfiguration {
      * Secondary Hadoop file system is provided for pass-through, write-through, and read-through
      * purposes.
      * <p>
-     * Default mode is {@link GridGgfsMode#DUAL_ASYNC}. If secondary Hadoop file system is
-     * not configured, this mode will work just like {@link GridGgfsMode#PRIMARY} mode.
+     * Default mode is {@link IgniteFsMode#DUAL_ASYNC}. If secondary Hadoop file system is
+     * not configured, this mode will work just like {@link IgniteFsMode#PRIMARY} mode.
      *
      * @return Mode to specify how GGFS interacts with secondary HDFS file system.
      */
-    public GridGgfsMode getDefaultMode() {
+    public IgniteFsMode getDefaultMode() {
         return dfltMode;
     }
 
@@ -501,7 +501,7 @@ public class IgniteFsConfiguration {
      *
      * @param dfltMode {@code GGFS} mode.
      */
-    public void setDefaultMode(GridGgfsMode dfltMode) {
+    public void setDefaultMode(IgniteFsMode dfltMode) {
         this.dfltMode = dfltMode;
     }
 
@@ -541,7 +541,7 @@ public class IgniteFsConfiguration {
      *
      * @return Map of paths to {@code GGFS} modes.
      */
-    @Nullable public Map<String, GridGgfsMode> getPathModes() {
+    @Nullable public Map<String, IgniteFsMode> getPathModes() {
         return pathModes;
     }
 
@@ -553,7 +553,7 @@ public class IgniteFsConfiguration {
      *
      * @param pathModes Map of paths to {@code GGFS} modes.
      */
-    public void setPathModes(Map<String, GridGgfsMode> pathModes) {
+    public void setPathModes(Map<String, IgniteFsMode> pathModes) {
         this.pathModes = pathModes;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsMode.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsMode.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsMode.java
new file mode 100644
index 0000000..67f5eef
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsMode.java
@@ -0,0 +1,72 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+import org.jetbrains.annotations.*;
+
+/**
+ * {@code GGFS} mode defining interactions with underlying secondary Hadoop file system.
+ * Secondary Hadoop file system is provided for pass-through, write-through, and
+ * read-through purposes.
+ * <p>
+ * This mode is configured via {@link IgniteFsConfiguration#getDefaultMode()}
+ * configuration property.
+ */
+public enum IgniteFsMode {
+    /**
+     * In this mode GGFS will not delegate to secondary Hadoop file system and will
+     * cache all the files in memory only.
+     */
+    PRIMARY,
+
+    /**
+     * In this mode GGFS will not cache any files in memory and will only pass them
+     * through to secondary Hadoop file system. If this mode is enabled, then
+     * secondary Hadoop file system must be configured.
+     *
+     * @see IgniteFsConfiguration#getSecondaryHadoopFileSystemUri()
+     */
+    PROXY,
+
+    /**
+     * In this mode {@code GGFS} will cache files locally and also <i>synchronously</i>
+     * write them through to secondary Hadoop file system.
+     * <p>
+     * If secondary Hadoop file system is not configured, then this mode behaves like
+     * {@link #PRIMARY} mode.
+     *
+     * @see IgniteFsConfiguration#getSecondaryHadoopFileSystemUri()
+     */
+    DUAL_SYNC,
+
+    /**
+     * In this mode {@code GGFS} will cache files locally and also <i>asynchronously</i>
+     * write them through to secondary Hadoop file system.
+     * <p>
+     * If secondary Hadoop file system is not configured, then this mode behaves like
+     * {@link #PRIMARY} mode.
+     *
+     * @see IgniteFsConfiguration#getSecondaryHadoopFileSystemUri()
+     */
+    DUAL_ASYNC;
+
+    /** Enumerated values. */
+    private static final IgniteFsMode[] VALS = values();
+
+    /**
+     * Efficiently gets enumerated value from its ordinal.
+     *
+     * @param ord Ordinal value.
+     * @return Enumerated value or {@code null} if ordinal out of range.
+     */
+    @Nullable public static IgniteFsMode fromOrdinal(int ord) {
+        return ord >= 0 && ord < VALS.length ? VALS[ord] : null;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsOutOfSpaceException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsOutOfSpaceException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsOutOfSpaceException.java
new file mode 100644
index 0000000..cdfee59
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsOutOfSpaceException.java
@@ -0,0 +1,50 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+import org.jetbrains.annotations.*;
+
+/**
+ * {@code GGFS} exception that is thrown when it detected out-of-space condition.
+ * It is thrown when number of writes written to a {@code GGFS} data nodes exceeds
+ * its maximum value (that is configured per-node).
+ */
+public class IgniteFsOutOfSpaceException extends IgniteFsException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Creates exception with given error message.
+     *
+     * @param msg Error message.
+     */
+    public IgniteFsOutOfSpaceException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * Creates an instance of exception with given exception cause.
+     *
+     * @param cause Exception cause.
+     */
+    public IgniteFsOutOfSpaceException(Throwable cause) {
+        super(cause);
+    }
+
+    /**
+     * Creates an instance of GGFS exception with given error message and given exception cause.
+     *
+     * @param msg Error message.
+     * @param cause Exception cause.
+     */
+    public IgniteFsOutOfSpaceException(String msg, @Nullable Throwable cause) {
+        super(msg, cause);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsOutputStream.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsOutputStream.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsOutputStream.java
new file mode 100644
index 0000000..76c6b1f
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsOutputStream.java
@@ -0,0 +1,27 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+import java.io.*;
+
+/**
+ * {@code GGFS} output stream to write data into the file system.
+ */
+public abstract class IgniteFsOutputStream extends OutputStream {
+    /**
+     * Transfers specified amount of bytes from data input to this output stream.
+     * This method is optimized to avoid unnecessary temporal buffer creation and byte array copy.
+     *
+     * @param in Data input to copy bytes from.
+     * @param len Data length to copy.
+     * @throws IOException If write failed, read from input failed or there is no enough data in data input.
+     */
+    public abstract void transferFrom(DataInput in, int len) throws IOException;
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsParentNotDirectoryException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsParentNotDirectoryException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsParentNotDirectoryException.java
new file mode 100644
index 0000000..9cc46b7
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsParentNotDirectoryException.java
@@ -0,0 +1,42 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+import org.jetbrains.annotations.*;
+
+/**
+ * Exception thrown when parent supposed to be a directory is a file.
+ */
+public class IgniteFsParentNotDirectoryException extends IgniteFsInvalidPathException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * @param msg Error message.
+     */
+    public IgniteFsParentNotDirectoryException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * @param cause Exception cause.
+     */
+    public IgniteFsParentNotDirectoryException(Throwable cause) {
+        super(cause);
+    }
+
+    /**
+     * @param msg Error message.
+     * @param cause Exception cause.
+     */
+    public IgniteFsParentNotDirectoryException(String msg, @Nullable Throwable cause) {
+        super(msg, cause);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
index 919a0cd..8beb1df 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
@@ -259,7 +259,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
         else if (errCode == ERR_DIRECTORY_NOT_EMPTY)
             throw new GridGgfsDirectoryNotEmptyException(err);
         else if (errCode == ERR_PARENT_NOT_DIRECTORY)
-            throw new GridGgfsParentNotDirectoryException(err);
+            throw new IgniteFsParentNotDirectoryException(err);
         else if (errCode == ERR_INVALID_HDFS_VERSION)
             throw new IgniteFsInvalidHdfsVersionException(err);
         else if (errCode == ERR_CORRUPTED_FILE)
@@ -330,7 +330,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
             return ERR_PATH_ALREADY_EXISTS;
         else if (GridGgfsDirectoryNotEmptyException.class.isInstance(e))
             return ERR_DIRECTORY_NOT_EMPTY;
-        else if (GridGgfsParentNotDirectoryException.class.isInstance(e))
+        else if (IgniteFsParentNotDirectoryException.class.isInstance(e))
             return ERR_PARENT_NOT_DIRECTORY;
         else if (IgniteFsInvalidHdfsVersionException.class.isInstance(e))
             return ERR_INVALID_HDFS_VERSION;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsLogger.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsLogger.java b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsLogger.java
index b1b7d8f..2f0af0b 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsLogger.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsLogger.java
@@ -248,7 +248,7 @@ public final class GridGgfsLogger {
      * @param bufSize Buffer size.
      * @param dataLen Data length.
      */
-    public void logOpen(long streamId, IgniteFsPath path, GridGgfsMode mode, int bufSize, long dataLen) {
+    public void logOpen(long streamId, IgniteFsPath path, IgniteFsMode mode, int bufSize, long dataLen) {
         addEntry(new Entry(TYPE_OPEN_IN, path.toString(), mode, streamId, bufSize, dataLen, null, null, null, null,
             null, null, null, null, null, null, null, null, null, null));
     }
@@ -264,7 +264,7 @@ public final class GridGgfsLogger {
      * @param replication Replication factor.
      * @param blockSize Block size.
      */
-    public void logCreate(long streamId, IgniteFsPath path, GridGgfsMode mode, boolean overwrite, int bufSize,
+    public void logCreate(long streamId, IgniteFsPath path, IgniteFsMode mode, boolean overwrite, int bufSize,
         int replication, long blockSize) {
         addEntry(new Entry(TYPE_OPEN_OUT, path.toString(), mode, streamId, bufSize, null, false, overwrite, replication,
             blockSize, null, null, null, null, null, null, null, null, null, null));
@@ -278,7 +278,7 @@ public final class GridGgfsLogger {
      * @param mode Mode.
      * @param bufSize Buffer size.
      */
-    public void logAppend(long streamId, IgniteFsPath path, GridGgfsMode mode, int bufSize) {
+    public void logAppend(long streamId, IgniteFsPath path, IgniteFsMode mode, int bufSize) {
         addEntry(new Entry(TYPE_OPEN_OUT, path.toString(), mode, streamId, bufSize, null, true, null, null, null, null,
             null, null, null, null, null, null, null, null, null));
     }
@@ -370,7 +370,7 @@ public final class GridGgfsLogger {
      * @param path Path.
      * @param mode Mode.
      */
-    public void logMakeDirectory(IgniteFsPath path, GridGgfsMode mode) {
+    public void logMakeDirectory(IgniteFsPath path, IgniteFsMode mode) {
         addEntry(new Entry(TYPE_DIR_MAKE, path.toString(), mode, null, null, null, null, null, null, null, null, null,
             null, null, null, null, null, null, null, null));
     }
@@ -382,7 +382,7 @@ public final class GridGgfsLogger {
      * @param mode Mode.
      * @param files Files.
      */
-    public void logListDirectory(IgniteFsPath path, GridGgfsMode mode, String[] files) {
+    public void logListDirectory(IgniteFsPath path, IgniteFsMode mode, String[] files) {
         addEntry(new Entry(TYPE_DIR_LIST, path.toString(), mode, null, null, null, null, null, null, null, null, null,
             null, null, null, null, null, null, null, files));
     }
@@ -394,7 +394,7 @@ public final class GridGgfsLogger {
      * @param mode Mode.
      * @param destPath Destination path.
      */
-    public void logRename(IgniteFsPath path, GridGgfsMode mode, IgniteFsPath destPath) {
+    public void logRename(IgniteFsPath path, IgniteFsMode mode, IgniteFsPath destPath) {
         addEntry(new Entry(TYPE_RENAME, path.toString(), mode, null, null, null, null, null, null, null, null, null,
             null, null, null, null, null, destPath.toString(), null, null));
     }
@@ -406,7 +406,7 @@ public final class GridGgfsLogger {
      * @param mode Mode.
      * @param recursive Recursive flag.
      */
-    public void logDelete(IgniteFsPath path, GridGgfsMode mode, boolean recursive) {
+    public void logDelete(IgniteFsPath path, IgniteFsMode mode, boolean recursive) {
         addEntry(new Entry(TYPE_DELETE, path.toString(), mode, null, null, null, null, null, null, null, null, null,
             null, null, null, null, null, null, recursive, null));
     }
@@ -491,7 +491,7 @@ public final class GridGgfsLogger {
         private final String path;
 
         /** Path mode. */
-        private GridGgfsMode mode;
+        private IgniteFsMode mode;
 
         /** Stream ID. */
         private final long streamId;
@@ -568,7 +568,7 @@ public final class GridGgfsLogger {
          * @param recursive Recursive flag.
          * @param list Listed directories.
          */
-        Entry(int type, String path, GridGgfsMode mode, Long streamId, Integer bufSize, Long dataLen, Boolean append,
+        Entry(int type, String path, IgniteFsMode mode, Long streamId, Integer bufSize, Long dataLen, Boolean append,
             Boolean overwrite, Integer replication, Long blockSize, Long pos, Integer readLen, Long skipCnt,
             Long readLimit, Long userTime, Long sysTime, Long total, String destPath, Boolean recursive,
             String[] list) {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
index 6b33e17..6e4ad66 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
@@ -173,30 +173,30 @@ public class GridGgfsAsyncImpl extends IgniteAsyncSupportAdapter implements Grid
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream create(IgniteFsPath path, boolean overwrite) throws GridException {
+    @Override public IgniteFsOutputStream create(IgniteFsPath path, boolean overwrite) throws GridException {
         return ggfs.create(path, overwrite);
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication,
+    @Override public IgniteFsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication,
         long blockSize, @Nullable Map<String, String> props) throws GridException {
         return ggfs.create(path, bufSize, overwrite, replication, blockSize, props);
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite,
+    @Override public IgniteFsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite,
         @Nullable IgniteUuid affKey, int replication, long blockSize, @Nullable Map<String, String> props)
         throws GridException {
         return ggfs.create(path, bufSize, overwrite, affKey, replication, blockSize, props);
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream append(IgniteFsPath path, boolean create) throws GridException {
+    @Override public IgniteFsOutputStream append(IgniteFsPath path, boolean create) throws GridException {
         return ggfs.append(path, create);
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream append(IgniteFsPath path, int bufSize, boolean create,
+    @Override public IgniteFsOutputStream append(IgniteFsPath path, int bufSize, boolean create,
         @Nullable Map<String, String> props) throws GridException {
         return ggfs.append(path, bufSize, create, props);
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributes.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributes.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributes.java
index 26b80c5..885ca75 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributes.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributes.java
@@ -40,13 +40,13 @@ public class GridGgfsAttributes implements Externalizable {
     private String dataCacheName;
 
     /** Default mode. */
-    private GridGgfsMode dfltMode;
+    private IgniteFsMode dfltMode;
 
     /** Fragmentizer enabled flag. */
     private boolean fragmentizerEnabled;
 
     /** Path modes. */
-    private Map<String, GridGgfsMode> pathModes;
+    private Map<String, IgniteFsMode> pathModes;
 
     /**
      * @param ggfsName GGFS name.
@@ -58,7 +58,7 @@ public class GridGgfsAttributes implements Externalizable {
      * @param pathModes Path modes.
      */
     public GridGgfsAttributes(String ggfsName, int blockSize, int grpSize, String metaCacheName, String dataCacheName,
-        GridGgfsMode dfltMode, Map<String, GridGgfsMode> pathModes, boolean fragmentizerEnabled) {
+        IgniteFsMode dfltMode, Map<String, IgniteFsMode> pathModes, boolean fragmentizerEnabled) {
         this.blockSize = blockSize;
         this.ggfsName = ggfsName;
         this.grpSize = grpSize;
@@ -114,14 +114,14 @@ public class GridGgfsAttributes implements Externalizable {
     /**
      * @return Default mode.
      */
-    public GridGgfsMode defaultMode() {
+    public IgniteFsMode defaultMode() {
         return dfltMode;
     }
 
     /**
      * @return Path modes.
      */
-    public Map<String, GridGgfsMode> pathModes() {
+    public Map<String, IgniteFsMode> pathModes() {
         return pathModes != null ? Collections.unmodifiableMap(pathModes) : null;
     }
 
@@ -147,7 +147,7 @@ public class GridGgfsAttributes implements Externalizable {
 
             out.writeInt(pathModes.size());
 
-            for (Map.Entry<String, GridGgfsMode> pathMode : pathModes.entrySet()) {
+            for (Map.Entry<String, IgniteFsMode> pathMode : pathModes.entrySet()) {
                 U.writeString(out, pathMode.getKey());
                 U.writeEnum0(out, pathMode.getValue());
             }
@@ -163,7 +163,7 @@ public class GridGgfsAttributes implements Externalizable {
         grpSize = in.readInt();
         metaCacheName = U.readString(in);
         dataCacheName = U.readString(in);
-        dfltMode = GridGgfsMode.fromOrdinal(U.readEnumOrdinal0(in));
+        dfltMode = IgniteFsMode.fromOrdinal(U.readEnumOrdinal0(in));
         fragmentizerEnabled = in.readBoolean();
 
         if (in.readBoolean()) {
@@ -172,7 +172,7 @@ public class GridGgfsAttributes implements Externalizable {
             pathModes = new HashMap<>(size, 1.0f);
 
             for (int i = 0; i < size; i++)
-                pathModes.put(U.readString(in), GridGgfsMode.fromOrdinal(U.readEnumOrdinal0(in)));
+                pathModes.put(U.readString(in), IgniteFsMode.fromOrdinal(U.readEnumOrdinal0(in)));
         }
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
index 031c15a..0b8fe5f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
@@ -1090,7 +1090,7 @@ public class GridGgfsDataManager extends GridGgfsManager {
                     return;
                 }
 
-                completionFut.onLocalError(new GridGgfsOutOfSpaceException("Failed to write data block " +
+                completionFut.onLocalError(new IgniteFsOutOfSpaceException("Failed to write data block " +
                     "(GGFS maximum data size exceeded) [used=" + dataCachePrj.ggfsDataSpaceUsed() +
                         ", allowed=" + dataCachePrj.ggfsDataSpaceMax() + ']'));
 
@@ -1253,7 +1253,7 @@ public class GridGgfsDataManager extends GridGgfsManager {
                 // Additional size check.
                 if (dataCachePrj.ggfsDataSpaceUsed() >= dataCachePrj.ggfsDataSpaceMax())
                     return new GridFinishedFuture<Object>(ggfsCtx.kernalContext(),
-                        new GridGgfsOutOfSpaceException("Failed to write data block (GGFS maximum data size " +
+                        new IgniteFsOutOfSpaceException("Failed to write data block (GGFS maximum data size " +
                             "exceeded) [used=" + dataCachePrj.ggfsDataSpaceUsed() +
                             ", allowed=" + dataCachePrj.ggfsDataSpaceMax() + ']'));
 
@@ -1833,7 +1833,7 @@ public class GridGgfsDataManager extends GridGgfsManager {
 
             // If waiting for ack from this node.
             if (reqIds != null && !reqIds.isEmpty()) {
-                if (e instanceof GridGgfsOutOfSpaceException)
+                if (e instanceof IgniteFsOutOfSpaceException)
                     onDone(new GridException("Failed to write data (not enough space on node): " + nodeId, e));
                 else
                     onDone(new GridException(
@@ -1845,7 +1845,7 @@ public class GridGgfsDataManager extends GridGgfsManager {
          * @param e Error.
          */
         private void onLocalError(GridException e) {
-            if (e instanceof GridGgfsOutOfSpaceException)
+            if (e instanceof IgniteFsOutOfSpaceException)
                 onDone(new GridException("Failed to write data (not enough space on node): " +
                     ggfsCtx.kernalContext().localNodeId(), e));
             else

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
index 45a8add..5145abd 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
@@ -38,7 +38,7 @@ import java.util.*;
 import java.util.concurrent.atomic.*;
 
 import static org.apache.ignite.events.IgniteEventType.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 import static org.gridgain.grid.kernal.GridNodeAttributes.*;
 import static org.gridgain.grid.kernal.GridTopic.*;
 import static org.gridgain.grid.kernal.processors.ggfs.GridGgfsFileInfo.*;
@@ -129,7 +129,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
         secondaryFs = cfg.getSecondaryFileSystem();
 
         /* Default GGFS mode. */
-        GridGgfsMode dfltMode;
+        IgniteFsMode dfltMode;
 
         if (secondaryFs == null) {
             if (cfg.getDefaultMode() == PROXY)
@@ -140,8 +140,8 @@ public final class GridGgfsImpl implements GridGgfsEx {
         else
             dfltMode = cfg.getDefaultMode();
 
-        Map<String, GridGgfsMode> cfgModes = new LinkedHashMap<>();
-        Map<String, GridGgfsMode> dfltModes = new LinkedHashMap<>(4, 1.0f);
+        Map<String, IgniteFsMode> cfgModes = new LinkedHashMap<>();
+        Map<String, IgniteFsMode> dfltModes = new LinkedHashMap<>(4, 1.0f);
 
         dfltModes.put("/gridgain/primary", PRIMARY);
 
@@ -154,7 +154,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
         cfgModes.putAll(dfltModes);
 
         if (ggfsCtx.configuration().getPathModes() != null) {
-            for (Map.Entry<String, GridGgfsMode> e : ggfsCtx.configuration().getPathModes().entrySet()) {
+            for (Map.Entry<String, IgniteFsMode> e : ggfsCtx.configuration().getPathModes().entrySet()) {
                 if (!dfltModes.containsKey(e.getKey()))
                     cfgModes.put(e.getKey(), e.getValue());
                 else
@@ -163,13 +163,13 @@ public final class GridGgfsImpl implements GridGgfsEx {
             }
         }
 
-        ArrayList<T2<IgniteFsPath, GridGgfsMode>> modes = null;
+        ArrayList<T2<IgniteFsPath, IgniteFsMode>> modes = null;
 
         if (!cfgModes.isEmpty()) {
             modes = new ArrayList<>(cfgModes.size());
 
-            for (Map.Entry<String, GridGgfsMode> mode : cfgModes.entrySet()) {
-                GridGgfsMode mode0 = secondaryFs == null ? mode.getValue() == PROXY ? PROXY : PRIMARY : mode.getValue();
+            for (Map.Entry<String, IgniteFsMode> mode : cfgModes.entrySet()) {
+                IgniteFsMode mode0 = secondaryFs == null ? mode.getValue() == PROXY ? PROXY : PRIMARY : mode.getValue();
 
                 try {
                     modes.add(new T2<>(new IgniteFsPath(mode.getKey()), mode0));
@@ -467,7 +467,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
         if (log.isDebugEnabled())
             log.debug("Check file exists: " + path);
 
-        GridGgfsMode mode = modeRslvr.resolveMode(path);
+        IgniteFsMode mode = modeRslvr.resolveMode(path);
 
         if (mode == PROXY)
             throw new GridException("PROXY mode cannot be used in GGFS directly: " + path);
@@ -505,7 +505,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 if (log.isDebugEnabled())
                     log.debug("Get file info: " + path);
 
-                GridGgfsMode mode = modeRslvr.resolveMode(path);
+                IgniteFsMode mode = modeRslvr.resolveMode(path);
 
                 if (mode == PROXY)
                     throw new GridException("PROXY mode cannot be used in GGFS directly: " + path);
@@ -564,7 +564,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 if (log.isDebugEnabled())
                     log.debug("Set file properties [path=" + path + ", props=" + props + ']');
 
-                GridGgfsMode mode = modeRslvr.resolveMode(path);
+                IgniteFsMode mode = modeRslvr.resolveMode(path);
 
                 if (mode == PROXY)
                     throw new GridException("PROXY mode cannot be used in GGFS directly: " + path);
@@ -619,8 +619,8 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 if (log.isDebugEnabled())
                     log.debug("Rename file [src=" + src + ", dest=" + dest + ']');
 
-                GridGgfsMode mode = modeRslvr.resolveMode(src);
-                Set<GridGgfsMode> childrenModes = modeRslvr.resolveChildrenModes(src);
+                IgniteFsMode mode = modeRslvr.resolveMode(src);
+                Set<IgniteFsMode> childrenModes = modeRslvr.resolveChildrenModes(src);
 
                 if (mode == PROXY)
                     throw new GridException("PROXY mode cannot be used in GGFS directly: " + src);
@@ -692,7 +692,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
 
                 // Can move only into directory, but not into file.
                 if (destDesc.isFile)
-                    throw new GridGgfsParentNotDirectoryException("Failed to rename (destination is not a directory): "
+                    throw new IgniteFsParentNotDirectoryException("Failed to rename (destination is not a directory): "
                         + dest);
 
                 meta.move(srcDesc.fileId, srcFileName, srcDesc.parentId, destFileName, destDesc.fileId);
@@ -727,8 +727,8 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 if (log.isDebugEnabled())
                     log.debug("Deleting file [path=" + path + ", recursive=" + recursive + ']');
 
-                GridGgfsMode mode = modeRslvr.resolveMode(path);
-                Set<GridGgfsMode> childrenModes = modeRslvr.resolveChildrenModes(path);
+                IgniteFsMode mode = modeRslvr.resolveMode(path);
+                Set<IgniteFsMode> childrenModes = modeRslvr.resolveChildrenModes(path);
 
                 if (mode == PROXY)
                     throw new GridException("PROXY mode cannot be used in GGFS directly: " + path);
@@ -831,7 +831,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 if (props == null)
                     props = DFLT_DIR_META;
 
-                GridGgfsMode mode = modeRslvr.resolveMode(path);
+                IgniteFsMode mode = modeRslvr.resolveMode(path);
 
                 if (mode == PROXY)
                     throw new GridException("PROXY mode cannot be used in GGFS directly: " + path);
@@ -886,7 +886,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                                 throw new IgniteFsException(e);
 
                             if (!stored.isDirectory())
-                                throw new GridGgfsParentNotDirectoryException("Failed to create directory (parent " +
+                                throw new IgniteFsParentNotDirectoryException("Failed to create directory (parent " +
                                     "element is not a directory)");
 
                             fileId = stored.id(); // Update node ID.
@@ -915,12 +915,12 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 if (log.isDebugEnabled())
                     log.debug("List directory: " + path);
 
-                GridGgfsMode mode = modeRslvr.resolveMode(path);
+                IgniteFsMode mode = modeRslvr.resolveMode(path);
 
                 if (mode == PROXY)
                     throw new GridException("PROXY mode cannot be used in GGFS directly: " + path);
 
-                Set<GridGgfsMode> childrenModes = modeRslvr.resolveChildrenModes(path);
+                Set<IgniteFsMode> childrenModes = modeRslvr.resolveChildrenModes(path);
 
                 Collection<String> files = new HashSet<>();
 
@@ -967,12 +967,12 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 if (log.isDebugEnabled())
                     log.debug("List directory details: " + path);
 
-                GridGgfsMode mode = modeRslvr.resolveMode(path);
+                IgniteFsMode mode = modeRslvr.resolveMode(path);
 
                 if (mode == PROXY)
                     throw new GridException("PROXY mode cannot be used in GGFS directly: " + path);
 
-                Set<GridGgfsMode> childrenModes = modeRslvr.resolveChildrenModes(path);
+                Set<IgniteFsMode> childrenModes = modeRslvr.resolveChildrenModes(path);
 
                 Collection<IgniteFsFile> files = new HashSet<>();
 
@@ -1060,7 +1060,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 if (bufSize == 0)
                     bufSize = cfg.getStreamBufferSize();
 
-                GridGgfsMode mode = modeRslvr.resolveMode(path);
+                IgniteFsMode mode = modeRslvr.resolveMode(path);
 
                 if (mode == PROXY)
                     throw new GridException("PROXY mode cannot be used in GGFS directly: " + path);
@@ -1107,18 +1107,18 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream create(IgniteFsPath path, boolean overwrite) throws GridException {
+    @Override public IgniteFsOutputStream create(IgniteFsPath path, boolean overwrite) throws GridException {
         return create0(path, cfg.getStreamBufferSize(), overwrite, null, 0, null, true);
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication,
+    @Override public IgniteFsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication,
         long blockSize, @Nullable Map<String, String> props) throws GridException {
         return create0(path, bufSize, overwrite, null, replication, props, false);
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite,
+    @Override public IgniteFsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite,
         @Nullable IgniteUuid affKey, int replication, long blockSize, @Nullable Map<String, String> props)
         throws GridException {
         return create0(path, bufSize, overwrite, affKey, replication, props, false);
@@ -1137,7 +1137,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
      * @return Output stream.
      * @throws GridException If file creation failed.
      */
-    private GridGgfsOutputStream create0(
+    private IgniteFsOutputStream create0(
         final IgniteFsPath path,
         final int bufSize,
         final boolean overwrite,
@@ -1155,7 +1155,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                     log.debug("Open file for writing [path=" + path + ", bufSize=" + bufSize + ", overwrite=" +
                         overwrite + ", props=" + props + ']');
 
-                GridGgfsMode mode = modeRslvr.resolveMode(path);
+                IgniteFsMode mode = modeRslvr.resolveMode(path);
 
                 GridGgfsFileWorkerBatch batch = null;
 
@@ -1248,12 +1248,12 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream append(IgniteFsPath path, boolean create) throws GridException {
+    @Override public IgniteFsOutputStream append(IgniteFsPath path, boolean create) throws GridException {
         return append(path, cfg.getStreamBufferSize(), create, null);
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream append(final IgniteFsPath path, final int bufSize, boolean create,
+    @Override public IgniteFsOutputStream append(final IgniteFsPath path, final int bufSize, boolean create,
         @Nullable Map<String, String> props) throws GridException {
         if (enterBusy()) {
             try {
@@ -1264,7 +1264,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                     log.debug("Open file for appending [path=" + path + ", bufSize=" + bufSize + ", create=" + create +
                         ", props=" + props + ']');
 
-                GridGgfsMode mode = modeRslvr.resolveMode(path);
+                IgniteFsMode mode = modeRslvr.resolveMode(path);
 
                 GridGgfsFileWorkerBatch batch = null;
 
@@ -1396,7 +1396,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 if (log.isDebugEnabled())
                     log.debug("Get affinity for file block [path=" + path + ", start=" + start + ", len=" + len + ']');
 
-                GridGgfsMode mode = modeRslvr.resolveMode(path);
+                IgniteFsMode mode = modeRslvr.resolveMode(path);
 
                 if (mode == PROXY)
                     throw new GridException("PROXY mode cannot be used in GGFS directly: " + path);
@@ -1783,7 +1783,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
      * @return File info or {@code null} in case file is not found.
      * @throws GridException If failed.
      */
-    private GridGgfsFileInfo resolveFileInfo(IgniteFsPath path, GridGgfsMode mode) throws GridException {
+    private GridGgfsFileInfo resolveFileInfo(IgniteFsPath path, IgniteFsMode mode) throws GridException {
         assert path != null;
         assert mode != null;
 
@@ -1899,7 +1899,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     /**
      * GGFS output stream extension that fires events.
      */
-    private class GgfsEventAwareOutputStream extends GridGgfsOutputStreamImpl {
+    private class GgfsEventAwareOutputStream extends IgniteFsOutputStreamImpl {
         /** Close guard. */
         private final AtomicBoolean closeGuard = new AtomicBoolean(false);
 
@@ -1915,7 +1915,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
          * @throws GridException In case of error.
          */
         GgfsEventAwareOutputStream(IgniteFsPath path, GridGgfsFileInfo fileInfo,
-            IgniteUuid parentId, int bufSize, GridGgfsMode mode, @Nullable GridGgfsFileWorkerBatch batch)
+            IgniteUuid parentId, int bufSize, IgniteFsMode mode, @Nullable GridGgfsFileWorkerBatch batch)
             throws GridException {
             super(ggfsCtx, path, fileInfo, parentId, bufSize, mode, batch, metrics);
 
@@ -2137,7 +2137,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
 
     /** {@inheritDoc} */
     @Override public boolean isProxy(URI path) {
-        GridGgfsMode mode = F.isEmpty(cfg.getPathModes()) ? cfg.getDefaultMode() :
+        IgniteFsMode mode = F.isEmpty(cfg.getPathModes()) ? cfg.getDefaultMode() :
             modeRslvr.resolveMode(new IgniteFsPath(path));
 
         return mode == PROXY;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsIpcHandler.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsIpcHandler.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsIpcHandler.java
index decad5a..14d05bd 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsIpcHandler.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsIpcHandler.java
@@ -415,7 +415,7 @@ class GridGgfsIpcHandler implements GridGgfsServerHandler {
                 }
                 catch (IOException e) {
                     // Unwrap OutOfSpaceException, if has one.
-                    GridGgfsOutOfSpaceException space = X.cause(e, GridGgfsOutOfSpaceException.class);
+                    IgniteFsOutOfSpaceException space = X.cause(e, IgniteFsOutOfSpaceException.class);
 
                     if (space != null)
                         throw space;
@@ -471,7 +471,7 @@ class GridGgfsIpcHandler implements GridGgfsServerHandler {
             case WRITE_BLOCK: {
                 assert rsrcId != null : "Missing stream ID";
 
-                GridGgfsOutputStream out = (GridGgfsOutputStream)resource(ses, rsrcId);
+                IgniteFsOutputStream out = (IgniteFsOutputStream)resource(ses, rsrcId);
 
                 if (out == null)
                     throw new GridException("Output stream not found (already closed?): " + rsrcId);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolver.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolver.java
index 022ca75..c0701ef 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolver.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolver.java
@@ -24,33 +24,33 @@ public class GridGgfsModeResolver {
     private static final int MAX_PATH_CACHE = 1000;
 
     /** Default mode. */
-    private final GridGgfsMode dfltMode;
+    private final IgniteFsMode dfltMode;
 
     /** Modes for particular paths. Ordered from longest to shortest. */
-    private ArrayList<T2<IgniteFsPath, GridGgfsMode>> modes;
+    private ArrayList<T2<IgniteFsPath, IgniteFsMode>> modes;
 
     /** Cached modes per path. */
-    private Map<IgniteFsPath, GridGgfsMode> modesCache;
+    private Map<IgniteFsPath, IgniteFsMode> modesCache;
 
     /** Cached children modes per path. */
-    private Map<IgniteFsPath, Set<GridGgfsMode>> childrenModesCache;
+    private Map<IgniteFsPath, Set<IgniteFsMode>> childrenModesCache;
 
     /**
      * @param dfltMode Default GGFS mode.
      * @param modes List of configured modes.
      */
-    public GridGgfsModeResolver(GridGgfsMode dfltMode, @Nullable List<T2<IgniteFsPath, GridGgfsMode>> modes) {
+    public GridGgfsModeResolver(IgniteFsMode dfltMode, @Nullable List<T2<IgniteFsPath, IgniteFsMode>> modes) {
         assert dfltMode != null;
 
         this.dfltMode = dfltMode;
 
         if (modes != null) {
-            ArrayList<T2<IgniteFsPath, GridGgfsMode>> modes0 = new ArrayList<>(modes);
+            ArrayList<T2<IgniteFsPath, IgniteFsMode>> modes0 = new ArrayList<>(modes);
 
             // Sort paths, longest first.
-            Collections.sort(modes0, new Comparator<Map.Entry<IgniteFsPath, GridGgfsMode>>() {
-                @Override public int compare(Map.Entry<IgniteFsPath, GridGgfsMode> o1,
-                    Map.Entry<IgniteFsPath, GridGgfsMode> o2) {
+            Collections.sort(modes0, new Comparator<Map.Entry<IgniteFsPath, IgniteFsMode>>() {
+                @Override public int compare(Map.Entry<IgniteFsPath, IgniteFsMode> o1,
+                    Map.Entry<IgniteFsPath, IgniteFsMode> o2) {
                     return o2.getKey().components().size() - o1.getKey().components().size();
                 }
             });
@@ -68,16 +68,16 @@ public class GridGgfsModeResolver {
      * @param path GGFS path.
      * @return GGFS mode.
      */
-    public GridGgfsMode resolveMode(IgniteFsPath path) {
+    public IgniteFsMode resolveMode(IgniteFsPath path) {
         assert path != null;
 
         if (modes == null)
             return dfltMode;
         else {
-            GridGgfsMode mode = modesCache.get(path);
+            IgniteFsMode mode = modesCache.get(path);
 
             if (mode == null) {
-                for (T2<IgniteFsPath, GridGgfsMode> entry : modes) {
+                for (T2<IgniteFsPath, IgniteFsMode> entry : modes) {
                     if (startsWith(path, entry.getKey())) {
                         // As modes ordered from most specific to least specific first mode found is ours.
                         mode = entry.getValue();
@@ -100,20 +100,20 @@ public class GridGgfsModeResolver {
      * @param path Path.
      * @return Set of all modes that children paths could have.
      */
-    public Set<GridGgfsMode> resolveChildrenModes(IgniteFsPath path) {
+    public Set<IgniteFsMode> resolveChildrenModes(IgniteFsPath path) {
         assert path != null;
 
         if (modes == null)
             return Collections.singleton(dfltMode);
         else {
-            Set<GridGgfsMode> children = childrenModesCache.get(path);
+            Set<IgniteFsMode> children = childrenModesCache.get(path);
 
             if (children == null) {
-                children = new HashSet<>(GridGgfsMode.values().length, 1.0f);
+                children = new HashSet<>(IgniteFsMode.values().length, 1.0f);
 
-                GridGgfsMode pathDefault = dfltMode;
+                IgniteFsMode pathDefault = dfltMode;
 
-                for (T2<IgniteFsPath, GridGgfsMode> child : modes) {
+                for (T2<IgniteFsPath, IgniteFsMode> child : modes) {
                     if (startsWith(path, child.getKey())) {
                         pathDefault = child.getValue();
 
@@ -136,7 +136,7 @@ public class GridGgfsModeResolver {
      * @return Unmodifiable copy of properly ordered modes prefixes
      *  or {@code null} if no modes set.
      */
-    @Nullable public List<T2<IgniteFsPath, GridGgfsMode>> modesOrdered() {
+    @Nullable public List<T2<IgniteFsPath, IgniteFsMode>> modesOrdered() {
         return modes != null ? Collections.unmodifiableList(modes) : null;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamAdapter.java
deleted file mode 100644
index 40334fc..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamAdapter.java
+++ /dev/null
@@ -1,255 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.kernal.processors.ggfs;
-
-import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
-import org.gridgain.grid.util.typedef.internal.*;
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-import java.nio.*;
-
-/**
- * Output stream to store data into grid cache with separate blocks.
- */
-@SuppressWarnings("NonPrivateFieldAccessedInSynchronizedContext")
-abstract class GridGgfsOutputStreamAdapter extends GridGgfsOutputStream {
-    /** Path to file. */
-    protected final IgniteFsPath path;
-
-    /** Buffer size. */
-    private final int bufSize;
-
-    /** Flag for this stream open/closed state. */
-    private boolean closed;
-
-    /** Local buffer to store stream data as consistent block. */
-    private ByteBuffer buf;
-
-    /** Bytes written. */
-    @SuppressWarnings("FieldAccessedSynchronizedAndUnsynchronized")
-    protected long bytes;
-
-    /** Time consumed by write operations. */
-    protected long time;
-
-    /**
-     * Constructs file output stream.
-     *
-     * @param path Path to stored file.
-     * @param bufSize The size of the buffer to be used.
-     */
-    GridGgfsOutputStreamAdapter(IgniteFsPath path, int bufSize) {
-        assert path != null;
-        assert bufSize > 0;
-
-        this.path = path;
-        this.bufSize = bufSize;
-    }
-
-    /**
-     * Gets number of written bytes.
-     *
-     * @return Written bytes.
-     */
-    public long bytes() {
-        return bytes;
-    }
-
-    /** {@inheritDoc} */
-    @Override public synchronized void write(int b) throws IOException {
-        checkClosed(null, 0);
-
-        long startTime = System.nanoTime();
-
-        b &= 0xFF;
-
-        if (buf == null)
-            buf = ByteBuffer.allocate(bufSize);
-
-        buf.put((byte)b);
-
-        if (buf.position() >= bufSize)
-            sendData(true); // Send data to server.
-
-        time += System.nanoTime() - startTime;
-    }
-
-    /** {@inheritDoc} */
-    @Override public synchronized void write(byte[] b, int off, int len) throws IOException {
-        A.notNull(b, "b");
-
-        if ((off < 0) || (off > b.length) || (len < 0) || ((off + len) > b.length) || ((off + len) < 0)) {
-            throw new IndexOutOfBoundsException("Invalid bounds [data.length=" + b.length + ", offset=" + off +
-                ", length=" + len + ']');
-        }
-
-        checkClosed(null, 0);
-
-        if (len == 0)
-            return; // Done.
-
-        long startTime = System.nanoTime();
-
-        if (buf == null) {
-            // Do not allocate and copy byte buffer if will send data immediately.
-            if (len >= bufSize) {
-                buf = ByteBuffer.wrap(b, off, len);
-
-                sendData(false);
-
-                return;
-            }
-
-            buf = ByteBuffer.allocate(Math.max(bufSize, len));
-        }
-
-        if (buf.remaining() < len)
-            // Expand buffer capacity, if remaining size is less then data size.
-            buf = ByteBuffer.allocate(buf.position() + len).put((ByteBuffer)buf.flip());
-
-        assert len <= buf.remaining() : "Expects write data size less or equal then remaining buffer capacity " +
-            "[len=" + len + ", buf.remaining=" + buf.remaining() + ']';
-
-        buf.put(b, off, len);
-
-        if (buf.position() >= bufSize)
-            sendData(true); // Send data to server.
-
-        time += System.nanoTime() - startTime;
-    }
-
-    /** {@inheritDoc} */
-    @Override public synchronized void transferFrom(DataInput in, int len) throws IOException {
-        checkClosed(in, len);
-
-        long startTime = System.nanoTime();
-
-        // Send all IPC data from the local buffer before streaming.
-        if (buf != null && buf.position() > 0)
-            sendData(true);
-
-        try {
-            storeDataBlocks(in, len);
-        }
-        catch (GridException e) {
-            throw new IOException(e.getMessage(), e);
-        }
-
-        time += System.nanoTime() - startTime;
-    }
-
-    /**
-     * Flushes this output stream and forces any buffered output bytes to be written out.
-     *
-     * @exception IOException  if an I/O error occurs.
-     */
-    @Override public synchronized void flush() throws IOException {
-        checkClosed(null, 0);
-
-        // Send all IPC data from the local buffer.
-        if (buf != null && buf.position() > 0)
-            sendData(true);
-    }
-
-    /** {@inheritDoc} */
-    @Override public final synchronized void close() throws IOException {
-        // Do nothing if stream is already closed.
-        if (closed)
-            return;
-
-        try {
-            // Send all IPC data from the local buffer.
-            try {
-                flush();
-            }
-            finally {
-                onClose(); // "onClose()" routine must be invoked anyway!
-            }
-        }
-        finally {
-            // Mark this stream closed AFTER flush.
-            closed = true;
-        }
-    }
-
-    /**
-     * Store data blocks in file.<br/>
-     * Note! If file concurrently deleted we'll get lost blocks.
-     *
-     * @param data Data to store.
-     * @throws GridException If failed.
-     */
-    protected abstract void storeDataBlock(ByteBuffer data) throws GridException, IOException;
-
-    /**
-     * Store data blocks in file reading appropriate number of bytes from given data input.
-     *
-     * @param in Data input to read from.
-     * @param len Data length to store.
-     * @throws GridException If failed.
-     */
-    protected abstract void storeDataBlocks(DataInput in, int len) throws GridException, IOException;
-
-    /**
-     * Close callback. It will be called only once in synchronized section.
-     *
-     * @throws IOException If failed.
-     */
-    protected void onClose() throws IOException {
-        // No-op.
-    }
-
-    /**
-     * Validate this stream is open.
-     *
-     * @throws IOException If this stream is closed.
-     */
-    private void checkClosed(@Nullable DataInput in, int len) throws IOException {
-        assert Thread.holdsLock(this);
-
-        if (closed) {
-            // Must read data from stream before throwing exception.
-            if (in != null)
-                in.skipBytes(len);
-
-            throw new IOException("Stream has been closed: " + this);
-        }
-    }
-
-    /**
-     * Send all local-buffered data to server.
-     *
-     * @param flip Whether to flip buffer on sending data. We do not want to flip it if sending wrapped
-     *      byte array.
-     * @throws IOException In case of IO exception.
-     */
-    private void sendData(boolean flip) throws IOException {
-        assert Thread.holdsLock(this);
-
-        try {
-            if (flip)
-                buf.flip();
-
-            storeDataBlock(buf);
-        }
-        catch (GridException e) {
-            throw new IOException("Failed to store data into file: " + path, e);
-        }
-
-        buf = null;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridGgfsOutputStreamAdapter.class, this);
-    }
-}


[35/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/test/config/load/dsi-load-base.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/load/dsi-load-base.xml b/modules/core/src/test/config/load/dsi-load-base.xml
index 4ac4001..e75e190 100644
--- a/modules/core/src/test/config/load/dsi-load-base.xml
+++ b/modules/core/src/test/config/load/dsi-load-base.xml
@@ -71,7 +71,7 @@
         <property name="deploymentMode" value="CONTINUOUS"/>
 
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() * 4}"/>
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() * 4}"/>
                 <constructor-arg type="long">
@@ -84,7 +84,7 @@
         </property>
 
         <property name="systemExecutorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() * 8}"/>
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() * 8}"/>
                 <constructor-arg type="long">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/test/config/load/merge-sort-base.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/load/merge-sort-base.xml b/modules/core/src/test/config/load/merge-sort-base.xml
index 6712024..130bfe3 100644
--- a/modules/core/src/test/config/load/merge-sort-base.xml
+++ b/modules/core/src/test/config/load/merge-sort-base.xml
@@ -57,7 +57,7 @@
 
         <!-- Disable pools -->
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="100"/>
                 <constructor-arg type="int" value="100"/>
                 <constructor-arg type="long">
@@ -70,7 +70,7 @@
         </property>
 
         <property name="systemExecutorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="100"/>
                 <constructor-arg type="int" value="100"/>
                 <constructor-arg type="long">
@@ -83,7 +83,7 @@
         </property>
 
         <property name="peerClassLoadingExecutorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="100"/>
                 <constructor-arg type="int" value="100"/>
                 <constructor-arg type="long">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/test/config/load/mongo-multinode-foster.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/load/mongo-multinode-foster.xml b/modules/core/src/test/config/load/mongo-multinode-foster.xml
index 9790871..3235a6f 100644
--- a/modules/core/src/test/config/load/mongo-multinode-foster.xml
+++ b/modules/core/src/test/config/load/mongo-multinode-foster.xml
@@ -115,7 +115,7 @@
         <property name="peerClassLoadingEnabled" value="false"/>
 
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() * 2}"/>
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() * 2}"/>
                 <constructor-arg type="long">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/test/config/spring-multicache.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/spring-multicache.xml b/modules/core/src/test/config/spring-multicache.xml
index 13929f6..c60c6b3 100644
--- a/modules/core/src/test/config/spring-multicache.xml
+++ b/modules/core/src/test/config/spring-multicache.xml
@@ -288,7 +288,7 @@
             All threads are pre-started and are available for use.
         -->
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="10"/>
                 <constructor-arg type="int" value="10"/>
                 <constructor-arg type="long">
@@ -306,7 +306,7 @@
             Threads are not started unless used.
         -->
         <property name="systemExecutorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="10"/>
                 <constructor-arg type="int" value="10"/>
                 <constructor-arg type="long">
@@ -324,7 +324,7 @@
             Threads are not started unless used.
         -->
         <property name="peerClassLoadingExecutorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="2"/>
                 <constructor-arg type="int" value="2"/>
                 <constructor-arg type="long">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/distributed/GridCachePreloadLifecycleAbstractTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/distributed/GridCachePreloadLifecycleAbstractTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/distributed/GridCachePreloadLifecycleAbstractTest.java
index d417e13..2bfefff 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/distributed/GridCachePreloadLifecycleAbstractTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/distributed/GridCachePreloadLifecycleAbstractTest.java
@@ -80,9 +80,9 @@ public abstract class GridCachePreloadLifecycleAbstractTest extends GridCommonAb
 //        c.setPeerClassLoadingLocalClassPathExclude(GridCachePreloadLifecycleAbstractTest.class.getName(),
 //            MyValue.class.getName());
 
-        c.setExecutorService(new GridThreadPoolExecutor(10, 10, 0, new LinkedBlockingQueue<Runnable>()));
-        c.setSystemExecutorService(new GridThreadPoolExecutor(10, 10, 0, new LinkedBlockingQueue<Runnable>()));
-        c.setPeerClassLoadingExecutorService(new GridThreadPoolExecutor(3, 3, 0, new LinkedBlockingQueue<Runnable>()));
+        c.setExecutorService(new IgniteThreadPoolExecutor(10, 10, 0, new LinkedBlockingQueue<Runnable>()));
+        c.setSystemExecutorService(new IgniteThreadPoolExecutor(10, 10, 0, new LinkedBlockingQueue<Runnable>()));
+        c.setPeerClassLoadingExecutorService(new IgniteThreadPoolExecutor(3, 3, 0, new LinkedBlockingQueue<Runnable>()));
 
         c.setLifecycleBeans(lifecycleBean);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/test/java/org/gridgain/grid/marshaller/GridMarshallerResourceBean.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/marshaller/GridMarshallerResourceBean.java b/modules/core/src/test/java/org/gridgain/grid/marshaller/GridMarshallerResourceBean.java
index 9f6b1e4..af48d70 100644
--- a/modules/core/src/test/java/org/gridgain/grid/marshaller/GridMarshallerResourceBean.java
+++ b/modules/core/src/test/java/org/gridgain/grid/marshaller/GridMarshallerResourceBean.java
@@ -63,7 +63,7 @@ class GridMarshallerResourceBean implements Serializable {
         marshaller = new IgniteJdkMarshaller();
         mbeanSrv = ManagementFactory.getPlatformMBeanServer();
         ses = new GridTestTaskSession();
-        execSvc = new GridThreadPoolExecutor(1, 1, 0, new LinkedBlockingQueue<Runnable>());
+        execSvc = new IgniteThreadPoolExecutor(1, 1, 0, new LinkedBlockingQueue<Runnable>());
         appCtx = new GenericApplicationContext();
         jobCtx = new GridTestJobContext();
         balancer = new LoadBalancer();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadPoolExecutorServiceSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadPoolExecutorServiceSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadPoolExecutorServiceSelfTest.java
index 1ee02fc..469014b 100644
--- a/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadPoolExecutorServiceSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadPoolExecutorServiceSelfTest.java
@@ -17,7 +17,7 @@ import java.util.concurrent.atomic.*;
 import static java.util.concurrent.TimeUnit.*;
 
 /**
- * Test for {@link GridThreadPoolExecutor}.
+ * Test for {@link IgniteThreadPoolExecutor}.
  */
 @GridCommonTest(group = "Utils")
 public class GridThreadPoolExecutorServiceSelfTest extends GridCommonAbstractTest {
@@ -49,7 +49,7 @@ public class GridThreadPoolExecutorServiceSelfTest extends GridCommonAbstractTes
      * @throws Exception If failed.
      */
     public void testSingleGridThreadExecutor() throws Exception {
-        ExecutorService exec = Executors.newSingleThreadExecutor(new GridThreadFactory("gridName"));
+        ExecutorService exec = Executors.newSingleThreadExecutor(new IgniteThreadFactory("gridName"));
 
         exec.submit(new InterruptingRunnable()).get();
 
@@ -70,7 +70,7 @@ public class GridThreadPoolExecutorServiceSelfTest extends GridCommonAbstractTes
      * @throws ExecutionException If failed.
      */
     public void testGridThreadPoolExecutor() throws Exception {
-        GridThreadPoolExecutor exec = new GridThreadPoolExecutor(1, 1, 0, new LinkedBlockingQueue<Runnable>());
+        IgniteThreadPoolExecutor exec = new IgniteThreadPoolExecutor(1, 1, 0, new LinkedBlockingQueue<Runnable>());
 
         exec.submit(new InterruptingRunnable()).get();
 
@@ -86,7 +86,7 @@ public class GridThreadPoolExecutorServiceSelfTest extends GridCommonAbstractTes
      * @throws ExecutionException If failed.
      */
     public void testGridThreadPoolExecutorRejection() throws Exception {
-        GridThreadPoolExecutor exec = new GridThreadPoolExecutor(1, 1, 0, new LinkedBlockingQueue<Runnable>());
+        IgniteThreadPoolExecutor exec = new IgniteThreadPoolExecutor(1, 1, 0, new LinkedBlockingQueue<Runnable>());
 
         for (int i = 0; i < 10; i++)
             exec.submit(new TestRunnable());
@@ -104,7 +104,7 @@ public class GridThreadPoolExecutorServiceSelfTest extends GridCommonAbstractTes
         final CountDownLatch startLatch = new CountDownLatch(THREAD_CNT);
         final CountDownLatch stopLatch = new CountDownLatch(THREAD_CNT);
 
-        GridThreadPoolExecutor exec = new GridThreadPoolExecutor(
+        IgniteThreadPoolExecutor exec = new IgniteThreadPoolExecutor(
             THREAD_CNT, THREAD_CNT, Long.MAX_VALUE,
             new LinkedBlockingQueue<Runnable>(),
             new ThreadFactory() {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadTest.java b/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadTest.java
index 770d2f7..f99ceae 100644
--- a/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadTest.java
@@ -14,7 +14,7 @@ import org.gridgain.testframework.junits.common.*;
 import java.util.*;
 
 /**
- * Test for {@link GridThread}.
+ * Test for {@link IgniteThread}.
  */
 @GridCommonTest(group = "Utils")
 public class GridThreadTest extends GridCommonAbstractTest {
@@ -25,20 +25,20 @@ public class GridThreadTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testAssertion() throws Exception {
-        Collection<GridThread> ts = new ArrayList<>();
+        Collection<IgniteThread> ts = new ArrayList<>();
 
         for (int i = 0; i < THREAD_CNT; i++) {
-            ts.add(new GridThread("test-grid-" + i, "test-thread", new Runnable() {
+            ts.add(new IgniteThread("test-grid-" + i, "test-thread", new Runnable() {
                 @Override public void run() {
                     assert false : "Expected assertion.";
                 }
             }));
         }
 
-        for (GridThread t : ts)
+        for (IgniteThread t : ts)
             t.start();
 
-        for (GridThread t : ts)
+        for (IgniteThread t : ts)
             t.join();
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/test/java/org/gridgain/loadtests/cache/GridCacheSingleNodeLoadTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/loadtests/cache/GridCacheSingleNodeLoadTest.java b/modules/core/src/test/java/org/gridgain/loadtests/cache/GridCacheSingleNodeLoadTest.java
index 6644d6e..2264ced 100644
--- a/modules/core/src/test/java/org/gridgain/loadtests/cache/GridCacheSingleNodeLoadTest.java
+++ b/modules/core/src/test/java/org/gridgain/loadtests/cache/GridCacheSingleNodeLoadTest.java
@@ -114,8 +114,8 @@ public class GridCacheSingleNodeLoadTest {
 
         c.setCollisionSpi(cols);
 
-        c.setExecutorService(new GridThreadPoolExecutor(THREADS / 2, THREADS / 2, 0L, new LinkedBlockingQueue<Runnable>()));
-        c.setSystemExecutorService(new GridThreadPoolExecutor(THREADS * 2, THREADS * 2, 0L,
+        c.setExecutorService(new IgniteThreadPoolExecutor(THREADS / 2, THREADS / 2, 0L, new LinkedBlockingQueue<Runnable>()));
+        c.setSystemExecutorService(new IgniteThreadPoolExecutor(THREADS * 2, THREADS * 2, 0L,
             new LinkedBlockingQueue<Runnable>()));
 
         GridCacheConfiguration cc = new GridCacheConfiguration();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/test/java/org/gridgain/loadtests/colocation/GridTestMain.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/loadtests/colocation/GridTestMain.java b/modules/core/src/test/java/org/gridgain/loadtests/colocation/GridTestMain.java
index c6b4979..900e418 100644
--- a/modules/core/src/test/java/org/gridgain/loadtests/colocation/GridTestMain.java
+++ b/modules/core/src/test/java/org/gridgain/loadtests/colocation/GridTestMain.java
@@ -111,7 +111,7 @@ public class GridTestMain {
     private static void localPoolRun() {
         X.println("Local thread pool run...");
 
-        ExecutorService exe = new GridThreadPoolExecutor(400, 400, 0, new ArrayBlockingQueue<Runnable>(400) {
+        ExecutorService exe = new IgniteThreadPoolExecutor(400, 400, 0, new ArrayBlockingQueue<Runnable>(400) {
             @Override public boolean offer(Runnable runnable) {
                 try {
                     put(runnable);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/test/java/org/gridgain/loadtests/colocation/spring-colocation.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/loadtests/colocation/spring-colocation.xml b/modules/core/src/test/java/org/gridgain/loadtests/colocation/spring-colocation.xml
index bd1e0eb..e0c8cc8 100644
--- a/modules/core/src/test/java/org/gridgain/loadtests/colocation/spring-colocation.xml
+++ b/modules/core/src/test/java/org/gridgain/loadtests/colocation/spring-colocation.xml
@@ -70,7 +70,7 @@
             All threads are pre-started and are available for use.
         -->
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="400"/>
                 <constructor-arg type="int" value="400"/>
                 <constructor-arg type="long">
@@ -88,7 +88,7 @@
             Threads are not started unless used.
         -->
         <property name="systemExecutorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="400"/>
                 <constructor-arg type="int" value="400"/>
                 <constructor-arg type="long">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/test/java/org/gridgain/loadtests/direct/newnodes/GridSingleSplitsNewNodesAbstractLoadTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/loadtests/direct/newnodes/GridSingleSplitsNewNodesAbstractLoadTest.java b/modules/core/src/test/java/org/gridgain/loadtests/direct/newnodes/GridSingleSplitsNewNodesAbstractLoadTest.java
index 383424a..4c3dc2f 100644
--- a/modules/core/src/test/java/org/gridgain/loadtests/direct/newnodes/GridSingleSplitsNewNodesAbstractLoadTest.java
+++ b/modules/core/src/test/java/org/gridgain/loadtests/direct/newnodes/GridSingleSplitsNewNodesAbstractLoadTest.java
@@ -54,7 +54,7 @@ public abstract class GridSingleSplitsNewNodesAbstractLoadTest extends GridCommo
         // Set up new executor service because we have 1 per test and thus all
         // nodes have the same executor service. As soon as node get stopped
         // it stops executor service and may fail active nodes.
-        cfg.setExecutorService(new GridThreadPoolExecutor());
+        cfg.setExecutorService(new IgniteThreadPoolExecutor());
 
         ((ThreadPoolExecutor)cfg.getExecutorService()).prestartAllCoreThreads();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/test/java/org/gridgain/testframework/junits/GridTestResources.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/testframework/junits/GridTestResources.java b/modules/core/src/test/java/org/gridgain/testframework/junits/GridTestResources.java
index 2b99542..bea8f4c 100644
--- a/modules/core/src/test/java/org/gridgain/testframework/junits/GridTestResources.java
+++ b/modules/core/src/test/java/org/gridgain/testframework/junits/GridTestResources.java
@@ -134,7 +134,7 @@ public class GridTestResources {
      * @param prestart Prestart flag.
      */
     public void startThreads(boolean prestart) {
-        execSvc = new GridThreadPoolExecutor(nodeId.toString(), 40, 40, Long.MAX_VALUE,
+        execSvc = new IgniteThreadPoolExecutor(nodeId.toString(), 40, 40, Long.MAX_VALUE,
             new LinkedBlockingQueue<Runnable>());
 
         // Improve concurrency for testing.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/email/src/main/java/org/gridgain/grid/kernal/processors/email/GridEmailProcessor.java
----------------------------------------------------------------------
diff --git a/modules/email/src/main/java/org/gridgain/grid/kernal/processors/email/GridEmailProcessor.java b/modules/email/src/main/java/org/gridgain/grid/kernal/processors/email/GridEmailProcessor.java
index 4d214f4..c5403d4 100644
--- a/modules/email/src/main/java/org/gridgain/grid/kernal/processors/email/GridEmailProcessor.java
+++ b/modules/email/src/main/java/org/gridgain/grid/kernal/processors/email/GridEmailProcessor.java
@@ -34,7 +34,7 @@ public class GridEmailProcessor extends GridEmailProcessorAdapter {
     private Deque<GridEmailHolder> q;
 
     /** */
-    private GridThread snd;
+    private IgniteThread snd;
 
     /** */
     private GridWorker worker;
@@ -87,7 +87,7 @@ public class GridEmailProcessor extends GridEmailProcessorAdapter {
 
             q = new LinkedList<>();
 
-            snd = new GridThread(ctx.config().getGridName(), "email-sender-thread", worker);
+            snd = new IgniteThread(ctx.config().getGridName(), "email-sender-thread", worker);
 
             snd.start();
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/shuffle/GridHadoopShuffleJob.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/shuffle/GridHadoopShuffleJob.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/shuffle/GridHadoopShuffleJob.java
index 38e23e1..533f939 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/shuffle/GridHadoopShuffleJob.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/shuffle/GridHadoopShuffleJob.java
@@ -159,7 +159,7 @@ public class GridHadoopShuffleJob<T> implements AutoCloseable {
                 }
             };
 
-            new GridThread(snd).start();
+            new IgniteThread(snd).start();
         }
 
         ioInitLatch.countDown();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/GridHadoopExecutorService.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/GridHadoopExecutorService.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/GridHadoopExecutorService.java
index 9510c8d..bd4fb1b 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/GridHadoopExecutorService.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/GridHadoopExecutorService.java
@@ -186,7 +186,7 @@ public class GridHadoopExecutorService {
         if (shutdown)
             w.cancel();
 
-        new GridThread(w).start();
+        new IgniteThread(w).start();
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/communication/GridHadoopExternalCommunication.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/communication/GridHadoopExternalCommunication.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/communication/GridHadoopExternalCommunication.java
index a9fa657..b9fc2ca 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/communication/GridHadoopExternalCommunication.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/communication/GridHadoopExternalCommunication.java
@@ -546,7 +546,7 @@ public class GridHadoopExternalCommunication {
         if (shmemSrv != null) {
             shmemAcceptWorker = new ShmemAcceptWorker(shmemSrv);
 
-            new GridThread(shmemAcceptWorker).start();
+            new IgniteThread(shmemAcceptWorker).start();
         }
 
         nioSrvr.start();
@@ -860,7 +860,7 @@ public class GridHadoopExternalCommunication {
 
                 client = new GridHadoopTcpNioCommunicationClient(ses);
 
-                new GridThread(worker).start();
+                new IgniteThread(worker).start();
 
                 fin.await(connTimeout0);
             }
@@ -1089,7 +1089,7 @@ public class GridHadoopExternalCommunication {
 
                     shmemWorkers.add(e);
 
-                    new GridThread(e).start();
+                    new IgniteThread(e).start();
                 }
             }
             catch (GridException e) {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/visor-console/src/main/scala/org/gridgain/visor/visor.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/gridgain/visor/visor.scala b/modules/visor-console/src/main/scala/org/gridgain/visor/visor.scala
index 32d25d5..8f67380 100644
--- a/modules/visor-console/src/main/scala/org/gridgain/visor/visor.scala
+++ b/modules/visor-console/src/main/scala/org/gridgain/visor/visor.scala
@@ -216,7 +216,7 @@ object visor extends VisorTag {
     @volatile private var logStarted = false
 
     /** Internal thread pool. */
-    @volatile var pool: ExecutorService = new GridThreadPoolExecutor()
+    @volatile var pool: ExecutorService = new IgniteThreadPoolExecutor()
 
     /** Configuration file path, if any. */
     @volatile var cfgPath: String = null
@@ -1514,7 +1514,7 @@ object visor extends VisorTag {
 
                 cfg.setClientConnectionConfiguration(null)
 
-                def createExecutor = new GridThreadPoolExecutor(cpuCnt, cpuCnt, Long.MaxValue, new LinkedBlockingQueue[Runnable])
+                def createExecutor = new IgniteThreadPoolExecutor(cpuCnt, cpuCnt, Long.MaxValue, new LinkedBlockingQueue[Runnable])
 
                 // All thread pools are overridden to have size equal to number of CPUs.
                 cfg.setExecutorService(createExecutor)
@@ -2149,7 +2149,7 @@ object visor extends VisorTag {
                         Thread.currentThread.interrupt()
                 }
 
-                pool = new GridThreadPoolExecutor()
+                pool = new IgniteThreadPoolExecutor()
             }
 
             // Call all close callbacks.


[32/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
# Renaming


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

Branch: refs/heads/master
Commit: 81e01957ee9d674b3803173bfaeebd23821fb3cd
Parents: 243e521
Author: sboikov <sb...@gridgain.com>
Authored: Fri Dec 5 11:29:36 2014 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Dec 5 11:29:39 2014 +0300

----------------------------------------------------------------------
 examples/config/filesystem/example-ggfs.xml     |   4 +-
 .../org/gridgain/examples/ggfs/GgfsExample.java |   2 +-
 .../examples/ggfs/GgfsMapReduceExample.java     |   2 +-
 .../src/main/java/org/apache/ignite/Ignite.java |  12 +-
 .../main/java/org/apache/ignite/IgniteFs.java   |  24 +-
 .../configuration/IgniteConfiguration.java      |   2 +-
 .../org/apache/ignite/events/IgniteFsEvent.java |   2 +-
 .../apache/ignite/fs/IgniteFsBlockLocation.java |  55 ++
 ...IgniteFsConcurrentModificationException.java |  28 +
 .../apache/ignite/fs/IgniteFsConfiguration.java | 798 ++++++++++++++++++
 .../fs/IgniteFsCorruptedFileException.java      |  42 +
 .../org/apache/ignite/fs/IgniteFsException.java |  49 ++
 .../java/org/apache/ignite/fs/IgniteFsFile.java | 112 +++
 .../fs/IgniteFsFileNotFoundException.java       |  36 +
 .../apache/ignite/fs/IgniteFsFileSystem.java    | 208 +++++
 .../fs/IgniteFsGroupDataBlocksKeyMapper.java    |  93 +++
 .../apache/ignite/fs/IgniteFsInputStream.java   |  72 ++
 .../fs/IgniteFsInvalidHdfsVersionException.java |  34 +
 .../ignite/fs/IgniteFsInvalidPathException.java |  49 ++
 .../org/apache/ignite/fs/IgniteFsMetrics.java   | 151 ++++
 .../java/org/apache/ignite/fs/IgniteFsMode.java |  72 ++
 .../ignite/fs/IgniteFsOutOfSpaceException.java  |  50 ++
 .../apache/ignite/fs/IgniteFsOutputStream.java  |  27 +
 .../fs/IgniteFsParentNotDirectoryException.java |  42 +
 .../java/org/apache/ignite/fs/IgniteFsPath.java | 254 ++++++
 .../fs/IgniteFsPathAlreadyExistsException.java  |  42 +
 .../apache/ignite/fs/IgniteFsPathSummary.java   | 130 +++
 .../org/apache/ignite/fs/IgniteFsReader.java    |  30 +
 .../main/java/org/apache/ignite/fs/package.html |  15 +
 .../GridCacheGgfsPerBlockLruEvictionPolicy.java |   2 +-
 .../grid/ggfs/IgniteFsBlockLocation.java        |  55 --
 ...IgniteFsConcurrentModificationException.java |  28 -
 .../grid/ggfs/IgniteFsConfiguration.java        | 800 -------------------
 .../ggfs/IgniteFsCorruptedFileException.java    |  42 -
 .../gridgain/grid/ggfs/IgniteFsException.java   |  49 --
 .../org/gridgain/grid/ggfs/IgniteFsFile.java    | 112 ---
 .../ggfs/IgniteFsFileNotFoundException.java     |  36 -
 .../gridgain/grid/ggfs/IgniteFsFileSystem.java  | 208 -----
 .../ggfs/IgniteFsGroupDataBlocksKeyMapper.java  |  93 ---
 .../gridgain/grid/ggfs/IgniteFsInputStream.java |  72 --
 .../IgniteFsInvalidHdfsVersionException.java    |  34 -
 .../grid/ggfs/IgniteFsInvalidPathException.java |  49 --
 .../org/gridgain/grid/ggfs/IgniteFsMetrics.java | 151 ----
 .../org/gridgain/grid/ggfs/IgniteFsMode.java    |  72 --
 .../grid/ggfs/IgniteFsOutOfSpaceException.java  |  50 --
 .../grid/ggfs/IgniteFsOutputStream.java         |  27 -
 .../IgniteFsParentNotDirectoryException.java    |  42 -
 .../org/gridgain/grid/ggfs/IgniteFsPath.java    | 254 ------
 .../IgniteFsPathAlreadyExistsException.java     |  42 -
 .../gridgain/grid/ggfs/IgniteFsPathSummary.java | 130 ---
 .../org/gridgain/grid/ggfs/IgniteFsReader.java  |  30 -
 .../grid/ggfs/mapreduce/IgniteFsFileRange.java  |   2 +-
 .../IgniteFsInputStreamJobAdapter.java          |   4 +-
 .../grid/ggfs/mapreduce/IgniteFsJob.java        |   6 +-
 .../mapreduce/IgniteFsRangeInputStream.java     |   4 +-
 .../ggfs/mapreduce/IgniteFsRecordResolver.java  |   2 +-
 .../grid/ggfs/mapreduce/IgniteFsTask.java       |   6 +-
 .../grid/ggfs/mapreduce/IgniteFsTaskArgs.java   |   6 +-
 .../IgniteFsByteDelimiterRecordResolver.java    |   2 +-
 .../IgniteFsFixedLengthRecordResolver.java      |   2 +-
 .../java/org/gridgain/grid/ggfs/package.html    |  15 -
 .../org/gridgain/grid/kernal/GridGainEx.java    |   2 +-
 .../ggfs/common/GridGgfsControlResponse.java    |   2 +-
 .../grid/kernal/ggfs/common/GridGgfsLogger.java |   2 +-
 .../kernal/ggfs/common/GridGgfsMarshaller.java  |   4 +-
 .../ggfs/common/GridGgfsPathControlRequest.java |   2 +-
 .../processors/cache/GridCacheAdapter.java      |   2 +-
 .../processors/cache/GridCacheProcessor.java    |   2 +-
 .../kernal/processors/cache/GridCacheUtils.java |   2 +-
 .../processors/ggfs/GridGgfsAsyncImpl.java      |   2 +-
 .../processors/ggfs/GridGgfsAttributes.java     |   8 +-
 .../ggfs/GridGgfsBlockLocationImpl.java         |   2 +-
 .../kernal/processors/ggfs/GridGgfsContext.java |   2 +-
 .../processors/ggfs/GridGgfsDataManager.java    |   2 +-
 .../GridGgfsDirectoryNotEmptyException.java     |   2 +-
 .../grid/kernal/processors/ggfs/GridGgfsEx.java |   2 +-
 .../processors/ggfs/GridGgfsFileInfo.java       |   4 +-
 .../ggfs/GridGgfsFileWorkerBatch.java           |   2 +-
 .../kernal/processors/ggfs/GridGgfsImpl.java    |   8 +-
 .../ggfs/GridGgfsInputStreamAdapter.java        |   2 +-
 .../ggfs/GridGgfsInputStreamImpl.java           |   2 +-
 .../processors/ggfs/GridGgfsIpcHandler.java     |   2 +-
 .../kernal/processors/ggfs/GridGgfsJobImpl.java |   2 +-
 .../processors/ggfs/GridGgfsMetaManager.java    |   2 +-
 .../processors/ggfs/GridGgfsModeResolver.java   |   2 +-
 .../kernal/processors/ggfs/GridGgfsPaths.java   |   2 +-
 .../processors/ggfs/GridGgfsProcessor.java      |   4 +-
 .../ggfs/GridGgfsProcessorAdapter.java          |   2 +-
 .../GridGgfsSecondaryInputStreamDescriptor.java |   2 +-
 .../processors/ggfs/GridGgfsServerManager.java  |   4 +-
 .../processors/ggfs/GridNoopGgfsProcessor.java  |   2 +-
 .../processors/ggfs/IgniteFsFileImpl.java       |   2 +-
 .../processors/ggfs/IgniteFsMetricsAdapter.java |   2 +-
 .../ggfs/IgniteFsOutputStreamAdapter.java       |   2 +-
 .../ggfs/IgniteFsOutputStreamImpl.java          |   4 +-
 .../processors/ggfs/IgniteFsTaskArgsImpl.java   |   2 +-
 .../kernal/processors/job/GridJobWorker.java    |   2 +-
 .../kernal/processors/task/GridTaskWorker.java  |   2 +-
 .../grid/kernal/visor/ggfs/VisorGgfs.java       |   2 +-
 .../kernal/visor/ggfs/VisorGgfsMetrics.java     |   4 +-
 .../kernal/visor/ggfs/VisorGgfsProfiler.java    |   2 +-
 .../visor/ggfs/VisorGgfsProfilerEntry.java      |   2 +-
 .../visor/ggfs/VisorGgfsProfilerTask.java       |   2 +-
 .../visor/node/VisorGgfsConfiguration.java      |   2 +-
 .../grid/kernal/visor/util/VisorTaskUtils.java  |   2 +-
 modules/core/src/test/config/ggfs-loopback.xml  |   4 +-
 .../core/src/test/config/ggfs-no-endpoint.xml   |   4 +-
 modules/core/src/test/config/ggfs-shmem.xml     |   4 +-
 .../ggfs/GridGgfsEventsAbstractSelfTest.java    |   1 +
 .../GridGgfsFragmentizerAbstractSelfTest.java   |   1 +
 .../grid/ggfs/GridGgfsFragmentizerSelfTest.java |   1 +
 .../GridGgfsFragmentizerTopologySelfTest.java   |   1 +
 .../grid/ggfs/GridGgfsPathSelfTest.java         |   3 +-
 ...heGgfsPerBlockLruEvictionPolicySelfTest.java |   4 +-
 .../ggfs/GridGgfsAbstractSelfTest.java          |   4 +-
 .../ggfs/GridGgfsAttributesSelfTest.java        |   4 +-
 .../processors/ggfs/GridGgfsCacheSelfTest.java  |   2 +-
 .../ggfs/GridGgfsDataManagerSelfTest.java       |   2 +-
 .../ggfs/GridGgfsDualAbstractSelfTest.java      |   4 +-
 .../ggfs/GridGgfsDualAsyncSelfTest.java         |   2 +-
 .../ggfs/GridGgfsDualSyncSelfTest.java          |   2 +-
 ...GgfsGroupDataBlockKeyMapperHashSelfTest.java |   4 +-
 .../ggfs/GridGgfsMetaManagerSelfTest.java       |   2 +-
 .../ggfs/GridGgfsMetricsSelfTest.java           |   4 +-
 .../ggfs/GridGgfsModeResolverSelfTest.java      |   4 +-
 .../processors/ggfs/GridGgfsModesSelfTest.java  |   4 +-
 .../GridGgfsPrimaryOffheapTieredSelfTest.java   |   2 +-
 .../GridGgfsPrimaryOffheapValuesSelfTest.java   |   2 +-
 .../ggfs/GridGgfsPrimarySelfTest.java           |   2 +-
 .../ggfs/GridGgfsProcessorSelfTest.java         |   2 +-
 .../GridGgfsProcessorValidationSelfTest.java    |   8 +-
 ...IpcEndpointRegistrationAbstractSelfTest.java |   4 +-
 ...dpointRegistrationOnLinuxAndMacSelfTest.java |   2 +-
 .../processors/ggfs/GridGgfsSizeSelfTest.java   |   2 +-
 .../ggfs/GridGgfsStreamsSelfTest.java           |   2 +-
 .../processors/ggfs/GridGgfsTaskSelfTest.java   |   4 +-
 .../GridGgfsAbstractRecordResolverSelfTest.java |   4 +-
 ...GgfsByteDelimiterRecordResolverSelfTest.java |   2 +-
 ...idGgfsFixedLengthRecordResolverSelfTest.java |   2 +-
 ...sNewLineDelimiterRecordResolverSelfTest.java |   2 +-
 ...fsStringDelimiterRecordResolverSelfTest.java |   2 +-
 .../shmem/GridIpcSharedMemoryNodeStartup.java   |   2 +-
 .../ggfs/hadoop/GridGgfsHadoopParameters.java   |   2 +-
 .../hadoop/v1/GridGgfsHadoopFileSystem.java     |   6 +-
 .../hadoop/v2/GridGgfsHadoopFileSystem.java     |   6 +-
 .../grid/kernal/ggfs/hadoop/GridGgfsHadoop.java |   2 +-
 .../ggfs/hadoop/GridGgfsHadoopEndpoint.java     |   2 +-
 .../hadoop/GridGgfsHadoopFileSystemWrapper.java |   4 +-
 .../ggfs/hadoop/GridGgfsHadoopInProc.java       |   2 +-
 .../ggfs/hadoop/GridGgfsHadoopOutProc.java      |   2 +-
 .../ggfs/hadoop/GridGgfsHadoopReader.java       |   2 +-
 .../kernal/ggfs/hadoop/GridGgfsHadoopUtils.java |   2 +-
 .../ggfs/hadoop/GridGgfsHadoopWrapper.java      |   2 +-
 .../fs/GridHadoopDistributedFileSystem.java     |   2 +-
 .../GridHadoopDefaultMapReducePlanner.java      |   2 +-
 .../GridHadoopClientProtocolSelfTest.java       |   2 +-
 .../grid/ggfs/GridGgfsEventsTestSuite.java      |   3 +-
 ...dGgfsHadoop20FileSystemAbstractSelfTest.java |   3 +-
 ...doop20FileSystemLoopbackPrimarySelfTest.java |   2 +-
 ...sHadoop20FileSystemShmemPrimarySelfTest.java |   2 +-
 .../GridGgfsHadoopDualAbstractSelfTest.java     |   3 +-
 .../ggfs/GridGgfsHadoopDualAsyncSelfTest.java   |   2 +-
 .../ggfs/GridGgfsHadoopDualSyncSelfTest.java    |   2 +-
 ...ridGgfsHadoopFileSystemAbstractSelfTest.java |   3 +-
 .../GridGgfsHadoopFileSystemClientSelfTest.java |   1 +
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |   3 +-
 ...ridGgfsHadoopFileSystemIpcCacheSelfTest.java |   1 +
 .../GridGgfsHadoopFileSystemLoggerSelfTest.java |   3 +-
 ...GgfsHadoopFileSystemLoggerStateSelfTest.java |   3 +-
 ...adoopFileSystemLoopbackAbstractSelfTest.java |   2 +
 ...SystemLoopbackEmbeddedDualAsyncSelfTest.java |   2 +-
 ...eSystemLoopbackEmbeddedDualSyncSelfTest.java |   2 +-
 ...leSystemLoopbackEmbeddedPrimarySelfTest.java |   2 +-
 ...SystemLoopbackEmbeddedSecondarySelfTest.java |   2 +-
 ...SystemLoopbackExternalDualAsyncSelfTest.java |   2 +-
 ...eSystemLoopbackExternalDualSyncSelfTest.java |   2 +-
 ...leSystemLoopbackExternalPrimarySelfTest.java |   2 +-
 ...SystemLoopbackExternalSecondarySelfTest.java |   2 +-
 ...fsHadoopFileSystemSecondaryModeSelfTest.java |   3 +-
 ...fsHadoopFileSystemShmemAbstractSelfTest.java |   1 +
 ...ileSystemShmemEmbeddedDualAsyncSelfTest.java |   2 +-
 ...FileSystemShmemEmbeddedDualSyncSelfTest.java |   2 +-
 ...pFileSystemShmemEmbeddedPrimarySelfTest.java |   2 +-
 ...ileSystemShmemEmbeddedSecondarySelfTest.java |   2 +-
 ...ileSystemShmemExternalDualAsyncSelfTest.java |   2 +-
 ...FileSystemShmemExternalDualSyncSelfTest.java |   2 +-
 ...pFileSystemShmemExternalPrimarySelfTest.java |   2 +-
 ...ileSystemShmemExternalSecondarySelfTest.java |   2 +-
 .../ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java |   1 +
 .../hadoop/GridHadoopAbstractSelfTest.java      |   2 +-
 .../hadoop/GridHadoopAbstractWordCountTest.java |   2 +-
 .../hadoop/GridHadoopCommandLineTest.java       |   2 +-
 ...idHadoopDefaultMapReducePlannerSelfTest.java |   2 +-
 .../GridHadoopMapReduceEmbeddedSelfTest.java    |   2 +-
 .../hadoop/GridHadoopMapReduceTest.java         |   2 +-
 .../hadoop/GridHadoopTaskExecutionSelfTest.java |   2 +-
 .../hadoop/GridHadoopTasksAllVersionsTest.java  |   2 +-
 ...GridHadoopExternalTaskExecutionSelfTest.java |   2 +-
 198 files changed, 2612 insertions(+), 2595 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/examples/config/filesystem/example-ggfs.xml
----------------------------------------------------------------------
diff --git a/examples/config/filesystem/example-ggfs.xml b/examples/config/filesystem/example-ggfs.xml
index 1387438..d9b1533 100644
--- a/examples/config/filesystem/example-ggfs.xml
+++ b/examples/config/filesystem/example-ggfs.xml
@@ -62,7 +62,7 @@
 
         <property name="ggfsConfiguration">
             <list>
-                <bean class="org.gridgain.grid.ggfs.IgniteFsConfiguration">
+                <bean class="org.apache.ignite.fs.IgniteFsConfiguration">
                     <property name="name" value="ggfs"/>
                     <property name="metaCacheName" value="ggfs-meta"/>
                     <property name="dataCacheName" value="ggfs-data"/>
@@ -119,7 +119,7 @@
                     <property name="distributionMode" value="PARTITIONED_ONLY"/>
                     <property name="backups" value="0"/>
                     <property name="affinityMapper">
-                        <bean class="org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper">
+                        <bean class="org.apache.ignite.fs.IgniteFsGroupDataBlocksKeyMapper">
                             <!-- Haw many blocks in row will be stored on the same node. -->
                             <constructor-arg value="512"/>
                         </bean>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java
index ecdd947..18d2fbf 100644
--- a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java
+++ b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java
@@ -10,8 +10,8 @@
 package org.gridgain.examples.ggfs;
 
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.jetbrains.annotations.*;
 
 import java.io.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
index 454a54e..ec9c52a 100644
--- a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
+++ b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
@@ -11,8 +11,8 @@ package org.gridgain.examples.ggfs;
 
 import org.apache.ignite.*;
 import org.apache.ignite.compute.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.ggfs.mapreduce.records.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/Ignite.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/Ignite.java b/modules/core/src/main/java/org/apache/ignite/Ignite.java
index 5c387e2..ae706f8 100644
--- a/modules/core/src/main/java/org/apache/ignite/Ignite.java
+++ b/modules/core/src/main/java/org/apache/ignite/Ignite.java
@@ -214,9 +214,9 @@ public interface Ignite extends AutoCloseable {
      * @param <V> Value type.
      * @param name Cache name.
      * @return Cache instance for given name.
-     * @see org.gridgain.grid.ggfs.IgniteFsConfiguration
-     * @see org.gridgain.grid.ggfs.IgniteFsConfiguration#getDataCacheName()
-     * @see org.gridgain.grid.ggfs.IgniteFsConfiguration#getMetaCacheName()
+     * @see org.apache.ignite.fs.IgniteFsConfiguration
+     * @see org.apache.ignite.fs.IgniteFsConfiguration#getDataCacheName()
+     * @see org.apache.ignite.fs.IgniteFsConfiguration#getMetaCacheName()
      */
     public <K, V> GridCache<K, V> cache(@Nullable String name);
 
@@ -224,9 +224,9 @@ public interface Ignite extends AutoCloseable {
      * Gets all configured caches.
      * Caches that are used as GGFS meta and data caches will not be returned in resulting collection.
      *
-     * @see org.gridgain.grid.ggfs.IgniteFsConfiguration
-     * @see org.gridgain.grid.ggfs.IgniteFsConfiguration#getDataCacheName()
-     * @see org.gridgain.grid.ggfs.IgniteFsConfiguration#getMetaCacheName()
+     * @see org.apache.ignite.fs.IgniteFsConfiguration
+     * @see org.apache.ignite.fs.IgniteFsConfiguration#getDataCacheName()
+     * @see org.apache.ignite.fs.IgniteFsConfiguration#getMetaCacheName()
      * @return All configured caches.
      */
     public Collection<GridCache<?, ?>> caches();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
index fd3c88c..323a778 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
@@ -9,9 +9,9 @@
 
 package org.apache.ignite;
 
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.jetbrains.annotations.*;
 
@@ -75,7 +75,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      *
      * @param path Path to get information for.
      * @return Summary object.
-     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path is not found.
+     * @throws org.apache.ignite.fs.IgniteFsFileNotFoundException If path is not found.
      * @throws GridException If failed.
      */
     public IgniteFsPathSummary summary(IgniteFsPath path) throws GridException;
@@ -86,7 +86,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @param path File path to read.
      * @return File input stream to read data from.
      * @throws GridException In case of error.
-     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist.
+     * @throws org.apache.ignite.fs.IgniteFsFileNotFoundException If path doesn't exist.
      */
     public IgniteFsInputStream open(IgniteFsPath path) throws GridException;
 
@@ -97,7 +97,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @param bufSize Read buffer size (bytes) or {@code zero} to use default value.
      * @return File input stream to read data from.
      * @throws GridException In case of error.
-     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist.
+     * @throws org.apache.ignite.fs.IgniteFsFileNotFoundException If path doesn't exist.
      */
     @Override public IgniteFsInputStream open(IgniteFsPath path, int bufSize) throws GridException;
 
@@ -109,7 +109,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @param seqReadsBeforePrefetch Amount of sequential reads before prefetch is started.
      * @return File input stream to read data from.
      * @throws GridException In case of error.
-     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist.
+     * @throws org.apache.ignite.fs.IgniteFsFileNotFoundException If path doesn't exist.
      */
     public IgniteFsInputStream open(IgniteFsPath path, int bufSize, int seqReadsBeforePrefetch) throws GridException;
 
@@ -163,7 +163,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @param create Create file if it doesn't exist yet.
      * @return File output stream to append data to.
      * @throws GridException In case of error.
-     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist and create flag is {@code false}.
+     * @throws org.apache.ignite.fs.IgniteFsFileNotFoundException If path doesn't exist and create flag is {@code false}.
      */
     public IgniteFsOutputStream append(IgniteFsPath path, boolean create) throws GridException;
 
@@ -176,7 +176,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @param props File properties to set only in case it file was just created.
      * @return File output stream to append data to.
      * @throws GridException In case of error.
-     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist and create flag is {@code false}.
+     * @throws org.apache.ignite.fs.IgniteFsFileNotFoundException If path doesn't exist and create flag is {@code false}.
      */
     @Override public IgniteFsOutputStream append(IgniteFsPath path, int bufSize, boolean create,
         @Nullable Map<String, String> props) throws GridException;
@@ -189,7 +189,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @param accessTime Optional last access time to set. Value {@code -1} does not update access time.
      * @param modificationTime Optional last modification time to set. Value {@code -1} does not update
      *      modification time.
-     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If target was not found.
+     * @throws org.apache.ignite.fs.IgniteFsFileNotFoundException If target was not found.
      * @throws GridException If error occurred.
      */
     public void setTimes(IgniteFsPath path, long accessTime, long modificationTime) throws GridException;
@@ -203,7 +203,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @param len Size of data in the file to resolve affinity for.
      * @return Affinity block locations.
      * @throws GridException In case of error.
-     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist.
+     * @throws org.apache.ignite.fs.IgniteFsFileNotFoundException If path doesn't exist.
      */
     public Collection<IgniteFsBlockLocation> affinity(IgniteFsPath path, long start, long len) throws GridException;
 
@@ -218,7 +218,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @param maxLen Maximum length of a single returned block location length.
      * @return Affinity block locations.
      * @throws GridException In case of error.
-     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist.
+     * @throws org.apache.ignite.fs.IgniteFsFileNotFoundException If path doesn't exist.
      */
     public Collection<IgniteFsBlockLocation> affinity(IgniteFsPath path, long start, long len, long maxLen)
         throws GridException;
@@ -274,7 +274,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
 
     /**
      * Executes GGFS task with overridden maximum range length (see
-     * {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()} for more information).
+     * {@link org.apache.ignite.fs.IgniteFsConfiguration#getMaximumTaskRangeLength()} for more information).
      * <p>
      * Supports asynchronous execution (see {@link IgniteAsyncSupport}).
      *
@@ -310,7 +310,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
 
     /**
      * Executes GGFS task with overridden maximum range length (see
-     * {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()} for more information).
+     * {@link org.apache.ignite.fs.IgniteFsConfiguration#getMaximumTaskRangeLength()} for more information).
      * <p>
      * Supports asynchronous execution (see {@link IgniteAsyncSupport}).
      *

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java b/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
index 4bfb26c..d0927ea 100644
--- a/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
@@ -11,6 +11,7 @@ package org.apache.ignite.configuration;
 
 import org.apache.ignite.*;
 import org.apache.ignite.events.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.lifecycle.*;
 import org.apache.ignite.managed.*;
@@ -23,7 +24,6 @@ import org.gridgain.grid.cache.*;
 import org.gridgain.grid.dotnet.*;
 import org.gridgain.grid.dr.hub.receiver.*;
 import org.gridgain.grid.dr.hub.sender.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.hadoop.*;
 import org.gridgain.grid.kernal.managers.eventstorage.*;
 import org.gridgain.grid.security.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/events/IgniteFsEvent.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/events/IgniteFsEvent.java b/modules/core/src/main/java/org/apache/ignite/events/IgniteFsEvent.java
index 21e6a20..c2b641c 100644
--- a/modules/core/src/main/java/org/apache/ignite/events/IgniteFsEvent.java
+++ b/modules/core/src/main/java/org/apache/ignite/events/IgniteFsEvent.java
@@ -10,7 +10,7 @@
 package org.apache.ignite.events;
 
 import org.apache.ignite.cluster.*;
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.util.tostring.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.jetbrains.annotations.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsBlockLocation.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsBlockLocation.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsBlockLocation.java
new file mode 100644
index 0000000..88031a8
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsBlockLocation.java
@@ -0,0 +1,55 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+import java.util.*;
+
+/**
+ * {@code GGFS} file's data block location in the grid. It is used to determine
+ * node affinity of a certain file block within the Grid by calling
+ * {@link org.apache.ignite.IgniteFs#affinity(IgniteFsPath, long, long)} method.
+ */
+public interface IgniteFsBlockLocation {
+    /**
+     * Start position in the file this block relates to.
+     *
+     * @return Start position in the file this block relates to.
+     */
+    public long start();
+
+    /**
+     * Length of the data block in the file.
+     *
+     * @return Length of the data block in the file.
+     */
+    public long length();
+
+    /**
+     * Nodes this block belongs to. First node id in collection is
+     * primary node id.
+     *
+     * @return Nodes this block belongs to.
+     */
+    public Collection<UUID> nodeIds();
+
+    /**
+     * Compliant with Hadoop interface.
+     *
+     * @return Collection of host:port addresses.
+     */
+    public Collection<String> names();
+
+    /**
+     * Compliant with Hadoop interface.
+     *
+     * @return Collection of host names.
+     */
+    public Collection<String> hosts();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsConcurrentModificationException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsConcurrentModificationException.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsConcurrentModificationException.java
new file mode 100644
index 0000000..79c0049
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsConcurrentModificationException.java
@@ -0,0 +1,28 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+/**
+ * {@code GGFS} exception indicating that file system structure was modified concurrently. This error
+ * indicates that an operation performed in DUAL mode cannot proceed due to these changes.
+ */
+public class IgniteFsConcurrentModificationException extends IgniteFsException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Creates new exception.
+     *
+     * @param path Affected path.
+     */
+    public IgniteFsConcurrentModificationException(IgniteFsPath path) {
+        super("File system entry has been modified concurrently: " + path, null);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsConfiguration.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsConfiguration.java
new file mode 100644
index 0000000..13e6746
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsConfiguration.java
@@ -0,0 +1,798 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+import org.gridgain.grid.util.typedef.internal.*;
+import org.jetbrains.annotations.*;
+
+import java.util.*;
+import java.util.concurrent.*;
+
+/**
+ * {@code GGFS} configuration. More than one file system can be configured within grid.
+ * {@code GGFS} configuration is provided via {@link org.apache.ignite.configuration.IgniteConfiguration#getGgfsConfiguration()}
+ * method.
+ * <p>
+ * Refer to {@code config/hadoop/default-config.xml} or {@code config/hadoop/default-config-client.xml}
+ * configuration files under GridGain installation to see sample {@code GGFS} configuration.
+ */
+public class IgniteFsConfiguration {
+    /** Default file system user name. */
+    public static final String DFLT_USER_NAME = System.getProperty("user.name", "anonymous");
+
+    /** Default IPC port. */
+    public static final int DFLT_IPC_PORT = 10500;
+
+    /** Default fragmentizer throttling block length. */
+    public static final long DFLT_FRAGMENTIZER_THROTTLING_BLOCK_LENGTH = 16 * 1024 * 1024;
+
+    /** Default fragmentizer throttling delay. */
+    public static final long DFLT_FRAGMENTIZER_THROTTLING_DELAY = 200;
+
+    /** Default fragmentizer concurrent files. */
+    public static final int DFLT_FRAGMENTIZER_CONCURRENT_FILES = 0;
+
+    /** Default fragmentizer local writes ratio. */
+    public static final float DFLT_FRAGMENTIZER_LOCAL_WRITES_RATIO = 0.8f;
+
+    /** Fragmentizer enabled property. */
+    public static final boolean DFLT_FRAGMENTIZER_ENABLED = true;
+
+    /** Default batch size for logging. */
+    public static final int DFLT_GGFS_LOG_BATCH_SIZE = 100;
+
+    /** Default {@code GGFS} log directory. */
+    public static final String DFLT_GGFS_LOG_DIR = "work/ggfs/log";
+
+    /** Default per node buffer size. */
+    public static final int DFLT_PER_NODE_BATCH_SIZE = 100;
+
+    /** Default number of per node parallel operations. */
+    public static final int DFLT_PER_NODE_PARALLEL_BATCH_CNT = 8;
+
+    /** Default GGFS mode. */
+    public static final IgniteFsMode DFLT_MODE = IgniteFsMode.DUAL_ASYNC;
+
+    /** Default file's data block size (bytes). */
+    public static final int DFLT_BLOCK_SIZE = 1 << 16;
+
+    /** Default read/write buffers size (bytes). */
+    public static final int DFLT_BUF_SIZE = 1 << 16;
+
+    /** Default trash directory purge await timeout in case data cache oversize is detected. */
+    public static final long DFLT_TRASH_PURGE_TIMEOUT = 1000;
+
+    /** Default management port. */
+    public static final int DFLT_MGMT_PORT = 11400;
+
+    /** Default IPC endpoint enabled flag. */
+    public static final boolean DFLT_IPC_ENDPOINT_ENABLED = true;
+
+    /** GGFS instance name. */
+    private String name;
+
+    /** Cache name to store GGFS meta information. */
+    private String metaCacheName;
+
+    /** Cache name to store file's data blocks. */
+    private String dataCacheName;
+
+    /** File's data block size (bytes). */
+    private int blockSize = DFLT_BLOCK_SIZE;
+
+    /** The number of pre-fetched blocks if specific file's chunk is requested. */
+    private int prefetchBlocks;
+
+    /** Amount of sequential block reads before prefetch is triggered. */
+    private int seqReadsBeforePrefetch;
+
+    /** Read/write buffers size for stream operations (bytes). */
+    private int bufSize = DFLT_BUF_SIZE;
+
+    /** Per node buffer size. */
+    private int perNodeBatchSize = DFLT_PER_NODE_BATCH_SIZE;
+
+    /** Per node parallel operations. */
+    private int perNodeParallelBatchCnt = DFLT_PER_NODE_PARALLEL_BATCH_CNT;
+
+    /** IPC endpoint properties to publish GGFS over. */
+    private Map<String, String> ipcEndpointCfg;
+
+    /** IPC endpoint enabled flag. */
+    private boolean ipcEndpointEnabled = DFLT_IPC_ENDPOINT_ENABLED;
+
+    /** Management port. */
+    private int mgmtPort = DFLT_MGMT_PORT;
+
+    /** Secondary file system */
+    private IgniteFsFileSystem secondaryFs;
+
+    /** GGFS mode. */
+    private IgniteFsMode dfltMode = DFLT_MODE;
+
+    /** Fragmentizer throttling block length. */
+    private long fragmentizerThrottlingBlockLen = DFLT_FRAGMENTIZER_THROTTLING_BLOCK_LENGTH;
+
+    /** Fragmentizer throttling delay. */
+    private long fragmentizerThrottlingDelay = DFLT_FRAGMENTIZER_THROTTLING_DELAY;
+
+    /** Fragmentizer concurrent files. */
+    private int fragmentizerConcurrentFiles = DFLT_FRAGMENTIZER_CONCURRENT_FILES;
+
+    /** Fragmentizer local writes ratio. */
+    private float fragmentizerLocWritesRatio = DFLT_FRAGMENTIZER_LOCAL_WRITES_RATIO;
+
+    /** Fragmentizer enabled flag. */
+    private boolean fragmentizerEnabled = DFLT_FRAGMENTIZER_ENABLED;
+
+    /** Path modes. */
+    private Map<String, IgniteFsMode> pathModes;
+
+    /** Maximum space. */
+    private long maxSpace;
+
+    /** Trash purge await timeout. */
+    private long trashPurgeTimeout = DFLT_TRASH_PURGE_TIMEOUT;
+
+    /** Dual mode PUT operations executor service. */
+    private ExecutorService dualModePutExec;
+
+    /** Dual mode PUT operations executor service shutdown flag. */
+    private boolean dualModePutExecShutdown;
+
+    /** Maximum amount of data in pending puts. */
+    private long dualModeMaxPendingPutsSize;
+
+    /** Maximum range length. */
+    private long maxTaskRangeLen;
+
+    /**
+     * Constructs default configuration.
+     */
+    public IgniteFsConfiguration() {
+        // No-op.
+    }
+
+    /**
+     * Constructs the copy of the configuration.
+     *
+     * @param cfg Configuration to copy.
+     */
+    public IgniteFsConfiguration(IgniteFsConfiguration cfg) {
+        assert cfg != null;
+
+        /*
+         * Must preserve alphabetical order!
+         */
+        blockSize = cfg.getBlockSize();
+        bufSize = cfg.getStreamBufferSize();
+        dataCacheName = cfg.getDataCacheName();
+        dfltMode = cfg.getDefaultMode();
+        dualModeMaxPendingPutsSize = cfg.getDualModeMaxPendingPutsSize();
+        dualModePutExec = cfg.getDualModePutExecutorService();
+        dualModePutExecShutdown = cfg.getDualModePutExecutorServiceShutdown();
+        fragmentizerConcurrentFiles = cfg.getFragmentizerConcurrentFiles();
+        fragmentizerLocWritesRatio = cfg.getFragmentizerLocalWritesRatio();
+        fragmentizerEnabled = cfg.isFragmentizerEnabled();
+        fragmentizerThrottlingBlockLen = cfg.getFragmentizerThrottlingBlockLength();
+        fragmentizerThrottlingDelay = cfg.getFragmentizerThrottlingDelay();
+        secondaryFs = cfg.getSecondaryFileSystem();
+        ipcEndpointCfg = cfg.getIpcEndpointConfiguration();
+        ipcEndpointEnabled = cfg.isIpcEndpointEnabled();
+        maxSpace = cfg.getMaxSpaceSize();
+        maxTaskRangeLen = cfg.getMaximumTaskRangeLength();
+        metaCacheName = cfg.getMetaCacheName();
+        mgmtPort = cfg.getManagementPort();
+        name = cfg.getName();
+        pathModes = cfg.getPathModes();
+        perNodeBatchSize = cfg.getPerNodeBatchSize();
+        perNodeParallelBatchCnt = cfg.getPerNodeParallelBatchCount();
+        prefetchBlocks = cfg.getPrefetchBlocks();
+        seqReadsBeforePrefetch = cfg.getSequentialReadsBeforePrefetch();
+        trashPurgeTimeout = cfg.getTrashPurgeTimeout();
+    }
+
+    /**
+     * Gets GGFS instance name. If {@code null}, then instance with default
+     * name will be used.
+     *
+     * @return GGFS instance name.
+     */
+    @Nullable public String getName() {
+        return name;
+    }
+
+    /**
+     * Sets GGFS instance name.
+     *
+     * @param name GGFS instance name.
+     */
+    public void setName(String name) {
+        this.name = name;
+    }
+
+    /**
+     * Cache name to store GGFS meta information. If {@code null}, then instance
+     * with default meta-cache name will be used.
+     *
+     * @return Cache name to store GGFS meta information.
+     */
+    @Nullable public String getMetaCacheName() {
+        return metaCacheName;
+    }
+
+    /**
+     * Sets cache name to store GGFS meta information.
+     *
+     * @param metaCacheName Cache name to store GGFS meta information.
+     */
+    public void setMetaCacheName(String metaCacheName) {
+        this.metaCacheName = metaCacheName;
+    }
+
+    /**
+     * Cache name to store GGFS data.
+     *
+     * @return Cache name to store GGFS data.
+     */
+    @Nullable public String getDataCacheName() {
+        return dataCacheName;
+    }
+
+    /**
+     * Sets cache name to store GGFS data.
+     *
+     * @param dataCacheName Cache name to store GGFS data.
+     */
+    public void setDataCacheName(String dataCacheName) {
+        this.dataCacheName = dataCacheName;
+    }
+
+    /**
+     * Get file's data block size.
+     *
+     * @return File's data block size.
+     */
+    public int getBlockSize() {
+        return blockSize;
+    }
+
+    /**
+     * Sets file's data block size.
+     *
+     * @param blockSize File's data block size (bytes) or {@code 0} to reset default value.
+     */
+    public void setBlockSize(int blockSize) {
+        A.ensure(blockSize >= 0, "blockSize >= 0");
+
+        this.blockSize = blockSize == 0 ? DFLT_BLOCK_SIZE : blockSize;
+    }
+
+    /**
+     * Get number of pre-fetched blocks if specific file's chunk is requested.
+     *
+     * @return The number of pre-fetched blocks.
+     */
+    public int getPrefetchBlocks() {
+        return prefetchBlocks;
+    }
+
+    /**
+     * Sets the number of pre-fetched blocks if specific file's chunk is requested.
+     *
+     * @param prefetchBlocks New number of pre-fetched blocks.
+     */
+    public void setPrefetchBlocks(int prefetchBlocks) {
+        A.ensure(prefetchBlocks >= 0, "prefetchBlocks >= 0");
+
+        this.prefetchBlocks = prefetchBlocks;
+    }
+
+    /**
+     * Get amount of sequential block reads before prefetch is triggered. The
+     * higher this value, the longer GGFS will wait before starting to prefetch
+     * values ahead of time. Depending on the use case, this can either help
+     * or hurt performance.
+     * <p>
+     * Default is {@code 0} which means that pre-fetching will start right away.
+     * <h1 class="header">Integration With Hadoop</h1>
+     * This parameter can be also overridden for individual Hadoop MapReduce tasks by passing
+     * {@code org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.PARAM_GGFS_SEQ_READS_BEFORE_PREFETCH}
+     * configuration property directly to Hadoop MapReduce task.
+     * <p>
+     * <b>NOTE:</b> Integration with Hadoop is available only in {@code In-Memory Accelerator For Hadoop} edition.
+     *
+     * @return Amount of sequential block reads.
+     */
+    public int getSequentialReadsBeforePrefetch() {
+        return seqReadsBeforePrefetch;
+    }
+
+    /**
+     * Sets amount of sequential block reads before prefetch is triggered. The
+     * higher this value, the longer GGFS will wait before starting to prefetch
+     * values ahead of time. Depending on the use case, this can either help
+     * or hurt performance.
+     * <p>
+     * Default is {@code 0} which means that pre-fetching will start right away.
+     * <h1 class="header">Integration With Hadoop</h1>
+     * This parameter can be also overridden for individual Hadoop MapReduce tasks by passing
+     * {@code org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.PARAM_GGFS_SEQ_READS_BEFORE_PREFETCH}
+     * configuration property directly to Hadoop MapReduce task.
+     * <p>
+     * <b>NOTE:</b> Integration with Hadoop is available only in {@code In-Memory Accelerator For Hadoop} edition.
+     *
+     * @param seqReadsBeforePrefetch Amount of sequential block reads before prefetch is triggered.
+     */
+    public void setSequentialReadsBeforePrefetch(int seqReadsBeforePrefetch) {
+        A.ensure(seqReadsBeforePrefetch >= 0, "seqReadsBeforePrefetch >= 0");
+
+        this.seqReadsBeforePrefetch = seqReadsBeforePrefetch;
+    }
+
+    /**
+     * Get read/write buffer size for {@code GGFS} stream operations in bytes.
+     *
+     * @return Read/write buffers size (bytes).
+     */
+    public int getStreamBufferSize() {
+        return bufSize;
+    }
+
+    /**
+     * Sets read/write buffers size for {@code GGFS} stream operations (bytes).
+     *
+     * @param bufSize Read/write buffers size for stream operations (bytes) or {@code 0} to reset default value.
+     */
+    public void setStreamBufferSize(int bufSize) {
+        A.ensure(bufSize >= 0, "bufSize >= 0");
+
+        this.bufSize = bufSize == 0 ? DFLT_BUF_SIZE : bufSize;
+    }
+
+    /**
+     * Gets number of file blocks buffered on local node before sending batch to remote node.
+     *
+     * @return Per node buffer size.
+     */
+    public int getPerNodeBatchSize() {
+        return perNodeBatchSize;
+    }
+
+    /**
+     * Sets number of file blocks collected on local node before sending batch to remote node.
+     *
+     * @param perNodeBatchSize Per node buffer size.
+     */
+    public void setPerNodeBatchSize(int perNodeBatchSize) {
+        this.perNodeBatchSize = perNodeBatchSize;
+    }
+
+    /**
+     * Gets number of batches that can be concurrently sent to remote node.
+     *
+     * @return Number of batches for each node.
+     */
+    public int getPerNodeParallelBatchCount() {
+        return perNodeParallelBatchCnt;
+    }
+
+    /**
+     * Sets number of file block batches that can be concurrently sent to remote node.
+     *
+     * @param perNodeParallelBatchCnt Per node parallel load operations.
+     */
+    public void setPerNodeParallelBatchCount(int perNodeParallelBatchCnt) {
+        this.perNodeParallelBatchCnt = perNodeParallelBatchCnt;
+    }
+
+    /**
+     * Gets map of IPC endpoint configuration properties. There are 2 different
+     * types of endpoint supported: {@code shared-memory}, and {@code TCP}.
+     * <p>
+     * The following configuration properties are supported for {@code shared-memory}
+     * endpoint:
+     * <ul>
+     *     <li>{@code type} - value is {@code shmem} to specify {@code shared-memory} approach.</li>
+     *     <li>{@code port} - endpoint port.</li>
+     *     <li>{@code size} - memory size allocated for single endpoint communication.</li>
+     *     <li>
+     *         {@code tokenDirectoryPath} - path, either absolute or relative to {@code GRIDGAIN_HOME} to
+     *         store shared memory tokens.
+     *     </li>
+     * </ul>
+     * <p>
+     * The following configuration properties are supported for {@code TCP} approach:
+     * <ul>
+     *     <li>{@code type} - value is {@code tcp} to specify {@code TCP} approach.</li>
+     *     <li>{@code port} - endpoint bind port.</li>
+     *     <li>
+     *         {@code host} - endpoint bind host. If omitted '127.0.0.1' will be used.
+     *     </li>
+     * </ul>
+     * <p>
+     * Note that {@code shared-memory} approach is not supported on Windows environments.
+     * In case GGFS is failed to bind to particular port, further attempts will be performed every 3 seconds.
+     *
+     * @return Map of IPC endpoint configuration properties. In case the value is not set, defaults will be used. Default
+     * type for Windows is "tcp", for all other platforms - "shmem". Default port is {@link #DFLT_IPC_PORT}.
+     */
+    @Nullable public Map<String,String> getIpcEndpointConfiguration() {
+        return ipcEndpointCfg;
+    }
+
+    /**
+     * Sets IPC endpoint configuration to publish GGFS over.
+     *
+     * @param ipcEndpointCfg Map of IPC endpoint config properties.
+     */
+    public void setIpcEndpointConfiguration(@Nullable Map<String,String> ipcEndpointCfg) {
+        this.ipcEndpointCfg = ipcEndpointCfg;
+    }
+
+    /**
+     * Get IPC endpoint enabled flag. In case it is set to {@code true} endpoint will be created and bound to specific
+     * port. Otherwise endpoint will not be created. Default value is {@link #DFLT_IPC_ENDPOINT_ENABLED}.
+     *
+     * @return {@code True} in case endpoint is enabled.
+     */
+    public boolean isIpcEndpointEnabled() {
+        return ipcEndpointEnabled;
+    }
+
+    /**
+     * Set IPC endpoint enabled flag. See {@link #isIpcEndpointEnabled()}.
+     *
+     * @param ipcEndpointEnabled IPC endpoint enabled flag.
+     */
+    public void setIpcEndpointEnabled(boolean ipcEndpointEnabled) {
+        this.ipcEndpointEnabled = ipcEndpointEnabled;
+    }
+
+    /**
+     * Gets port number for management endpoint. All GGFS nodes should have this port open
+     * for Visor Management Console to work with GGFS.
+     * <p>
+     * Default value is {@link #DFLT_MGMT_PORT}
+     *
+     * @return Port number or {@code -1} if management endpoint should be disabled.
+     */
+    public int getManagementPort() {
+        return mgmtPort;
+    }
+
+    /**
+     * Sets management endpoint port.
+     *
+     * @param mgmtPort port number or {@code -1} to disable management endpoint.
+     */
+    public void setManagementPort(int mgmtPort) {
+        this.mgmtPort = mgmtPort;
+    }
+
+    /**
+     * Gets mode to specify how {@code GGFS} interacts with Hadoop file system, like {@code HDFS}.
+     * Secondary Hadoop file system is provided for pass-through, write-through, and read-through
+     * purposes.
+     * <p>
+     * Default mode is {@link IgniteFsMode#DUAL_ASYNC}. If secondary Hadoop file system is
+     * not configured, this mode will work just like {@link IgniteFsMode#PRIMARY} mode.
+     *
+     * @return Mode to specify how GGFS interacts with secondary HDFS file system.
+     */
+    public IgniteFsMode getDefaultMode() {
+        return dfltMode;
+    }
+
+    /**
+     * Sets {@code GGFS} mode to specify how it should interact with secondary
+     * Hadoop file system, like {@code HDFS}. Secondary Hadoop file system is provided
+     * for pass-through, write-through, and read-through purposes.
+     *
+     * @param dfltMode {@code GGFS} mode.
+     */
+    public void setDefaultMode(IgniteFsMode dfltMode) {
+        this.dfltMode = dfltMode;
+    }
+
+    /**
+     * Gets the secondary file system. Secondary file system is provided for pass-through, write-through,
+     * and read-through purposes.
+     *
+     * @return Secondary file system.
+     */
+    public IgniteFsFileSystem getSecondaryFileSystem() {
+        return secondaryFs;
+    }
+
+    /**
+     * Sets the secondary file system. Secondary file system is provided for pass-through, write-through,
+     * and read-through purposes.
+     *
+     * @param fileSystem
+     */
+    public void setSecondaryFileSystem(IgniteFsFileSystem fileSystem) {
+        secondaryFs = fileSystem;
+    }
+
+    /**
+     * Gets map of path prefixes to {@code GGFS} modes used for them.
+     * <p>
+     * If path doesn't correspond to any specified prefix or mappings are not provided, then
+     * {@link #getDefaultMode()} is used.
+     * <p>
+     * Several folders under {@code '/gridgain'} folder have predefined mappings which cannot be overridden.
+     * <li>{@code /gridgain/primary} and all it's sub-folders will always work in {@code PRIMARY} mode.</li>
+     * <p>
+     * And in case secondary file system URI is provided:
+     * <li>{@code /gridgain/proxy} and all it's sub-folders will always work in {@code PROXY} mode.</li>
+     * <li>{@code /gridgain/sync} and all it's sub-folders will always work in {@code DUAL_SYNC} mode.</li>
+     * <li>{@code /gridgain/async} and all it's sub-folders will always work in {@code DUAL_ASYNC} mode.</li>
+     *
+     * @return Map of paths to {@code GGFS} modes.
+     */
+    @Nullable public Map<String, IgniteFsMode> getPathModes() {
+        return pathModes;
+    }
+
+    /**
+     * Sets map of path prefixes to {@code GGFS} modes used for them.
+     * <p>
+     * If path doesn't correspond to any specified prefix or mappings are not provided, then
+     * {@link #getDefaultMode()} is used.
+     *
+     * @param pathModes Map of paths to {@code GGFS} modes.
+     */
+    public void setPathModes(Map<String, IgniteFsMode> pathModes) {
+        this.pathModes = pathModes;
+    }
+
+    /**
+     * Gets the length of file chunk to send before delaying the fragmentizer.
+     *
+     * @return File chunk length in bytes.
+     */
+    public long getFragmentizerThrottlingBlockLength() {
+        return fragmentizerThrottlingBlockLen;
+    }
+
+    /**
+     * Sets length of file chunk to transmit before throttling is delayed.
+     *
+     * @param fragmentizerThrottlingBlockLen Block length in bytes.
+     */
+    public void setFragmentizerThrottlingBlockLength(long fragmentizerThrottlingBlockLen) {
+        this.fragmentizerThrottlingBlockLen = fragmentizerThrottlingBlockLen;
+    }
+
+    /**
+     * Gets throttle delay for fragmentizer.
+     *
+     * @return Throttle delay in milliseconds.
+     */
+    public long getFragmentizerThrottlingDelay() {
+        return fragmentizerThrottlingDelay;
+    }
+
+    /**
+     * Sets delay in milliseconds for which fragmentizer is paused.
+     *
+     * @param fragmentizerThrottlingDelay Delay in milliseconds.
+     */
+    public void setFragmentizerThrottlingDelay(long fragmentizerThrottlingDelay) {
+        this.fragmentizerThrottlingDelay = fragmentizerThrottlingDelay;
+    }
+
+    /**
+     * Gets number of files that can be processed by fragmentizer concurrently.
+     *
+     * @return Number of files to process concurrently.
+     */
+    public int getFragmentizerConcurrentFiles() {
+        return fragmentizerConcurrentFiles;
+    }
+
+    /**
+     * Sets number of files to process concurrently by fragmentizer.
+     *
+     * @param fragmentizerConcurrentFiles Number of files to process concurrently.
+     */
+    public void setFragmentizerConcurrentFiles(int fragmentizerConcurrentFiles) {
+        this.fragmentizerConcurrentFiles = fragmentizerConcurrentFiles;
+    }
+
+    /**
+     * Gets amount of local memory (in % of local GGFS max space size) available for local writes
+     * during file creation.
+     * <p>
+     * If current GGFS space size is less than {@code fragmentizerLocalWritesRatio * maxSpaceSize},
+     * then file blocks will be written to the local node first and then asynchronously distributed
+     * among cluster nodes (fragmentized).
+     * <p>
+     * Default value is {@link #DFLT_FRAGMENTIZER_LOCAL_WRITES_RATIO}.
+     *
+     * @return Ratio for local writes space.
+     */
+    public float getFragmentizerLocalWritesRatio() {
+        return fragmentizerLocWritesRatio;
+    }
+
+    /**
+     * Sets ratio for space available for local file writes.
+     *
+     * @param fragmentizerLocWritesRatio Ratio for local file writes.
+     * @see #getFragmentizerLocalWritesRatio()
+     */
+    public void setFragmentizerLocalWritesRatio(float fragmentizerLocWritesRatio) {
+        this.fragmentizerLocWritesRatio = fragmentizerLocWritesRatio;
+    }
+
+    /**
+     * Gets flag indicating whether GGFS fragmentizer is enabled. If fragmentizer is disabled, files will be
+     * written in distributed fashion.
+     *
+     * @return Flag indicating whether fragmentizer is enabled.
+     */
+    public boolean isFragmentizerEnabled() {
+        return fragmentizerEnabled;
+    }
+
+    /**
+     * Sets property indicating whether fragmentizer is enabled.
+     *
+     * @param fragmentizerEnabled {@code True} if fragmentizer is enabled.
+     */
+    public void setFragmentizerEnabled(boolean fragmentizerEnabled) {
+        this.fragmentizerEnabled = fragmentizerEnabled;
+    }
+
+    /**
+     * Get maximum space available for data cache to store file system entries.
+     *
+     * @return Maximum space available for data cache.
+     */
+    public long getMaxSpaceSize() {
+        return maxSpace;
+    }
+
+    /**
+     * Set maximum space in bytes available in data cache.
+     *
+     * @param maxSpace Maximum space available in data cache.
+     */
+    public void setMaxSpaceSize(long maxSpace) {
+        this.maxSpace = maxSpace;
+    }
+
+    /**
+     * Gets maximum timeout awaiting for trash purging in case data cache oversize is detected.
+     *
+     * @return Maximum timeout awaiting for trash purging in case data cache oversize is detected.
+     */
+    public long getTrashPurgeTimeout() {
+        return trashPurgeTimeout;
+    }
+
+    /**
+     * Sets maximum timeout awaiting for trash purging in case data cache oversize is detected.
+     *
+     * @param trashPurgeTimeout Maximum timeout awaiting for trash purging in case data cache oversize is detected.
+     */
+    public void setTrashPurgeTimeout(long trashPurgeTimeout) {
+        this.trashPurgeTimeout = trashPurgeTimeout;
+    }
+
+    /**
+     * Get DUAL mode put operation executor service. This executor service will process cache PUT requests for
+     * data which came from the secondary file system and about to be written to GGFS data cache.
+     * In case no executor service is provided, default one will be created with maximum amount of threads equals
+     * to amount of processor cores.
+     *
+     * @return Get DUAL mode put operation executor service
+     */
+    @Nullable public ExecutorService getDualModePutExecutorService() {
+        return dualModePutExec;
+    }
+
+    /**
+     * Set DUAL mode put operations executor service.
+     *
+     * @param dualModePutExec Dual mode put operations executor service.
+     */
+    public void setDualModePutExecutorService(ExecutorService dualModePutExec) {
+        this.dualModePutExec = dualModePutExec;
+    }
+
+    /**
+     * Get DUAL mode put operation executor service shutdown flag.
+     *
+     * @return DUAL mode put operation executor service shutdown flag.
+     */
+    public boolean getDualModePutExecutorServiceShutdown() {
+        return dualModePutExecShutdown;
+    }
+
+    /**
+     * Set DUAL mode put operations executor service shutdown flag.
+     *
+     * @param dualModePutExecShutdown Dual mode put operations executor service shutdown flag.
+     */
+    public void setDualModePutExecutorServiceShutdown(boolean dualModePutExecShutdown) {
+        this.dualModePutExecShutdown = dualModePutExecShutdown;
+    }
+
+    /**
+     * Get maximum amount of pending data read from the secondary file system and waiting to be written to data
+     * cache. {@code 0} or negative value stands for unlimited size.
+     * <p>
+     * By default this value is set to {@code 0}. It is recommended to set positive value in case your
+     * application performs frequent reads of large amount of data from the secondary file system in order to
+     * avoid issues with increasing GC pauses or out-of-memory error.
+     *
+     * @return Maximum amount of pending data read from the secondary file system
+     */
+    public long getDualModeMaxPendingPutsSize() {
+        return dualModeMaxPendingPutsSize;
+    }
+
+    /**
+     * Set maximum amount of data in pending put operations.
+     *
+     * @param dualModeMaxPendingPutsSize Maximum amount of data in pending put operations.
+     */
+    public void setDualModeMaxPendingPutsSize(long dualModeMaxPendingPutsSize) {
+        this.dualModeMaxPendingPutsSize = dualModeMaxPendingPutsSize;
+    }
+
+    /**
+     * Get maximum default range size of a file being split during GGFS task execution. When GGFS task is about to
+     * be executed, it requests file block locations first. Each location is defined as {@link org.gridgain.grid.ggfs.mapreduce.IgniteFsFileRange} which
+     * has length. In case this parameter is set to positive value, then GGFS will split single file range into smaller
+     * ranges with length not greater that this parameter. The only exception to this case is when maximum task range
+     * length is smaller than file block size. In this case maximum task range size will be overridden and set to file
+     * block size.
+     * <p>
+     * Note that this parameter is applied when task is split into jobs before {@link org.gridgain.grid.ggfs.mapreduce.IgniteFsRecordResolver} is
+     * applied. Therefore, final file ranges being assigned to particular jobs could be greater than value of this
+     * parameter depending on file data layout and selected resolver type.
+     * <p>
+     * Setting this parameter might be useful when file is highly colocated and have very long consequent data chunks
+     * so that task execution suffers from insufficient parallelism. E.g., in case you have one GGFS node in topology
+     * and want to process 1Gb file, then only single range of length 1Gb will be returned. This will result in
+     * a single job which will be processed in one thread. But in case you provide this configuration parameter and set
+     * maximum range length to 16Mb, then 64 ranges will be returned resulting in 64 jobs which could be executed in
+     * parallel.
+     * <p>
+     * Note that some {@code GridGgfs.execute()} methods can override value of this parameter.
+     * <p>
+     * In case value of this parameter is set to {@code 0} or negative value, it is simply ignored. Default value is
+     * {@code 0}.
+     *
+     * @return Maximum range size of a file being split during GGFS task execution.
+     */
+    public long getMaximumTaskRangeLength() {
+        return maxTaskRangeLen;
+    }
+
+    /**
+     * Set maximum default range size of a file being split during GGFS task execution.
+     * See {@link #getMaximumTaskRangeLength()} for more details.
+     *
+     * @param maxTaskRangeLen Set maximum default range size of a file being split during GGFS task execution.
+     */
+    public void setMaximumTaskRangeLength(long maxTaskRangeLen) {
+        this.maxTaskRangeLen = maxTaskRangeLen;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsConfiguration.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsCorruptedFileException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsCorruptedFileException.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsCorruptedFileException.java
new file mode 100644
index 0000000..28932ff
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsCorruptedFileException.java
@@ -0,0 +1,42 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+import org.jetbrains.annotations.*;
+
+/**
+ * Exception thrown when target file's block is not found in data cache.
+ */
+public class IgniteFsCorruptedFileException extends IgniteFsException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * @param msg Error message.
+     */
+    public IgniteFsCorruptedFileException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * @param cause Error cause.
+     */
+    public IgniteFsCorruptedFileException(Throwable cause) {
+        super(cause);
+    }
+
+    /**
+     * @param msg Error message.
+     * @param cause Error cause.
+     */
+    public IgniteFsCorruptedFileException(String msg, @Nullable Throwable cause) {
+        super(msg, cause);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsException.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsException.java
new file mode 100644
index 0000000..d791197
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsException.java
@@ -0,0 +1,49 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+import org.gridgain.grid.*;
+import org.jetbrains.annotations.*;
+
+/**
+ * {@code GGFS} exception thrown by file system components.
+ */
+public class IgniteFsException extends GridException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Creates an instance of GGFS exception with descriptive error message.
+     *
+     * @param msg Error message.
+     */
+    public IgniteFsException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * Creates an instance of GGFS exception caused by nested exception.
+     *
+     * @param cause Exception cause.
+     */
+    public IgniteFsException(Throwable cause) {
+        super(cause);
+    }
+
+    /**
+     * Creates an instance of GGFS exception with error message and underlying cause.
+     *
+     * @param msg Error message.
+     * @param cause Exception cause.
+     */
+    public IgniteFsException(String msg, @Nullable Throwable cause) {
+        super(msg, cause);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsFile.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsFile.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsFile.java
new file mode 100644
index 0000000..d6bd513
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsFile.java
@@ -0,0 +1,112 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+import org.jetbrains.annotations.*;
+
+import java.util.*;
+
+/**
+ * {@code GGFS} file or directory descriptor. For example, to get information about
+ * a file you would use the following code:
+ * <pre name="code" class="java">
+ *     GridGgfsPath filePath = new GridGgfsPath("my/working/dir", "file.txt");
+ *
+ *     // Get metadata about file.
+ *     GridGgfsFile file = ggfs.info(filePath);
+ * </pre>
+ */
+public interface IgniteFsFile {
+    /**
+     * Gets path to file.
+     *
+     * @return Path to file.
+     */
+    public IgniteFsPath path();
+
+    /**
+     * Check this file is a data file.
+     *
+     * @return {@code True} if this is a data file.
+     */
+    public boolean isFile();
+
+    /**
+     * Check this file is a directory.
+     *
+     * @return {@code True} if this is a directory.
+     */
+    public boolean isDirectory();
+
+    /**
+     * Gets file's length.
+     *
+     * @return File's length or {@code zero} for directories.
+     */
+    public long length();
+
+    /**
+     * Gets file's data block size.
+     *
+     * @return File's data block size or {@code zero} for directories.
+     */
+    public int blockSize();
+
+    /**
+     * Gets file group block size (i.e. block size * group size).
+     *
+     * @return File group block size.
+     */
+    public long groupBlockSize();
+
+    /**
+     * Gets file last access time. File last access time is not updated automatically due to
+     * performance considerations and can be updated on demand with
+     * {@link org.apache.ignite.IgniteFs#setTimes(IgniteFsPath, long, long)} method.
+     * <p>
+     * By default last access time equals file creation time.
+     *
+     * @return Last access time.
+     */
+    public long accessTime();
+
+    /**
+     * Gets file last modification time. File modification time is updated automatically on each file write and
+     * append.
+     *
+     * @return Last modification time.
+     */
+    public long modificationTime();
+
+    /**
+     * Get file's property for specified name.
+     *
+     * @param name Name of the property.
+     * @return File's property for specified name.
+     * @throws IllegalArgumentException If requested property was not found.
+     */
+    public String property(String name) throws IllegalArgumentException;
+
+    /**
+     * Get file's property for specified name.
+     *
+     * @param name Name of the property.
+     * @param dfltVal Default value if requested property was not found.
+     * @return File's property for specified name.
+     */
+    @Nullable public String property(String name, @Nullable String dfltVal);
+
+    /**
+     * Get properties of the file.
+     *
+     * @return Properties of the file.
+     */
+    public Map<String, String> properties();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsFileNotFoundException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsFileNotFoundException.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsFileNotFoundException.java
new file mode 100644
index 0000000..0dc1bdc
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsFileNotFoundException.java
@@ -0,0 +1,36 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+/**
+ * {@code GGFS} exception indicating that target resource is not found.
+ */
+public class IgniteFsFileNotFoundException extends IgniteFsInvalidPathException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Creates exception with error message specified.
+     *
+     * @param msg Error message.
+     */
+    public IgniteFsFileNotFoundException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * Creates exception with given exception cause.
+     *
+     * @param cause Exception cause.
+     */
+    public IgniteFsFileNotFoundException(Throwable cause) {
+        super(cause);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsFileSystem.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsFileSystem.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsFileSystem.java
new file mode 100644
index 0000000..4cd30ac
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsFileSystem.java
@@ -0,0 +1,208 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+import org.gridgain.grid.*;
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+import java.util.*;
+
+/**
+ * Common file system interface. It provides a typical generalized "view" of any file system:
+ * <ul>
+ *     <li>list directories or get information for a single path</li>
+ *     <li>create/move/delete files or directories</li>
+ *     <li>write/read data streams into/from files</li>
+ * </ul>
+ *
+ * This is the minimum of functionality that is needed to work as secondary file system in dual modes of GGFS.
+ */
+public interface IgniteFsFileSystem {
+    /** File property: user name. */
+    public static final String PROP_USER_NAME = "usrName";
+
+    /** File property: group name. */
+    public static final String PROP_GROUP_NAME = "grpName";
+
+    /** File property: permission. */
+    public static final String PROP_PERMISSION = "permission";
+
+    /**
+     * Checks if the specified path exists in the file system.
+     *
+     * @param path Path to check for existence in the file system.
+     * @return {@code True} if such file exists, otherwise - {@code false}.
+     * @throws GridException In case of error.
+     */
+    public boolean exists(IgniteFsPath path) throws GridException;
+
+    /**
+     * Updates file information for the specified path. Existent properties, not listed in the passed collection,
+     * will not be affected. Other properties will be added or overwritten. Passed properties with {@code null} values
+     * will be removed from the stored properties or ignored if they don't exist in the file info.
+     * <p>
+     * When working in {@code DUAL_SYNC} or {@code DUAL_ASYNC} modes only the following properties will be propagated
+     * to the secondary file system:
+     * <ul>
+     * <li>{@code usrName} - file owner name;</li>
+     * <li>{@code grpName} - file owner group;</li>
+     * <li>{@code permission} - Unix-style string representing file permissions.</li>
+     * </ul>
+     *
+     * @param path File path to set properties for.
+     * @param props Properties to update.
+     * @return File information for specified path or {@code null} if such path does not exist.
+     * @throws GridException In case of error.
+     */
+    @Nullable public IgniteFsFile update(IgniteFsPath path, Map<String, String> props) throws GridException;
+
+    /**
+     * Renames/moves a file.
+     * <p>
+     * You are free to rename/move data files as you wish, but directories can be only renamed.
+     * You cannot move the directory between different parent directories.
+     * <p>
+     * Examples:
+     * <ul>
+     *     <li>"/work/file.txt" => "/home/project/Presentation Scenario.txt"</li>
+     *     <li>"/work" => "/work-2012.bkp"</li>
+     *     <li>"/work" => "<strike>/backups/work</strike>" - such operation is restricted for directories.</li>
+     * </ul>
+     *
+     * @param src Source file path to rename.
+     * @param dest Destination file path. If destination path is a directory, then source file will be placed
+     *     into destination directory with original name.
+     * @throws GridException In case of error.
+     * @throws IgniteFsFileNotFoundException If source file doesn't exist.
+     */
+    public void rename(IgniteFsPath src, IgniteFsPath dest) throws GridException;
+
+    /**
+     * Deletes file.
+     *
+     * @param path File path to delete.
+     * @param recursive Delete non-empty directories recursively.
+     * @return {@code True} in case of success, {@code false} otherwise.
+     * @throws GridException In case of error.
+     */
+    boolean delete(IgniteFsPath path, boolean recursive) throws GridException;
+
+    /**
+     * Creates directories under specified path.
+     *
+     * @param path Path of directories chain to create.
+     * @throws GridException In case of error.
+     */
+    public void mkdirs(IgniteFsPath path) throws GridException;
+
+    /**
+     * Creates directories under specified path with the specified properties.
+     *
+     * @param path Path of directories chain to create.
+     * @param props Metadata properties to set on created directories.
+     * @throws GridException In case of error.
+     */
+    public void mkdirs(IgniteFsPath path, @Nullable Map<String, String> props) throws GridException;
+
+    /**
+     * Lists file paths under the specified path.
+     *
+     * @param path Path to list files under.
+     * @return List of files under the specified path.
+     * @throws GridException In case of error.
+     * @throws IgniteFsFileNotFoundException If path doesn't exist.
+     */
+    public Collection<IgniteFsPath> listPaths(IgniteFsPath path) throws GridException;
+
+    /**
+     * Lists files under the specified path.
+     *
+     * @param path Path to list files under.
+     * @return List of files under the specified path.
+     * @throws GridException In case of error.
+     * @throws IgniteFsFileNotFoundException If path doesn't exist.
+     */
+    public Collection<IgniteFsFile> listFiles(IgniteFsPath path) throws GridException;
+
+    /**
+     * Opens a file for reading.
+     *
+     * @param path File path to read.
+     * @param bufSize Read buffer size (bytes) or {@code zero} to use default value.
+     * @return File input stream to read data from.
+     * @throws GridException In case of error.
+     * @throws IgniteFsFileNotFoundException If path doesn't exist.
+     */
+    public IgniteFsReader open(IgniteFsPath path, int bufSize) throws GridException;
+
+    /**
+     * Creates a file and opens it for writing.
+     *
+     * @param path File path to create.
+     * @param overwrite Overwrite file if it already exists. Note: you cannot overwrite an existent directory.
+     * @return File output stream to write data to.
+     * @throws GridException In case of error.
+     */
+    public OutputStream create(IgniteFsPath path, boolean overwrite) throws GridException;
+
+    /**
+     * Creates a file and opens it for writing.
+     *
+     * @param path File path to create.
+     * @param bufSize Write buffer size (bytes) or {@code zero} to use default value.
+     * @param overwrite Overwrite file if it already exists. Note: you cannot overwrite an existent directory.
+     * @param replication Replication factor.
+     * @param blockSize Block size.
+     * @param props File properties to set.
+     * @return File output stream to write data to.
+     * @throws GridException In case of error.
+     */
+    public OutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication, long blockSize,
+       @Nullable Map<String, String> props) throws GridException;
+
+    /**
+     * Opens an output stream to an existing file for appending data.
+     *
+     * @param path File path to append.
+     * @param bufSize Write buffer size (bytes) or {@code zero} to use default value.
+     * @param create Create file if it doesn't exist yet.
+     * @param props File properties to set only in case it file was just created.
+     * @return File output stream to append data to.
+     * @throws GridException In case of error.
+     * @throws IgniteFsFileNotFoundException If path doesn't exist and create flag is {@code false}.
+     */
+    public OutputStream append(IgniteFsPath path, int bufSize, boolean create, @Nullable Map<String, String> props)
+        throws GridException;
+
+    /**
+     * Gets file information for the specified path.
+     *
+     * @param path Path to get information for.
+     * @return File information for specified path or {@code null} if such path does not exist.
+     * @throws GridException In case of error.
+     */
+    @Nullable public IgniteFsFile info(IgniteFsPath path) throws GridException;
+
+    /**
+     * Gets used space in bytes.
+     *
+     * @return Used space in bytes.
+     * @throws GridException In case of error.
+     */
+    public long usedSpaceSize() throws GridException;
+
+    /**
+     * Gets the implementation specific properties of file system.
+     *
+     * @return Map of properties.
+     */
+    public Map<String,String> properties();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsGroupDataBlocksKeyMapper.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsGroupDataBlocksKeyMapper.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsGroupDataBlocksKeyMapper.java
new file mode 100644
index 0000000..0410c17
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsGroupDataBlocksKeyMapper.java
@@ -0,0 +1,93 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+import org.gridgain.grid.kernal.processors.cache.*;
+import org.gridgain.grid.kernal.processors.ggfs.*;
+import org.gridgain.grid.util.typedef.internal.*;
+
+/**
+ * {@code GGFS} class providing ability to group file's data blocks together on one node.
+ * All blocks within the same group are guaranteed to be cached together on the same node.
+ * Group size parameter controls how many sequential blocks will be cached together on the same node.
+ * <p>
+ * For example, if block size is {@code 64kb} and group size is {@code 256}, then each group will contain
+ * {@code 64kb * 256 = 16Mb}. Larger group sizes would reduce number of splits required to run map-reduce
+ * tasks, but will increase inequality of data size being stored on different nodes.
+ * <p>
+ * Note that {@link #groupSize()} parameter must correlate to Hadoop split size parameter defined
+ * in Hadoop via {@code mapred.max.split.size} property. Ideally you want all blocks accessed
+ * within one split to be mapped to {@code 1} group, so they can be located on the same grid node.
+ * For example, default Hadoop split size is {@code 64mb} and default {@code GGFS} block size
+ * is {@code 64kb}. This means that to make sure that each split goes only through blocks on
+ * the same node (without hopping between nodes over network), we have to make the {@link #groupSize()}
+ * value be equal to {@code 64mb / 64kb = 1024}.
+ * <p>
+ * It is required for {@code GGFS} data cache to be configured with this mapper. Here is an
+ * example of how it can be specified in XML configuration:
+ * <pre name="code" class="xml">
+ * &lt;bean id="cacheCfgBase" class="org.gridgain.grid.cache.GridCacheConfiguration" abstract="true"&gt;
+ *     ...
+ *     &lt;property name="affinityMapper"&gt;
+ *         &lt;bean class="org.gridgain.grid.ggfs.GridGgfsGroupDataBlocksKeyMapper"&gt;
+ *             &lt;!-- How many sequential blocks will be stored on the same node. --&gt;
+ *             &lt;constructor-arg value="512"/&gt;
+ *         &lt;/bean&gt;
+ *     &lt;/property&gt;
+ *     ...
+ * &lt;/bean&gt;
+ * </pre>
+ */
+public class IgniteFsGroupDataBlocksKeyMapper extends GridCacheDefaultAffinityKeyMapper {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** Size of the group. */
+    private final int grpSize;
+
+    /***
+     * Constructs affinity mapper to group several data blocks with the same key.
+     *
+     * @param grpSize Size of the group in blocks.
+     */
+    public IgniteFsGroupDataBlocksKeyMapper(int grpSize) {
+        A.ensure(grpSize >= 1, "grpSize >= 1");
+
+        this.grpSize = grpSize;
+    }
+
+    /** {@inheritDoc} */
+    @Override public Object affinityKey(Object key) {
+        if (key != null && GridGgfsBlockKey.class.equals(key.getClass())) {
+            GridGgfsBlockKey blockKey = (GridGgfsBlockKey)key;
+
+            if (blockKey.affinityKey() != null)
+                return blockKey.affinityKey();
+
+            long grpId = blockKey.getBlockId() / grpSize;
+
+            return blockKey.getFileId().hashCode() + (int)(grpId ^ (grpId >>> 32));
+        }
+
+        return super.affinityKey(key);
+    }
+
+    /**
+     * @return Size of the group.
+     */
+    public int groupSize() {
+        return grpSize;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsGroupDataBlocksKeyMapper.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsInputStream.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsInputStream.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsInputStream.java
new file mode 100644
index 0000000..d98d051
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsInputStream.java
@@ -0,0 +1,72 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+import java.io.*;
+
+/**
+ * {@code GGFS} input stream to read data from the file system.
+ * It provides several additional methods for asynchronous access.
+ */
+public abstract class IgniteFsInputStream extends InputStream implements IgniteFsReader {
+    /**
+     * Gets file length during file open.
+     *
+     * @return File length.
+     */
+    public abstract long length();
+
+    /**
+     * Seek to the specified position.
+     *
+     * @param pos Position to seek to.
+     * @throws IOException In case of IO exception.
+     */
+    public abstract void seek(long pos) throws IOException;
+
+    /**
+     * Get the current position in the input stream.
+     *
+     * @return The current position in the input stream.
+     * @throws IOException In case of IO exception.
+     */
+    public abstract long position() throws IOException;
+
+    /**
+     * Read bytes from the given position in the stream to the given buffer.
+     * Continues to read until passed buffer becomes filled.
+     *
+     * @param pos Position in the input stream to seek.
+     * @param buf Buffer into which data is read.
+     * @throws IOException In case of IO exception.
+     */
+    public abstract void readFully(long pos, byte[] buf) throws IOException;
+
+    /**
+     *
+     * @param pos Position in the input stream to seek.
+     * @param buf Buffer into which data is read.
+     * @param off Offset in the buffer from which stream data should be written.
+     * @param len The number of bytes to read.
+     * @throws IOException In case of IO exception.
+     */
+    public abstract void readFully(long pos, byte[] buf, int off, int len) throws IOException;
+
+    /**
+     *
+     * @param pos Position in the input stream to seek.
+     * @param buf Buffer into which data is read.
+     * @param off Offset in the buffer from which stream data should be written.
+     * @param len The number of bytes to read.
+     * @return Total number of bytes read into the buffer, or -1 if there is no more data (EOF).
+     * @throws IOException In case of IO exception.
+     */
+    @Override public abstract int read(long pos, byte[] buf, int off, int len) throws IOException;
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsInvalidHdfsVersionException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsInvalidHdfsVersionException.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsInvalidHdfsVersionException.java
new file mode 100644
index 0000000..4edd97b
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsInvalidHdfsVersionException.java
@@ -0,0 +1,34 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+/**
+ * Exception thrown when GridGain detects that remote HDFS version differs from version of HDFS libraries
+ * in GridGain classpath.
+ */
+public class IgniteFsInvalidHdfsVersionException extends IgniteFsException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * @param msg Error message.
+     */
+    public IgniteFsInvalidHdfsVersionException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * @param msg Error message.
+     * @param cause Error cause.
+     */
+    public IgniteFsInvalidHdfsVersionException(String msg, Throwable cause) {
+        super(msg, cause);
+    }
+}


[05/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
# Renaming


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

Branch: refs/heads/master
Commit: a228c7d6912a6059d2b44168541a5d5b6b9da58d
Parents: 2f80979
Author: sboikov <sb...@gridgain.com>
Authored: Fri Dec 5 11:03:34 2014 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Dec 5 11:03:34 2014 +0300

----------------------------------------------------------------------
 .../gridgain/client/GridClientTestPortable.java |   6 +-
 .../clients/src/test/resources/spring-cache.xml |   2 +-
 .../src/test/resources/spring-server-node.xml   |   2 +-
 .../test/resources/spring-server-ssl-node.xml   |   2 +-
 .../java/org/apache/ignite/IgnitePortables.java |  42 ++---
 .../configuration/IgniteConfiguration.java      |   6 +-
 .../ignite/portables/GridPortableBuilder.java   | 129 -------------
 .../portables/GridPortableConfiguration.java    | 181 -------------------
 .../ignite/portables/GridPortableException.java |  49 -----
 .../ignite/portables/GridPortableIdMapper.java  |  47 -----
 .../GridPortableInvalidClassException.java      |  50 -----
 .../portables/GridPortableMarshalAware.java     |  40 ----
 .../ignite/portables/GridPortableObject.java    |  24 +--
 .../ignite/portables/GridPortableRawReader.java | 124 ++++++-------
 .../ignite/portables/GridPortableRawWriter.java | 116 ++++++------
 .../ignite/portables/GridPortableReader.java    | 128 ++++++-------
 .../portables/GridPortableSerializer.java       |  12 +-
 .../GridPortableTypeConfiguration.java          |  14 +-
 .../ignite/portables/GridPortableWriter.java    | 120 ++++++------
 .../ignite/portables/PortableBuilder.java       | 129 +++++++++++++
 .../ignite/portables/PortableConfiguration.java | 181 +++++++++++++++++++
 .../ignite/portables/PortableException.java     |  49 +++++
 .../ignite/portables/PortableIdMapper.java      |  47 +++++
 .../PortableInvalidClassException.java          |  50 +++++
 .../ignite/portables/PortableMarshalAware.java  |  40 ++++
 .../client/GridClientConfiguration.java         |   6 +-
 .../grid/dotnet/GridDotNetConfiguration.java    |   6 +-
 .../dotnet/GridDotNetPortableConfiguration.java |   6 +-
 .../GridDotNetPortableTypeConfiguration.java    |   6 +-
 .../gridgain/grid/kernal/GridPortablesImpl.java |  16 +-
 .../managers/indexing/GridIndexingManager.java  |   2 +-
 .../affinity/GridAffinityAssignmentCache.java   |   2 +-
 .../processors/cache/GridCacheAdapter.java      |   8 +-
 .../processors/cache/GridCacheContext.java      |   4 +-
 .../GridCacheDefaultAffinityKeyMapper.java      |   2 +-
 .../cache/GridCacheTxLocalAdapter.java          |   6 +-
 .../cache/affinity/GridCacheAffinityImpl.java   |   2 +-
 .../portable/GridPortableProcessor.java         |  46 ++---
 .../portable/os/GridOsPortableProcessor.java    |  22 +--
 .../message/GridClientAbstractMessage.java      |   6 +-
 .../GridClientAuthenticationRequest.java        |   4 +-
 .../message/GridClientCacheQueryRequest.java    |   4 +-
 .../client/message/GridClientCacheRequest.java  |   4 +-
 .../message/GridClientGetMetaDataRequest.java   |   4 +-
 .../client/message/GridClientLogRequest.java    |   4 +-
 .../message/GridClientMetaDataResponse.java     |   6 +-
 .../rest/client/message/GridClientNodeBean.java |   6 +-
 .../message/GridClientNodeMetricsBean.java      |   6 +-
 .../message/GridClientPortableMetaData.java     |   6 +-
 .../message/GridClientPutMetaDataRequest.java   |   4 +-
 .../rest/client/message/GridClientResponse.java |   4 +-
 .../client/message/GridClientTaskRequest.java   |   4 +-
 .../message/GridClientTaskResultBean.java       |   6 +-
 .../message/GridClientTopologyRequest.java      |   4 +-
 .../cache/GridCacheClientQueryResult.java       |   6 +-
 .../handlers/task/GridTaskCommandHandler.java   |   2 +-
 .../grid/security/GridSecurityCredentials.java  |   6 +-
 .../util/portable/GridPortableRawReaderEx.java  |   4 +-
 .../util/portable/GridPortableRawWriterEx.java  |   4 +-
 .../GridCacheOffHeapTieredAbstractSelfTest.java |   2 +-
 ...heOffHeapTieredEvictionAbstractSelfTest.java |   2 +-
 .../GridCacheSwapScanQueryAbstractSelfTest.java |   2 +-
 .../dataload/GridDataLoaderImplSelfTest.java    |   8 +-
 63 files changed, 916 insertions(+), 916 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/clients/src/test/java/org/gridgain/client/GridClientTestPortable.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/gridgain/client/GridClientTestPortable.java b/modules/clients/src/test/java/org/gridgain/client/GridClientTestPortable.java
index b9d948c..9836e05 100644
--- a/modules/clients/src/test/java/org/gridgain/client/GridClientTestPortable.java
+++ b/modules/clients/src/test/java/org/gridgain/client/GridClientTestPortable.java
@@ -19,7 +19,7 @@ import java.util.*;
  * Test portable object.
  */
 @SuppressWarnings("PublicField")
-public class GridClientTestPortable implements GridPortableMarshalAware, Serializable {
+public class GridClientTestPortable implements PortableMarshalAware, Serializable {
     /** */
     public byte b;
 
@@ -303,7 +303,7 @@ public class GridClientTestPortable implements GridPortableMarshalAware, Seriali
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         writer.writeByte("_b", b);
         writer.writeShort("_s", s);
         writer.writeInt("_i", i);
@@ -368,7 +368,7 @@ public class GridClientTestPortable implements GridPortableMarshalAware, Seriali
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         b = reader.readByte("_b");
         s = reader.readShort("_s");
         i = reader.readInt("_i");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/clients/src/test/resources/spring-cache.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-cache.xml b/modules/clients/src/test/resources/spring-cache.xml
index ee34262..bb4a4cd 100644
--- a/modules/clients/src/test/resources/spring-cache.xml
+++ b/modules/clients/src/test/resources/spring-cache.xml
@@ -236,7 +236,7 @@
         </property>
 
         <property name="portableConfiguration">
-            <bean class="org.apache.ignite.portables.GridPortableConfiguration">
+            <bean class="org.apache.ignite.portables.PortableConfiguration">
                 <property name="typeConfigurations">
                     <list>
                         <bean class="org.apache.ignite.portables.GridPortableTypeConfiguration">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/clients/src/test/resources/spring-server-node.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-server-node.xml b/modules/clients/src/test/resources/spring-server-node.xml
index 2c4b58b..d5d8530 100644
--- a/modules/clients/src/test/resources/spring-server-node.xml
+++ b/modules/clients/src/test/resources/spring-server-node.xml
@@ -70,7 +70,7 @@
         </property>
 
         <property name="portableConfiguration">
-            <bean class="org.apache.ignite.portables.GridPortableConfiguration">
+            <bean class="org.apache.ignite.portables.PortableConfiguration">
                 <property name="typeConfigurations">
                     <list>
                         <bean class="org.apache.ignite.portables.GridPortableTypeConfiguration">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/clients/src/test/resources/spring-server-ssl-node.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-server-ssl-node.xml b/modules/clients/src/test/resources/spring-server-ssl-node.xml
index 144bf45..0a363d5 100644
--- a/modules/clients/src/test/resources/spring-server-ssl-node.xml
+++ b/modules/clients/src/test/resources/spring-server-ssl-node.xml
@@ -318,7 +318,7 @@
         <property name="systemExecutorServiceShutdown" value="true"/>
 
         <property name="portableConfiguration">
-            <bean class="org.apache.ignite.portables.GridPortableConfiguration">
+            <bean class="org.apache.ignite.portables.PortableConfiguration">
                 <property name="typeConfigurations">
                     <list>
                         <bean class="org.apache.ignite.portables.GridPortableTypeConfiguration">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/IgnitePortables.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/IgnitePortables.java b/modules/core/src/main/java/org/apache/ignite/IgnitePortables.java
index 547daba..88d0e4d 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgnitePortables.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgnitePortables.java
@@ -98,7 +98,7 @@ import java.util.Date;
  * in Java is {@code Dictionary} in C#, and {@link TreeMap} in Java becomes {@code SortedDictionary}
  * in C#, etc.
  * <h1 class="header">Building Portable Objects</h1>
- * GridGain comes with {@link org.apache.ignite.portables.GridPortableBuilder} which allows to build portable objects dynamically:
+ * GridGain comes with {@link org.apache.ignite.portables.PortableBuilder} which allows to build portable objects dynamically:
  * <pre name=code class=java>
  * GridPortableBuilder builder = GridGain.grid().portables().builder();
  *
@@ -138,7 +138,7 @@ import java.util.Date;
  * As the structure of a portable object changes, the new fields become available for SQL queries
  * automatically.
  * <h1 class="header">Configuration</h1>
- * To make any object portable, you have to specify it in {@link org.apache.ignite.portables.GridPortableConfiguration}
+ * To make any object portable, you have to specify it in {@link org.apache.ignite.portables.PortableConfiguration}
  * at startup. The only requirement GridGain imposes is that your object has an empty
  * constructor. Note, that since server side does not have to know the class definition,
  * you only need to list portable objects in configuration on the client side. However, if you
@@ -200,9 +200,9 @@ import java.util.Date;
  * &lt;/property&gt;
  * </pre>
  * <h1 class="header">Serialization</h1>
- * Once portable object is specified in {@link org.apache.ignite.portables.GridPortableConfiguration}, GridGain will
+ * Once portable object is specified in {@link org.apache.ignite.portables.PortableConfiguration}, GridGain will
  * be able to serialize and deserialize it. However, you can provide your own custom
- * serialization logic by optionally implementing {@link org.apache.ignite.portables.GridPortableMarshalAware} interface, like so:
+ * serialization logic by optionally implementing {@link org.apache.ignite.portables.PortableMarshalAware} interface, like so:
  * <pre name=code class=java>
  * public class Address implements GridPortableMarshalAware {
  *     private String street;
@@ -223,7 +223,7 @@ import java.util.Date;
  * }
  * </pre>
  * Alternatively, if you cannot change class definitions, you can provide custom serialization
- * logic in {@link org.apache.ignite.portables.GridPortableSerializer} either globally in {@link org.apache.ignite.portables.GridPortableConfiguration} or
+ * logic in {@link org.apache.ignite.portables.GridPortableSerializer} either globally in {@link org.apache.ignite.portables.PortableConfiguration} or
  * for a specific type via {@link org.apache.ignite.portables.GridPortableTypeConfiguration} instance.
  * <p>
  * Similar to java serialization you can use {@code writeReplace()} and {@code readResolve()} methods.
@@ -241,9 +241,9 @@ import java.util.Date;
  * <h1 class="header">Custom ID Mappers</h1>
  * GridGain implementation uses name hash codes to generate IDs for class names or field names
  * internally. However, in cases when you want to provide your own ID mapping schema,
- * you can provide your own {@link org.apache.ignite.portables.GridPortableIdMapper} implementation.
+ * you can provide your own {@link org.apache.ignite.portables.PortableIdMapper} implementation.
  * <p>
- * ID-mapper may be provided either globally in {@link org.apache.ignite.portables.GridPortableConfiguration},
+ * ID-mapper may be provided either globally in {@link org.apache.ignite.portables.PortableConfiguration},
  * or for a specific type via {@link org.apache.ignite.portables.GridPortableTypeConfiguration} instance.
  * <h1 class="header">Query Indexing</h1>
  * Portable objects can be indexed for querying by specifying index fields in
@@ -289,13 +289,13 @@ public interface IgnitePortables {
     /**
      * Converts provided object to instance of {@link org.apache.ignite.portables.GridPortableObject}.
      * <p>
-     * Note that object's type needs to be configured in {@link org.apache.ignite.portables.GridPortableConfiguration}.
+     * Note that object's type needs to be configured in {@link org.apache.ignite.portables.PortableConfiguration}.
      *
      * @param obj Object to convert.
      * @return Converted object.
-     * @throws org.apache.ignite.portables.GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    public <T> T toPortable(@Nullable Object obj) throws GridPortableException;
+    public <T> T toPortable(@Nullable Object obj) throws PortableException;
 
     /**
      * Creates new portable builder.
@@ -303,7 +303,7 @@ public interface IgnitePortables {
      * @param typeId ID of the type.
      * @return Newly portable builder.
      */
-    public GridPortableBuilder builder(int typeId);
+    public PortableBuilder builder(int typeId);
 
     /**
      * Creates new portable builder.
@@ -311,7 +311,7 @@ public interface IgnitePortables {
      * @param typeName Type name.
      * @return Newly portable builder.
      */
-    public GridPortableBuilder builder(String typeName);
+    public PortableBuilder builder(String typeName);
 
     /**
      * Creates portable builder initialized by existing portable object.
@@ -319,40 +319,40 @@ public interface IgnitePortables {
      * @param portableObj Portable object to initialize builder.
      * @return Portable builder.
      */
-    public GridPortableBuilder builder(GridPortableObject portableObj);
+    public PortableBuilder builder(GridPortableObject portableObj);
 
     /**
      * Gets metadata for provided class.
      *
      * @param cls Class.
      * @return Metadata.
-     * @throws GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    @Nullable public GridPortableMetadata metadata(Class<?> cls) throws GridPortableException;
+    @Nullable public GridPortableMetadata metadata(Class<?> cls) throws PortableException;
 
     /**
      * Gets metadata for provided class name.
      *
      * @param typeName Type name.
      * @return Metadata.
-     * @throws GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    @Nullable public GridPortableMetadata metadata(String typeName) throws GridPortableException;
+    @Nullable public GridPortableMetadata metadata(String typeName) throws PortableException;
 
     /**
      * Gets metadata for provided type ID.
      *
      * @param typeId Type ID.
      * @return Metadata.
-     * @throws GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    @Nullable public GridPortableMetadata metadata(int typeId) throws GridPortableException;
+    @Nullable public GridPortableMetadata metadata(int typeId) throws PortableException;
 
     /**
      * Gets metadata for all known types.
      *
      * @return Metadata.
-     * @throws GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    public Collection<GridPortableMetadata> metadata() throws GridPortableException;
+    public Collection<GridPortableMetadata> metadata() throws PortableException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java b/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
index 1d40d13..72d3fda 100644
--- a/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
@@ -535,7 +535,7 @@ public class IgniteConfiguration {
     private GridClientConnectionConfiguration clientCfg;
 
     /** Portable configuration. */
-    private GridPortableConfiguration portableCfg;
+    private PortableConfiguration portableCfg;
 
     /** Warmup closure. Will be invoked before actual grid start. */
     private IgniteInClosure<IgniteConfiguration> warmupClos;
@@ -3127,14 +3127,14 @@ public class IgniteConfiguration {
     /**
      * @return Portable configuration.
      */
-    public GridPortableConfiguration getPortableConfiguration() {
+    public PortableConfiguration getPortableConfiguration() {
         return portableCfg;
     }
 
     /**
      * @param portableCfg Portable configuration.
      */
-    public void setPortableConfiguration(GridPortableConfiguration portableCfg) {
+    public void setPortableConfiguration(PortableConfiguration portableCfg) {
         this.portableCfg = portableCfg;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/GridPortableBuilder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableBuilder.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableBuilder.java
deleted file mode 100644
index a400047..0000000
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableBuilder.java
+++ /dev/null
@@ -1,129 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.portables;
-
-import org.jetbrains.annotations.*;
-
-/**
- * Portable object builder. Provides ability to build portable objects dynamically
- * without having class definitions.
- * <p>
- * Here is an example of how a portable object can be built dynamically:
- * <pre name=code class=java>
- * GridPortableBuilder builder = GridGain.grid().portables().builder("org.project.MyObject");
- *
- * builder.setField("fieldA", "A");
- * builder.setField("fieldB", "B");
- *
- * GridPortableObject portableObj = builder.build();
- * </pre>
- *
- * <p>
- * Also builder can be initialized by existing portable object. This allows changing some fields without affecting
- * other fields.
- * <pre name=code class=java>
- * GridPortableBuilder builder = GridGain.grid().portables().builder(person);
- *
- * builder.setField("name", "John");
- *
- * person = builder.build();
- * </pre>
- * </p>
- *
- * If you need to modify nested portable object you can get builder for nested object using
- * {@link #getField(String)}, changes made on nested builder will affect parent object,
- * for example:
- *
- * <pre name=code class=java>
- * GridPortableBuilder personBuilder = grid.portables().createBuilder(personPortableObj);
- * GridPortableBuilder addressBuilder = personBuilder.setField("address");
- *
- * addressBuilder.setField("city", "New York");
- *
- * personPortableObj = personBuilder.build();
- *
- * // Should be "New York".
- * String city = personPortableObj.getField("address").getField("city");
- * </pre>
- *
- * @see org.apache.ignite.IgnitePortables#builder(int)
- * @see org.apache.ignite.IgnitePortables#builder(String)
- * @see org.apache.ignite.IgnitePortables#builder(GridPortableObject)
- */
-public interface GridPortableBuilder {
-    /**
-     * Returns value assigned to the specified field.
-     * If the value is a portable object instance of {@code GridPortableBuilder} will be returned,
-     * which can be modified.
-     * <p>
-     * Collections and maps returned from this method are modifiable.
-     *
-     * @param name Field name.
-     * @return Filed value.
-     */
-    public <T> T getField(String name);
-
-    /**
-     * Sets field value.
-     *
-     * @param name Field name.
-     * @param val Field value (cannot be {@code null}).
-     * @see GridPortableObject#metaData()
-     */
-    public GridPortableBuilder setField(String name, Object val);
-
-    /**
-     * Sets field value with value type specification.
-     * <p>
-     * Field type is needed for proper metadata update.
-     *
-     * @param name Field name.
-     * @param val Field value.
-     * @param type Field type.
-     * @see GridPortableObject#metaData()
-     */
-    public <T> GridPortableBuilder setField(String name, @Nullable T val, Class<? super T> type);
-
-    /**
-     * Sets field value.
-     * <p>
-     * This method should be used if field is portable object.
-     *
-     * @param name Field name.
-     * @param builder Builder for object field.
-     */
-    public GridPortableBuilder setField(String name, @Nullable GridPortableBuilder builder);
-
-    /**
-     * Removes field from this builder.
-     *
-     * @param fieldName Field name.
-     * @return {@code this} instance for chaining.
-     */
-    public GridPortableBuilder removeField(String fieldName);
-
-    /**
-     * Sets hash code for resulting portable object returned by {@link #build()} method.
-     * <p>
-     * If not set {@code 0} is used.
-     *
-     * @param hashCode Hash code.
-     * @return {@code this} instance for chaining.
-     */
-    public GridPortableBuilder hashCode(int hashCode);
-
-    /**
-     * Builds portable object.
-     *
-     * @return Portable object.
-     * @throws GridPortableException In case of error.
-     */
-    public GridPortableObject build() throws GridPortableException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/GridPortableConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableConfiguration.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableConfiguration.java
deleted file mode 100644
index c1cfa0d..0000000
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableConfiguration.java
+++ /dev/null
@@ -1,181 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.portables;
-
-import org.gridgain.grid.util.typedef.internal.*;
-
-import java.sql.Timestamp;
-import java.util.*;
-
-/**
- * Defines configuration for GridGain portable functionality. All configuration
- * properties defined here can be overridden on per-type level in
- * {@link GridPortableTypeConfiguration}. Type configurations are provided via
- * {@link #getTypeConfigurations()} method.
- */
-public class GridPortableConfiguration {
-    /** Class names. */
-    private Collection<String> clsNames;
-
-    /** ID mapper. */
-    private GridPortableIdMapper idMapper;
-
-    /** Serializer. */
-    private GridPortableSerializer serializer;
-
-    /** Types. */
-    private Collection<GridPortableTypeConfiguration> typeCfgs;
-
-    /** Use timestamp flag. */
-    private boolean useTs = true;
-
-    /** Meta data enabled flag. */
-    private boolean metaDataEnabled = true;
-
-    /** Keep deserialized flag. */
-    private boolean keepDeserialized = true;
-
-    /**
-     * Gets class names.
-     *
-     * @return Class names.
-     */
-    public Collection<String> getClassNames() {
-        return clsNames;
-    }
-
-    /**
-     * Sets class names.
-     *
-     * @param clsNames Class names.
-     */
-    public void setClassNames(Collection<String> clsNames) {
-        this.clsNames = clsNames;
-    }
-
-    /**
-     * Gets ID mapper.
-     *
-     * @return ID mapper.
-     */
-    public GridPortableIdMapper getIdMapper() {
-        return idMapper;
-    }
-
-    /**
-     * Sets ID mapper.
-     *
-     * @param idMapper ID mapper.
-     */
-    public void setIdMapper(GridPortableIdMapper idMapper) {
-        this.idMapper = idMapper;
-    }
-
-    /**
-     * Gets serializer.
-     *
-     * @return Serializer.
-     */
-    public GridPortableSerializer getSerializer() {
-        return serializer;
-    }
-
-    /**
-     * Sets serializer.
-     *
-     * @param serializer Serializer.
-     */
-    public void setSerializer(GridPortableSerializer serializer) {
-        this.serializer = serializer;
-    }
-
-    /**
-     * Gets types configuration.
-     *
-     * @return Types configuration.
-     */
-    public Collection<GridPortableTypeConfiguration> getTypeConfigurations() {
-        return typeCfgs;
-    }
-
-    /**
-     * Sets type configurations.
-     *
-     * @param typeCfgs Type configurations.
-     */
-    public void setTypeConfigurations(Collection<GridPortableTypeConfiguration> typeCfgs) {
-        this.typeCfgs = typeCfgs;
-    }
-
-    /**
-     * If {@code true} then date values converted to {@link Timestamp} on deserialization.
-     * <p>
-     * Default value is {@code true}.
-     *
-     * @return Flag indicating whether date values converted to {@link Timestamp} during unmarshalling.
-     */
-    public boolean isUseTimestamp() {
-        return useTs;
-    }
-
-    /**
-     * @param useTs Flag indicating whether date values converted to {@link Timestamp} during unmarshalling.
-     */
-    public void setUseTimestamp(boolean useTs) {
-        this.useTs = useTs;
-    }
-
-    /**
-     * If {@code true}, meta data will be collected or all types. If you need to override this behaviour for
-     * some specific type, use {@link GridPortableTypeConfiguration#setMetaDataEnabled(Boolean)} method.
-     * <p>
-     * Default value if {@code true}.
-     *
-     * @return Whether meta data is collected.
-     */
-    public boolean isMetaDataEnabled() {
-        return metaDataEnabled;
-    }
-
-    /**
-     * @param metaDataEnabled Whether meta data is collected.
-     */
-    public void setMetaDataEnabled(boolean metaDataEnabled) {
-        this.metaDataEnabled = metaDataEnabled;
-    }
-
-    /**
-     * If {@code true}, {@link GridPortableObject} will cache deserialized instance after
-     * {@link GridPortableObject#deserialize()} is called. All consequent calls of this
-     * method on the same instance of {@link GridPortableObject} will return that cached
-     * value without actually deserializing portable object. If you need to override this
-     * behaviour for some specific type, use {@link GridPortableTypeConfiguration#setKeepDeserialized(Boolean)}
-     * method.
-     * <p>
-     * Default value if {@code true}.
-     *
-     * @return Whether deserialized value is kept.
-     */
-    public boolean isKeepDeserialized() {
-        return keepDeserialized;
-    }
-
-    /**
-     * @param keepDeserialized Whether deserialized value is kept.
-     */
-    public void setKeepDeserialized(boolean keepDeserialized) {
-        this.keepDeserialized = keepDeserialized;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridPortableConfiguration.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/GridPortableException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableException.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableException.java
deleted file mode 100644
index 2a5e430..0000000
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableException.java
+++ /dev/null
@@ -1,49 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.portables;
-
-import org.gridgain.grid.*;
-import org.jetbrains.annotations.*;
-
-/**
- * Exception indicating portable object serialization error.
- */
-public class GridPortableException extends GridRuntimeException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Creates portable exception with error message.
-     *
-     * @param msg Error message.
-     */
-    public GridPortableException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * Creates portable exception with {@link Throwable} as a cause.
-     *
-     * @param cause Cause.
-     */
-    public GridPortableException(Throwable cause) {
-        super(cause);
-    }
-
-    /**
-     * Creates portable exception with error message and {@link Throwable} as a cause.
-     *
-     * @param msg Error message.
-     * @param cause Cause.
-     */
-    public GridPortableException(String msg, @Nullable Throwable cause) {
-        super(msg, cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/GridPortableIdMapper.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableIdMapper.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableIdMapper.java
deleted file mode 100644
index b5cff6f..0000000
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableIdMapper.java
+++ /dev/null
@@ -1,47 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.portables;
-
-/**
- * Type and field ID mapper for portable objects. GridGain never writes full
- * strings for field or type names. Instead, for performance reasons, GridGain
- * writes integer hash codes for type and field names. It has been tested that
- * hash code conflicts for the type names or the field names
- * within the same type are virtually non-existent and, to gain performance, it is safe
- * to work with hash codes. For the cases when hash codes for different types or fields
- * actually do collide {@code GridPortableIdMapper} allows to override the automatically
- * generated hash code IDs for the type and field names.
- * <p>
- * Portable ID mapper can be configured for all portable objects via
- * {@link GridPortableConfiguration#getIdMapper()} method, or for a specific
- * portable type via {@link GridPortableTypeConfiguration#getIdMapper()} method.
- */
-public interface GridPortableIdMapper {
-    /**
-     * Gets type ID for provided class name.
-     * <p>
-     * If {@code 0} is returned, hash code of class simple name will be used.
-     *
-     * @param clsName Class name.
-     * @return Type ID.
-     */
-    public int typeId(String clsName);
-
-    /**
-     * Gets ID for provided field.
-     * <p>
-     * If {@code 0} is returned, hash code of field name will be used.
-     *
-     * @param typeId Type ID.
-     * @param fieldName Field name.
-     * @return Field ID.
-     */
-    public int fieldId(int typeId, String fieldName);
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/GridPortableInvalidClassException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableInvalidClassException.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableInvalidClassException.java
deleted file mode 100644
index 24fabc5..0000000
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableInvalidClassException.java
+++ /dev/null
@@ -1,50 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.portables;
-
-import org.jetbrains.annotations.*;
-
-/**
- * Exception indicating that class needed for deserialization of portable object does not exist.
- * <p>
- * Thrown from {@link GridPortableObject#deserialize()} method.
- */
-public class GridPortableInvalidClassException extends GridPortableException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Creates invalid class exception with error message.
-     *
-     * @param msg Error message.
-     */
-    public GridPortableInvalidClassException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * Creates invalid class exception with {@link Throwable} as a cause.
-     *
-     * @param cause Cause.
-     */
-    public GridPortableInvalidClassException(Throwable cause) {
-        super(cause);
-    }
-
-    /**
-     * Creates invalid class exception with error message and {@link Throwable} as a cause.
-     *
-     * @param msg Error message.
-     * @param cause Cause.
-     */
-    public GridPortableInvalidClassException(String msg, @Nullable Throwable cause) {
-        super(msg, cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/GridPortableMarshalAware.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableMarshalAware.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableMarshalAware.java
deleted file mode 100644
index 6dde0dc..0000000
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableMarshalAware.java
+++ /dev/null
@@ -1,40 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.portables;
-
-/**
- * Interface that allows to implement custom serialization
- * logic for portable objects. Portable objects are not required
- * to implement this interface, in which case GridGain will automatically
- * serialize portable objects using reflection.
- * <p>
- * This interface, in a way, is analogous to {@link java.io.Externalizable}
- * interface, which allows users to override default serialization logic,
- * usually for performance reasons. The only difference here is that portable
- * serialization is already very fast and implementing custom serialization
- * logic for portables does not provide significant performance gains.
- */
-public interface GridPortableMarshalAware {
-    /**
-     * Writes fields to provided writer.
-     *
-     * @param writer Portable object writer.
-     * @throws GridPortableException In case of error.
-     */
-    public void writePortable(GridPortableWriter writer) throws GridPortableException;
-
-    /**
-     * Reads fields from provided reader.
-     *
-     * @param reader Portable object reader.
-     * @throws GridPortableException In case of error.
-     */
-    public void readPortable(GridPortableReader reader) throws GridPortableException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/GridPortableObject.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableObject.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableObject.java
index 12b6049..eb1f593 100644
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableObject.java
+++ b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableObject.java
@@ -82,7 +82,7 @@ import java.util.*;
  * As the structure of a portable object changes, the new fields become available for SQL queries
  * automatically.
  * <h1 class="header">Building Portable Objects</h1>
- * GridGain comes with {@link GridPortableBuilder} which allows to build portable objects dynamically:
+ * GridGain comes with {@link PortableBuilder} which allows to build portable objects dynamically:
  * <pre name=code class=java>
  * GridPortableBuilder builder = GridGain.grid().portables().builder("org.project.MyObject");
  *
@@ -121,27 +121,27 @@ public interface GridPortableObject extends Serializable, Cloneable {
      * Gets meta data for this portable object.
      *
      * @return Meta data.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public GridPortableMetadata metaData() throws GridPortableException;
+    @Nullable public GridPortableMetadata metaData() throws PortableException;
 
     /**
      * Gets field value.
      *
      * @param fieldName Field name.
      * @return Field value.
-     * @throws GridPortableException In case of any other error.
+     * @throws PortableException In case of any other error.
      */
-    @Nullable public <F> F field(String fieldName) throws GridPortableException;
+    @Nullable public <F> F field(String fieldName) throws PortableException;
 
     /**
      * Gets fully deserialized instance of portable object.
      *
      * @return Fully deserialized instance of portable object.
-     * @throws GridPortableInvalidClassException If class doesn't exist.
-     * @throws GridPortableException In case of any other error.
+     * @throws PortableInvalidClassException If class doesn't exist.
+     * @throws PortableException In case of any other error.
      */
-    @Nullable public <T> T deserialize() throws GridPortableException;
+    @Nullable public <T> T deserialize() throws PortableException;
 
     /**
      * Creates a copy of this portable object and optionally changes field values
@@ -150,12 +150,12 @@ public interface GridPortableObject extends Serializable, Cloneable {
      *
      * @param fields Fields to modify in copy.
      * @return Copy of this portable object.
-     * @throws GridPortableException In case of error.
-     * @deprecated Use {@link GridPortableBuilder} instead.
-     * @see GridPortableBuilder
+     * @throws PortableException In case of error.
+     * @deprecated Use {@link PortableBuilder} instead.
+     * @see PortableBuilder
      */
     @Deprecated
-    public GridPortableObject copy(@Nullable Map<String, Object> fields) throws GridPortableException;
+    public GridPortableObject copy(@Nullable Map<String, Object> fields) throws PortableException;
 
     /**
      * Copies this portable object.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawReader.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawReader.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawReader.java
index bd45f01..49f86bd 100644
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawReader.java
+++ b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawReader.java
@@ -23,192 +23,192 @@ import java.util.Date;
 public interface GridPortableRawReader {
     /**
      * @return Byte value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public byte readByte() throws GridPortableException;
+    public byte readByte() throws PortableException;
 
     /**
      * @return Short value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public short readShort() throws GridPortableException;
+    public short readShort() throws PortableException;
 
     /**
      * @return Integer value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public int readInt() throws GridPortableException;
+    public int readInt() throws PortableException;
 
     /**
      * @return Long value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public long readLong() throws GridPortableException;
+    public long readLong() throws PortableException;
 
     /**
      * @return Float value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public float readFloat() throws GridPortableException;
+    public float readFloat() throws PortableException;
 
     /**
      * @return Double value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public double readDouble() throws GridPortableException;
+    public double readDouble() throws PortableException;
 
     /**
      * @return Char value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public char readChar() throws GridPortableException;
+    public char readChar() throws PortableException;
 
     /**
      * @return Boolean value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public boolean readBoolean() throws GridPortableException;
+    public boolean readBoolean() throws PortableException;
 
     /**
      * @return String value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public String readString() throws GridPortableException;
+    @Nullable public String readString() throws PortableException;
 
     /**
      * @return UUID.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public UUID readUuid() throws GridPortableException;
+    @Nullable public UUID readUuid() throws PortableException;
 
     /**
      * @return Date.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public Date readDate() throws GridPortableException;
+    @Nullable public Date readDate() throws PortableException;
 
     /**
      * @return Timestamp.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public Timestamp readTimestamp() throws GridPortableException;
+    @Nullable public Timestamp readTimestamp() throws PortableException;
 
     /**
      * @return Object.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public Object readObject() throws GridPortableException;
+    @Nullable public Object readObject() throws PortableException;
 
     /**
      * @return Byte array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public byte[] readByteArray() throws GridPortableException;
+    @Nullable public byte[] readByteArray() throws PortableException;
 
     /**
      * @return Short array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public short[] readShortArray() throws GridPortableException;
+    @Nullable public short[] readShortArray() throws PortableException;
 
     /**
      * @return Integer array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public int[] readIntArray() throws GridPortableException;
+    @Nullable public int[] readIntArray() throws PortableException;
 
     /**
      * @return Long array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public long[] readLongArray() throws GridPortableException;
+    @Nullable public long[] readLongArray() throws PortableException;
 
     /**
      * @return Float array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public float[] readFloatArray() throws GridPortableException;
+    @Nullable public float[] readFloatArray() throws PortableException;
 
     /**
      * @return Byte array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public double[] readDoubleArray() throws GridPortableException;
+    @Nullable public double[] readDoubleArray() throws PortableException;
 
     /**
      * @return Char array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public char[] readCharArray() throws GridPortableException;
+    @Nullable public char[] readCharArray() throws PortableException;
 
     /**
      * @return Boolean array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public boolean[] readBooleanArray() throws GridPortableException;
+    @Nullable public boolean[] readBooleanArray() throws PortableException;
 
     /**
      * @return String array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public String[] readStringArray() throws GridPortableException;
+    @Nullable public String[] readStringArray() throws PortableException;
 
     /**
      * @return UUID array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public UUID[] readUuidArray() throws GridPortableException;
+    @Nullable public UUID[] readUuidArray() throws PortableException;
 
     /**
      * @return Date array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public Date[] readDateArray() throws GridPortableException;
+    @Nullable public Date[] readDateArray() throws PortableException;
 
     /**
      * @return Object array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public Object[] readObjectArray() throws GridPortableException;
+    @Nullable public Object[] readObjectArray() throws PortableException;
 
     /**
      * @return Collection.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public <T> Collection<T> readCollection() throws GridPortableException;
+    @Nullable public <T> Collection<T> readCollection() throws PortableException;
 
     /**
      * @param colCls Collection class.
      * @return Collection.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
     @Nullable public <T> Collection<T> readCollection(Class<? extends Collection<T>> colCls)
-        throws GridPortableException;
+        throws PortableException;
 
     /**
      * @return Map.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public <K, V> Map<K, V> readMap() throws GridPortableException;
+    @Nullable public <K, V> Map<K, V> readMap() throws PortableException;
 
     /**
      * @param mapCls Map class.
      * @return Map.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public <K, V> Map<K, V> readMap(Class<? extends Map<K, V>> mapCls) throws GridPortableException;
+    @Nullable public <K, V> Map<K, V> readMap(Class<? extends Map<K, V>> mapCls) throws PortableException;
 
     /**
      * @param enumCls Enum class.
      * @return Value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public <T extends Enum<?>> T readEnum(Class<T> enumCls) throws GridPortableException;
+    @Nullable public <T extends Enum<?>> T readEnum(Class<T> enumCls) throws PortableException;
 
     /**
      * @param enumCls Enum class.
      * @return Value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public <T extends Enum<?>> T[] readEnumArray(Class<T> enumCls) throws GridPortableException;
+    @Nullable public <T extends Enum<?>> T[] readEnumArray(Class<T> enumCls) throws PortableException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawWriter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawWriter.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawWriter.java
index 8127219..6cb0931 100644
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawWriter.java
+++ b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawWriter.java
@@ -23,175 +23,175 @@ import java.util.Date;
 public interface GridPortableRawWriter {
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeByte(byte val) throws GridPortableException;
+    public void writeByte(byte val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeShort(short val) throws GridPortableException;
+    public void writeShort(short val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeInt(int val) throws GridPortableException;
+    public void writeInt(int val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeLong(long val) throws GridPortableException;
+    public void writeLong(long val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeFloat(float val) throws GridPortableException;
+    public void writeFloat(float val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeDouble(double val) throws GridPortableException;
+    public void writeDouble(double val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeChar(char val) throws GridPortableException;
+    public void writeChar(char val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeBoolean(boolean val) throws GridPortableException;
+    public void writeBoolean(boolean val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeString(@Nullable String val) throws GridPortableException;
+    public void writeString(@Nullable String val) throws PortableException;
 
     /**
      * @param val UUID to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeUuid(@Nullable UUID val) throws GridPortableException;
+    public void writeUuid(@Nullable UUID val) throws PortableException;
 
     /**
      * @param val Date to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeDate(@Nullable Date val) throws GridPortableException;
+    public void writeDate(@Nullable Date val) throws PortableException;
 
     /**
      * @param val Timestamp to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeTimestamp(@Nullable Timestamp val) throws GridPortableException;
+    public void writeTimestamp(@Nullable Timestamp val) throws PortableException;
 
     /**
      * @param obj Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeObject(@Nullable Object obj) throws GridPortableException;
+    public void writeObject(@Nullable Object obj) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeByteArray(@Nullable byte[] val) throws GridPortableException;
+    public void writeByteArray(@Nullable byte[] val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeShortArray(@Nullable short[] val) throws GridPortableException;
+    public void writeShortArray(@Nullable short[] val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeIntArray(@Nullable int[] val) throws GridPortableException;
+    public void writeIntArray(@Nullable int[] val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeLongArray(@Nullable long[] val) throws GridPortableException;
+    public void writeLongArray(@Nullable long[] val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeFloatArray(@Nullable float[] val) throws GridPortableException;
+    public void writeFloatArray(@Nullable float[] val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeDoubleArray(@Nullable double[] val) throws GridPortableException;
+    public void writeDoubleArray(@Nullable double[] val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeCharArray(@Nullable char[] val) throws GridPortableException;
+    public void writeCharArray(@Nullable char[] val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeBooleanArray(@Nullable boolean[] val) throws GridPortableException;
+    public void writeBooleanArray(@Nullable boolean[] val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeStringArray(@Nullable String[] val) throws GridPortableException;
+    public void writeStringArray(@Nullable String[] val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeUuidArray(@Nullable UUID[] val) throws GridPortableException;
+    public void writeUuidArray(@Nullable UUID[] val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeDateArray(@Nullable Date[] val) throws GridPortableException;
+    public void writeDateArray(@Nullable Date[] val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writeObjectArray(@Nullable Object[] val) throws GridPortableException;
+    public void writeObjectArray(@Nullable Object[] val) throws PortableException;
 
     /**
      * @param col Collection to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public <T> void writeCollection(@Nullable Collection<T> col) throws GridPortableException;
+    public <T> void writeCollection(@Nullable Collection<T> col) throws PortableException;
 
     /**
      * @param map Map to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public <K, V> void writeMap(@Nullable Map<K, V> map) throws GridPortableException;
+    public <K, V> void writeMap(@Nullable Map<K, V> map) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public <T extends Enum<?>> void writeEnum(T val) throws GridPortableException;
+    public <T extends Enum<?>> void writeEnum(T val) throws PortableException;
 
     /**
      * @param val Value to write.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public <T extends Enum<?>> void writeEnumArray(T[] val) throws GridPortableException;
+    public <T extends Enum<?>> void writeEnumArray(T[] val) throws PortableException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/GridPortableReader.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableReader.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableReader.java
index eb2338d..e244ee7 100644
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableReader.java
+++ b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableReader.java
@@ -16,7 +16,7 @@ import java.util.*;
 import java.util.Date;
 
 /**
- * Reader for portable objects used in {@link GridPortableMarshalAware} implementations.
+ * Reader for portable objects used in {@link PortableMarshalAware} implementations.
  * Useful for the cases when user wants a fine-grained control over serialization.
  * <p>
  * Note that GridGain never writes full strings for field or type names. Instead,
@@ -24,233 +24,233 @@ import java.util.Date;
  * It has been tested that hash code conflicts for the type names or the field names
  * within the same type are virtually non-existent and, to gain performance, it is safe
  * to work with hash codes. For the cases when hash codes for different types or fields
- * actually do collide, GridGain provides {@link GridPortableIdMapper} which
+ * actually do collide, GridGain provides {@link PortableIdMapper} which
  * allows to override the automatically generated hash code IDs for the type and field names.
  */
 public interface GridPortableReader {
     /**
      * @param fieldName Field name.
      * @return Byte value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public byte readByte(String fieldName) throws GridPortableException;
+    public byte readByte(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Short value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public short readShort(String fieldName) throws GridPortableException;
+    public short readShort(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Integer value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public int readInt(String fieldName) throws GridPortableException;
+    public int readInt(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Long value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public long readLong(String fieldName) throws GridPortableException;
+    public long readLong(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      * @return Float value.
      */
-    public float readFloat(String fieldName) throws GridPortableException;
+    public float readFloat(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Double value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public double readDouble(String fieldName) throws GridPortableException;
+    public double readDouble(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Char value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public char readChar(String fieldName) throws GridPortableException;
+    public char readChar(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Boolean value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public boolean readBoolean(String fieldName) throws GridPortableException;
+    public boolean readBoolean(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return String value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public String readString(String fieldName) throws GridPortableException;
+    @Nullable public String readString(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return UUID.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public UUID readUuid(String fieldName) throws GridPortableException;
+    @Nullable public UUID readUuid(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Date.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public Date readDate(String fieldName) throws GridPortableException;
+    @Nullable public Date readDate(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Timestamp.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public Timestamp readTimestamp(String fieldName) throws GridPortableException;
+    @Nullable public Timestamp readTimestamp(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Object.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public <T> T readObject(String fieldName) throws GridPortableException;
+    @Nullable public <T> T readObject(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Byte array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public byte[] readByteArray(String fieldName) throws GridPortableException;
+    @Nullable public byte[] readByteArray(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Short array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public short[] readShortArray(String fieldName) throws GridPortableException;
+    @Nullable public short[] readShortArray(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Integer array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public int[] readIntArray(String fieldName) throws GridPortableException;
+    @Nullable public int[] readIntArray(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Long array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public long[] readLongArray(String fieldName) throws GridPortableException;
+    @Nullable public long[] readLongArray(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Float array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public float[] readFloatArray(String fieldName) throws GridPortableException;
+    @Nullable public float[] readFloatArray(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Byte array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public double[] readDoubleArray(String fieldName) throws GridPortableException;
+    @Nullable public double[] readDoubleArray(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Char array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public char[] readCharArray(String fieldName) throws GridPortableException;
+    @Nullable public char[] readCharArray(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Boolean array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public boolean[] readBooleanArray(String fieldName) throws GridPortableException;
+    @Nullable public boolean[] readBooleanArray(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return String array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public String[] readStringArray(String fieldName) throws GridPortableException;
+    @Nullable public String[] readStringArray(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return UUID array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public UUID[] readUuidArray(String fieldName) throws GridPortableException;
+    @Nullable public UUID[] readUuidArray(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Date array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public Date[] readDateArray(String fieldName) throws GridPortableException;
+    @Nullable public Date[] readDateArray(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Object array.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public Object[] readObjectArray(String fieldName) throws GridPortableException;
+    @Nullable public Object[] readObjectArray(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Collection.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public <T> Collection<T> readCollection(String fieldName) throws GridPortableException;
+    @Nullable public <T> Collection<T> readCollection(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param colCls Collection class.
      * @return Collection.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
     @Nullable public <T> Collection<T> readCollection(String fieldName, Class<? extends Collection<T>> colCls)
-        throws GridPortableException;
+        throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @return Map.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public <K, V> Map<K, V> readMap(String fieldName) throws GridPortableException;
+    @Nullable public <K, V> Map<K, V> readMap(String fieldName) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param mapCls Map class.
      * @return Map.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
     @Nullable public <K, V> Map<K, V> readMap(String fieldName, Class<? extends Map<K, V>> mapCls)
-        throws GridPortableException;
+        throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param enumCls Enum class.
      * @return Value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    @Nullable public <T extends Enum<?>> T readEnum(String fieldName, Class<T> enumCls) throws GridPortableException;
+    @Nullable public <T extends Enum<?>> T readEnum(String fieldName, Class<T> enumCls) throws PortableException;
 
     /**
      * @param fieldName Field name.
      * @param enumCls Enum class.
      * @return Value.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
     @Nullable public <T extends Enum<?>> T[] readEnumArray(String fieldName, Class<T> enumCls)
-        throws GridPortableException;
+        throws PortableException;
 
     /**
      * Gets raw reader. Raw reader does not use field name hash codes, therefore,

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/GridPortableSerializer.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableSerializer.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableSerializer.java
index 1037b49..30932f4 100644
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableSerializer.java
+++ b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableSerializer.java
@@ -11,11 +11,11 @@ package org.apache.ignite.portables;
 
 /**
  * Interface that allows to implement custom serialization logic for portable objects.
- * Can be used instead of {@link GridPortableMarshalAware} in case if the class
+ * Can be used instead of {@link PortableMarshalAware} in case if the class
  * cannot be changed directly.
  * <p>
  * Portable serializer can be configured for all portable objects via
- * {@link GridPortableConfiguration#getSerializer()} method, or for a specific
+ * {@link PortableConfiguration#getSerializer()} method, or for a specific
  * portable type via {@link GridPortableTypeConfiguration#getSerializer()} method.
  */
 public interface GridPortableSerializer {
@@ -24,16 +24,16 @@ public interface GridPortableSerializer {
      *
      * @param obj Empty object.
      * @param writer Portable object writer.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void writePortable(Object obj, GridPortableWriter writer) throws GridPortableException;
+    public void writePortable(Object obj, GridPortableWriter writer) throws PortableException;
 
     /**
      * Reads fields from provided reader.
      *
      * @param obj Empty object
      * @param reader Portable object reader.
-     * @throws GridPortableException In case of error.
+     * @throws PortableException In case of error.
      */
-    public void readPortable(Object obj, GridPortableReader reader) throws GridPortableException;
+    public void readPortable(Object obj, GridPortableReader reader) throws PortableException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/apache/ignite/portables/GridPortableTypeConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableTypeConfiguration.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableTypeConfiguration.java
index 3a362fe..8278544 100644
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableTypeConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableTypeConfiguration.java
@@ -16,19 +16,19 @@ import java.sql.*;
 /**
  * Defines configuration properties for a specific portable type. Providing per-type
  * configuration is optional, as it is generally enough to provide global
- * portable configuration in {@link GridPortableConfiguration} instance. However,
+ * portable configuration in {@link PortableConfiguration} instance. However,
  * this class allows you to change configuration properties for a specific
  * portable type without affecting configuration for other portable types.
  * <p>
  * Per-type portable configuration can be specified in
- * {@link GridPortableConfiguration#getTypeConfigurations()} method.
+ * {@link PortableConfiguration#getTypeConfigurations()} method.
  */
 public class GridPortableTypeConfiguration {
     /** Class name. */
     private String clsName;
 
     /** ID mapper. */
-    private GridPortableIdMapper idMapper;
+    private PortableIdMapper idMapper;
 
     /** Serializer. */
     private GridPortableSerializer serializer;
@@ -81,7 +81,7 @@ public class GridPortableTypeConfiguration {
      *
      * @return ID mapper.
      */
-    public GridPortableIdMapper getIdMapper() {
+    public PortableIdMapper getIdMapper() {
         return idMapper;
     }
 
@@ -90,7 +90,7 @@ public class GridPortableTypeConfiguration {
      *
      * @param idMapper ID mapper.
      */
-    public void setIdMapper(GridPortableIdMapper idMapper) {
+    public void setIdMapper(PortableIdMapper idMapper) {
         this.idMapper = idMapper;
     }
 
@@ -130,7 +130,7 @@ public class GridPortableTypeConfiguration {
 
     /**
      * Defines whether meta data is collected for this type. If provided, this value will override
-     * {@link GridPortableConfiguration#isMetaDataEnabled()} property.
+     * {@link PortableConfiguration#isMetaDataEnabled()} property.
      *
      * @return Whether meta data is collected.
      */
@@ -147,7 +147,7 @@ public class GridPortableTypeConfiguration {
 
     /**
      * Defines whether {@link GridPortableObject} should cache deserialized instance. If provided,
-     * this value will override {@link GridPortableConfiguration#isKeepDeserialized()} property.
+     * this value will override {@link PortableConfiguration#isKeepDeserialized()} property.
      *
      * @return Whether deserialized value is kept.
      */


[38/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
# Renaming


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

Branch: refs/heads/master
Commit: c6781a1c0b42aa1c6a82a20c9bd7562d1d26bd03
Parents: 5068cc6
Author: sboikov <sb...@gridgain.com>
Authored: Fri Dec 5 11:38:16 2014 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Dec 5 11:38:16 2014 +0300

----------------------------------------------------------------------
 .../src/test/resources/spring-server-node.xml   |   4 +-
 .../test/resources/spring-server-ssl-node.xml   |   4 +-
 .../thread/IgniteStripedThreadPoolExecutor.java | 216 +++++++++++++++++
 .../org/apache/ignite/thread/IgniteThread.java  | 100 ++++++++
 .../ignite/thread/IgniteThreadFactory.java      |  53 ++++
 .../ignite/thread/IgniteThreadPoolExecutor.java | 242 +++++++++++++++++++
 .../java/org/apache/ignite/thread/package.html  |  15 ++
 .../sender/store/fs/GridDrSenderHubFsStore.java |   2 +-
 .../org/gridgain/grid/kernal/GridGainEx.java    |   2 +-
 .../discovery/GridDiscoveryManager.java         |   2 +-
 .../cache/GridCacheEvictionManager.java         |   2 +-
 .../GridCachePartitionExchangeManager.java      |   2 +-
 .../processors/cache/GridCacheTtlManager.java   |   2 +-
 .../cache/GridCacheWriteBehindStore.java        |   2 +-
 .../preloader/GridDhtPartitionDemandPool.java   |   2 +-
 .../preloader/GridDhtPartitionSupplyPool.java   |   2 +-
 .../processors/clock/GridClockServer.java       |   2 +-
 .../clock/GridClockSyncProcessor.java           |   2 +-
 .../continuous/GridContinuousProcessor.java     |   2 +-
 .../dataload/GridDataLoaderProcessor.java       |   2 +-
 .../processors/ggfs/GridGgfsDataManager.java    |   2 +-
 .../ggfs/GridGgfsFragmentizerManager.java       |   2 +-
 .../kernal/processors/ggfs/GridGgfsServer.java  |   2 +-
 .../processors/ggfs/GridGgfsServerManager.java  |   2 +-
 .../service/GridServiceProcessor.java           |   2 +-
 .../processors/streamer/IgniteStreamerImpl.java |   2 +-
 .../timeout/GridTimeoutProcessor.java           |   2 +-
 .../tcp/GridTcpCommunicationSpi.java            |   2 +-
 .../thread/IgniteStripedThreadPoolExecutor.java | 216 -----------------
 .../org/gridgain/grid/thread/IgniteThread.java  | 100 --------
 .../grid/thread/IgniteThreadFactory.java        |  53 ----
 .../grid/thread/IgniteThreadPoolExecutor.java   | 242 -------------------
 .../java/org/gridgain/grid/thread/package.html  |  15 --
 .../GridIpcSharedMemoryServerEndpoint.java      |   2 +-
 .../util/nio/GridNioBackPressureControl.java    |   2 +-
 .../gridgain/grid/util/nio/GridNioServer.java   |   2 +-
 .../src/test/config/job-loadtest/client.xml     |   6 +-
 .../src/test/config/job-loadtest/server.xml     |   2 +-
 modules/core/src/test/config/jobs-load-base.xml |   4 +-
 .../core/src/test/config/load/dsi-load-base.xml |   4 +-
 .../src/test/config/load/merge-sort-base.xml    |   6 +-
 .../test/config/load/mongo-multinode-foster.xml |   2 +-
 .../core/src/test/config/spring-multicache.xml  |   6 +-
 .../GridCachePreloadLifecycleAbstractTest.java  |   2 +-
 .../marshaller/GridMarshallerResourceBean.java  |   2 +-
 .../GridThreadPoolExecutorServiceSelfTest.java  |   1 +
 .../gridgain/grid/thread/GridThreadTest.java    |   3 +-
 .../cache/GridCacheSingleNodeLoadTest.java      |   2 +-
 .../loadtests/colocation/GridTestMain.java      |   2 +-
 .../loadtests/colocation/spring-colocation.xml  |   4 +-
 ...ridSingleSplitsNewNodesAbstractLoadTest.java |   2 +-
 .../testframework/junits/GridTestResources.java |   2 +-
 .../processors/email/GridEmailProcessor.java    |   2 +-
 .../hadoop/shuffle/GridHadoopShuffleJob.java    |   2 +-
 .../taskexecutor/GridHadoopExecutorService.java |   2 +-
 .../GridHadoopExternalCommunication.java        |   2 +-
 .../main/scala/org/gridgain/visor/visor.scala   |   1 +
 57 files changed, 685 insertions(+), 682 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/clients/src/test/resources/spring-server-node.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-server-node.xml b/modules/clients/src/test/resources/spring-server-node.xml
index 2fb48ae..a9c05f4 100644
--- a/modules/clients/src/test/resources/spring-server-node.xml
+++ b/modules/clients/src/test/resources/spring-server-node.xml
@@ -319,7 +319,7 @@
             possible started nodes count in one VM.
         -->
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg value="SERVER"/>
                 <constructor-arg type="int" value="15"/>
                 <constructor-arg type="int" value="15"/>
@@ -335,7 +335,7 @@
         <property name="executorServiceShutdown" value="true"/>
 
         <property name="systemExecutorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg value="SYS-SERVER"/>
                 <constructor-arg type="int" value="15"/>
                 <constructor-arg type="int" value="15"/>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/clients/src/test/resources/spring-server-ssl-node.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-server-ssl-node.xml b/modules/clients/src/test/resources/spring-server-ssl-node.xml
index af9421c..3c0a688 100644
--- a/modules/clients/src/test/resources/spring-server-ssl-node.xml
+++ b/modules/clients/src/test/resources/spring-server-ssl-node.xml
@@ -286,7 +286,7 @@
             possible started nodes count in one VM.
         -->
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg value="SERVER"/>
                 <constructor-arg type="int" value="15"/>
                 <constructor-arg type="int" value="15"/>
@@ -302,7 +302,7 @@
         <property name="executorServiceShutdown" value="true"/>
 
         <property name="systemExecutorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg value="SYS-SERVER"/>
                 <constructor-arg type="int" value="15"/>
                 <constructor-arg type="int" value="15"/>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/apache/ignite/thread/IgniteStripedThreadPoolExecutor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/thread/IgniteStripedThreadPoolExecutor.java b/modules/core/src/main/java/org/apache/ignite/thread/IgniteStripedThreadPoolExecutor.java
new file mode 100644
index 0000000..fc52c65
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/thread/IgniteStripedThreadPoolExecutor.java
@@ -0,0 +1,216 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.thread;
+
+import org.gridgain.grid.util.typedef.internal.*;
+
+import java.util.*;
+import java.util.concurrent.*;
+
+/**
+ * An {@link ExecutorService} that executes submitted tasks using pooled grid threads.
+ */
+public class IgniteStripedThreadPoolExecutor implements ExecutorService {
+    /** */
+    public static final int DFLT_SEG_POOL_SIZE = 8;
+
+    /** */
+    public static final int DFLT_CONCUR_LVL = 16;
+
+    /** */
+    private final ExecutorService[] execs;
+
+    /** */
+    private final int segShift;
+
+    /** */
+    private final int segMask;
+
+    /**
+     *
+     */
+    public IgniteStripedThreadPoolExecutor() {
+        execs = new ExecutorService[DFLT_CONCUR_LVL];
+
+        ThreadFactory factory = new IgniteThreadFactory(null);
+
+        for (int i = 0; i < DFLT_CONCUR_LVL; i++)
+            execs[i] = Executors.newFixedThreadPool(DFLT_SEG_POOL_SIZE, factory);
+
+        // Find power-of-two sizes best matching arguments
+        int sshift = 0;
+        int ssize = 1;
+
+        while (ssize < DFLT_CONCUR_LVL) {
+            ++sshift;
+
+            ssize <<= 1;
+        }
+
+        segShift = 32 - sshift;
+        segMask = ssize - 1;
+
+    }
+
+    /** {@inheritDoc} */
+    @Override public void shutdown() {
+        for (ExecutorService exec : execs)
+            exec.shutdown();
+    }
+
+    /** {@inheritDoc} */
+    @Override public List<Runnable> shutdownNow() {
+        List<Runnable> res = new LinkedList<>();
+
+        for (ExecutorService exec : execs) {
+            for (Runnable r : exec.shutdownNow())
+                res.add(r);
+        }
+
+        return res;
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean isShutdown() {
+        for (ExecutorService exec : execs) {
+            if (!exec.isShutdown())
+                return false;
+        }
+
+        return true;
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean isTerminated() {
+        for (ExecutorService exec : execs) {
+            if (!exec.isTerminated())
+                return false;
+        }
+
+        return true;
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean awaitTermination(long timeout, TimeUnit unit) throws InterruptedException {
+        boolean res = true;
+
+        for (ExecutorService exec : execs)
+            res &= exec.awaitTermination(timeout, unit);
+
+        return res;
+    }
+
+    /** {@inheritDoc} */
+    @Override public <T> Future<T> submit(Callable<T> task) {
+        return execForTask(task).submit(task);
+    }
+
+    /** {@inheritDoc} */
+    @Override public <T> Future<T> submit(Runnable task, T result) {
+        return execForTask(task).submit(task, result);
+    }
+
+    /** {@inheritDoc} */
+    @Override public Future<?> submit(Runnable task) {
+        return execForTask(task).submit(task);
+    }
+
+    /** {@inheritDoc} */
+    @Override public <T> List<Future<T>> invokeAll(Collection<? extends Callable<T>> tasks)
+        throws InterruptedException {
+        List<Future<T>> futs = new LinkedList<>();
+
+        for (Callable<T> task : tasks)
+            futs.add(execForTask(task).submit(task));
+
+        boolean done = false;
+
+        try {
+            for (Future<T> fut : futs) {
+                try {
+                    fut.get();
+                }
+                catch (ExecutionException | InterruptedException ignored) {
+                    // No-op.
+                }
+            }
+
+            done = true;
+
+            return futs;
+        }
+        finally {
+            if (!done) {
+                for (Future<T> fut : futs)
+                    fut.cancel(true);
+            }
+        }
+    }
+
+    /** {@inheritDoc} */
+    @Override public <T> List<Future<T>> invokeAll(Collection<? extends Callable<T>> tasks, long timeout,
+        TimeUnit unit) throws InterruptedException {
+        throw new RuntimeException("Not implemented.");
+    }
+
+    /** {@inheritDoc} */
+    @Override public <T> T invokeAny(Collection<? extends Callable<T>> tasks) throws InterruptedException,
+        ExecutionException {
+        throw new RuntimeException("Not implemented.");
+    }
+
+    /** {@inheritDoc} */
+    @Override public <T> T invokeAny(Collection<? extends Callable<T>> tasks, long timeout, TimeUnit unit)
+        throws InterruptedException, ExecutionException, TimeoutException {
+        throw new RuntimeException("Not implemented.");
+    }
+
+    /** {@inheritDoc} */
+    @Override public void execute(Runnable cmd) {
+        execForTask(cmd).execute(cmd);
+    }
+
+    /**
+     * Applies a supplemental hash function to a given hashCode, which
+     * defends against poor quality hash functions.  This is critical
+     * because ConcurrentHashMap uses power-of-two length hash tables,
+     * that otherwise encounter collisions for hashCodes that do not
+     * differ in lower or upper bits.
+     *
+     * @param h Hash code.
+     * @return Enhanced hash code.
+     */
+    private int hash(int h) {
+        // Spread bits to regularize both segment and index locations,
+        // using variant of single-word Wang/Jenkins hash.
+        h += (h <<  15) ^ 0xffffcd7d;
+        h ^= (h >>> 10);
+        h += (h <<   3);
+        h ^= (h >>>  6);
+        h += (h <<   2) + (h << 14);
+        return h ^ (h >>> 16);
+    }
+
+    /**
+     * @param cmd Command.
+     * @return Service.
+     */
+    private <T> ExecutorService execForTask(T cmd) {
+        assert cmd != null;
+
+        //return execs[ThreadLocalRandom8.current().nextInt(DFLT_CONCUR_LVL)];
+        return execs[(hash(cmd.hashCode()) >>> segShift) & segMask];
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteStripedThreadPoolExecutor.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/apache/ignite/thread/IgniteThread.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/thread/IgniteThread.java b/modules/core/src/main/java/org/apache/ignite/thread/IgniteThread.java
new file mode 100644
index 0000000..772f798
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/thread/IgniteThread.java
@@ -0,0 +1,100 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.thread;
+
+import org.gridgain.grid.util.typedef.internal.*;
+import org.gridgain.grid.util.worker.*;
+
+import java.util.concurrent.atomic.*;
+
+/**
+ * This class adds some necessary plumbing on top of the {@link Thread} class.
+ * Specifically, it adds:
+ * <ul>
+ *      <li>Consistent naming of threads</li>
+ *      <li>Dedicated parent thread group</li>
+ *      <li>Backing interrupted flag</li>
+ * </ul>
+ * <b>Note</b>: this class is intended for internal use only.
+ */
+public class IgniteThread extends Thread {
+    /** Default thread's group. */
+    private static final ThreadGroup DFLT_GRP = new ThreadGroup("gridgain");
+
+    /** Number of all grid threads in the system. */
+    private static final AtomicLong threadCntr = new AtomicLong(0);
+
+    /** Boolean flag indicating of this thread is currently processing message. */
+    private boolean procMsg;
+
+    /**
+     * Creates thread with given worker.
+     *
+     * @param worker Runnable to create thread with.
+     */
+    public IgniteThread(GridWorker worker) {
+        this(DFLT_GRP, worker.gridName(), worker.name(), worker);
+    }
+
+    /**
+     * Creates grid thread with given name for a given grid.
+     *
+     * @param gridName Name of grid this thread is created for.
+     * @param threadName Name of thread.
+     * @param r Runnable to execute.
+     */
+    public IgniteThread(String gridName, String threadName, Runnable r) {
+        this(DFLT_GRP, gridName, threadName, r);
+    }
+
+    /**
+     * Creates grid thread with given name for a given grid with specified
+     * thread group.
+     *
+     * @param grp Thread group.
+     * @param gridName Name of grid this thread is created for.
+     * @param threadName Name of thread.
+     * @param r Runnable to execute.
+     */
+    public IgniteThread(ThreadGroup grp, String gridName, String threadName, Runnable r) {
+        super(grp, r, createName(threadCntr.incrementAndGet(), threadName, gridName));
+    }
+
+    /**
+     * Creates new thread name.
+     *
+     * @param num Thread number.
+     * @param threadName Thread name.
+     * @param gridName Grid name.
+     * @return New thread name.
+     */
+    private static String createName(long num, String threadName, String gridName) {
+        return threadName + "-#" + num + '%' + gridName + '%';
+    }
+
+    /**
+     * @param procMsg Flag indicating whether thread is currently processing message.
+     */
+    public void processingMessage(boolean procMsg) {
+        this.procMsg = procMsg;
+    }
+
+    /**
+     * @return Flag indicating whether thread is currently processing message.
+     */
+    public boolean processingMessage() {
+        return procMsg;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteThread.class, this, "name", getName());
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/apache/ignite/thread/IgniteThreadFactory.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/thread/IgniteThreadFactory.java b/modules/core/src/main/java/org/apache/ignite/thread/IgniteThreadFactory.java
new file mode 100644
index 0000000..4d3ec6f
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/thread/IgniteThreadFactory.java
@@ -0,0 +1,53 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.thread;
+
+import org.jetbrains.annotations.*;
+
+import java.util.concurrent.*;
+
+/**
+ * This class provides implementation of {@link ThreadFactory} factory
+ * for creating grid threads.
+ */
+public class IgniteThreadFactory implements ThreadFactory {
+    /** Grid name. */
+    private final String gridName;
+
+    /** Thread name. */
+    private final String threadName;
+
+    /**
+     * Constructs new thread factory for given grid. All threads will belong
+     * to the same default thread group.
+     *
+     * @param gridName Grid name.
+     */
+    public IgniteThreadFactory(String gridName) {
+        this(gridName, "gridgain");
+    }
+
+    /**
+     * Constructs new thread factory for given grid. All threads will belong
+     * to the same default thread group.
+     *
+     * @param gridName Grid name.
+     * @param threadName Thread name.
+     */
+    public IgniteThreadFactory(String gridName, String threadName) {
+        this.gridName = gridName;
+        this.threadName = threadName;
+    }
+
+    /** {@inheritDoc} */
+    @Override public Thread newThread(@NotNull Runnable r) {
+        return new IgniteThread(gridName, threadName, r);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/apache/ignite/thread/IgniteThreadPoolExecutor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/thread/IgniteThreadPoolExecutor.java b/modules/core/src/main/java/org/apache/ignite/thread/IgniteThreadPoolExecutor.java
new file mode 100644
index 0000000..e3563bb
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/thread/IgniteThreadPoolExecutor.java
@@ -0,0 +1,242 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.thread;
+
+import org.jetbrains.annotations.*;
+
+import java.util.concurrent.*;
+
+/**
+ * An {@link ExecutorService} that executes submitted tasks using pooled grid threads.
+ */
+public class IgniteThreadPoolExecutor extends ThreadPoolExecutor {
+    /** Default core pool size (value is {@code 100}). */
+    public static final int DFLT_CORE_POOL_SIZE = 100;
+
+    /**
+     * Creates a new service with default initial parameters.
+     * Default values are:
+     * <table class="doctable">
+     * <tr>
+     *      <th>Name</th>
+     *      <th>Default Value</th>
+     * </tr>
+     * <tr>
+     *      <td>Core Pool Size</td>
+     *      <td>{@code 100} (see {@link #DFLT_CORE_POOL_SIZE}).</td>
+     * </tr>
+     * <tr>
+     *      <td>Maximum Pool Size</td>
+     *      <td>None, is it is not used for unbounded queues.</td>
+     * </tr>
+     * <tr>
+     *      <td>Keep alive time</td>
+     *      <td>No limit (see {@link Long#MAX_VALUE}).</td>
+     * </tr>
+     * <tr>
+     *      <td>Blocking Queue (see {@link BlockingQueue}).</td>
+     *      <td>Unbounded linked blocking queue (see {@link LinkedBlockingDeque}).</td>
+     * </tr>
+     * </table>
+     */
+    public IgniteThreadPoolExecutor() {
+        this(
+            DFLT_CORE_POOL_SIZE,
+            DFLT_CORE_POOL_SIZE,
+            0,
+            new LinkedBlockingDeque<Runnable>(),
+            new IgniteThreadFactory(null),
+            null
+        );
+    }
+
+    /**
+     * Creates a new service with the given initial parameters.
+     *
+     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
+     * @param maxPoolSize The maximum number of threads to allow in the pool.
+     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
+     *      that excess idle threads will wait for new tasks before terminating.
+     * @param workQueue The queue to use for holding tasks before they are executed. This queue will hold only
+     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
+     */
+    public IgniteThreadPoolExecutor(
+        int corePoolSize,
+        int maxPoolSize,
+        long keepAliveTime,
+        BlockingQueue<Runnable> workQueue) {
+        this(
+            corePoolSize,
+            maxPoolSize,
+            keepAliveTime,
+            workQueue,
+            new IgniteThreadFactory(null),
+            null
+        );
+    }
+
+    /**
+     * Creates a new service with the given initial parameters.
+     *
+     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
+     * @param maxPoolSize The maximum number of threads to allow in the pool.
+     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
+     *      that excess idle threads will wait for new tasks before terminating.
+     * @param workQ The queue to use for holding tasks before they are executed. This queue will hold only the
+     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
+     * @param hnd Optional handler to use when execution is blocked because the thread bounds and queue
+     *      capacities are reached. If {@code null} then {@code AbortPolicy}
+     *      handler is used by default.
+     */
+    public IgniteThreadPoolExecutor(
+        int corePoolSize,
+        int maxPoolSize,
+        long keepAliveTime,
+        BlockingQueue<Runnable> workQ,
+        RejectedExecutionHandler hnd) {
+        this(
+            corePoolSize,
+            maxPoolSize,
+            keepAliveTime,
+            workQ,
+            new IgniteThreadFactory(null),
+            hnd
+        );
+    }
+
+    /**
+     * Creates a new service with default initial parameters.
+     * Default values are:
+     * <table class="doctable">
+     * <tr>
+     *      <th>Name</th>
+     *      <th>Default Value</th>
+     * </tr>
+     * <tr>
+     *      <td>Core Pool Size</td>
+     *      <td>{@code 100} (see {@link #DFLT_CORE_POOL_SIZE}).</td>
+     * </tr>
+     * <tr>
+     *      <td>Maximum Pool Size</td>
+     *      <td>None, is it is not used for unbounded queues.</td>
+     * </tr>
+     * <tr>
+     *      <td>Keep alive time</td>
+     *      <td>No limit (see {@link Long#MAX_VALUE}).</td>
+     * </tr>
+     * <tr>
+     *      <td>Blocking Queue (see {@link BlockingQueue}).</td>
+     *      <td>Unbounded linked blocking queue (see {@link LinkedBlockingDeque}).</td>
+     * </tr>
+     * </table>
+     *
+     * @param gridName Name of the grid.
+     */
+    public IgniteThreadPoolExecutor(String gridName) {
+        this(
+            DFLT_CORE_POOL_SIZE,
+            DFLT_CORE_POOL_SIZE,
+            0,
+            new LinkedBlockingDeque<Runnable>(),
+            new IgniteThreadFactory(gridName),
+            null
+        );
+    }
+
+    /**
+     * Creates a new service with the given initial parameters.
+     *
+     * @param gridName Name of the grid
+     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
+     * @param maxPoolSize The maximum number of threads to allow in the pool.
+     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
+     *      that excess idle threads will wait for new tasks before terminating.
+     * @param workQ The queue to use for holding tasks before they are executed. This queue will hold only
+     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
+     */
+    public IgniteThreadPoolExecutor(
+        String gridName,
+        int corePoolSize,
+        int maxPoolSize,
+        long keepAliveTime,
+        BlockingQueue<Runnable> workQ) {
+        super(
+            corePoolSize,
+            maxPoolSize,
+            keepAliveTime,
+            TimeUnit.MILLISECONDS,
+            workQ,
+            new IgniteThreadFactory(gridName)
+        );
+    }
+
+    /**
+     * Creates a new service with the given initial parameters.
+     *
+     * @param gridName Name of the grid.
+     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
+     * @param maxPoolSize The maximum number of threads to allow in the pool.
+     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
+     *      that excess idle threads will wait for new tasks before terminating.
+     * @param workQ The queue to use for holding tasks before they are executed. This queue will hold only the
+     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
+     * @param hnd Optional handler to use when execution is blocked because the thread bounds and queue
+     *      capacities are reached. If {@code null} then {@code AbortPolicy}
+     *      handler is used by default.
+     */
+    public IgniteThreadPoolExecutor(
+        String gridName,
+        int corePoolSize,
+        int maxPoolSize,
+        long keepAliveTime,
+        BlockingQueue<Runnable> workQ,
+        RejectedExecutionHandler hnd) {
+        this(
+            corePoolSize,
+            maxPoolSize,
+            keepAliveTime,
+            workQ,
+            new IgniteThreadFactory(gridName),
+            hnd
+        );
+    }
+
+    /**
+     * Creates a new service with the given initial parameters.
+     *
+     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
+     * @param maxPoolSize The maximum number of threads to allow in the pool.
+     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
+     *      that excess idle threads will wait for new tasks before terminating.
+     * @param workQ The queue to use for holding tasks before they are executed. This queue will hold only the
+     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
+     * @param threadFactory Thread factory.
+     * @param hnd Optional handler to use when execution is blocked because the thread bounds and queue
+     *      capacities are reached. If {@code null} then {@code AbortPolicy}
+     *      handler is used by default.
+     */
+    public IgniteThreadPoolExecutor(
+        int corePoolSize,
+        int maxPoolSize,
+        long keepAliveTime,
+        BlockingQueue<Runnable> workQ,
+        ThreadFactory threadFactory,
+        @Nullable RejectedExecutionHandler hnd) {
+        super(
+            corePoolSize,
+            maxPoolSize,
+            keepAliveTime,
+            TimeUnit.MILLISECONDS,
+            workQ,
+            threadFactory,
+            hnd == null ? new AbortPolicy() : hnd
+        );
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/apache/ignite/thread/package.html
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/thread/package.html b/modules/core/src/main/java/org/apache/ignite/thread/package.html
new file mode 100644
index 0000000..e17f6f0
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/thread/package.html
@@ -0,0 +1,15 @@
+<!DOCTYPE html PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+    @html.file.header
+    _________        _____ __________________        _____
+    __  ____/___________(_)______  /__  ____/______ ____(_)_______
+    _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+    / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+    \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+-->
+<html>
+<body>
+    <!-- Package description. -->
+    Contains threads-related utility classes.
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/dr/hub/sender/store/fs/GridDrSenderHubFsStore.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/dr/hub/sender/store/fs/GridDrSenderHubFsStore.java b/modules/core/src/main/java/org/gridgain/grid/dr/hub/sender/store/fs/GridDrSenderHubFsStore.java
index 38ee4ad..c2f04c2 100644
--- a/modules/core/src/main/java/org/gridgain/grid/dr/hub/sender/store/fs/GridDrSenderHubFsStore.java
+++ b/modules/core/src/main/java/org/gridgain/grid/dr/hub/sender/store/fs/GridDrSenderHubFsStore.java
@@ -12,9 +12,9 @@ package org.gridgain.grid.dr.hub.sender.store.fs;
 import org.apache.ignite.*;
 import org.apache.ignite.lifecycle.*;
 import org.apache.ignite.resources.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.dr.hub.sender.store.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.tostring.*;
 import org.gridgain.grid.util.typedef.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java b/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java
index 0515da4..95a4254 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java
@@ -19,6 +19,7 @@ import org.apache.ignite.marshaller.*;
 import org.apache.ignite.marshaller.jdk.*;
 import org.apache.ignite.marshaller.optimized.*;
 import org.apache.ignite.mbean.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.cache.affinity.rendezvous.*;
@@ -53,7 +54,6 @@ import org.gridgain.grid.spi.swapspace.*;
 import org.gridgain.grid.spi.swapspace.file.*;
 import org.gridgain.grid.spi.swapspace.noop.*;
 import org.gridgain.grid.streamer.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/managers/discovery/GridDiscoveryManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/managers/discovery/GridDiscoveryManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/managers/discovery/GridDiscoveryManager.java
index 74ae650..6771468 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/managers/discovery/GridDiscoveryManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/managers/discovery/GridDiscoveryManager.java
@@ -14,6 +14,7 @@ import org.apache.ignite.events.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.plugin.extensions.discovery.*;
 import org.apache.ignite.product.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.managers.*;
@@ -27,7 +28,6 @@ import org.gridgain.grid.security.*;
 import org.gridgain.grid.segmentation.*;
 import org.gridgain.grid.spi.*;
 import org.gridgain.grid.spi.discovery.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.future.*;
 import org.gridgain.grid.util.lang.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheEvictionManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheEvictionManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheEvictionManager.java
index b44bccf..0ace1a8 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheEvictionManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheEvictionManager.java
@@ -12,6 +12,7 @@ package org.gridgain.grid.kernal.processors.cache;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.events.*;
 import org.apache.ignite.lang.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.cache.eviction.*;
@@ -19,7 +20,6 @@ import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.managers.eventstorage.*;
 import org.gridgain.grid.kernal.processors.cache.distributed.dht.*;
 import org.gridgain.grid.kernal.processors.timeout.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.future.*;
 import org.gridgain.grid.util.lang.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCachePartitionExchangeManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCachePartitionExchangeManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCachePartitionExchangeManager.java
index e56ca45..5dc2c3c 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCachePartitionExchangeManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCachePartitionExchangeManager.java
@@ -12,12 +12,12 @@ package org.gridgain.grid.kernal.processors.cache;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.events.*;
 import org.apache.ignite.lang.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.managers.eventstorage.*;
 import org.gridgain.grid.kernal.processors.cache.distributed.dht.*;
 import org.gridgain.grid.kernal.processors.cache.distributed.dht.preloader.*;
 import org.gridgain.grid.kernal.processors.timeout.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.future.*;
 import org.gridgain.grid.util.tostring.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTtlManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTtlManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTtlManager.java
index 827665c..3e7e6ef 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTtlManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTtlManager.java
@@ -9,9 +9,9 @@
 
 package org.gridgain.grid.kernal.processors.cache;
 
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheWriteBehindStore.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheWriteBehindStore.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheWriteBehindStore.java
index a8b2ffc..b39d725 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheWriteBehindStore.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheWriteBehindStore.java
@@ -12,12 +12,12 @@ package org.gridgain.grid.kernal.processors.cache;
 import org.apache.ignite.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.lifecycle.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.cache.store.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.processors.interop.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.gridgain.grid.util.tostring.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
index 6c2e31f..5e3a3d3 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
@@ -13,12 +13,12 @@ import org.apache.ignite.*;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.events.*;
 import org.apache.ignite.lang.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.kernal.processors.cache.*;
 import org.gridgain.grid.kernal.processors.cache.distributed.dht.*;
 import org.gridgain.grid.kernal.processors.timeout.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.future.*;
 import org.gridgain.grid.util.tostring.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionSupplyPool.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionSupplyPool.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionSupplyPool.java
index bbba8b2..e605b0c 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionSupplyPool.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionSupplyPool.java
@@ -12,11 +12,11 @@ package org.gridgain.grid.kernal.processors.cache.distributed.dht.preloader;
 import org.apache.ignite.*;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.lang.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.managers.deployment.*;
 import org.gridgain.grid.kernal.processors.cache.*;
 import org.gridgain.grid.kernal.processors.cache.distributed.dht.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.lang.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockServer.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockServer.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockServer.java
index 5d17e7f..ce30919 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockServer.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockServer.java
@@ -10,9 +10,9 @@
 package org.gridgain.grid.kernal.processors.clock;
 
 import org.apache.ignite.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.gridgain.grid.util.worker.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockSyncProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockSyncProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockSyncProcessor.java
index 38720c9..e12691f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockSyncProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockSyncProcessor.java
@@ -11,13 +11,13 @@ package org.gridgain.grid.kernal.processors.clock;
 
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.events.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.managers.communication.*;
 import org.gridgain.grid.kernal.managers.discovery.*;
 import org.gridgain.grid.kernal.managers.eventstorage.*;
 import org.gridgain.grid.kernal.processors.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.worker.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/continuous/GridContinuousProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/continuous/GridContinuousProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/continuous/GridContinuousProcessor.java
index 969b34d..83beb7f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/continuous/GridContinuousProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/continuous/GridContinuousProcessor.java
@@ -13,6 +13,7 @@ import org.apache.ignite.cluster.*;
 import org.apache.ignite.events.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.marshaller.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.managers.communication.*;
@@ -20,7 +21,6 @@ import org.gridgain.grid.kernal.managers.deployment.*;
 import org.gridgain.grid.kernal.managers.eventstorage.*;
 import org.gridgain.grid.kernal.processors.*;
 import org.gridgain.grid.kernal.processors.timeout.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.future.*;
 import org.gridgain.grid.util.tostring.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderProcessor.java
index fb65bb8..9c5372f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderProcessor.java
@@ -13,12 +13,12 @@ import org.apache.ignite.*;
 import org.apache.ignite.dataload.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.marshaller.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.managers.communication.*;
 import org.gridgain.grid.kernal.managers.deployment.*;
 import org.gridgain.grid.kernal.processors.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.gridgain.grid.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
index bd70a69..19b5c4e 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
@@ -14,6 +14,7 @@ import org.apache.ignite.cluster.*;
 import org.apache.ignite.events.*;
 import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.cache.affinity.*;
@@ -23,7 +24,6 @@ import org.gridgain.grid.kernal.managers.eventstorage.*;
 import org.gridgain.grid.kernal.processors.cache.*;
 import org.gridgain.grid.kernal.processors.dataload.*;
 import org.gridgain.grid.kernal.processors.task.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.future.*;
 import org.gridgain.grid.util.lang.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFragmentizerManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFragmentizerManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFragmentizerManager.java
index 11c53d6..e2c7d11 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFragmentizerManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFragmentizerManager.java
@@ -12,10 +12,10 @@ package org.gridgain.grid.kernal.processors.ggfs;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.events.*;
 import org.apache.ignite.lang.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.managers.communication.*;
 import org.gridgain.grid.kernal.managers.eventstorage.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.gridgain.grid.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServer.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServer.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServer.java
index 03ba200..99bd0ea 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServer.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServer.java
@@ -11,9 +11,9 @@ package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.*;
 import org.apache.ignite.lang.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.ggfs.common.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.gridgain.grid.util.ipc.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java
index 1dc8b19..9cfa972 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java
@@ -11,8 +11,8 @@ package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.gridgain.grid.util.ipc.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessor.java
index 8cbae3f..cb4d0b0 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessor.java
@@ -15,6 +15,7 @@ import org.apache.ignite.events.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.managed.*;
 import org.apache.ignite.marshaller.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.cache.query.GridCacheContinuousQueryEntry;
@@ -24,7 +25,6 @@ import org.gridgain.grid.kernal.processors.*;
 import org.gridgain.grid.kernal.processors.cache.*;
 import org.gridgain.grid.kernal.processors.cache.query.continuous.*;
 import org.gridgain.grid.kernal.processors.timeout.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.future.*;
 import org.gridgain.grid.util.typedef.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerImpl.java
index 8ee317f..bde0c6f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerImpl.java
@@ -12,6 +12,7 @@ package org.gridgain.grid.kernal.processors.streamer;
 import org.apache.ignite.*;
 import org.apache.ignite.events.*;
 import org.apache.ignite.lang.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.managers.communication.*;
@@ -19,7 +20,6 @@ import org.gridgain.grid.kernal.managers.deployment.*;
 import org.gridgain.grid.kernal.managers.eventstorage.*;
 import org.gridgain.grid.streamer.*;
 import org.gridgain.grid.streamer.router.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.direct.*;
 import org.gridgain.grid.util.future.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/timeout/GridTimeoutProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/timeout/GridTimeoutProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/timeout/GridTimeoutProcessor.java
index 79ee81a..c4d0015 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/timeout/GridTimeoutProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/timeout/GridTimeoutProcessor.java
@@ -9,10 +9,10 @@
 
 package org.gridgain.grid.kernal.processors.timeout;
 
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.processors.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/spi/communication/tcp/GridTcpCommunicationSpi.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/spi/communication/tcp/GridTcpCommunicationSpi.java b/modules/core/src/main/java/org/gridgain/grid/spi/communication/tcp/GridTcpCommunicationSpi.java
index 0fd2328..feb41c4 100644
--- a/modules/core/src/main/java/org/gridgain/grid/spi/communication/tcp/GridTcpCommunicationSpi.java
+++ b/modules/core/src/main/java/org/gridgain/grid/spi/communication/tcp/GridTcpCommunicationSpi.java
@@ -16,11 +16,11 @@ import org.apache.ignite.lang.*;
 import org.apache.ignite.marshaller.*;
 import org.apache.ignite.product.*;
 import org.apache.ignite.resources.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.managers.eventstorage.*;
 import org.gridgain.grid.spi.*;
 import org.gridgain.grid.spi.communication.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.direct.*;
 import org.gridgain.grid.util.ipc.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/thread/IgniteStripedThreadPoolExecutor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/thread/IgniteStripedThreadPoolExecutor.java b/modules/core/src/main/java/org/gridgain/grid/thread/IgniteStripedThreadPoolExecutor.java
deleted file mode 100644
index dcd7094..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/thread/IgniteStripedThreadPoolExecutor.java
+++ /dev/null
@@ -1,216 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.thread;
-
-import org.gridgain.grid.util.typedef.internal.*;
-
-import java.util.*;
-import java.util.concurrent.*;
-
-/**
- * An {@link ExecutorService} that executes submitted tasks using pooled grid threads.
- */
-public class IgniteStripedThreadPoolExecutor implements ExecutorService {
-    /** */
-    public static final int DFLT_SEG_POOL_SIZE = 8;
-
-    /** */
-    public static final int DFLT_CONCUR_LVL = 16;
-
-    /** */
-    private final ExecutorService[] execs;
-
-    /** */
-    private final int segShift;
-
-    /** */
-    private final int segMask;
-
-    /**
-     *
-     */
-    public IgniteStripedThreadPoolExecutor() {
-        execs = new ExecutorService[DFLT_CONCUR_LVL];
-
-        ThreadFactory factory = new IgniteThreadFactory(null);
-
-        for (int i = 0; i < DFLT_CONCUR_LVL; i++)
-            execs[i] = Executors.newFixedThreadPool(DFLT_SEG_POOL_SIZE, factory);
-
-        // Find power-of-two sizes best matching arguments
-        int sshift = 0;
-        int ssize = 1;
-
-        while (ssize < DFLT_CONCUR_LVL) {
-            ++sshift;
-
-            ssize <<= 1;
-        }
-
-        segShift = 32 - sshift;
-        segMask = ssize - 1;
-
-    }
-
-    /** {@inheritDoc} */
-    @Override public void shutdown() {
-        for (ExecutorService exec : execs)
-            exec.shutdown();
-    }
-
-    /** {@inheritDoc} */
-    @Override public List<Runnable> shutdownNow() {
-        List<Runnable> res = new LinkedList<>();
-
-        for (ExecutorService exec : execs) {
-            for (Runnable r : exec.shutdownNow())
-                res.add(r);
-        }
-
-        return res;
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean isShutdown() {
-        for (ExecutorService exec : execs) {
-            if (!exec.isShutdown())
-                return false;
-        }
-
-        return true;
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean isTerminated() {
-        for (ExecutorService exec : execs) {
-            if (!exec.isTerminated())
-                return false;
-        }
-
-        return true;
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean awaitTermination(long timeout, TimeUnit unit) throws InterruptedException {
-        boolean res = true;
-
-        for (ExecutorService exec : execs)
-            res &= exec.awaitTermination(timeout, unit);
-
-        return res;
-    }
-
-    /** {@inheritDoc} */
-    @Override public <T> Future<T> submit(Callable<T> task) {
-        return execForTask(task).submit(task);
-    }
-
-    /** {@inheritDoc} */
-    @Override public <T> Future<T> submit(Runnable task, T result) {
-        return execForTask(task).submit(task, result);
-    }
-
-    /** {@inheritDoc} */
-    @Override public Future<?> submit(Runnable task) {
-        return execForTask(task).submit(task);
-    }
-
-    /** {@inheritDoc} */
-    @Override public <T> List<Future<T>> invokeAll(Collection<? extends Callable<T>> tasks)
-        throws InterruptedException {
-        List<Future<T>> futs = new LinkedList<>();
-
-        for (Callable<T> task : tasks)
-            futs.add(execForTask(task).submit(task));
-
-        boolean done = false;
-
-        try {
-            for (Future<T> fut : futs) {
-                try {
-                    fut.get();
-                }
-                catch (ExecutionException | InterruptedException ignored) {
-                    // No-op.
-                }
-            }
-
-            done = true;
-
-            return futs;
-        }
-        finally {
-            if (!done) {
-                for (Future<T> fut : futs)
-                    fut.cancel(true);
-            }
-        }
-    }
-
-    /** {@inheritDoc} */
-    @Override public <T> List<Future<T>> invokeAll(Collection<? extends Callable<T>> tasks, long timeout,
-        TimeUnit unit) throws InterruptedException {
-        throw new RuntimeException("Not implemented.");
-    }
-
-    /** {@inheritDoc} */
-    @Override public <T> T invokeAny(Collection<? extends Callable<T>> tasks) throws InterruptedException,
-        ExecutionException {
-        throw new RuntimeException("Not implemented.");
-    }
-
-    /** {@inheritDoc} */
-    @Override public <T> T invokeAny(Collection<? extends Callable<T>> tasks, long timeout, TimeUnit unit)
-        throws InterruptedException, ExecutionException, TimeoutException {
-        throw new RuntimeException("Not implemented.");
-    }
-
-    /** {@inheritDoc} */
-    @Override public void execute(Runnable cmd) {
-        execForTask(cmd).execute(cmd);
-    }
-
-    /**
-     * Applies a supplemental hash function to a given hashCode, which
-     * defends against poor quality hash functions.  This is critical
-     * because ConcurrentHashMap uses power-of-two length hash tables,
-     * that otherwise encounter collisions for hashCodes that do not
-     * differ in lower or upper bits.
-     *
-     * @param h Hash code.
-     * @return Enhanced hash code.
-     */
-    private int hash(int h) {
-        // Spread bits to regularize both segment and index locations,
-        // using variant of single-word Wang/Jenkins hash.
-        h += (h <<  15) ^ 0xffffcd7d;
-        h ^= (h >>> 10);
-        h += (h <<   3);
-        h ^= (h >>>  6);
-        h += (h <<   2) + (h << 14);
-        return h ^ (h >>> 16);
-    }
-
-    /**
-     * @param cmd Command.
-     * @return Service.
-     */
-    private <T> ExecutorService execForTask(T cmd) {
-        assert cmd != null;
-
-        //return execs[ThreadLocalRandom8.current().nextInt(DFLT_CONCUR_LVL)];
-        return execs[(hash(cmd.hashCode()) >>> segShift) & segMask];
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(IgniteStripedThreadPoolExecutor.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThread.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThread.java b/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThread.java
deleted file mode 100644
index e6c5c23..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThread.java
+++ /dev/null
@@ -1,100 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.thread;
-
-import org.gridgain.grid.util.typedef.internal.*;
-import org.gridgain.grid.util.worker.*;
-
-import java.util.concurrent.atomic.*;
-
-/**
- * This class adds some necessary plumbing on top of the {@link Thread} class.
- * Specifically, it adds:
- * <ul>
- *      <li>Consistent naming of threads</li>
- *      <li>Dedicated parent thread group</li>
- *      <li>Backing interrupted flag</li>
- * </ul>
- * <b>Note</b>: this class is intended for internal use only.
- */
-public class IgniteThread extends Thread {
-    /** Default thread's group. */
-    private static final ThreadGroup DFLT_GRP = new ThreadGroup("gridgain");
-
-    /** Number of all grid threads in the system. */
-    private static final AtomicLong threadCntr = new AtomicLong(0);
-
-    /** Boolean flag indicating of this thread is currently processing message. */
-    private boolean procMsg;
-
-    /**
-     * Creates thread with given worker.
-     *
-     * @param worker Runnable to create thread with.
-     */
-    public IgniteThread(GridWorker worker) {
-        this(DFLT_GRP, worker.gridName(), worker.name(), worker);
-    }
-
-    /**
-     * Creates grid thread with given name for a given grid.
-     *
-     * @param gridName Name of grid this thread is created for.
-     * @param threadName Name of thread.
-     * @param r Runnable to execute.
-     */
-    public IgniteThread(String gridName, String threadName, Runnable r) {
-        this(DFLT_GRP, gridName, threadName, r);
-    }
-
-    /**
-     * Creates grid thread with given name for a given grid with specified
-     * thread group.
-     *
-     * @param grp Thread group.
-     * @param gridName Name of grid this thread is created for.
-     * @param threadName Name of thread.
-     * @param r Runnable to execute.
-     */
-    public IgniteThread(ThreadGroup grp, String gridName, String threadName, Runnable r) {
-        super(grp, r, createName(threadCntr.incrementAndGet(), threadName, gridName));
-    }
-
-    /**
-     * Creates new thread name.
-     *
-     * @param num Thread number.
-     * @param threadName Thread name.
-     * @param gridName Grid name.
-     * @return New thread name.
-     */
-    private static String createName(long num, String threadName, String gridName) {
-        return threadName + "-#" + num + '%' + gridName + '%';
-    }
-
-    /**
-     * @param procMsg Flag indicating whether thread is currently processing message.
-     */
-    public void processingMessage(boolean procMsg) {
-        this.procMsg = procMsg;
-    }
-
-    /**
-     * @return Flag indicating whether thread is currently processing message.
-     */
-    public boolean processingMessage() {
-        return procMsg;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(IgniteThread.class, this, "name", getName());
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThreadFactory.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThreadFactory.java b/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThreadFactory.java
deleted file mode 100644
index 7caa5b2..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThreadFactory.java
+++ /dev/null
@@ -1,53 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.thread;
-
-import org.jetbrains.annotations.*;
-
-import java.util.concurrent.*;
-
-/**
- * This class provides implementation of {@link ThreadFactory} factory
- * for creating grid threads.
- */
-public class IgniteThreadFactory implements ThreadFactory {
-    /** Grid name. */
-    private final String gridName;
-
-    /** Thread name. */
-    private final String threadName;
-
-    /**
-     * Constructs new thread factory for given grid. All threads will belong
-     * to the same default thread group.
-     *
-     * @param gridName Grid name.
-     */
-    public IgniteThreadFactory(String gridName) {
-        this(gridName, "gridgain");
-    }
-
-    /**
-     * Constructs new thread factory for given grid. All threads will belong
-     * to the same default thread group.
-     *
-     * @param gridName Grid name.
-     * @param threadName Thread name.
-     */
-    public IgniteThreadFactory(String gridName, String threadName) {
-        this.gridName = gridName;
-        this.threadName = threadName;
-    }
-
-    /** {@inheritDoc} */
-    @Override public Thread newThread(@NotNull Runnable r) {
-        return new IgniteThread(gridName, threadName, r);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThreadPoolExecutor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThreadPoolExecutor.java b/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThreadPoolExecutor.java
deleted file mode 100644
index 500d50e..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThreadPoolExecutor.java
+++ /dev/null
@@ -1,242 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.thread;
-
-import org.jetbrains.annotations.*;
-
-import java.util.concurrent.*;
-
-/**
- * An {@link ExecutorService} that executes submitted tasks using pooled grid threads.
- */
-public class IgniteThreadPoolExecutor extends ThreadPoolExecutor {
-    /** Default core pool size (value is {@code 100}). */
-    public static final int DFLT_CORE_POOL_SIZE = 100;
-
-    /**
-     * Creates a new service with default initial parameters.
-     * Default values are:
-     * <table class="doctable">
-     * <tr>
-     *      <th>Name</th>
-     *      <th>Default Value</th>
-     * </tr>
-     * <tr>
-     *      <td>Core Pool Size</td>
-     *      <td>{@code 100} (see {@link #DFLT_CORE_POOL_SIZE}).</td>
-     * </tr>
-     * <tr>
-     *      <td>Maximum Pool Size</td>
-     *      <td>None, is it is not used for unbounded queues.</td>
-     * </tr>
-     * <tr>
-     *      <td>Keep alive time</td>
-     *      <td>No limit (see {@link Long#MAX_VALUE}).</td>
-     * </tr>
-     * <tr>
-     *      <td>Blocking Queue (see {@link BlockingQueue}).</td>
-     *      <td>Unbounded linked blocking queue (see {@link LinkedBlockingDeque}).</td>
-     * </tr>
-     * </table>
-     */
-    public IgniteThreadPoolExecutor() {
-        this(
-            DFLT_CORE_POOL_SIZE,
-            DFLT_CORE_POOL_SIZE,
-            0,
-            new LinkedBlockingDeque<Runnable>(),
-            new IgniteThreadFactory(null),
-            null
-        );
-    }
-
-    /**
-     * Creates a new service with the given initial parameters.
-     *
-     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
-     * @param maxPoolSize The maximum number of threads to allow in the pool.
-     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
-     *      that excess idle threads will wait for new tasks before terminating.
-     * @param workQueue The queue to use for holding tasks before they are executed. This queue will hold only
-     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
-     */
-    public IgniteThreadPoolExecutor(
-        int corePoolSize,
-        int maxPoolSize,
-        long keepAliveTime,
-        BlockingQueue<Runnable> workQueue) {
-        this(
-            corePoolSize,
-            maxPoolSize,
-            keepAliveTime,
-            workQueue,
-            new IgniteThreadFactory(null),
-            null
-        );
-    }
-
-    /**
-     * Creates a new service with the given initial parameters.
-     *
-     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
-     * @param maxPoolSize The maximum number of threads to allow in the pool.
-     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
-     *      that excess idle threads will wait for new tasks before terminating.
-     * @param workQ The queue to use for holding tasks before they are executed. This queue will hold only the
-     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
-     * @param hnd Optional handler to use when execution is blocked because the thread bounds and queue
-     *      capacities are reached. If {@code null} then {@code AbortPolicy}
-     *      handler is used by default.
-     */
-    public IgniteThreadPoolExecutor(
-        int corePoolSize,
-        int maxPoolSize,
-        long keepAliveTime,
-        BlockingQueue<Runnable> workQ,
-        RejectedExecutionHandler hnd) {
-        this(
-            corePoolSize,
-            maxPoolSize,
-            keepAliveTime,
-            workQ,
-            new IgniteThreadFactory(null),
-            hnd
-        );
-    }
-
-    /**
-     * Creates a new service with default initial parameters.
-     * Default values are:
-     * <table class="doctable">
-     * <tr>
-     *      <th>Name</th>
-     *      <th>Default Value</th>
-     * </tr>
-     * <tr>
-     *      <td>Core Pool Size</td>
-     *      <td>{@code 100} (see {@link #DFLT_CORE_POOL_SIZE}).</td>
-     * </tr>
-     * <tr>
-     *      <td>Maximum Pool Size</td>
-     *      <td>None, is it is not used for unbounded queues.</td>
-     * </tr>
-     * <tr>
-     *      <td>Keep alive time</td>
-     *      <td>No limit (see {@link Long#MAX_VALUE}).</td>
-     * </tr>
-     * <tr>
-     *      <td>Blocking Queue (see {@link BlockingQueue}).</td>
-     *      <td>Unbounded linked blocking queue (see {@link LinkedBlockingDeque}).</td>
-     * </tr>
-     * </table>
-     *
-     * @param gridName Name of the grid.
-     */
-    public IgniteThreadPoolExecutor(String gridName) {
-        this(
-            DFLT_CORE_POOL_SIZE,
-            DFLT_CORE_POOL_SIZE,
-            0,
-            new LinkedBlockingDeque<Runnable>(),
-            new IgniteThreadFactory(gridName),
-            null
-        );
-    }
-
-    /**
-     * Creates a new service with the given initial parameters.
-     *
-     * @param gridName Name of the grid
-     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
-     * @param maxPoolSize The maximum number of threads to allow in the pool.
-     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
-     *      that excess idle threads will wait for new tasks before terminating.
-     * @param workQ The queue to use for holding tasks before they are executed. This queue will hold only
-     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
-     */
-    public IgniteThreadPoolExecutor(
-        String gridName,
-        int corePoolSize,
-        int maxPoolSize,
-        long keepAliveTime,
-        BlockingQueue<Runnable> workQ) {
-        super(
-            corePoolSize,
-            maxPoolSize,
-            keepAliveTime,
-            TimeUnit.MILLISECONDS,
-            workQ,
-            new IgniteThreadFactory(gridName)
-        );
-    }
-
-    /**
-     * Creates a new service with the given initial parameters.
-     *
-     * @param gridName Name of the grid.
-     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
-     * @param maxPoolSize The maximum number of threads to allow in the pool.
-     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
-     *      that excess idle threads will wait for new tasks before terminating.
-     * @param workQ The queue to use for holding tasks before they are executed. This queue will hold only the
-     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
-     * @param hnd Optional handler to use when execution is blocked because the thread bounds and queue
-     *      capacities are reached. If {@code null} then {@code AbortPolicy}
-     *      handler is used by default.
-     */
-    public IgniteThreadPoolExecutor(
-        String gridName,
-        int corePoolSize,
-        int maxPoolSize,
-        long keepAliveTime,
-        BlockingQueue<Runnable> workQ,
-        RejectedExecutionHandler hnd) {
-        this(
-            corePoolSize,
-            maxPoolSize,
-            keepAliveTime,
-            workQ,
-            new IgniteThreadFactory(gridName),
-            hnd
-        );
-    }
-
-    /**
-     * Creates a new service with the given initial parameters.
-     *
-     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
-     * @param maxPoolSize The maximum number of threads to allow in the pool.
-     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
-     *      that excess idle threads will wait for new tasks before terminating.
-     * @param workQ The queue to use for holding tasks before they are executed. This queue will hold only the
-     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
-     * @param threadFactory Thread factory.
-     * @param hnd Optional handler to use when execution is blocked because the thread bounds and queue
-     *      capacities are reached. If {@code null} then {@code AbortPolicy}
-     *      handler is used by default.
-     */
-    public IgniteThreadPoolExecutor(
-        int corePoolSize,
-        int maxPoolSize,
-        long keepAliveTime,
-        BlockingQueue<Runnable> workQ,
-        ThreadFactory threadFactory,
-        @Nullable RejectedExecutionHandler hnd) {
-        super(
-            corePoolSize,
-            maxPoolSize,
-            keepAliveTime,
-            TimeUnit.MILLISECONDS,
-            workQ,
-            threadFactory,
-            hnd == null ? new AbortPolicy() : hnd
-        );
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/thread/package.html
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/thread/package.html b/modules/core/src/main/java/org/gridgain/grid/thread/package.html
deleted file mode 100644
index e17f6f0..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/thread/package.html
+++ /dev/null
@@ -1,15 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
-<!--
-    @html.file.header
-    _________        _____ __________________        _____
-    __  ____/___________(_)______  /__  ____/______ ____(_)_______
-    _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
-    / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
-    \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
--->
-<html>
-<body>
-    <!-- Package description. -->
-    Contains threads-related utility classes.
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryServerEndpoint.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryServerEndpoint.java b/modules/core/src/main/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryServerEndpoint.java
index f2c74ed..01a1500 100644
--- a/modules/core/src/main/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryServerEndpoint.java
+++ b/modules/core/src/main/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryServerEndpoint.java
@@ -11,9 +11,9 @@ package org.gridgain.grid.util.ipc.shmem;
 
 import org.apache.ignite.*;
 import org.apache.ignite.resources.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.processors.resource.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioBackPressureControl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioBackPressureControl.java b/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioBackPressureControl.java
index 98d452f..e1bf838 100644
--- a/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioBackPressureControl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioBackPressureControl.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.util.nio;
 
-import org.gridgain.grid.thread.*;
+import org.apache.ignite.thread.*;
 
 /**
  * Utility class that allows to ignore back-pressure control for threads that are processing messages.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioServer.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioServer.java b/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioServer.java
index f279ef7..1e61a17 100644
--- a/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioServer.java
+++ b/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioServer.java
@@ -11,8 +11,8 @@ package org.gridgain.grid.util.nio;
 
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.direct.*;
 import org.gridgain.grid.util.nio.ssl.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/test/config/job-loadtest/client.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/job-loadtest/client.xml b/modules/core/src/test/config/job-loadtest/client.xml
index 32fc339..e86b455 100644
--- a/modules/core/src/test/config/job-loadtest/client.xml
+++ b/modules/core/src/test/config/job-loadtest/client.xml
@@ -45,7 +45,7 @@
 
         <!-- Disable pools -->
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="20"/>
                 <constructor-arg type="int" value="20"/>
                 <constructor-arg type="long">
@@ -58,7 +58,7 @@
         </property>
 
         <property name="systemExecutorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="20"/>
                 <constructor-arg type="int" value="20"/>
                 <constructor-arg type="long">
@@ -71,7 +71,7 @@
         </property>
 
         <property name="peerClassLoadingExecutorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="2"/>
                 <constructor-arg type="int" value="2"/>
                 <constructor-arg type="long">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/test/config/job-loadtest/server.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/job-loadtest/server.xml b/modules/core/src/test/config/job-loadtest/server.xml
index 9723503..74be5ca 100644
--- a/modules/core/src/test/config/job-loadtest/server.xml
+++ b/modules/core/src/test/config/job-loadtest/server.xml
@@ -23,7 +23,7 @@
         <property name="deploymentMode" value="CONTINUOUS"/>
 
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="300"/>
                 <constructor-arg type="int" value="300"/>
                 <constructor-arg type="long">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/test/config/jobs-load-base.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/jobs-load-base.xml b/modules/core/src/test/config/jobs-load-base.xml
index 2b721f6..c2b7686 100644
--- a/modules/core/src/test/config/jobs-load-base.xml
+++ b/modules/core/src/test/config/jobs-load-base.xml
@@ -71,7 +71,7 @@
         <property name="deploymentMode" value="SHARED"/>
 
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() / 2}"/>
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() / 2}"/>
                 <constructor-arg type="long">
@@ -84,7 +84,7 @@
         </property>
 
         <property name="systemExecutorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() / 2}"/>
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() / 2}"/>
                 <constructor-arg type="long">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/test/config/load/dsi-load-base.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/load/dsi-load-base.xml b/modules/core/src/test/config/load/dsi-load-base.xml
index e75e190..c0879a2 100644
--- a/modules/core/src/test/config/load/dsi-load-base.xml
+++ b/modules/core/src/test/config/load/dsi-load-base.xml
@@ -71,7 +71,7 @@
         <property name="deploymentMode" value="CONTINUOUS"/>
 
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() * 4}"/>
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() * 4}"/>
                 <constructor-arg type="long">
@@ -84,7 +84,7 @@
         </property>
 
         <property name="systemExecutorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() * 8}"/>
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() * 8}"/>
                 <constructor-arg type="long">


[22/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
index 1323c4b..bbb9f2c 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
@@ -25,7 +25,7 @@ import java.util.*;
 
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * GGFS modes self test.
@@ -41,10 +41,10 @@ public class GridGgfsModesSelfTest extends GridGgfsCommonAbstractTest {
     private GridGgfsImpl ggfsSecondary;
 
     /** Default GGFS mode. */
-    private GridGgfsMode mode;
+    private IgniteFsMode mode;
 
     /** Modes map. */
-    private Map<String, GridGgfsMode> pathModes;
+    private Map<String, IgniteFsMode> pathModes;
 
     /** Whether to set "null" mode. */
     private boolean setNullMode;
@@ -189,12 +189,12 @@ public class GridGgfsModesSelfTest extends GridGgfsCommonAbstractTest {
      * @param modes Modes.
      */
     @SafeVarargs
-    final void pathModes(IgniteBiTuple<String, GridGgfsMode>... modes) {
+    final void pathModes(IgniteBiTuple<String, IgniteFsMode>... modes) {
         assert modes != null;
 
         pathModes = new LinkedHashMap<>(modes.length, 1.0f);
 
-        for (IgniteBiTuple<String, GridGgfsMode> mode : modes)
+        for (IgniteBiTuple<String, IgniteFsMode> mode : modes)
             pathModes.put(mode.getKey(), mode.getValue());
     }
 
@@ -477,14 +477,14 @@ public class GridGgfsModesSelfTest extends GridGgfsCommonAbstractTest {
      * @param expMode Expected mode.
      * @throws Exception If failed.
      */
-    private void checkMode(String pathStr, GridGgfsMode expMode) throws Exception {
+    private void checkMode(String pathStr, IgniteFsMode expMode) throws Exception {
         assert ggfs != null;
 
         IgniteFsPath path = new IgniteFsPath(pathStr);
 
         GridGgfsModeResolver rslvr = ggfs.modeResolver();
 
-        GridGgfsMode mode = rslvr.resolveMode(path);
+        IgniteFsMode mode = rslvr.resolveMode(path);
 
         assertEquals(expMode, mode);
     }
@@ -515,7 +515,7 @@ public class GridGgfsModesSelfTest extends GridGgfsCommonAbstractTest {
         ggfs.mkdirs(dir);
 
         // Create new file.
-        GridGgfsOutputStream os = ggfs.create(file, 1024, true, null, 0, 2048, null);
+        IgniteFsOutputStream os = ggfs.create(file, 1024, true, null, 0, 2048, null);
 
         os.write(testData1);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapTieredSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapTieredSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapTieredSelfTest.java
index b42c2d9..302dc4a 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapTieredSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapTieredSelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 import static org.gridgain.grid.cache.GridCacheMemoryMode.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapValuesSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapValuesSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapValuesSelfTest.java
index 4440975..86faae8 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapValuesSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimaryOffheapValuesSelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 import static org.gridgain.grid.cache.GridCacheMemoryMode.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimarySelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimarySelfTest.java
index b0f3a6c..f39fe7b 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimarySelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPrimarySelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * Tests for PRIMARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
index 3175792..d13a1c6 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
@@ -195,7 +195,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
     public void testCreate() throws Exception {
         IgniteFsPath path = path("/file");
 
-        try (GridGgfsOutputStream os = ggfs.create(path, false)) {
+        try (IgniteFsOutputStream os = ggfs.create(path, false)) {
             assert os != null;
 
             IgniteFsFileImpl info = (IgniteFsFileImpl)ggfs.info(path);
@@ -422,7 +422,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
         IgniteFsPath fileSubdir1 = path("/dir1/subdir1/file");
         IgniteFsPath fileDir2 = path("/dir2/file");
 
-        GridGgfsOutputStream os = ggfs.create(fileDir1, false);
+        IgniteFsOutputStream os = ggfs.create(fileDir1, false);
         os.write(new byte[1000]);
         os.close();
 
@@ -669,7 +669,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
     public void testDeleteCacheConsistency() throws Exception {
         IgniteFsPath path = new IgniteFsPath("/someFile");
 
-        try (GridGgfsOutputStream out = ggfs.create(path, true)) {
+        try (IgniteFsOutputStream out = ggfs.create(path, true)) {
             out.write(new byte[10 * 1024 * 1024]);
         }
 
@@ -786,7 +786,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
         for (int i = 0; i < buf.length; i++)
             buf[i] = (byte)(i * i);
 
-        GridGgfsOutputStream os = ggfs.create(path, bufSize, true, null, 0, 1024, null);
+        IgniteFsOutputStream os = ggfs.create(path, bufSize, true, null, 0, 1024, null);
 
         try {
             for (int i = 0; i < cnt; i++)
@@ -837,7 +837,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
      */
     private String create(String path, boolean overwrite, String text) throws Exception {
 
-        try (GridGgfsOutputStream out = ggfs.create(path(path), overwrite)) {
+        try (IgniteFsOutputStream out = ggfs.create(path(path), overwrite)) {
             IOUtils.write(text, out, UTF_8);
         }
 
@@ -857,7 +857,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
      */
     private String append(String path, boolean create, String text) throws Exception {
 
-        try (GridGgfsOutputStream out = ggfs.append(path(path), create)) {
+        try (IgniteFsOutputStream out = ggfs.append(path(path), create)) {
             IOUtils.write(text, out, UTF_8);
         }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java
index 612a4a0..a1991c5 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java
@@ -24,7 +24,7 @@ import java.util.*;
 
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * Tests for node validation logic in {@link GridGgfsProcessor}.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
index eff53d1..9dce0df 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
@@ -421,7 +421,7 @@ public class GridGgfsSizeSelfTest extends GridGgfsCommonAbstractTest {
         final IgniteFsPath path = new IgniteFsPath("/file");
 
         // This write is expected to be successful.
-        GridGgfsOutputStream os = ggfs(0).create(path, false);
+        IgniteFsOutputStream os = ggfs(0).create(path, false);
         os.write(chunk(BLOCK_SIZE - 1));
         os.close();
 
@@ -433,7 +433,7 @@ public class GridGgfsSizeSelfTest extends GridGgfsCommonAbstractTest {
         // This write must fail w/ exception.
         GridTestUtils.assertThrows(log(), new Callable<Object>() {
             @Override public Object call() throws Exception {
-                GridGgfsOutputStream osErr = ggfs(0).append(path, false);
+                IgniteFsOutputStream osErr = ggfs(0).append(path, false);
 
                 try {
                     osErr.write(chunk(BLOCK_SIZE));
@@ -453,7 +453,7 @@ public class GridGgfsSizeSelfTest extends GridGgfsCommonAbstractTest {
                     U.closeQuiet(osErr);
                 }
             }
-        }, GridGgfsOutOfSpaceException.class, "Failed to write data block (GGFS maximum data size exceeded) [used=" +
+        }, IgniteFsOutOfSpaceException.class, "Failed to write data block (GGFS maximum data size exceeded) [used=" +
             ggfsMaxData + ", allowed=" + ggfsMaxData + ']');
     }
 
@@ -476,7 +476,7 @@ public class GridGgfsSizeSelfTest extends GridGgfsCommonAbstractTest {
         final IgniteFsPath otherPath = new IgniteFsPath("/fileOther");
 
         // Fill cache with data up to it's limit.
-        GridGgfsOutputStream os = ggfs.create(path, false);
+        IgniteFsOutputStream os = ggfs.create(path, false);
         os.write(chunk((int)ggfsMaxData));
         os.close();
 
@@ -780,7 +780,7 @@ public class GridGgfsSizeSelfTest extends GridGgfsCommonAbstractTest {
 
             // Actual write.
             for (GgfsBlock block : blocks) {
-                GridGgfsOutputStream os = ggfs(0).append(path, false);
+                IgniteFsOutputStream os = ggfs(0).append(path, false);
 
                 os.write(chunk(block.length()));
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
index d9f6f15..b79dca0 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
@@ -194,7 +194,7 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
             idx++;
         }
 
-        try (GridGgfsOutputStream out = fs.create(path, 1024, true, affKey, 0, 1024, null)) {
+        try (IgniteFsOutputStream out = fs.create(path, 1024, true, affKey, 0, 1024, null)) {
             // Write 5M, should be enough to test distribution.
             for (int i = 0; i < 15; i++)
                 out.write(new byte[1024 * 1024]);
@@ -226,7 +226,7 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
             IgniteFs fs1 = grid(1).fileSystem("ggfs");
             IgniteFs fs2 = grid(2).fileSystem("ggfs");
 
-            try (GridGgfsOutputStream out = fs0.create(path, 128, false, 1, CFG_GRP_SIZE,
+            try (IgniteFsOutputStream out = fs0.create(path, 128, false, 1, CFG_GRP_SIZE,
                 F.asMap(IgniteFs.PROP_PREFER_LOCAL_WRITES, "true"))) {
                 // 1.5 blocks
                 byte[] data = new byte[CFG_BLOCK_SIZE * 3 / 2];
@@ -236,7 +236,7 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
                 out.write(data);
             }
 
-            try (GridGgfsOutputStream out = fs1.append(path, false)) {
+            try (IgniteFsOutputStream out = fs1.append(path, false)) {
                 // 1.5 blocks.
                 byte[] data = new byte[CFG_BLOCK_SIZE * 3 / 2];
 
@@ -318,7 +318,7 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
 
                 IgniteFsPath f = new IgniteFsPath(path.parent(), "asdf" + (id > 1 ? "-" + id : ""));
 
-                try (GridGgfsOutputStream out = fs.create(f, 0, true, null, 0, 1024, null)) {
+                try (IgniteFsOutputStream out = fs.create(f, 0, true, null, 0, 1024, null)) {
                     assertNotNull(out);
 
                     cleanUp.add(f); // Add all created into cleanup list.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
index 8eb4dbb..641977a 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
@@ -32,7 +32,7 @@ import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheDistributionMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
 import static org.gridgain.grid.cache.GridCacheWriteSynchronizationMode.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * Tests for {@link GridGgfsTask}.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
index d348944..9199576 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
@@ -26,7 +26,7 @@ import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheDistributionMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
 import static org.gridgain.grid.cache.GridCacheWriteSynchronizationMode.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * Base class for all split resolvers
@@ -156,7 +156,7 @@ public class GridGgfsAbstractRecordResolverSelfTest extends GridCommonAbstractTe
      * @throws Exception In case of exception.
      */
     protected void write(byte[]... chunks) throws Exception {
-        GridGgfsOutputStream os =  ggfs.create(FILE, true);
+        IgniteFsOutputStream os =  ggfs.create(FILE, true);
 
         if (chunks != null) {
             for (byte[] chunk : chunks)

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
index 09fd723..df55bb3 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
@@ -32,7 +32,7 @@ import java.util.concurrent.atomic.*;
 
 import static org.apache.ignite.IgniteFs.*;
 import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 import static org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.*;
 import static org.gridgain.grid.kernal.ggfs.hadoop.GridGgfsHadoopUtils.*;
 
@@ -263,8 +263,8 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
             boolean initSecondary = paths.defaultMode() == PROXY;
 
             if (paths.pathModes() != null && !paths.pathModes().isEmpty()) {
-                for (T2<IgniteFsPath, GridGgfsMode> pathMode : paths.pathModes()) {
-                    GridGgfsMode mode = pathMode.getValue();
+                for (T2<IgniteFsPath, IgniteFsMode> pathMode : paths.pathModes()) {
+                    IgniteFsMode mode = pathMode.getValue();
 
                     initSecondary |= mode == PROXY;
                 }
@@ -477,7 +477,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
 
         try {
             IgniteFsPath path = convert(f);
-            GridGgfsMode mode = mode(path);
+            IgniteFsMode mode = mode(path);
 
             if (mode == PROXY) {
                 if (secondaryFs == null) {
@@ -545,7 +545,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
 
         try {
             IgniteFsPath path = convert(f);
-            GridGgfsMode mode = mode(path);
+            IgniteFsMode mode = mode(path);
 
             if (LOG.isDebugEnabled())
                 LOG.debug("Opening output stream in create [thread=" + Thread.currentThread().getName() + "path=" +
@@ -623,7 +623,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
 
         try {
             IgniteFsPath path = convert(f);
-            GridGgfsMode mode = mode(path);
+            IgniteFsMode mode = mode(path);
 
             if (LOG.isDebugEnabled())
                 LOG.debug("Opening output stream in append [thread=" + Thread.currentThread().getName() +
@@ -689,7 +689,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
         try {
             IgniteFsPath srcPath = convert(src);
             IgniteFsPath dstPath = convert(dst);
-            GridGgfsMode mode = mode(srcPath);
+            IgniteFsMode mode = mode(srcPath);
 
             if (mode == PROXY) {
                 if (secondaryFs == null) {
@@ -740,7 +740,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
 
         try {
             IgniteFsPath path = convert(f);
-            GridGgfsMode mode = mode(path);
+            IgniteFsMode mode = mode(path);
 
             if (mode == PROXY) {
                 if (secondaryFs == null) {
@@ -785,7 +785,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
 
         try {
             IgniteFsPath path = convert(f);
-            GridGgfsMode mode = mode(path);
+            IgniteFsMode mode = mode(path);
 
             if (mode == PROXY) {
                 if (secondaryFs == null) {
@@ -899,7 +899,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
 
         try {
             IgniteFsPath path = convert(f);
-            GridGgfsMode mode = mode(path);
+            IgniteFsMode mode = mode(path);
 
             if (mode == PROXY) {
                 if (secondaryFs == null) {
@@ -1051,7 +1051,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
      * @param path HDFS path.
      * @return Path mode.
      */
-    public GridGgfsMode mode(Path path) {
+    public IgniteFsMode mode(Path path) {
         return mode(convert(path));
     }
 
@@ -1061,7 +1061,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
      * @param path GGFS path.
      * @return Path mode.
      */
-    public GridGgfsMode mode(IgniteFsPath path) {
+    public IgniteFsMode mode(IgniteFsPath path) {
         return modeRslvr.resolveMode(path);
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
index 201adcf..31e4ced 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
@@ -32,7 +32,7 @@ import java.util.concurrent.atomic.*;
 
 import static org.apache.ignite.IgniteFs.*;
 import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 import static org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.*;
 import static org.gridgain.grid.kernal.ggfs.hadoop.GridGgfsHadoopUtils.*;
 
@@ -258,8 +258,8 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
             boolean initSecondary = paths.defaultMode() == PROXY;
 
             if (paths.pathModes() != null) {
-                for (T2<IgniteFsPath, GridGgfsMode> pathMode : paths.pathModes()) {
-                    GridGgfsMode mode = pathMode.getValue();
+                for (T2<IgniteFsPath, IgniteFsMode> pathMode : paths.pathModes()) {
+                    IgniteFsMode mode = pathMode.getValue();
 
                     initSecondary |= mode == PROXY;
                 }
@@ -422,7 +422,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
 
         try {
             IgniteFsPath path = convert(f);
-            GridGgfsMode mode = modeRslvr.resolveMode(path);
+            IgniteFsMode mode = modeRslvr.resolveMode(path);
 
             if (mode == PROXY) {
                 FSDataInputStream is = secondaryFs.open(toSecondary(f), bufSize);
@@ -497,7 +497,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
 
         try {
             IgniteFsPath path = convert(f);
-            GridGgfsMode mode = modeRslvr.resolveMode(path);
+            IgniteFsMode mode = modeRslvr.resolveMode(path);
 
             if (LOG.isDebugEnabled())
                 LOG.debug("Opening output stream in create [thread=" + Thread.currentThread().getName() + "path=" +
@@ -596,7 +596,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
         try {
             IgniteFsPath srcPath = convert(src);
             IgniteFsPath dstPath = convert(dst);
-            Set<GridGgfsMode> childrenModes = modeRslvr.resolveChildrenModes(srcPath);
+            Set<IgniteFsMode> childrenModes = modeRslvr.resolveChildrenModes(srcPath);
 
             if (childrenModes.contains(PROXY)) {
                 if (clientLog.isLogEnabled())
@@ -623,8 +623,8 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
 
         try {
             IgniteFsPath path = convert(f);
-            GridGgfsMode mode = modeRslvr.resolveMode(path);
-            Set<GridGgfsMode> childrenModes = modeRslvr.resolveChildrenModes(path);
+            IgniteFsMode mode = modeRslvr.resolveMode(path);
+            Set<IgniteFsMode> childrenModes = modeRslvr.resolveChildrenModes(path);
 
             if (childrenModes.contains(PROXY)) {
                 if (clientLog.isLogEnabled())
@@ -668,7 +668,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
 
         try {
             IgniteFsPath path = convert(f);
-            GridGgfsMode mode = modeRslvr.resolveMode(path);
+            IgniteFsMode mode = modeRslvr.resolveMode(path);
 
             if (mode == PROXY) {
                 FileStatus[] arr = secondaryFs.listStatus(toSecondary(f));
@@ -728,7 +728,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
 
         try {
             IgniteFsPath path = convert(f);
-            GridGgfsMode mode = modeRslvr.resolveMode(path);
+            IgniteFsMode mode = modeRslvr.resolveMode(path);
 
             if (mode == PROXY) {
                 if (clientLog.isLogEnabled())
@@ -811,7 +811,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
      * @param path HDFS path.
      * @return Path mode.
      */
-    public GridGgfsMode mode(Path path) {
+    public IgniteFsMode mode(Path path) {
         return modeRslvr.resolveMode(convert(path));
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
index 091091a..ca08ca1 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
@@ -112,7 +112,7 @@ public class GridGgfsHadoopFileSystemWrapper implements IgniteFsFileSystem, Auto
         if (e instanceof FileNotFoundException)
             return new IgniteFsFileNotFoundException(e);
         else if (e instanceof ParentNotDirectoryException)
-            return new GridGgfsParentNotDirectoryException(msg, e);
+            return new IgniteFsParentNotDirectoryException(msg, e);
         else if (e instanceof PathIsNotEmptyDirectoryException)
             return new GridGgfsDirectoryNotEmptyException(e);
         else if (e instanceof PathExistsException)

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java
index e14f9b9..b77c49a 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java
@@ -221,7 +221,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     @Override public GridGgfsHadoopStreamDelegate create(IgniteFsPath path, boolean overwrite, boolean colocate,
         int replication, long blockSize, @Nullable Map<String, String> props) throws GridException {
         try {
-            GridGgfsOutputStream stream = ggfs.create(path, bufSize, overwrite,
+            IgniteFsOutputStream stream = ggfs.create(path, bufSize, overwrite,
                 colocate ? ggfs.nextAffinityKey() : null, replication, blockSize, props);
 
             return new GridGgfsHadoopStreamDelegate(this, stream);
@@ -235,7 +235,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     @Override public GridGgfsHadoopStreamDelegate append(IgniteFsPath path, boolean create,
         @Nullable Map<String, String> props) throws GridException {
         try {
-            GridGgfsOutputStream stream = ggfs.append(path, bufSize, create, props);
+            IgniteFsOutputStream stream = ggfs.append(path, bufSize, create, props);
 
             return new GridGgfsHadoopStreamDelegate(this, stream);
         }
@@ -288,7 +288,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     @Override public void writeData(GridGgfsHadoopStreamDelegate delegate, byte[] data, int off, int len)
         throws IOException {
         try {
-            GridGgfsOutputStream stream = delegate.target();
+            IgniteFsOutputStream stream = delegate.target();
 
             stream.write(data, off, len);
         }
@@ -308,7 +308,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     /** {@inheritDoc} */
     @Override public void flush(GridGgfsHadoopStreamDelegate delegate) throws IOException {
         try {
-            GridGgfsOutputStream stream = delegate.target();
+            IgniteFsOutputStream stream = delegate.target();
 
             stream.flush();
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java
index 9d52a99..17442fd 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java
@@ -104,7 +104,7 @@ public class GridGgfsHadoopUtils {
             return e.getCause(IOException.class);
         else if (e instanceof IgniteFsFileNotFoundException)
             return new FileNotFoundException(path); // TODO: Or PathNotFoundException?
-        else if (e instanceof GridGgfsParentNotDirectoryException)
+        else if (e instanceof IgniteFsParentNotDirectoryException)
             return new ParentNotDirectoryException(path);
         else if (path != null && e instanceof GridGgfsDirectoryNotEmptyException)
             return new PathIsNotEmptyDirectoryException(path);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsTestSuite.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsTestSuite.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsTestSuite.java
index 176ba85..b6655ad 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsTestSuite.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsTestSuite.java
@@ -20,7 +20,7 @@ import org.gridgain.grid.util.ipc.shmem.*;
 import org.gridgain.testframework.*;
 import org.jetbrains.annotations.*;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * Test suite for GGFS event tests.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
index edeec58..53fa471 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
@@ -41,7 +41,7 @@ import java.util.concurrent.atomic.*;
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
 import static org.apache.ignite.events.IgniteEventType.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * Hadoop 2.x compliant file system.
@@ -63,7 +63,7 @@ public abstract class GridGgfsHadoop20FileSystemAbstractSelfTest extends GridGgf
     private static AbstractFileSystem fs;
 
     /** Default GGFS mode. */
-    protected GridGgfsMode mode;
+    protected IgniteFsMode mode;
 
     /** Primary file system URI. */
     protected URI primaryFsUri;
@@ -76,7 +76,7 @@ public abstract class GridGgfsHadoop20FileSystemAbstractSelfTest extends GridGgf
      *
      * @param mode Default GGFS mode.
      */
-    protected GridGgfsHadoop20FileSystemAbstractSelfTest(GridGgfsMode mode) {
+    protected GridGgfsHadoop20FileSystemAbstractSelfTest(IgniteFsMode mode) {
         this.mode = mode;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemLoopbackPrimarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemLoopbackPrimarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemLoopbackPrimarySelfTest.java
index f3159e4..8040ae2 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemLoopbackPrimarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemLoopbackPrimarySelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 import static org.gridgain.grid.util.ipc.shmem.GridIpcSharedMemoryServerEndpoint.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemShmemPrimarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemShmemPrimarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemShmemPrimarySelfTest.java
index 81d5825..8b4d071 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemShmemPrimarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemShmemPrimarySelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 import static org.gridgain.grid.util.ipc.shmem.GridIpcSharedMemoryServerEndpoint.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
index 1f05f16..4952fe7 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
@@ -29,7 +29,7 @@ import java.util.concurrent.*;
 
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 import static org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.*;
 import static org.gridgain.grid.kernal.processors.ggfs.GridGgfsAbstractSelfTest.*;
 
@@ -83,14 +83,14 @@ public abstract class GridGgfsHadoopDualAbstractSelfTest extends GridGgfsCommonA
     protected static GridGgfsImpl ggfsSecondary;
 
     /** GGFS mode. */
-    protected final GridGgfsMode mode;
+    protected final IgniteFsMode mode;
 
     /**
      * Constructor.
      *
      * @param mode GGFS mode.
      */
-    protected GridGgfsHadoopDualAbstractSelfTest(GridGgfsMode mode) {
+    protected GridGgfsHadoopDualAbstractSelfTest(IgniteFsMode mode) {
         this.mode = mode;
         assert mode == DUAL_SYNC || mode == DUAL_ASYNC;
     }
@@ -106,7 +106,7 @@ public abstract class GridGgfsHadoopDualAbstractSelfTest extends GridGgfsCommonA
      * @return Started grid instance.
      * @throws Exception If failed.
      */
-    protected Ignite startGridWithGgfs(String gridName, String ggfsName, GridGgfsMode mode,
+    protected Ignite startGridWithGgfs(String gridName, String ggfsName, IgniteFsMode mode,
         @Nullable IgniteFsFileSystem secondaryFs, @Nullable String restCfg) throws Exception {
         IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
@@ -207,7 +207,7 @@ public abstract class GridGgfsHadoopDualAbstractSelfTest extends GridGgfsCommonA
         // Write enough data to the secondary file system.
         final int blockSize = GGFS_BLOCK_SIZE;
 
-        GridGgfsOutputStream out = ggfsSecondary.append(FILE, false);
+        IgniteFsOutputStream out = ggfsSecondary.append(FILE, false);
 
         int totalWritten = 0;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAsyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAsyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAsyncSelfTest.java
index d3b0ee5..88e2977 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAsyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAsyncSelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * Tests for DUAL_ASYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualSyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualSyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualSyncSelfTest.java
index 2fd5877..ede366f 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualSyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualSyncSelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * Tests for DUAL_SYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
index 17e0960..d0d7188 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
@@ -44,7 +44,7 @@ import java.util.concurrent.atomic.*;
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
 import static org.apache.ignite.events.IgniteEventType.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * Test hadoop file system implementation.
@@ -88,7 +88,7 @@ public abstract class GridGgfsHadoopFileSystemAbstractSelfTest extends GridGgfsC
     private static FileSystem fs;
 
     /** Default GGFS mode. */
-    protected final GridGgfsMode mode;
+    protected final IgniteFsMode mode;
 
     /** Skip embedded mode flag. */
     private final boolean skipEmbed;
@@ -124,7 +124,7 @@ public abstract class GridGgfsHadoopFileSystemAbstractSelfTest extends GridGgfsC
      * @param skipLocShmem Whether to skip local shmem mode.
      * @param skipLocTcp Whether to skip local TCP mode.
      */
-    protected GridGgfsHadoopFileSystemAbstractSelfTest(GridGgfsMode mode, boolean skipEmbed, boolean skipLocShmem) {
+    protected GridGgfsHadoopFileSystemAbstractSelfTest(IgniteFsMode mode, boolean skipEmbed, boolean skipLocShmem) {
         this.mode = mode;
         this.skipEmbed = skipEmbed;
         this.skipLocShmem = skipLocShmem;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
index 1c8c59f..ce54dfb 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
@@ -31,7 +31,7 @@ import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheDistributionMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
 import static org.gridgain.grid.cache.GridCacheWriteSynchronizationMode.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 import static org.gridgain.grid.kernal.ggfs.hadoop.GridGgfsHadoopUtils.*;
 import static org.gridgain.grid.util.ipc.shmem.GridIpcSharedMemoryServerEndpoint.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java
index ad016b9..182dc49 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java
@@ -16,7 +16,7 @@ import org.gridgain.grid.util.typedef.internal.*;
 import java.io.*;
 import java.util.*;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 import static org.gridgain.grid.kernal.ggfs.common.GridGgfsLogger.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java
index 03d55e3..dabfca9 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java
@@ -29,7 +29,7 @@ import java.nio.file.*;
 
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 import static org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackAbstractSelfTest.java
index d2a3e89..83cd2b9 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackAbstractSelfTest.java
@@ -22,7 +22,7 @@ public abstract class GridGgfsHadoopFileSystemLoopbackAbstractSelfTest extends
      * @param mode GGFS mode.
      * @param skipEmbed Skip embedded mode flag.
      */
-    protected GridGgfsHadoopFileSystemLoopbackAbstractSelfTest(GridGgfsMode mode, boolean skipEmbed) {
+    protected GridGgfsHadoopFileSystemLoopbackAbstractSelfTest(IgniteFsMode mode, boolean skipEmbed) {
         super(mode, skipEmbed, true);
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualAsyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualAsyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualAsyncSelfTest.java
index 487aa3d..2450d73 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualAsyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualAsyncSelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC loopback self test in DUAL_ASYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualSyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualSyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualSyncSelfTest.java
index fca7f2a..76da390 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualSyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedDualSyncSelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC loopback self test in DUAL_SYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedPrimarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedPrimarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedPrimarySelfTest.java
index 2b2efb4..4675501 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedPrimarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedPrimarySelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC loopback self test in PRIMARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedSecondarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedSecondarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedSecondarySelfTest.java
index c25f01a..e914278 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedSecondarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackEmbeddedSecondarySelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC loopback self test in SECONDARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualAsyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualAsyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualAsyncSelfTest.java
index 7ead3de..eab8491 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualAsyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualAsyncSelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC loopback self test in DUAL_ASYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualSyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualSyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualSyncSelfTest.java
index c4e60b2..f970dd7 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualSyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualSyncSelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC loopback self test in DUAL_SYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalPrimarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalPrimarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalPrimarySelfTest.java
index 6917376..b350feb 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalPrimarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalPrimarySelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC loopback self test in PRIMARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalSecondarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalSecondarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalSecondarySelfTest.java
index 0967608..9682207 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalSecondarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalSecondarySelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC loopback self test in SECONDARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java
index 09bf434..15270d3 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java
@@ -28,7 +28,7 @@ import java.util.*;
 
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * Ensures correct modes resolution for SECONDARY paths.
@@ -44,10 +44,10 @@ public class GridGgfsHadoopFileSystemSecondaryModeSelfTest extends GridGgfsCommo
     private static final String PATTERN_NOT_MATCHES = "/files";
 
     /** Default GGFS mode. */
-    private GridGgfsMode mode;
+    private IgniteFsMode mode;
 
     /** Path modes. */
-    private Map<String, GridGgfsMode> pathModes;
+    private Map<String, IgniteFsMode> pathModes;
 
     /** File system. */
     private GridGgfsHadoopFileSystem fs;
@@ -283,12 +283,12 @@ public class GridGgfsHadoopFileSystemSecondaryModeSelfTest extends GridGgfsCommo
      * @param modes Modes.
      */
     @SafeVarargs
-    final void pathModes(IgniteBiTuple<String, GridGgfsMode>... modes) {
+    final void pathModes(IgniteBiTuple<String, IgniteFsMode>... modes) {
         assert modes != null;
 
         pathModes = new LinkedHashMap<>(modes.length, 1.0f);
 
-        for (IgniteBiTuple<String, GridGgfsMode> mode : modes)
+        for (IgniteBiTuple<String, IgniteFsMode> mode : modes)
             pathModes.put(mode.getKey(), mode.getValue());
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemAbstractSelfTest.java
index 3458695..d0693e4 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemAbstractSelfTest.java
@@ -29,7 +29,7 @@ public abstract class GridGgfsHadoopFileSystemShmemAbstractSelfTest extends Grid
      * @param mode GGFS mode.
      * @param skipEmbed Skip embedded mode flag.
      */
-    protected GridGgfsHadoopFileSystemShmemAbstractSelfTest(GridGgfsMode mode, boolean skipEmbed) {
+    protected GridGgfsHadoopFileSystemShmemAbstractSelfTest(IgniteFsMode mode, boolean skipEmbed) {
         super(mode, skipEmbed, false);
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualAsyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualAsyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualAsyncSelfTest.java
index a9d7e53..e89885c 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualAsyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualAsyncSelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC shmem self test in DUAL_ASYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualSyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualSyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualSyncSelfTest.java
index a7c2003..f03a997 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualSyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualSyncSelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC shmem self test in DUAL_SYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedPrimarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedPrimarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedPrimarySelfTest.java
index 01897db..d97dde7 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedPrimarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedPrimarySelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC shmem self test in PRIMARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedSecondarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedSecondarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedSecondarySelfTest.java
index e3bbea2..27ac2e3 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedSecondarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedSecondarySelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC shmem self test in SECONDARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualAsyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualAsyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualAsyncSelfTest.java
index 3d66a3e..fd70c03 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualAsyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualAsyncSelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC shmem self test in DUAL_ASYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualSyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualSyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualSyncSelfTest.java
index 3034be1..4e6a53f 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualSyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualSyncSelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC shmem self test in DUAL_SYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalPrimarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalPrimarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalPrimarySelfTest.java
index d185de5..8f14dde 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalPrimarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalPrimarySelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC shmem self test in PRIMARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalSecondarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalSecondarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalSecondarySelfTest.java
index e7e2d96..7e602e5 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalSecondarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalSecondarySelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC shmem self test in SECONDARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
index 1679f80..b131f20 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
@@ -818,30 +818,30 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
         }
 
         /** {@inheritDoc} */
-        @Override public GridGgfsOutputStream create(IgniteFsPath path, boolean overwrite) throws GridException {
+        @Override public IgniteFsOutputStream create(IgniteFsPath path, boolean overwrite) throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Override public GridGgfsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication,
+        @Override public IgniteFsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication,
             long blockSize, @Nullable Map<String, String> props) throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Override public GridGgfsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite,
+        @Override public IgniteFsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite,
             @Nullable IgniteUuid affKey, int replication, long blockSize, @Nullable Map<String, String> props)
             throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Override public GridGgfsOutputStream append(IgniteFsPath path, boolean create) throws GridException {
+        @Override public IgniteFsOutputStream append(IgniteFsPath path, boolean create) throws GridException {
             return null;
         }
 
         /** {@inheritDoc} */
-        @Override public GridGgfsOutputStream append(IgniteFsPath path, int bufSize, boolean create,
+        @Override public IgniteFsOutputStream append(IgniteFsPath path, int bufSize, boolean create,
             @Nullable Map<String, String> props) throws GridException {
             return null;
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/GridHadoopExternalTaskExecutionSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/GridHadoopExternalTaskExecutionSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/GridHadoopExternalTaskExecutionSelfTest.java
index fe20f71..352a185 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/GridHadoopExternalTaskExecutionSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/GridHadoopExternalTaskExecutionSelfTest.java
@@ -143,7 +143,7 @@ public class GridHadoopExternalTaskExecutionSelfTest extends GridHadoopAbstractS
     private void prepareTestFile(String filePath) throws Exception {
         IgniteFs ggfs = grid(0).fileSystem(ggfsName);
 
-        try (GridGgfsOutputStream out = ggfs.create(new IgniteFsPath(filePath), true)) {
+        try (IgniteFsOutputStream out = ggfs.create(new IgniteFsPath(filePath), true)) {
             PrintWriter wr = new PrintWriter(new OutputStreamWriter(out));
 
             for (int i = 0; i < 1000; i++)


[27/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
# Renaming


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

Branch: refs/heads/master
Commit: 243e521ec2f9ab5a01860fe0ce983d91a9d683d2
Parents: 7cd638f
Author: sboikov <sb...@gridgain.com>
Authored: Fri Dec 5 11:26:58 2014 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Dec 5 11:26:58 2014 +0300

----------------------------------------------------------------------
 .../examples/ggfs/GgfsMapReduceExample.java     |   4 +-
 .../grid/ggfs/mapreduce/GridGgfsTaskArgs.java   |  74 ----
 .../mapreduce/GridGgfsTaskNoReduceAdapter.java  |  34 --
 .../ggfs/mapreduce/IgniteFsRecordResolver.java  |   9 +-
 .../grid/ggfs/mapreduce/IgniteFsTask.java       |   8 +-
 .../grid/ggfs/mapreduce/IgniteFsTaskArgs.java   |  74 ++++
 .../mapreduce/IgniteFsTaskNoReduceAdapter.java  |  34 ++
 .../GridGgfsByteDelimiterRecordResolver.java    | 340 -------------------
 .../GridGgfsFixedLengthRecordResolver.java      |  79 -----
 .../records/GridGgfsNewLineRecordResolver.java  |  58 ----
 .../GridGgfsStringDelimiterRecordResolver.java  |  76 -----
 .../IgniteFsByteDelimiterRecordResolver.java    | 340 +++++++++++++++++++
 .../IgniteFsFixedLengthRecordResolver.java      |  79 +++++
 .../records/IgniteFsNewLineRecordResolver.java  |  58 ++++
 .../IgniteFsStringDelimiterRecordResolver.java  |  76 +++++
 .../kernal/processors/ggfs/GridGgfsImpl.java    |   4 +-
 .../processors/ggfs/GridGgfsTaskArgsImpl.java   | 127 -------
 .../processors/ggfs/IgniteFsTaskArgsImpl.java   | 127 +++++++
 .../processors/ggfs/GridGgfsTaskSelfTest.java   |   6 +-
 ...GgfsByteDelimiterRecordResolverSelfTest.java |   8 +-
 ...idGgfsFixedLengthRecordResolverSelfTest.java |   8 +-
 ...sNewLineDelimiterRecordResolverSelfTest.java |  10 +-
 ...fsStringDelimiterRecordResolverSelfTest.java |   8 +-
 23 files changed, 820 insertions(+), 821 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
index edd3f70..454a54e 100644
--- a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
+++ b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
@@ -64,7 +64,7 @@ public class GgfsMapReduceExample {
 
                 writeFile(fs, fsPath, file);
 
-                Collection<Line> lines = fs.execute(new GrepTask(), GridGgfsNewLineRecordResolver.NEW_LINE,
+                Collection<Line> lines = fs.execute(new GrepTask(), IgniteFsNewLineRecordResolver.NEW_LINE,
                     Collections.singleton(fsPath), regexStr);
 
                 if (lines.isEmpty()) {
@@ -122,7 +122,7 @@ public class GgfsMapReduceExample {
     private static class GrepTask extends IgniteFsTask<String, Collection<Line>> {
         /** {@inheritDoc} */
         @Override public IgniteFsJob createJob(IgniteFsPath path, IgniteFsFileRange range,
-            GridGgfsTaskArgs<String> args) throws GridException {
+            IgniteFsTaskArgs<String> args) throws GridException {
             return new GrepJob(args.userArgument());
         }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
deleted file mode 100644
index caa0b44..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
+++ /dev/null
@@ -1,74 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-import org.gridgain.grid.ggfs.*;
-
-import java.util.*;
-
-/**
- * GGFS task arguments. When you initiate new GGFS task execution using one of {@code GridGgfs.execute(...)} methods,
- * all passed parameters are encapsulated in a single {@code GridGgfsTaskArgs} object. Later on this object is
- * passed to {@link IgniteFsTask#createJob(org.gridgain.grid.ggfs.IgniteFsPath, IgniteFsFileRange, GridGgfsTaskArgs)} method.
- * <p>
- * Task arguments encapsulates the following data:
- * <ul>
- *     <li>GGFS name</li>
- *     <li>File paths passed to {@code GridGgfs.execute()} method</li>
- *     <li>{@link IgniteFsRecordResolver} for that task</li>
- *     <li>Flag indicating whether to skip non-existent file paths or throw an exception</li>
- *     <li>User-defined task argument</li>
- *     <li>Maximum file range length for that task (see {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()})</li>
- * </ul>
- */
-public interface GridGgfsTaskArgs<T> {
-    /**
-     * Gets GGFS name.
-     *
-     * @return GGFS name.
-     */
-    public String ggfsName();
-
-    /**
-     * Gets file paths to process.
-     *
-     * @return File paths to process.
-     */
-    public Collection<IgniteFsPath> paths();
-
-    /**
-     * Gets record resolver for the task.
-     *
-     * @return Record resolver.
-     */
-    public IgniteFsRecordResolver recordResolver();
-
-    /**
-     * Flag indicating whether to fail or simply skip non-existent files.
-     *
-     * @return {@code True} if non-existent files should be skipped.
-     */
-    public boolean skipNonExistentFiles();
-
-    /**
-     * User argument provided for task execution.
-     *
-     * @return User argument.
-     */
-    public T userArgument();
-
-    /**
-     * Optional maximum allowed range length, {@code 0} by default. If not specified, full range including
-     * all consecutive blocks will be used without any limitations.
-     *
-     * @return Maximum range length.
-     */
-    public long maxRangeLength();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskNoReduceAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskNoReduceAdapter.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskNoReduceAdapter.java
deleted file mode 100644
index 802b7a5..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskNoReduceAdapter.java
+++ /dev/null
@@ -1,34 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-import org.apache.ignite.compute.*;
-
-import java.util.*;
-
-/**
- * Convenient {@link IgniteFsTask} adapter with empty reduce step. Use this adapter in case you are not interested in
- * results returned by jobs.
- */
-public abstract class GridGgfsTaskNoReduceAdapter<T, R> extends IgniteFsTask<T, R> {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Default implementation which will ignore all results sent from execution nodes.
-     *
-     * @param results Received results of broadcasted remote executions. Note that if task class has
-     *      {@link org.apache.ignite.compute.ComputeTaskNoResultCache} annotation, then this list will be empty.
-     * @return Will always return {@code null}.
-     */
-    @Override public R reduce(List<ComputeJobResult> results) {
-        return null;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java
index fdddc06..e9d254f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java
@@ -12,7 +12,6 @@ package org.gridgain.grid.ggfs.mapreduce;
 import org.apache.ignite.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.ggfs.*;
-import org.gridgain.grid.ggfs.mapreduce.records.*;
 import org.jetbrains.annotations.*;
 
 import java.io.*;
@@ -28,10 +27,10 @@ import java.io.*;
  * <p>
  * The following record resolvers are available out of the box:
  * <ul>
- *     <li>{@link GridGgfsFixedLengthRecordResolver}</li>
- *     <li>{@link GridGgfsByteDelimiterRecordResolver}</li>
- *     <li>{@link GridGgfsStringDelimiterRecordResolver}</li>
- *     <li>{@link GridGgfsNewLineRecordResolver}</li>
+ *     <li>{@link org.gridgain.grid.ggfs.mapreduce.records.IgniteFsFixedLengthRecordResolver}</li>
+ *     <li>{@link org.gridgain.grid.ggfs.mapreduce.records.IgniteFsByteDelimiterRecordResolver}</li>
+ *     <li>{@link org.gridgain.grid.ggfs.mapreduce.records.IgniteFsStringDelimiterRecordResolver}</li>
+ *     <li>{@link org.gridgain.grid.ggfs.mapreduce.records.IgniteFsNewLineRecordResolver}</li>
  * </ul>
  */
 public interface IgniteFsRecordResolver extends Serializable {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java
index 0721d0b..edfdf03 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java
@@ -26,7 +26,7 @@ import java.util.*;
  * GGFS task which can be executed on the grid using one of {@code GridGgfs.execute()} methods. Essentially GGFS task
  * is regular {@link org.apache.ignite.compute.ComputeTask} with different map logic. Instead of implementing
  * {@link org.apache.ignite.compute.ComputeTask#map(List, Object)} method to split task into jobs, you must implement
- * {@link IgniteFsTask#createJob(org.gridgain.grid.ggfs.IgniteFsPath, IgniteFsFileRange, GridGgfsTaskArgs)} method.
+ * {@link IgniteFsTask#createJob(org.gridgain.grid.ggfs.IgniteFsPath, IgniteFsFileRange, IgniteFsTaskArgs)} method.
  * <p>
  * Each file participating in GGFS task is split into {@link IgniteFsFileRange}s first. Normally range is a number of
  * consequent bytes located on a single node (see {@code GridGgfsGroupDataBlocksKeyMapper}). In case maximum range size
@@ -67,7 +67,7 @@ import java.util.*;
  * }
  * </pre>
  */
-public abstract class IgniteFsTask<T, R> extends ComputeTaskAdapter<GridGgfsTaskArgs<T>, R> {
+public abstract class IgniteFsTask<T, R> extends ComputeTaskAdapter<IgniteFsTaskArgs<T>, R> {
     /** */
     private static final long serialVersionUID = 0L;
 
@@ -77,7 +77,7 @@ public abstract class IgniteFsTask<T, R> extends ComputeTaskAdapter<GridGgfsTask
 
     /** {@inheritDoc} */
     @Nullable @Override public final Map<? extends ComputeJob, ClusterNode> map(List<ClusterNode> subgrid,
-        @Nullable GridGgfsTaskArgs<T> args) throws GridException {
+        @Nullable IgniteFsTaskArgs<T> args) throws GridException {
         assert ignite != null;
         assert args != null;
 
@@ -146,7 +146,7 @@ public abstract class IgniteFsTask<T, R> extends ComputeTaskAdapter<GridGgfsTask
      * @throws GridException If job creation failed.
      */
     @Nullable public abstract IgniteFsJob createJob(IgniteFsPath path, IgniteFsFileRange range,
-        GridGgfsTaskArgs<T> args) throws GridException;
+        IgniteFsTaskArgs<T> args) throws GridException;
 
     /**
      * Maps list by node ID.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskArgs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskArgs.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskArgs.java
new file mode 100644
index 0000000..4eb7757
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskArgs.java
@@ -0,0 +1,74 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs.mapreduce;
+
+import org.gridgain.grid.ggfs.*;
+
+import java.util.*;
+
+/**
+ * GGFS task arguments. When you initiate new GGFS task execution using one of {@code GridGgfs.execute(...)} methods,
+ * all passed parameters are encapsulated in a single {@code GridGgfsTaskArgs} object. Later on this object is
+ * passed to {@link IgniteFsTask#createJob(org.gridgain.grid.ggfs.IgniteFsPath, IgniteFsFileRange, IgniteFsTaskArgs)} method.
+ * <p>
+ * Task arguments encapsulates the following data:
+ * <ul>
+ *     <li>GGFS name</li>
+ *     <li>File paths passed to {@code GridGgfs.execute()} method</li>
+ *     <li>{@link IgniteFsRecordResolver} for that task</li>
+ *     <li>Flag indicating whether to skip non-existent file paths or throw an exception</li>
+ *     <li>User-defined task argument</li>
+ *     <li>Maximum file range length for that task (see {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()})</li>
+ * </ul>
+ */
+public interface IgniteFsTaskArgs<T> {
+    /**
+     * Gets GGFS name.
+     *
+     * @return GGFS name.
+     */
+    public String ggfsName();
+
+    /**
+     * Gets file paths to process.
+     *
+     * @return File paths to process.
+     */
+    public Collection<IgniteFsPath> paths();
+
+    /**
+     * Gets record resolver for the task.
+     *
+     * @return Record resolver.
+     */
+    public IgniteFsRecordResolver recordResolver();
+
+    /**
+     * Flag indicating whether to fail or simply skip non-existent files.
+     *
+     * @return {@code True} if non-existent files should be skipped.
+     */
+    public boolean skipNonExistentFiles();
+
+    /**
+     * User argument provided for task execution.
+     *
+     * @return User argument.
+     */
+    public T userArgument();
+
+    /**
+     * Optional maximum allowed range length, {@code 0} by default. If not specified, full range including
+     * all consecutive blocks will be used without any limitations.
+     *
+     * @return Maximum range length.
+     */
+    public long maxRangeLength();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskNoReduceAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskNoReduceAdapter.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskNoReduceAdapter.java
new file mode 100644
index 0000000..180d7a4
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskNoReduceAdapter.java
@@ -0,0 +1,34 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs.mapreduce;
+
+import org.apache.ignite.compute.*;
+
+import java.util.*;
+
+/**
+ * Convenient {@link IgniteFsTask} adapter with empty reduce step. Use this adapter in case you are not interested in
+ * results returned by jobs.
+ */
+public abstract class IgniteFsTaskNoReduceAdapter<T, R> extends IgniteFsTask<T, R> {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Default implementation which will ignore all results sent from execution nodes.
+     *
+     * @param results Received results of broadcasted remote executions. Note that if task class has
+     *      {@link org.apache.ignite.compute.ComputeTaskNoResultCache} annotation, then this list will be empty.
+     * @return Will always return {@code null}.
+     */
+    @Override public R reduce(List<ComputeJobResult> results) {
+        return null;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java
deleted file mode 100644
index 808092e..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java
+++ /dev/null
@@ -1,340 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce.records;
-
-import org.apache.ignite.*;
-import org.apache.ignite.lang.*;
-import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
-import org.gridgain.grid.util.typedef.*;
-import org.gridgain.grid.util.typedef.internal.*;
-import org.gridgain.grid.util.tostring.*;
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-import java.util.*;
-
-/**
- * Record resolver which adjusts records based on provided delimiters. Both start position and length are
- * shifted to the right, based on delimiter positions.
- * <p>
- * Note that you can use {@link GridGgfsStringDelimiterRecordResolver} if your delimiter is a plain string.
- */
-public class GridGgfsByteDelimiterRecordResolver implements IgniteFsRecordResolver, Externalizable {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** Delimiters. */
-    private byte[][] delims;
-
-    /** Maximum delimiter length. */
-    @GridToStringExclude
-    private int maxDelimLen;
-
-    /**
-     * Empty constructor required for {@link Externalizable} support.
-     */
-    public GridGgfsByteDelimiterRecordResolver() {
-        // No-op.
-    }
-
-    /**
-     * Creates delimiter-based record resolver.
-     *
-     * @param delims Delimiters.
-     */
-    public GridGgfsByteDelimiterRecordResolver(byte[]... delims) {
-        if (delims == null || delims.length == 0)
-            throw new IllegalArgumentException("Delimiters cannot be null or empty.");
-
-        this.delims = delims;
-
-        int maxDelimLen = 0;
-
-        for (byte[] delim : delims) {
-            if (delim == null)
-                throw new IllegalArgumentException("Delimiter cannot be null.");
-            else if (maxDelimLen < delim.length)
-                maxDelimLen = delim.length;
-        }
-
-        this.maxDelimLen = maxDelimLen;
-    }
-
-    /** {@inheritDoc} */
-    @Override public IgniteFsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
-        IgniteFsFileRange suggestedRecord) throws GridException, IOException {
-        long suggestedStart = suggestedRecord.start();
-        long suggestedEnd = suggestedStart + suggestedRecord.length();
-
-        IgniteBiTuple<State, Delimiter> firstDelim = findFirstDelimiter(stream, suggestedStart);
-
-        State state = firstDelim != null ? firstDelim.getKey() : new State();
-
-        Delimiter curDelim = firstDelim.getValue();
-
-        while (curDelim != null && curDelim.end < suggestedStart)
-            curDelim = nextDelimiter(stream, state);
-
-        if (curDelim != null && (curDelim.end >= suggestedStart && curDelim.end < suggestedEnd) ||
-            suggestedStart == 0 ) {
-            // We found start delimiter.
-            long start = suggestedStart == 0 ? 0 : curDelim.end;
-
-            if (curDelim == null || curDelim.end < suggestedEnd) {
-                IgniteBiTuple<State, Delimiter> lastDelim = findFirstDelimiter(stream, suggestedEnd);
-
-                state = lastDelim != null ? firstDelim.getKey() : new State();
-
-                curDelim = lastDelim.getValue();
-
-                while (curDelim != null && curDelim.end < suggestedEnd)
-                    curDelim = nextDelimiter(stream, state);
-            }
-
-            long end = curDelim != null ? curDelim.end : stream.position();
-
-            return new IgniteFsFileRange(suggestedRecord.path(), start, end - start);
-        }
-        else
-            // We failed to find any delimiters up to the EOS.
-            return null;
-    }
-
-    /**
-     * Calculate maximum delimiters length.
-     *
-     * @param delims Delimiters.
-     * @return Maximum delimiter length.
-     */
-    private int maxDelimiterLength(byte[][] delims) {
-        int maxDelimLen = 0;
-
-        for (byte[] delim : delims) {
-            if (delim == null)
-                throw new IllegalArgumentException("Delimiter cannot be null.");
-            else if (maxDelimLen < delim.length)
-                maxDelimLen = delim.length;
-        }
-
-        return maxDelimLen;
-    }
-
-    /**
-     * Find first delimiter. In order to achieve this we have to rewind the stream until we find the delimiter
-     * which stands at least [maxDelimLen] from the start search position or until we faced stream start.
-     * Otherwise we cannot be sure that delimiter position is determined correctly.
-     *
-     * @param stream GGFS input stream.
-     * @param startPos Start search position.
-     * @return The first found delimiter.
-     * @throws IOException In case of IO exception.
-     */
-    @Nullable private IgniteBiTuple<State, Delimiter> findFirstDelimiter(IgniteFsInputStream stream, long startPos)
-        throws IOException {
-        State state;
-        Delimiter delim;
-
-        long curPos = Math.max(0, startPos - maxDelimLen);
-
-        while (true) {
-            stream.seek(curPos);
-
-            state = new State();
-
-            delim = nextDelimiter(stream, state);
-
-            if (curPos == 0 || delim == null || delim.start - curPos > maxDelimLen - 1)
-                break;
-            else
-                curPos = Math.max(0, curPos - maxDelimLen);
-        }
-
-        return F.t(state, delim);
-    }
-
-    /**
-     * Resolve next delimiter.
-     *
-     * @param is GGFS input stream.
-     * @param state Current state.
-     * @return Next delimiter and updated map.
-     * @throws IOException In case of exception.
-     */
-    private Delimiter nextDelimiter(IgniteFsInputStream is, State state) throws IOException {
-        assert is != null;
-        assert state != null;
-
-        Map<Integer, Integer> parts = state.parts;
-        LinkedList<Delimiter> delimQueue = state.delims;
-
-        int nextByte = is.read();
-
-        while (nextByte != -1) {
-            // Process read byte.
-            for (int idx = 0; idx < delims.length; idx++) {
-                byte[] delim = delims[idx];
-
-                int val = parts.containsKey(idx) ? parts.get(idx) : 0;
-
-                if (delim[val] == nextByte) {
-                    if (val == delim.length - 1) {
-                        // Full delimiter is found.
-                        parts.remove(idx);
-
-                        Delimiter newDelim = new Delimiter(is.position() - delim.length, is.position());
-
-                        // Read queue from the end looking for the "inner" delimiters.
-                        boolean ignore = false;
-
-                        int replaceIdx = -1;
-
-                        for (int i = delimQueue.size() - 1; i >= 0; i--) {
-                            Delimiter prevDelim = delimQueue.get(i);
-
-                            if (prevDelim.start < newDelim.start) {
-                                if (prevDelim.end > newDelim.start) {
-                                    // Ignore this delimiter.
-                                    ignore = true;
-
-                                    break;
-                                }
-                            }
-                            else if (prevDelim.start == newDelim.start) {
-                                // Ok, we found matching delimiter.
-                                replaceIdx = i;
-
-                                break;
-                            }
-                        }
-
-                        if (!ignore) {
-                            if (replaceIdx >= 0)
-                                delimQueue.removeAll(delimQueue.subList(replaceIdx, delimQueue.size()));
-
-                            delimQueue.add(newDelim);
-                        }
-                    }
-                    else
-                        parts.put(idx, ++val);
-                }
-                else if (val != 0) {
-                    if (delim[0] == nextByte) {
-                        boolean shift = true;
-
-                        for (int k = 1; k < val; k++) {
-                            if (delim[k] != nextByte) {
-                                shift = false;
-
-                                break;
-                            }
-                        }
-
-                        if (!shift)
-                            parts.put(idx, 1);
-                    }
-                    else
-                        // Delimiter sequence is totally broken.
-                        parts.remove(idx);
-                }
-            }
-
-            // Check whether we can be sure that the first delimiter will not change.
-            if (!delimQueue.isEmpty()) {
-                Delimiter delim = delimQueue.get(0);
-
-                if (is.position() - delim.end >= maxDelimLen)
-                    return delimQueue.poll();
-            }
-
-            nextByte = is.read();
-        }
-
-        return delimQueue.poll();
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridGgfsByteDelimiterRecordResolver.class, this);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void writeExternal(ObjectOutput out) throws IOException {
-        if (delims != null) {
-            out.writeBoolean(true);
-
-            out.writeInt(delims.length);
-
-            for (byte[] delim : delims)
-                U.writeByteArray(out, delim);
-        }
-        else
-            out.writeBoolean(false);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
-        if (in.readBoolean()) {
-            int len = in.readInt();
-
-            delims = new byte[len][];
-
-            for (int i = 0; i < len; i++)
-                delims[i] = U.readByteArray(in);
-
-            maxDelimLen = maxDelimiterLength(delims);
-        }
-    }
-
-    /**
-     * Delimiter descriptor.
-     */
-    private static class Delimiter {
-        /** Delimiter start position. */
-        private final long start;
-
-        /** Delimiter end position. */
-        private final long end;
-
-        /**
-         * Constructor.
-         *
-         * @param start Delimiter start position.
-         * @param end Delimiter end position.
-         */
-        private Delimiter(long start, long end) {
-            assert start >= 0 && end >= 0 && start <= end;
-
-            this.start = start;
-            this.end = end;
-        }
-    }
-
-    /**
-     * Current resolution state.
-     */
-    private static class State {
-        /** Partially resolved delimiters. */
-        private final Map<Integer, Integer> parts;
-
-        /** Resolved delimiters which could potentially be merged. */
-        private final LinkedList<Delimiter> delims;
-
-        /**
-         * Constructor.
-         */
-        private State() {
-            parts = new HashMap<>();
-
-            delims = new LinkedList<>();
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java
deleted file mode 100644
index 1edeb1a..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java
+++ /dev/null
@@ -1,79 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce.records;
-
-import org.apache.ignite.*;
-import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
-import org.gridgain.grid.util.typedef.internal.*;
-
-import java.io.*;
-
-/**
- * Record resolver which adjusts records to fixed length. That is, start offset of the record is shifted to the
- * nearest position so that {@code newStart % length == 0}.
- */
-public class GridGgfsFixedLengthRecordResolver implements IgniteFsRecordResolver, Externalizable {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** Record length. */
-    private long recLen;
-
-    /**
-     * Empty constructor required for {@link Externalizable} support.
-     */
-    public GridGgfsFixedLengthRecordResolver() {
-        // No-op.
-    }
-
-    /**
-     * Creates fixed-length record resolver.
-     *
-     * @param recLen Record length.
-     */
-    public GridGgfsFixedLengthRecordResolver(long recLen) {
-        this.recLen = recLen;
-    }
-
-    /** {@inheritDoc} */
-    @Override public IgniteFsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
-        IgniteFsFileRange suggestedRecord)
-        throws GridException, IOException {
-        long suggestedEnd = suggestedRecord.start() + suggestedRecord.length();
-
-        long startRem = suggestedRecord.start() % recLen;
-        long endRem = suggestedEnd % recLen;
-
-        long start = Math.min(suggestedRecord.start() + (startRem != 0 ? (recLen - startRem) : 0),
-            stream.length());
-        long end = Math.min(suggestedEnd + (endRem != 0 ? (recLen - endRem) : 0), stream.length());
-
-        assert end >= start;
-
-        return start != end ? new IgniteFsFileRange(suggestedRecord.path(), start, end - start) : null;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridGgfsFixedLengthRecordResolver.class, this);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void writeExternal(ObjectOutput out) throws IOException {
-        out.writeLong(recLen);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
-        recLen = in.readLong();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsNewLineRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsNewLineRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsNewLineRecordResolver.java
deleted file mode 100644
index 808759f..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsNewLineRecordResolver.java
+++ /dev/null
@@ -1,58 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce.records;
-
-import org.gridgain.grid.util.typedef.internal.*;
-
-import java.io.*;
-
-/**
- * Record resolver based on new line detection. This resolver can detect new lines based on '\n' or '\r\n' sequences.
- * <p>
- * Note that this resolver cannot be created and has one constant implementations: {@link #NEW_LINE}.
- */
-public class GridGgfsNewLineRecordResolver extends GridGgfsByteDelimiterRecordResolver {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Singleton new line resolver. This resolver will resolve records based on new lines
-     * regardless if they have '\n' or '\r\n' patterns.
-     */
-    public static final GridGgfsNewLineRecordResolver NEW_LINE = new GridGgfsNewLineRecordResolver(true);
-
-    /** CR symbol. */
-    public static final byte SYM_CR = 0x0D;
-
-    /** LF symbol. */
-    public static final byte SYM_LF = 0x0A;
-
-    /**
-     * Empty constructor required for {@link Externalizable} support.
-     */
-    public GridGgfsNewLineRecordResolver() {
-        // No-op.
-    }
-
-    /**
-     * Creates new-line record resolver.
-     *
-     * @param b Artificial flag to differentiate from empty constructor.
-     */
-    @SuppressWarnings("UnusedParameters")
-    private GridGgfsNewLineRecordResolver(boolean b) {
-        super(new byte[] { SYM_CR, SYM_LF }, new byte[] { SYM_LF });
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridGgfsNewLineRecordResolver.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsStringDelimiterRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsStringDelimiterRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsStringDelimiterRecordResolver.java
deleted file mode 100644
index 504b7e9..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsStringDelimiterRecordResolver.java
+++ /dev/null
@@ -1,76 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce.records;
-
-import org.gridgain.grid.util.typedef.internal.*;
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-import java.nio.charset.*;
-
-/**
- * Record resolver based on delimiters represented as strings. Works in the same way as
- * {@link GridGgfsByteDelimiterRecordResolver}, but uses strings as delimiters instead of byte arrays.
- */
-public class GridGgfsStringDelimiterRecordResolver extends GridGgfsByteDelimiterRecordResolver {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Converts string delimiters to byte delimiters.
-     *
-     * @param charset Charset.
-     * @param delims String delimiters.
-     * @return Byte delimiters.
-     */
-    @Nullable private static byte[][] toBytes(Charset charset, @Nullable String... delims) {
-        byte[][] res = null;
-
-        if (delims != null) {
-            res = new byte[delims.length][];
-
-            for (int i = 0; i < delims.length; i++)
-                res[i] = delims[i].getBytes(charset);
-        }
-
-        return res;
-    }
-
-    /**
-     * Empty constructor required for {@link Externalizable} support.
-     */
-    public GridGgfsStringDelimiterRecordResolver() {
-        // No-op.
-    }
-
-    /**
-     * Creates record resolver from given string and given charset.
-     *
-     * @param delims Delimiters.
-     * @param charset Charset.
-     */
-    public GridGgfsStringDelimiterRecordResolver(Charset charset, String... delims) {
-        super(toBytes(charset, delims));
-    }
-
-    /**
-     * Creates record resolver based on given string with default charset.
-     *
-     * @param delims Delimiters.
-     */
-    public GridGgfsStringDelimiterRecordResolver(String... delims) {
-        super(toBytes(Charset.defaultCharset(), delims));
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridGgfsStringDelimiterRecordResolver.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java
new file mode 100644
index 0000000..79f928e
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java
@@ -0,0 +1,340 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs.mapreduce.records;
+
+import org.apache.ignite.*;
+import org.apache.ignite.lang.*;
+import org.gridgain.grid.*;
+import org.gridgain.grid.ggfs.*;
+import org.gridgain.grid.ggfs.mapreduce.*;
+import org.gridgain.grid.util.typedef.*;
+import org.gridgain.grid.util.typedef.internal.*;
+import org.gridgain.grid.util.tostring.*;
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+import java.util.*;
+
+/**
+ * Record resolver which adjusts records based on provided delimiters. Both start position and length are
+ * shifted to the right, based on delimiter positions.
+ * <p>
+ * Note that you can use {@link IgniteFsStringDelimiterRecordResolver} if your delimiter is a plain string.
+ */
+public class IgniteFsByteDelimiterRecordResolver implements IgniteFsRecordResolver, Externalizable {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** Delimiters. */
+    private byte[][] delims;
+
+    /** Maximum delimiter length. */
+    @GridToStringExclude
+    private int maxDelimLen;
+
+    /**
+     * Empty constructor required for {@link Externalizable} support.
+     */
+    public IgniteFsByteDelimiterRecordResolver() {
+        // No-op.
+    }
+
+    /**
+     * Creates delimiter-based record resolver.
+     *
+     * @param delims Delimiters.
+     */
+    public IgniteFsByteDelimiterRecordResolver(byte[]... delims) {
+        if (delims == null || delims.length == 0)
+            throw new IllegalArgumentException("Delimiters cannot be null or empty.");
+
+        this.delims = delims;
+
+        int maxDelimLen = 0;
+
+        for (byte[] delim : delims) {
+            if (delim == null)
+                throw new IllegalArgumentException("Delimiter cannot be null.");
+            else if (maxDelimLen < delim.length)
+                maxDelimLen = delim.length;
+        }
+
+        this.maxDelimLen = maxDelimLen;
+    }
+
+    /** {@inheritDoc} */
+    @Override public IgniteFsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
+        IgniteFsFileRange suggestedRecord) throws GridException, IOException {
+        long suggestedStart = suggestedRecord.start();
+        long suggestedEnd = suggestedStart + suggestedRecord.length();
+
+        IgniteBiTuple<State, Delimiter> firstDelim = findFirstDelimiter(stream, suggestedStart);
+
+        State state = firstDelim != null ? firstDelim.getKey() : new State();
+
+        Delimiter curDelim = firstDelim.getValue();
+
+        while (curDelim != null && curDelim.end < suggestedStart)
+            curDelim = nextDelimiter(stream, state);
+
+        if (curDelim != null && (curDelim.end >= suggestedStart && curDelim.end < suggestedEnd) ||
+            suggestedStart == 0 ) {
+            // We found start delimiter.
+            long start = suggestedStart == 0 ? 0 : curDelim.end;
+
+            if (curDelim == null || curDelim.end < suggestedEnd) {
+                IgniteBiTuple<State, Delimiter> lastDelim = findFirstDelimiter(stream, suggestedEnd);
+
+                state = lastDelim != null ? firstDelim.getKey() : new State();
+
+                curDelim = lastDelim.getValue();
+
+                while (curDelim != null && curDelim.end < suggestedEnd)
+                    curDelim = nextDelimiter(stream, state);
+            }
+
+            long end = curDelim != null ? curDelim.end : stream.position();
+
+            return new IgniteFsFileRange(suggestedRecord.path(), start, end - start);
+        }
+        else
+            // We failed to find any delimiters up to the EOS.
+            return null;
+    }
+
+    /**
+     * Calculate maximum delimiters length.
+     *
+     * @param delims Delimiters.
+     * @return Maximum delimiter length.
+     */
+    private int maxDelimiterLength(byte[][] delims) {
+        int maxDelimLen = 0;
+
+        for (byte[] delim : delims) {
+            if (delim == null)
+                throw new IllegalArgumentException("Delimiter cannot be null.");
+            else if (maxDelimLen < delim.length)
+                maxDelimLen = delim.length;
+        }
+
+        return maxDelimLen;
+    }
+
+    /**
+     * Find first delimiter. In order to achieve this we have to rewind the stream until we find the delimiter
+     * which stands at least [maxDelimLen] from the start search position or until we faced stream start.
+     * Otherwise we cannot be sure that delimiter position is determined correctly.
+     *
+     * @param stream GGFS input stream.
+     * @param startPos Start search position.
+     * @return The first found delimiter.
+     * @throws IOException In case of IO exception.
+     */
+    @Nullable private IgniteBiTuple<State, Delimiter> findFirstDelimiter(IgniteFsInputStream stream, long startPos)
+        throws IOException {
+        State state;
+        Delimiter delim;
+
+        long curPos = Math.max(0, startPos - maxDelimLen);
+
+        while (true) {
+            stream.seek(curPos);
+
+            state = new State();
+
+            delim = nextDelimiter(stream, state);
+
+            if (curPos == 0 || delim == null || delim.start - curPos > maxDelimLen - 1)
+                break;
+            else
+                curPos = Math.max(0, curPos - maxDelimLen);
+        }
+
+        return F.t(state, delim);
+    }
+
+    /**
+     * Resolve next delimiter.
+     *
+     * @param is GGFS input stream.
+     * @param state Current state.
+     * @return Next delimiter and updated map.
+     * @throws IOException In case of exception.
+     */
+    private Delimiter nextDelimiter(IgniteFsInputStream is, State state) throws IOException {
+        assert is != null;
+        assert state != null;
+
+        Map<Integer, Integer> parts = state.parts;
+        LinkedList<Delimiter> delimQueue = state.delims;
+
+        int nextByte = is.read();
+
+        while (nextByte != -1) {
+            // Process read byte.
+            for (int idx = 0; idx < delims.length; idx++) {
+                byte[] delim = delims[idx];
+
+                int val = parts.containsKey(idx) ? parts.get(idx) : 0;
+
+                if (delim[val] == nextByte) {
+                    if (val == delim.length - 1) {
+                        // Full delimiter is found.
+                        parts.remove(idx);
+
+                        Delimiter newDelim = new Delimiter(is.position() - delim.length, is.position());
+
+                        // Read queue from the end looking for the "inner" delimiters.
+                        boolean ignore = false;
+
+                        int replaceIdx = -1;
+
+                        for (int i = delimQueue.size() - 1; i >= 0; i--) {
+                            Delimiter prevDelim = delimQueue.get(i);
+
+                            if (prevDelim.start < newDelim.start) {
+                                if (prevDelim.end > newDelim.start) {
+                                    // Ignore this delimiter.
+                                    ignore = true;
+
+                                    break;
+                                }
+                            }
+                            else if (prevDelim.start == newDelim.start) {
+                                // Ok, we found matching delimiter.
+                                replaceIdx = i;
+
+                                break;
+                            }
+                        }
+
+                        if (!ignore) {
+                            if (replaceIdx >= 0)
+                                delimQueue.removeAll(delimQueue.subList(replaceIdx, delimQueue.size()));
+
+                            delimQueue.add(newDelim);
+                        }
+                    }
+                    else
+                        parts.put(idx, ++val);
+                }
+                else if (val != 0) {
+                    if (delim[0] == nextByte) {
+                        boolean shift = true;
+
+                        for (int k = 1; k < val; k++) {
+                            if (delim[k] != nextByte) {
+                                shift = false;
+
+                                break;
+                            }
+                        }
+
+                        if (!shift)
+                            parts.put(idx, 1);
+                    }
+                    else
+                        // Delimiter sequence is totally broken.
+                        parts.remove(idx);
+                }
+            }
+
+            // Check whether we can be sure that the first delimiter will not change.
+            if (!delimQueue.isEmpty()) {
+                Delimiter delim = delimQueue.get(0);
+
+                if (is.position() - delim.end >= maxDelimLen)
+                    return delimQueue.poll();
+            }
+
+            nextByte = is.read();
+        }
+
+        return delimQueue.poll();
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsByteDelimiterRecordResolver.class, this);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void writeExternal(ObjectOutput out) throws IOException {
+        if (delims != null) {
+            out.writeBoolean(true);
+
+            out.writeInt(delims.length);
+
+            for (byte[] delim : delims)
+                U.writeByteArray(out, delim);
+        }
+        else
+            out.writeBoolean(false);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
+        if (in.readBoolean()) {
+            int len = in.readInt();
+
+            delims = new byte[len][];
+
+            for (int i = 0; i < len; i++)
+                delims[i] = U.readByteArray(in);
+
+            maxDelimLen = maxDelimiterLength(delims);
+        }
+    }
+
+    /**
+     * Delimiter descriptor.
+     */
+    private static class Delimiter {
+        /** Delimiter start position. */
+        private final long start;
+
+        /** Delimiter end position. */
+        private final long end;
+
+        /**
+         * Constructor.
+         *
+         * @param start Delimiter start position.
+         * @param end Delimiter end position.
+         */
+        private Delimiter(long start, long end) {
+            assert start >= 0 && end >= 0 && start <= end;
+
+            this.start = start;
+            this.end = end;
+        }
+    }
+
+    /**
+     * Current resolution state.
+     */
+    private static class State {
+        /** Partially resolved delimiters. */
+        private final Map<Integer, Integer> parts;
+
+        /** Resolved delimiters which could potentially be merged. */
+        private final LinkedList<Delimiter> delims;
+
+        /**
+         * Constructor.
+         */
+        private State() {
+            parts = new HashMap<>();
+
+            delims = new LinkedList<>();
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java
new file mode 100644
index 0000000..6190207
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java
@@ -0,0 +1,79 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs.mapreduce.records;
+
+import org.apache.ignite.*;
+import org.gridgain.grid.*;
+import org.gridgain.grid.ggfs.*;
+import org.gridgain.grid.ggfs.mapreduce.*;
+import org.gridgain.grid.util.typedef.internal.*;
+
+import java.io.*;
+
+/**
+ * Record resolver which adjusts records to fixed length. That is, start offset of the record is shifted to the
+ * nearest position so that {@code newStart % length == 0}.
+ */
+public class IgniteFsFixedLengthRecordResolver implements IgniteFsRecordResolver, Externalizable {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** Record length. */
+    private long recLen;
+
+    /**
+     * Empty constructor required for {@link Externalizable} support.
+     */
+    public IgniteFsFixedLengthRecordResolver() {
+        // No-op.
+    }
+
+    /**
+     * Creates fixed-length record resolver.
+     *
+     * @param recLen Record length.
+     */
+    public IgniteFsFixedLengthRecordResolver(long recLen) {
+        this.recLen = recLen;
+    }
+
+    /** {@inheritDoc} */
+    @Override public IgniteFsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
+        IgniteFsFileRange suggestedRecord)
+        throws GridException, IOException {
+        long suggestedEnd = suggestedRecord.start() + suggestedRecord.length();
+
+        long startRem = suggestedRecord.start() % recLen;
+        long endRem = suggestedEnd % recLen;
+
+        long start = Math.min(suggestedRecord.start() + (startRem != 0 ? (recLen - startRem) : 0),
+            stream.length());
+        long end = Math.min(suggestedEnd + (endRem != 0 ? (recLen - endRem) : 0), stream.length());
+
+        assert end >= start;
+
+        return start != end ? new IgniteFsFileRange(suggestedRecord.path(), start, end - start) : null;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsFixedLengthRecordResolver.class, this);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void writeExternal(ObjectOutput out) throws IOException {
+        out.writeLong(recLen);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
+        recLen = in.readLong();
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsNewLineRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsNewLineRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsNewLineRecordResolver.java
new file mode 100644
index 0000000..81f359e
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsNewLineRecordResolver.java
@@ -0,0 +1,58 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs.mapreduce.records;
+
+import org.gridgain.grid.util.typedef.internal.*;
+
+import java.io.*;
+
+/**
+ * Record resolver based on new line detection. This resolver can detect new lines based on '\n' or '\r\n' sequences.
+ * <p>
+ * Note that this resolver cannot be created and has one constant implementations: {@link #NEW_LINE}.
+ */
+public class IgniteFsNewLineRecordResolver extends IgniteFsByteDelimiterRecordResolver {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Singleton new line resolver. This resolver will resolve records based on new lines
+     * regardless if they have '\n' or '\r\n' patterns.
+     */
+    public static final IgniteFsNewLineRecordResolver NEW_LINE = new IgniteFsNewLineRecordResolver(true);
+
+    /** CR symbol. */
+    public static final byte SYM_CR = 0x0D;
+
+    /** LF symbol. */
+    public static final byte SYM_LF = 0x0A;
+
+    /**
+     * Empty constructor required for {@link Externalizable} support.
+     */
+    public IgniteFsNewLineRecordResolver() {
+        // No-op.
+    }
+
+    /**
+     * Creates new-line record resolver.
+     *
+     * @param b Artificial flag to differentiate from empty constructor.
+     */
+    @SuppressWarnings("UnusedParameters")
+    private IgniteFsNewLineRecordResolver(boolean b) {
+        super(new byte[] { SYM_CR, SYM_LF }, new byte[] { SYM_LF });
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsNewLineRecordResolver.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsStringDelimiterRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsStringDelimiterRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsStringDelimiterRecordResolver.java
new file mode 100644
index 0000000..3a42333
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsStringDelimiterRecordResolver.java
@@ -0,0 +1,76 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs.mapreduce.records;
+
+import org.gridgain.grid.util.typedef.internal.*;
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+import java.nio.charset.*;
+
+/**
+ * Record resolver based on delimiters represented as strings. Works in the same way as
+ * {@link IgniteFsByteDelimiterRecordResolver}, but uses strings as delimiters instead of byte arrays.
+ */
+public class IgniteFsStringDelimiterRecordResolver extends IgniteFsByteDelimiterRecordResolver {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Converts string delimiters to byte delimiters.
+     *
+     * @param charset Charset.
+     * @param delims String delimiters.
+     * @return Byte delimiters.
+     */
+    @Nullable private static byte[][] toBytes(Charset charset, @Nullable String... delims) {
+        byte[][] res = null;
+
+        if (delims != null) {
+            res = new byte[delims.length][];
+
+            for (int i = 0; i < delims.length; i++)
+                res[i] = delims[i].getBytes(charset);
+        }
+
+        return res;
+    }
+
+    /**
+     * Empty constructor required for {@link Externalizable} support.
+     */
+    public IgniteFsStringDelimiterRecordResolver() {
+        // No-op.
+    }
+
+    /**
+     * Creates record resolver from given string and given charset.
+     *
+     * @param delims Delimiters.
+     * @param charset Charset.
+     */
+    public IgniteFsStringDelimiterRecordResolver(Charset charset, String... delims) {
+        super(toBytes(charset, delims));
+    }
+
+    /**
+     * Creates record resolver based on given string with default charset.
+     *
+     * @param delims Delimiters.
+     */
+    public IgniteFsStringDelimiterRecordResolver(String... delims) {
+        super(toBytes(Charset.defaultCharset(), delims));
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsStringDelimiterRecordResolver.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
index dff827e..5d4f4ad 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
@@ -1722,7 +1722,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
      */
     <T, R> IgniteFuture<R> executeAsync(IgniteFsTask<T, R> task, @Nullable IgniteFsRecordResolver rslvr,
         Collection<IgniteFsPath> paths, boolean skipNonExistentFiles, long maxRangeLen, @Nullable T arg) {
-        return ggfsCtx.kernalContext().task().execute(task, new GridGgfsTaskArgsImpl<>(cfg.getName(), paths, rslvr,
+        return ggfsCtx.kernalContext().task().execute(task, new IgniteFsTaskArgsImpl<>(cfg.getName(), paths, rslvr,
             skipNonExistentFiles, maxRangeLen, arg));
     }
 
@@ -1757,7 +1757,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
         @Nullable IgniteFsRecordResolver rslvr, Collection<IgniteFsPath> paths, boolean skipNonExistentFiles,
         long maxRangeLen, @Nullable T arg) {
         return ggfsCtx.kernalContext().task().execute((Class<IgniteFsTask<T, R>>)taskCls,
-            new GridGgfsTaskArgsImpl<>(cfg.getName(), paths, rslvr, skipNonExistentFiles, maxRangeLen, arg));
+            new IgniteFsTaskArgsImpl<>(cfg.getName(), paths, rslvr, skipNonExistentFiles, maxRangeLen, arg));
     }
 
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskArgsImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskArgsImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskArgsImpl.java
deleted file mode 100644
index 44cac9d..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskArgsImpl.java
+++ /dev/null
@@ -1,127 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.kernal.processors.ggfs;
-
-import org.gridgain.grid.ggfs.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
-import org.gridgain.grid.util.typedef.internal.*;
-
-import java.io.*;
-import java.util.*;
-
-/**
- * GGFS task arguments implementation.
- */
-public class GridGgfsTaskArgsImpl<T> implements GridGgfsTaskArgs<T>,  Externalizable {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** GGFS name. */
-    private String ggfsName;
-
-    /** Paths. */
-    private Collection<IgniteFsPath> paths;
-
-    /** Record resolver. */
-    private IgniteFsRecordResolver recRslvr;
-
-    /** Skip non existent files flag. */
-    private boolean skipNonExistentFiles;
-
-    /** Maximum range length. */
-    private long maxRangeLen;
-
-    /** User argument. */
-    private T usrArg;
-
-    /**
-     * {@link Externalizable} support.
-     */
-    public GridGgfsTaskArgsImpl() {
-        // No-op.
-    }
-
-    /**
-     * Constructor.
-     *
-     * @param ggfsName GGFS name.
-     * @param paths Paths.
-     * @param recRslvr Record resolver.
-     * @param skipNonExistentFiles Skip non existent files flag.
-     * @param maxRangeLen Maximum range length.
-     * @param usrArg User argument.
-     */
-    public GridGgfsTaskArgsImpl(String ggfsName, Collection<IgniteFsPath> paths, IgniteFsRecordResolver recRslvr,
-        boolean skipNonExistentFiles, long maxRangeLen, T usrArg) {
-        this.ggfsName = ggfsName;
-        this.paths = paths;
-        this.recRslvr = recRslvr;
-        this.skipNonExistentFiles = skipNonExistentFiles;
-        this.maxRangeLen = maxRangeLen;
-        this.usrArg = usrArg;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String ggfsName() {
-        return ggfsName;
-    }
-
-    /** {@inheritDoc} */
-    @Override public Collection<IgniteFsPath> paths() {
-        return paths;
-    }
-
-    /** {@inheritDoc} */
-    @Override public IgniteFsRecordResolver recordResolver() {
-        return recRslvr;
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean skipNonExistentFiles() {
-        return skipNonExistentFiles;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long maxRangeLength() {
-        return maxRangeLen;
-    }
-
-    /** {@inheritDoc} */
-    @Override public T userArgument() {
-        return usrArg;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridGgfsTaskArgsImpl.class, this);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void writeExternal(ObjectOutput out) throws IOException {
-        U.writeString(out, ggfsName);
-        U.writeCollection(out, paths);
-
-        out.writeObject(recRslvr);
-        out.writeBoolean(skipNonExistentFiles);
-        out.writeLong(maxRangeLen);
-        out.writeObject(usrArg);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
-        ggfsName = U.readString(in);
-        paths = U.readCollection(in);
-
-        recRslvr = (IgniteFsRecordResolver)in.readObject();
-        skipNonExistentFiles = in.readBoolean();
-        maxRangeLen = in.readLong();
-        usrArg = (T)in.readObject();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsTaskArgsImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsTaskArgsImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsTaskArgsImpl.java
new file mode 100644
index 0000000..1edaac8
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsTaskArgsImpl.java
@@ -0,0 +1,127 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.kernal.processors.ggfs;
+
+import org.gridgain.grid.ggfs.*;
+import org.gridgain.grid.ggfs.mapreduce.*;
+import org.gridgain.grid.util.typedef.internal.*;
+
+import java.io.*;
+import java.util.*;
+
+/**
+ * GGFS task arguments implementation.
+ */
+public class IgniteFsTaskArgsImpl<T> implements IgniteFsTaskArgs<T>,  Externalizable {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** GGFS name. */
+    private String ggfsName;
+
+    /** Paths. */
+    private Collection<IgniteFsPath> paths;
+
+    /** Record resolver. */
+    private IgniteFsRecordResolver recRslvr;
+
+    /** Skip non existent files flag. */
+    private boolean skipNonExistentFiles;
+
+    /** Maximum range length. */
+    private long maxRangeLen;
+
+    /** User argument. */
+    private T usrArg;
+
+    /**
+     * {@link Externalizable} support.
+     */
+    public IgniteFsTaskArgsImpl() {
+        // No-op.
+    }
+
+    /**
+     * Constructor.
+     *
+     * @param ggfsName GGFS name.
+     * @param paths Paths.
+     * @param recRslvr Record resolver.
+     * @param skipNonExistentFiles Skip non existent files flag.
+     * @param maxRangeLen Maximum range length.
+     * @param usrArg User argument.
+     */
+    public IgniteFsTaskArgsImpl(String ggfsName, Collection<IgniteFsPath> paths, IgniteFsRecordResolver recRslvr,
+                                boolean skipNonExistentFiles, long maxRangeLen, T usrArg) {
+        this.ggfsName = ggfsName;
+        this.paths = paths;
+        this.recRslvr = recRslvr;
+        this.skipNonExistentFiles = skipNonExistentFiles;
+        this.maxRangeLen = maxRangeLen;
+        this.usrArg = usrArg;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String ggfsName() {
+        return ggfsName;
+    }
+
+    /** {@inheritDoc} */
+    @Override public Collection<IgniteFsPath> paths() {
+        return paths;
+    }
+
+    /** {@inheritDoc} */
+    @Override public IgniteFsRecordResolver recordResolver() {
+        return recRslvr;
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean skipNonExistentFiles() {
+        return skipNonExistentFiles;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long maxRangeLength() {
+        return maxRangeLen;
+    }
+
+    /** {@inheritDoc} */
+    @Override public T userArgument() {
+        return usrArg;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsTaskArgsImpl.class, this);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void writeExternal(ObjectOutput out) throws IOException {
+        U.writeString(out, ggfsName);
+        U.writeCollection(out, paths);
+
+        out.writeObject(recRslvr);
+        out.writeBoolean(skipNonExistentFiles);
+        out.writeLong(maxRangeLen);
+        out.writeObject(usrArg);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
+        ggfsName = U.readString(in);
+        paths = U.readCollection(in);
+
+        recRslvr = (IgniteFsRecordResolver)in.readObject();
+        skipNonExistentFiles = in.readBoolean();
+        maxRangeLen = in.readLong();
+        usrArg = (T)in.readObject();
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
index 9443ee7..d962109 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
@@ -148,7 +148,7 @@ public class GridGgfsTaskSelfTest extends GridGgfsCommonAbstractTest {
             Long genLen = ggfs.info(FILE).length();
 
             IgniteBiTuple<Long, Integer> taskRes = ggfs.execute(new Task(),
-                new GridGgfsStringDelimiterRecordResolver(" "), Collections.singleton(FILE), arg);
+                new IgniteFsStringDelimiterRecordResolver(" "), Collections.singleton(FILE), arg);
 
             assert F.eq(genLen, taskRes.getKey());
             assert F.eq(TOTAL_WORDS, taskRes.getValue());
@@ -176,7 +176,7 @@ public class GridGgfsTaskSelfTest extends GridGgfsCommonAbstractTest {
             Long genLen = ggfs.info(FILE).length();
 
             assertNull(ggfsAsync.execute(
-                new Task(), new GridGgfsStringDelimiterRecordResolver(" "), Collections.singleton(FILE), arg));
+                new Task(), new IgniteFsStringDelimiterRecordResolver(" "), Collections.singleton(FILE), arg));
 
             IgniteFuture<IgniteBiTuple<Long, Integer>> fut = ggfsAsync.future();
 
@@ -231,7 +231,7 @@ public class GridGgfsTaskSelfTest extends GridGgfsCommonAbstractTest {
     private static class Task extends IgniteFsTask<String, IgniteBiTuple<Long, Integer>> {
         /** {@inheritDoc} */
         @Override public IgniteFsJob createJob(IgniteFsPath path, IgniteFsFileRange range,
-            GridGgfsTaskArgs<String> args) throws GridException {
+            IgniteFsTaskArgs<String> args) throws GridException {
             return new Job();
         }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
index b88ccc2..0c20431 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
@@ -278,7 +278,7 @@ public class GridGgfsByteDelimiterRecordResolverSelfTest extends GridGgfsAbstrac
         byte[]... delims) throws Exception {
         write(data);
 
-        GridGgfsByteDelimiterRecordResolver rslvr = resolver(delims);
+        IgniteFsByteDelimiterRecordResolver rslvr = resolver(delims);
 
         IgniteFsFileRange split;
 
@@ -304,7 +304,7 @@ public class GridGgfsByteDelimiterRecordResolverSelfTest extends GridGgfsAbstrac
         throws Exception {
         write(data);
 
-        GridGgfsByteDelimiterRecordResolver rslvr = resolver(delims);
+        IgniteFsByteDelimiterRecordResolver rslvr = resolver(delims);
 
         IgniteFsFileRange split;
 
@@ -321,7 +321,7 @@ public class GridGgfsByteDelimiterRecordResolverSelfTest extends GridGgfsAbstrac
      * @param delims Delimiters.
      * @return Resolver.
      */
-    private GridGgfsByteDelimiterRecordResolver resolver(byte[]... delims) {
-        return new GridGgfsByteDelimiterRecordResolver(delims);
+    private IgniteFsByteDelimiterRecordResolver resolver(byte[]... delims) {
+        return new IgniteFsByteDelimiterRecordResolver(delims);
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
index 287e119..98b0abc 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
@@ -90,7 +90,7 @@ public class GridGgfsFixedLengthRecordResolverSelfTest extends GridGgfsAbstractR
         throws Exception {
         write(data);
 
-        GridGgfsFixedLengthRecordResolver rslvr = resolver(len);
+        IgniteFsFixedLengthRecordResolver rslvr = resolver(len);
 
         IgniteFsFileRange split;
 
@@ -116,7 +116,7 @@ public class GridGgfsFixedLengthRecordResolverSelfTest extends GridGgfsAbstractR
         throws Exception {
         write(data);
 
-        GridGgfsFixedLengthRecordResolver rslvr = resolver(len);
+        IgniteFsFixedLengthRecordResolver rslvr = resolver(len);
 
         IgniteFsFileRange split;
 
@@ -133,7 +133,7 @@ public class GridGgfsFixedLengthRecordResolverSelfTest extends GridGgfsAbstractR
      * @param len Length.
      * @return Resolver.
      */
-    private GridGgfsFixedLengthRecordResolver resolver(int len) {
-        return new GridGgfsFixedLengthRecordResolver(len);
+    private IgniteFsFixedLengthRecordResolver resolver(int len) {
+        return new IgniteFsFixedLengthRecordResolver(len);
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
index 49328bb..4d3aae2 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
@@ -14,7 +14,7 @@ import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.ggfs.mapreduce.records.*;
 import org.gridgain.grid.util.typedef.*;
 
-import static org.gridgain.grid.ggfs.mapreduce.records.GridGgfsNewLineRecordResolver.*;
+import static org.gridgain.grid.ggfs.mapreduce.records.IgniteFsNewLineRecordResolver.*;
 
 /**
  * New line split resolver self test.
@@ -74,7 +74,7 @@ public class GridGgfsNewLineDelimiterRecordResolverSelfTest extends GridGgfsAbst
         throws Exception {
         write(data);
 
-        GridGgfsNewLineRecordResolver rslvr = resolver();
+        IgniteFsNewLineRecordResolver rslvr = resolver();
 
         IgniteFsFileRange split;
 
@@ -99,7 +99,7 @@ public class GridGgfsNewLineDelimiterRecordResolverSelfTest extends GridGgfsAbst
         throws Exception {
         write(data);
 
-        GridGgfsNewLineRecordResolver rslvr = resolver();
+        IgniteFsNewLineRecordResolver rslvr = resolver();
 
         IgniteFsFileRange split;
 
@@ -115,7 +115,7 @@ public class GridGgfsNewLineDelimiterRecordResolverSelfTest extends GridGgfsAbst
      *
      * @return Resolver.
      */
-    private GridGgfsNewLineRecordResolver resolver() {
-        return GridGgfsNewLineRecordResolver.NEW_LINE;
+    private IgniteFsNewLineRecordResolver resolver() {
+        return IgniteFsNewLineRecordResolver.NEW_LINE;
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/243e521e/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
index bf31792..51dbf5f 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
@@ -80,7 +80,7 @@ public class GridGgfsStringDelimiterRecordResolverSelfTest extends GridGgfsAbstr
         String... delims) throws Exception {
         write(data);
 
-        GridGgfsByteDelimiterRecordResolver rslvr = resolver(delims);
+        IgniteFsByteDelimiterRecordResolver rslvr = resolver(delims);
 
         IgniteFsFileRange split;
 
@@ -106,7 +106,7 @@ public class GridGgfsStringDelimiterRecordResolverSelfTest extends GridGgfsAbstr
         throws Exception {
         write(data);
 
-        GridGgfsStringDelimiterRecordResolver rslvr = resolver(delims);
+        IgniteFsStringDelimiterRecordResolver rslvr = resolver(delims);
 
         IgniteFsFileRange split;
 
@@ -123,7 +123,7 @@ public class GridGgfsStringDelimiterRecordResolverSelfTest extends GridGgfsAbstr
      * @param delims Delimiters.
      * @return Resolver.
      */
-    private GridGgfsStringDelimiterRecordResolver resolver(String... delims) {
-        return new GridGgfsStringDelimiterRecordResolver(UTF8, delims);
+    private IgniteFsStringDelimiterRecordResolver resolver(String... delims) {
+        return new IgniteFsStringDelimiterRecordResolver(UTF8, delims);
     }
 }


[12/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
index 625ad1a..e4230f5 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
@@ -47,26 +47,26 @@ public class GridGgfsAsyncImpl extends IgniteAsyncSupportAdapter implements Grid
 
     /** {@inheritDoc} */
     @Override public <T, R> R execute(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
-        Collection<GridGgfsPath> paths, @Nullable T arg) throws GridException {
+        Collection<IgniteFsPath> paths, @Nullable T arg) throws GridException {
         return saveOrGet(ggfs.executeAsync(task, rslvr, paths, arg));
     }
 
     /** {@inheritDoc} */
     @Override public <T, R> R execute(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
-        Collection<GridGgfsPath> paths, boolean skipNonExistentFiles, long maxRangeLen, @Nullable T arg)
+        Collection<IgniteFsPath> paths, boolean skipNonExistentFiles, long maxRangeLen, @Nullable T arg)
         throws GridException {
         return saveOrGet(ggfs.executeAsync(task, rslvr, paths, skipNonExistentFiles, maxRangeLen, arg));
     }
 
     /** {@inheritDoc} */
     @Override public <T, R> R execute(Class<? extends GridGgfsTask<T, R>> taskCls,
-        @Nullable GridGgfsRecordResolver rslvr, Collection<GridGgfsPath> paths, @Nullable T arg) throws GridException {
+        @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, @Nullable T arg) throws GridException {
         return saveOrGet(ggfs.executeAsync(taskCls, rslvr, paths, arg));
     }
 
     /** {@inheritDoc} */
     @Override public <T, R> R execute(Class<? extends GridGgfsTask<T, R>> taskCls,
-        @Nullable GridGgfsRecordResolver rslvr, Collection<GridGgfsPath> paths, boolean skipNonExistentFiles,
+        @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, boolean skipNonExistentFiles,
         long maxRangeLen, @Nullable T arg) throws GridException {
         return saveOrGet(ggfs.executeAsync(taskCls, rslvr, paths, skipNonExistentFiles, maxRangeLen, arg));
     }
@@ -87,18 +87,18 @@ public class GridGgfsAsyncImpl extends IgniteAsyncSupportAdapter implements Grid
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsInputStreamAdapter open(GridGgfsPath path, int bufSize,
+    @Override public GridGgfsInputStreamAdapter open(IgniteFsPath path, int bufSize,
         int seqReadsBeforePrefetch) throws GridException {
         return ggfs.open(path, bufSize, seqReadsBeforePrefetch);
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsInputStreamAdapter open(GridGgfsPath path) throws GridException {
+    @Override public GridGgfsInputStreamAdapter open(IgniteFsPath path) throws GridException {
         return ggfs.open(path);
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsInputStreamAdapter open(GridGgfsPath path, int bufSize) throws GridException {
+    @Override public GridGgfsInputStreamAdapter open(IgniteFsPath path, int bufSize) throws GridException {
         return ggfs.open(path, bufSize);
     }
 
@@ -143,7 +143,7 @@ public class GridGgfsAsyncImpl extends IgniteAsyncSupportAdapter implements Grid
     }
 
     /** {@inheritDoc} */
-    @Override public boolean evictExclude(GridGgfsPath path, boolean primary) {
+    @Override public boolean evictExclude(IgniteFsPath path, boolean primary) {
         return ggfs.evictExclude(path, primary);
     }
 
@@ -168,52 +168,52 @@ public class GridGgfsAsyncImpl extends IgniteAsyncSupportAdapter implements Grid
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsPathSummary summary(GridGgfsPath path) throws GridException {
+    @Override public IgniteFsPathSummary summary(IgniteFsPath path) throws GridException {
         return ggfs.summary(path);
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream create(GridGgfsPath path, boolean overwrite) throws GridException {
+    @Override public GridGgfsOutputStream create(IgniteFsPath path, boolean overwrite) throws GridException {
         return ggfs.create(path, overwrite);
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream create(GridGgfsPath path, int bufSize, boolean overwrite, int replication,
+    @Override public GridGgfsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication,
         long blockSize, @Nullable Map<String, String> props) throws GridException {
         return ggfs.create(path, bufSize, overwrite, replication, blockSize, props);
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream create(GridGgfsPath path, int bufSize, boolean overwrite,
+    @Override public GridGgfsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite,
         @Nullable IgniteUuid affKey, int replication, long blockSize, @Nullable Map<String, String> props)
         throws GridException {
         return ggfs.create(path, bufSize, overwrite, affKey, replication, blockSize, props);
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream append(GridGgfsPath path, boolean create) throws GridException {
+    @Override public GridGgfsOutputStream append(IgniteFsPath path, boolean create) throws GridException {
         return ggfs.append(path, create);
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream append(GridGgfsPath path, int bufSize, boolean create,
+    @Override public GridGgfsOutputStream append(IgniteFsPath path, int bufSize, boolean create,
         @Nullable Map<String, String> props) throws GridException {
         return ggfs.append(path, bufSize, create, props);
     }
 
     /** {@inheritDoc} */
-    @Override public void setTimes(GridGgfsPath path, long accessTime, long modificationTime) throws GridException {
+    @Override public void setTimes(IgniteFsPath path, long accessTime, long modificationTime) throws GridException {
         ggfs.setTimes(path, accessTime, modificationTime);
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsBlockLocation> affinity(GridGgfsPath path, long start, long len)
+    @Override public Collection<IgniteFsBlockLocation> affinity(IgniteFsPath path, long start, long len)
         throws GridException {
         return ggfs.affinity(path, start, len);
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsBlockLocation> affinity(GridGgfsPath path, long start, long len, long maxLen)
+    @Override public Collection<IgniteFsBlockLocation> affinity(IgniteFsPath path, long start, long len, long maxLen)
         throws GridException {
         return ggfs.affinity(path, start, len, maxLen);
     }
@@ -229,52 +229,52 @@ public class GridGgfsAsyncImpl extends IgniteAsyncSupportAdapter implements Grid
     }
 
     /** {@inheritDoc} */
-    @Override public long size(GridGgfsPath path) throws GridException {
+    @Override public long size(IgniteFsPath path) throws GridException {
         return ggfs.size(path);
     }
 
     /** {@inheritDoc} */
-    @Override public boolean exists(GridGgfsPath path) throws GridException {
+    @Override public boolean exists(IgniteFsPath path) throws GridException {
         return ggfs.exists(path);
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public GridGgfsFile update(GridGgfsPath path, Map<String, String> props) throws GridException {
+    @Nullable @Override public GridGgfsFile update(IgniteFsPath path, Map<String, String> props) throws GridException {
         return ggfs.update(path, props);
     }
 
     /** {@inheritDoc} */
-    @Override public void rename(GridGgfsPath src, GridGgfsPath dest) throws GridException {
+    @Override public void rename(IgniteFsPath src, IgniteFsPath dest) throws GridException {
         ggfs.rename(src, dest);
     }
 
     /** {@inheritDoc} */
-    @Override public boolean delete(GridGgfsPath path, boolean recursive) throws GridException {
+    @Override public boolean delete(IgniteFsPath path, boolean recursive) throws GridException {
         return ggfs.delete(path, recursive);
     }
 
     /** {@inheritDoc} */
-    @Override public void mkdirs(GridGgfsPath path) throws GridException {
+    @Override public void mkdirs(IgniteFsPath path) throws GridException {
         ggfs.mkdirs(path);
     }
 
     /** {@inheritDoc} */
-    @Override public void mkdirs(GridGgfsPath path, @Nullable Map<String, String> props) throws GridException {
+    @Override public void mkdirs(IgniteFsPath path, @Nullable Map<String, String> props) throws GridException {
         ggfs.mkdirs(path, props);
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsPath> listPaths(GridGgfsPath path) throws GridException {
+    @Override public Collection<IgniteFsPath> listPaths(IgniteFsPath path) throws GridException {
         return ggfs.listPaths(path);
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsFile> listFiles(GridGgfsPath path) throws GridException {
+    @Override public Collection<GridGgfsFile> listFiles(IgniteFsPath path) throws GridException {
         return ggfs.listFiles(path);
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public GridGgfsFile info(GridGgfsPath path) throws GridException {
+    @Nullable @Override public GridGgfsFile info(IgniteFsPath path) throws GridException {
         return ggfs.info(path);
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsBlockLocationImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsBlockLocationImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsBlockLocationImpl.java
index 18becde..b94e262 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsBlockLocationImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsBlockLocationImpl.java
@@ -23,7 +23,7 @@ import java.util.*;
 /**
  * File block location in the grid.
  */
-public class GridGgfsBlockLocationImpl implements GridGgfsBlockLocation, Externalizable {
+public class GridGgfsBlockLocationImpl implements IgniteFsBlockLocation, Externalizable {
     /** */
     private static final long serialVersionUID = 0L;
 
@@ -54,7 +54,7 @@ public class GridGgfsBlockLocationImpl implements GridGgfsBlockLocation, Externa
      * @param location HDFS block location.
      * @param len New length.
      */
-    public GridGgfsBlockLocationImpl(GridGgfsBlockLocation location, long len) {
+    public GridGgfsBlockLocationImpl(IgniteFsBlockLocation location, long len) {
         assert location != null;
 
         start = location.start();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
index c1e2c7e..1e1ff41 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
@@ -370,8 +370,8 @@ public class GridGgfsDataManager extends GridGgfsManager {
      * @return Requested data block or {@code null} if nothing found.
      * @throws GridException If failed.
      */
-    @Nullable public IgniteFuture<byte[]> dataBlock(final GridGgfsFileInfo fileInfo, final GridGgfsPath path,
-        final long blockIdx, @Nullable final GridGgfsReader secReader)
+    @Nullable public IgniteFuture<byte[]> dataBlock(final GridGgfsFileInfo fileInfo, final IgniteFsPath path,
+        final long blockIdx, @Nullable final IgniteFsReader secReader)
         throws GridException {
         //assert validTxState(any); // Allow this method call for any transaction state.
 
@@ -729,7 +729,7 @@ public class GridGgfsDataManager extends GridGgfsManager {
      * @return Affinity blocks locations.
      * @throws GridException If failed.
      */
-    public Collection<GridGgfsBlockLocation> affinity(GridGgfsFileInfo info, long start, long len)
+    public Collection<IgniteFsBlockLocation> affinity(GridGgfsFileInfo info, long start, long len)
         throws GridException {
         return affinity(info, start, len, 0);
     }
@@ -744,7 +744,7 @@ public class GridGgfsDataManager extends GridGgfsManager {
      * @return Affinity blocks locations.
      * @throws GridException If failed.
      */
-    public Collection<GridGgfsBlockLocation> affinity(GridGgfsFileInfo info, long start, long len, long maxLen)
+    public Collection<IgniteFsBlockLocation> affinity(GridGgfsFileInfo info, long start, long len, long maxLen)
         throws GridException {
         assert validTxState(false);
         assert info.isFile() : "Failed to get affinity (not a file): " + info;
@@ -770,7 +770,7 @@ public class GridGgfsDataManager extends GridGgfsManager {
 
         // In case when affinity key is not null the whole file resides on one node.
         if (info.affinityKey() != null) {
-            Collection<GridGgfsBlockLocation> res = new LinkedList<>();
+            Collection<IgniteFsBlockLocation> res = new LinkedList<>();
 
             splitBlocks(start, len, maxLen, dataCache.affinity().mapKeyToPrimaryAndBackups(
                 new GridGgfsBlockKey(info.id(), info.affinityKey(), info.evictExclude(), 0)), res);
@@ -779,7 +779,7 @@ public class GridGgfsDataManager extends GridGgfsManager {
         }
 
         // Need to merge ranges affinity with non-colocated affinity.
-        Deque<GridGgfsBlockLocation> res = new LinkedList<>();
+        Deque<IgniteFsBlockLocation> res = new LinkedList<>();
 
         if (info.fileMap().ranges().isEmpty()) {
             affinity0(info, start, len, maxLen, res);
@@ -803,7 +803,7 @@ public class GridGgfsDataManager extends GridGgfsManager {
                 pos = partEnd;
             }
 
-            GridGgfsBlockLocation last = res.peekLast();
+            IgniteFsBlockLocation last = res.peekLast();
 
             if (range.belongs(pos)) {
                 long partEnd = Math.min(range.endOffset() + 1, end);
@@ -854,7 +854,7 @@ public class GridGgfsDataManager extends GridGgfsManager {
      * @param res Result collection to add regions to.
      * @throws GridException If failed.
      */
-    private void affinity0(GridGgfsFileInfo info, long start, long len, long maxLen, Deque<GridGgfsBlockLocation> res)
+    private void affinity0(GridGgfsFileInfo info, long start, long len, long maxLen, Deque<IgniteFsBlockLocation> res)
         throws GridException {
         long firstGrpIdx = start / grpBlockSize;
         long limitGrpIdx = (start + len + grpBlockSize - 1) / grpBlockSize;
@@ -897,7 +897,7 @@ public class GridGgfsDataManager extends GridGgfsManager {
                 log.debug("Mapped key to nodes [key=" + key + ", nodes=" + F.nodeIds(affNodes) +
                 ", blockStart=" + blockStart + ", blockLen=" + blockLen + ']');
 
-            GridGgfsBlockLocation last = res.peekLast();
+            IgniteFsBlockLocation last = res.peekLast();
 
             // Merge with previous affinity block location?
             if (last != null && equal(last.nodeIds(), F.viewReadOnly(affNodes, F.node2id()))) {
@@ -926,7 +926,7 @@ public class GridGgfsDataManager extends GridGgfsManager {
      * @param res Where to put results.
      */
     private void splitBlocks(long start, long len, long maxLen,
-        Collection<ClusterNode> nodes, Collection<GridGgfsBlockLocation> res) {
+        Collection<ClusterNode> nodes, Collection<IgniteFsBlockLocation> res) {
         if (maxLen > 0) {
             long end = start + len;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsEx.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsEx.java
index eaf25ba..0738bbc 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsEx.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsEx.java
@@ -39,14 +39,14 @@ public interface GridGgfsEx extends IgniteFs {
     public GridGgfsPaths proxyPaths();
 
     /** {@inheritDoc} */
-    @Override GridGgfsInputStreamAdapter open(GridGgfsPath path, int bufSize, int seqReadsBeforePrefetch)
+    @Override GridGgfsInputStreamAdapter open(IgniteFsPath path, int bufSize, int seqReadsBeforePrefetch)
         throws GridException;
 
     /** {@inheritDoc} */
-    @Override GridGgfsInputStreamAdapter open(GridGgfsPath path) throws GridException;
+    @Override GridGgfsInputStreamAdapter open(IgniteFsPath path) throws GridException;
 
     /** {@inheritDoc} */
-    @Override GridGgfsInputStreamAdapter open(GridGgfsPath path, int bufSize) throws GridException;
+    @Override GridGgfsInputStreamAdapter open(IgniteFsPath path, int bufSize) throws GridException;
 
     /**
      * Gets global space counters.
@@ -116,7 +116,7 @@ public interface GridGgfsEx extends IgniteFs {
      * @param primary Whether the mode is PRIMARY.
      * @return {@code True} if path is excluded from evictions.
      */
-    public boolean evictExclude(GridGgfsPath path, boolean primary);
+    public boolean evictExclude(IgniteFsPath path, boolean primary);
 
     /**
      * Get next affinity key.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileImpl.java
index f6f18a1..0485761 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileImpl.java
@@ -25,7 +25,7 @@ public final class GridGgfsFileImpl implements GridGgfsFile, Externalizable {
     private static final long serialVersionUID = 0L;
 
     /** Path to this file. */
-    private GridGgfsPath path;
+    private IgniteFsPath path;
 
     /** File id. */
     private IgniteUuid fileId;
@@ -60,7 +60,7 @@ public final class GridGgfsFileImpl implements GridGgfsFile, Externalizable {
      *
      * @param path Path.
      */
-    public GridGgfsFileImpl(GridGgfsPath path, GridGgfsFileInfo info, long globalGrpBlockSize) {
+    public GridGgfsFileImpl(IgniteFsPath path, GridGgfsFileInfo info, long globalGrpBlockSize) {
         A.notNull(path, "path");
         A.notNull(info, "info");
 
@@ -90,7 +90,7 @@ public final class GridGgfsFileImpl implements GridGgfsFile, Externalizable {
      * @param path Path.
      * @param entry Listing entry.
      */
-    public GridGgfsFileImpl(GridGgfsPath path, GridGgfsListingEntry entry, long globalGrpSize) {
+    public GridGgfsFileImpl(IgniteFsPath path, GridGgfsListingEntry entry, long globalGrpSize) {
         A.notNull(path, "path");
         A.notNull(entry, "entry");
 
@@ -110,7 +110,7 @@ public final class GridGgfsFileImpl implements GridGgfsFile, Externalizable {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsPath path() {
+    @Override public IgniteFsPath path() {
         return path;
     }
 
@@ -200,7 +200,7 @@ public final class GridGgfsFileImpl implements GridGgfsFile, Externalizable {
      * @param in Data input.
      */
     @Override public void readExternal(ObjectInput in) throws IOException {
-        path = new GridGgfsPath();
+        path = new IgniteFsPath();
 
         path.readExternal(in);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileInfo.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileInfo.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileInfo.java
index da4e6ec..5078088 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileInfo.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileInfo.java
@@ -71,7 +71,7 @@ public final class GridGgfsFileInfo implements Externalizable {
      * Original file path. This is a helper field used only in some
      * operations like delete.
      */
-    private GridGgfsPath path;
+    private IgniteFsPath path;
 
     /**
      * {@link Externalizable} support.
@@ -459,7 +459,7 @@ public final class GridGgfsFileInfo implements Externalizable {
     /**
      * @return Original file path. This is a helper field used only in some operations like delete.
      */
-    public GridGgfsPath path() {
+    public IgniteFsPath path() {
         return path;
     }
 
@@ -492,7 +492,7 @@ public final class GridGgfsFileInfo implements Externalizable {
         accessTime = in.readLong();
         modificationTime = in.readLong();
         evictExclude = in.readBoolean();
-        path = (GridGgfsPath)in.readObject();
+        path = (IgniteFsPath)in.readObject();
     }
 
     /** {@inheritDoc} */
@@ -541,7 +541,7 @@ public final class GridGgfsFileInfo implements Externalizable {
          * @param path A new path value.
          * @return This builder instance (for chaining).
          */
-        public Builder path(GridGgfsPath path) {
+        public Builder path(IgniteFsPath path) {
             info.path = path;
 
             return this;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileWorkerBatch.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileWorkerBatch.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileWorkerBatch.java
index 1c3d19c..0d5b7d4 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileWorkerBatch.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileWorkerBatch.java
@@ -35,7 +35,7 @@ public class GridGgfsFileWorkerBatch {
     private final BlockingDeque<GridGgfsFileWorkerTask> queue = new LinkedBlockingDeque<>();
 
     /** Path to the file in the primary file system. */
-    private final GridGgfsPath path;
+    private final IgniteFsPath path;
 
     /** Output stream to the file. */
     private final OutputStream out;
@@ -52,7 +52,7 @@ public class GridGgfsFileWorkerBatch {
      * @param path Path to the file in the primary file system.
      * @param out Output stream opened to that file.
      */
-    GridGgfsFileWorkerBatch(GridGgfsPath path, OutputStream out) {
+    GridGgfsFileWorkerBatch(IgniteFsPath path, OutputStream out) {
         assert path != null;
         assert out != null;
 
@@ -182,7 +182,7 @@ public class GridGgfsFileWorkerBatch {
      *
      * @return Primary file system path.
      */
-    GridGgfsPath path() {
+    IgniteFsPath path() {
         return path;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
index a07539b..fca2fdb 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
@@ -87,7 +87,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     private final GridSpinBusyLock busyLock = new GridSpinBusyLock();
 
     /** Writers map. */
-    private final ConcurrentHashMap8<GridGgfsPath, GridGgfsFileWorker> workerMap = new ConcurrentHashMap8<>();
+    private final ConcurrentHashMap8<IgniteFsPath, GridGgfsFileWorker> workerMap = new ConcurrentHashMap8<>();
 
     /** Delete futures. */
     private final ConcurrentHashMap8<IgniteUuid, GridFutureAdapter<Object>> delFuts = new ConcurrentHashMap8<>();
@@ -163,7 +163,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
             }
         }
 
-        ArrayList<T2<GridGgfsPath, GridGgfsMode>> modes = null;
+        ArrayList<T2<IgniteFsPath, GridGgfsMode>> modes = null;
 
         if (!cfgModes.isEmpty()) {
             modes = new ArrayList<>(cfgModes.size());
@@ -172,7 +172,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 GridGgfsMode mode0 = secondaryFs == null ? mode.getValue() == PROXY ? PROXY : PRIMARY : mode.getValue();
 
                 try {
-                    modes.add(new T2<>(new GridGgfsPath(mode.getKey()), mode0));
+                    modes.add(new T2<>(new IgniteFsPath(mode.getKey()), mode0));
                 }
                 catch (IllegalArgumentException e) {
                     throw new GridException("Invalid path found in mode pattern: " + mode.getKey(), e);
@@ -256,7 +256,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
      * @return Created batch.
      * @throws GridException In case new batch cannot be created.
      */
-    private GridGgfsFileWorkerBatch newBatch(final GridGgfsPath path, OutputStream out) throws GridException {
+    private GridGgfsFileWorkerBatch newBatch(final IgniteFsPath path, OutputStream out) throws GridException {
         assert path != null;
         assert out != null;
 
@@ -319,15 +319,15 @@ public final class GridGgfsImpl implements GridGgfsEx {
      *
      * @param paths Paths to check.
      */
-    void await(GridGgfsPath... paths) {
+    void await(IgniteFsPath... paths) {
         assert paths != null;
 
-        for (Map.Entry<GridGgfsPath, GridGgfsFileWorker> workerEntry : workerMap.entrySet()) {
-            GridGgfsPath workerPath = workerEntry.getKey();
+        for (Map.Entry<IgniteFsPath, GridGgfsFileWorker> workerEntry : workerMap.entrySet()) {
+            IgniteFsPath workerPath = workerEntry.getKey();
 
             boolean await = false;
 
-            for (GridGgfsPath path : paths) {
+            for (IgniteFsPath path : paths) {
                 if (workerPath.isSubDirectoryOf(path) || workerPath.isSame(path))  {
                     await = true;
 
@@ -461,7 +461,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public boolean exists(GridGgfsPath path) throws GridException {
+    @Override public boolean exists(IgniteFsPath path) throws GridException {
         A.notNull(path, "path");
 
         if (log.isDebugEnabled())
@@ -497,7 +497,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile info(GridGgfsPath path) throws GridException {
+    @Override public GridGgfsFile info(IgniteFsPath path) throws GridException {
         if (enterBusy()) {
             try {
                 A.notNull(path, "path");
@@ -526,7 +526,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsPathSummary summary(GridGgfsPath path) throws GridException {
+    @Override public IgniteFsPathSummary summary(IgniteFsPath path) throws GridException {
         if (enterBusy()) {
             try {
                 A.notNull(path, "path");
@@ -539,7 +539,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 if (fileId == null)
                     throw new GridGgfsFileNotFoundException("Failed to get path summary (path not found): " + path);
 
-                GridGgfsPathSummary sum = new GridGgfsPathSummary(path);
+                IgniteFsPathSummary sum = new IgniteFsPathSummary(path);
 
                 summary0(fileId, sum);
 
@@ -554,7 +554,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile update(GridGgfsPath path, Map<String, String> props) throws GridException {
+    @Override public GridGgfsFile update(IgniteFsPath path, Map<String, String> props) throws GridException {
         if (enterBusy()) {
             try {
                 A.notNull(path, "path");
@@ -610,7 +610,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public void rename(GridGgfsPath src, GridGgfsPath dest) throws GridException {
+    @Override public void rename(IgniteFsPath src, IgniteFsPath dest) throws GridException {
         if (enterBusy()) {
             try {
                 A.notNull(src, "src");
@@ -651,7 +651,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                     return;
                 }
 
-                GridGgfsPath destParent = dest.parent();
+                IgniteFsPath destParent = dest.parent();
 
                 // Resolve source file info.
                 FileDescriptor srcDesc = getFileDescriptor(src);
@@ -701,7 +701,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                     if (evts.isRecordable(EVT_GGFS_FILE_RENAMED))
                         evts.record(new IgniteFsEvent(
                             src,
-                            newDest ? dest : new GridGgfsPath(dest, destFileName),
+                            newDest ? dest : new IgniteFsPath(dest, destFileName),
                             localNode(),
                             EVT_GGFS_FILE_RENAMED));
                 }
@@ -719,7 +719,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public boolean delete(GridGgfsPath path, boolean recursive) throws GridException {
+    @Override public boolean delete(IgniteFsPath path, boolean recursive) throws GridException {
         if (enterBusy()) {
             try {
                 A.notNull(path, "path");
@@ -783,9 +783,9 @@ public final class GridGgfsImpl implements GridGgfsEx {
      *      {@code recursive} flag is false, will return {@code false}.
      * @throws GridException In case of error.
      */
-    private boolean delete0(FileDescriptor desc, @Nullable GridGgfsPath parentPath, boolean recursive)
+    private boolean delete0(FileDescriptor desc, @Nullable IgniteFsPath parentPath, boolean recursive)
         throws GridException {
-        GridGgfsPath curPath = parentPath == null ? new GridGgfsPath() : new GridGgfsPath(parentPath, desc.fileName);
+        IgniteFsPath curPath = parentPath == null ? new IgniteFsPath() : new IgniteFsPath(parentPath, desc.fileName);
 
         if (desc.isFile) {
             deleteFile(curPath, desc, true);
@@ -815,12 +815,12 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public void mkdirs(GridGgfsPath path) throws GridException {
+    @Override public void mkdirs(IgniteFsPath path) throws GridException {
         mkdirs(path, null);
     }
 
     /** {@inheritDoc} */
-    @Override public void mkdirs(GridGgfsPath path, @Nullable Map<String, String> props) throws GridException {
+    @Override public void mkdirs(IgniteFsPath path, @Nullable Map<String, String> props) throws GridException {
         if (enterBusy()) {
             try {
                 A.notNull(path, "path");
@@ -853,7 +853,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
 
                 IgniteUuid parentId = ROOT_ID;
 
-                GridGgfsPath curPath = path.root();
+                IgniteFsPath curPath = path.root();
 
                 for (int step = 0, size = components.size(); step < size; step++) {
                     IgniteUuid fileId = ids.get(step + 1); // Skip the first ROOT element.
@@ -863,7 +863,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
 
                         String fileName = components.get(step); // Get current component name.
 
-                        curPath = new GridGgfsPath(curPath, fileName);
+                        curPath = new IgniteFsPath(curPath, fileName);
 
                         try {
                             // Fails only if parent is not a directory or if modified concurrently.
@@ -907,7 +907,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsPath> listPaths(final GridGgfsPath path) throws GridException {
+    @Override public Collection<IgniteFsPath> listPaths(final IgniteFsPath path) throws GridException {
         if (enterBusy()) {
             try {
                 A.notNull(path, "path");
@@ -927,9 +927,9 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 if (childrenModes.contains(DUAL_SYNC) || childrenModes.contains(DUAL_ASYNC)) {
                     assert secondaryFs != null;
 
-                    Collection<GridGgfsPath> children = secondaryFs.listPaths(path);
+                    Collection<IgniteFsPath> children = secondaryFs.listPaths(path);
 
-                    for (GridGgfsPath child : children)
+                    for (IgniteFsPath child : children)
                         files.add(child.name());
                 }
 
@@ -943,10 +943,10 @@ public final class GridGgfsImpl implements GridGgfsEx {
                     throw new GridGgfsFileNotFoundException("Failed to list files (path not found): " + path);
                 }
 
-                return F.viewReadOnly(files, new C1<String, GridGgfsPath>() {
+                return F.viewReadOnly(files, new C1<String, IgniteFsPath>() {
                     @Override
-                    public GridGgfsPath apply(String e) {
-                        return new GridGgfsPath(path, e);
+                    public IgniteFsPath apply(String e) {
+                        return new IgniteFsPath(path, e);
                     }
                 });
             }
@@ -959,7 +959,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsFile> listFiles(final GridGgfsPath path) throws GridException {
+    @Override public Collection<GridGgfsFile> listFiles(final IgniteFsPath path) throws GridException {
         if (enterBusy()) {
             try {
                 A.notNull(path, "path");
@@ -1003,7 +1003,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
 
                         // Perform the listing.
                         for (Map.Entry<String, GridGgfsListingEntry> e : info.listing().entrySet()) {
-                            GridGgfsPath p = new GridGgfsPath(path, e.getKey());
+                            IgniteFsPath p = new IgniteFsPath(path, e.getKey());
 
                             files.add(new GridGgfsFileImpl(p, e.getValue(), data.groupBlockSize()));
                         }
@@ -1036,17 +1036,17 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsInputStreamAdapter open(GridGgfsPath path) throws GridException {
+    @Override public GridGgfsInputStreamAdapter open(IgniteFsPath path) throws GridException {
         return open(path, cfg.getStreamBufferSize(), cfg.getSequentialReadsBeforePrefetch());
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsInputStreamAdapter open(GridGgfsPath path, int bufSize) throws GridException {
+    @Override public GridGgfsInputStreamAdapter open(IgniteFsPath path, int bufSize) throws GridException {
         return open(path, bufSize, cfg.getSequentialReadsBeforePrefetch());
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsInputStreamAdapter open(GridGgfsPath path, int bufSize, int seqReadsBeforePrefetch)
+    @Override public GridGgfsInputStreamAdapter open(IgniteFsPath path, int bufSize, int seqReadsBeforePrefetch)
         throws GridException {
         if (enterBusy()) {
             try {
@@ -1107,18 +1107,18 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream create(GridGgfsPath path, boolean overwrite) throws GridException {
+    @Override public GridGgfsOutputStream create(IgniteFsPath path, boolean overwrite) throws GridException {
         return create0(path, cfg.getStreamBufferSize(), overwrite, null, 0, null, true);
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream create(GridGgfsPath path, int bufSize, boolean overwrite, int replication,
+    @Override public GridGgfsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication,
         long blockSize, @Nullable Map<String, String> props) throws GridException {
         return create0(path, bufSize, overwrite, null, replication, props, false);
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream create(GridGgfsPath path, int bufSize, boolean overwrite,
+    @Override public GridGgfsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite,
         @Nullable IgniteUuid affKey, int replication, long blockSize, @Nullable Map<String, String> props)
         throws GridException {
         return create0(path, bufSize, overwrite, affKey, replication, props, false);
@@ -1138,7 +1138,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
      * @throws GridException If file creation failed.
      */
     private GridGgfsOutputStream create0(
-        final GridGgfsPath path,
+        final IgniteFsPath path,
         final int bufSize,
         final boolean overwrite,
         @Nullable IgniteUuid affKey,
@@ -1181,7 +1181,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 }
 
                 // Re-create parents when working in PRIMARY mode. In DUAL mode this is done by MetaManager.
-                GridGgfsPath parent = path.parent();
+                IgniteFsPath parent = path.parent();
 
                 // Create missing parent directories if necessary.
                 if (parent != null)
@@ -1209,13 +1209,13 @@ public final class GridGgfsImpl implements GridGgfsEx {
                         break;
 
                     if (!overwrite)
-                        throw new GridGgfsPathAlreadyExistsException("Failed to create file (file already exists): " +
+                        throw new IgniteFsPathAlreadyExistsException("Failed to create file (file already exists): " +
                             path);
 
                     GridGgfsFileInfo oldInfo = meta.info(oldId);
 
                     if (oldInfo.isDirectory())
-                        throw new GridGgfsPathAlreadyExistsException("Failed to create file (path points to a " +
+                        throw new IgniteFsPathAlreadyExistsException("Failed to create file (path points to a " +
                             "directory): " + path);
 
                     // Remove old file from the tree.
@@ -1248,12 +1248,12 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream append(GridGgfsPath path, boolean create) throws GridException {
+    @Override public GridGgfsOutputStream append(IgniteFsPath path, boolean create) throws GridException {
         return append(path, cfg.getStreamBufferSize(), create, null);
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsOutputStream append(final GridGgfsPath path, final int bufSize, boolean create,
+    @Override public GridGgfsOutputStream append(final IgniteFsPath path, final int bufSize, boolean create,
         @Nullable Map<String, String> props) throws GridException {
         if (enterBusy()) {
             try {
@@ -1332,7 +1332,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public void setTimes(GridGgfsPath path, long accessTime, long modificationTime)
+    @Override public void setTimes(IgniteFsPath path, long accessTime, long modificationTime)
         throws GridException {
         if (enterBusy()) {
             try {
@@ -1369,7 +1369,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
      * @param path Path to check.
      * @throws GridException If path exists.
      */
-    private void checkConflictWithPrimary(GridGgfsPath path) throws GridException {
+    private void checkConflictWithPrimary(IgniteFsPath path) throws GridException {
         if (secondaryFs != null) {
             if (secondaryFs.info(path) != null) {
                 throw new GridException("Path mapped to a PRIMARY mode found in secondary file " +
@@ -1379,13 +1379,13 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsBlockLocation> affinity(GridGgfsPath path, long start, long len)
+    @Override public Collection<IgniteFsBlockLocation> affinity(IgniteFsPath path, long start, long len)
         throws GridException {
         return affinity(path, start, len, 0L);
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsBlockLocation> affinity(GridGgfsPath path, long start, long len, long maxLen)
+    @Override public Collection<IgniteFsBlockLocation> affinity(IgniteFsPath path, long start, long len, long maxLen)
         throws GridException {
         if (enterBusy()) {
             try {
@@ -1434,7 +1434,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     @Override public GridGgfsMetrics metrics() throws GridException {
         if (enterBusy()) {
             try {
-                GridGgfsPathSummary sum = new GridGgfsPathSummary();
+                IgniteFsPathSummary sum = new IgniteFsPathSummary();
 
                 summary0(ROOT_ID, sum);
 
@@ -1482,7 +1482,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public long size(GridGgfsPath path) throws GridException {
+    @Override public long size(IgniteFsPath path) throws GridException {
         if (enterBusy()) {
             try {
                 A.notNull(path, "path");
@@ -1492,7 +1492,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 if (nextId == null)
                     return 0;
 
-                GridGgfsPathSummary sum = new GridGgfsPathSummary(path);
+                IgniteFsPathSummary sum = new IgniteFsPathSummary(path);
 
                 summary0(nextId, sum);
 
@@ -1513,7 +1513,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
      * @param sum Summary object that will collect information.
      * @throws GridException If failed.
      */
-    private void summary0(IgniteUuid fileId, GridGgfsPathSummary sum) throws GridException {
+    private void summary0(IgniteUuid fileId, IgniteFsPathSummary sum) throws GridException {
         assert sum != null;
 
         GridGgfsFileInfo info = meta.info(fileId);
@@ -1611,7 +1611,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
      * @return Detailed file descriptor or {@code null}, if file does not exist.
      * @throws GridException If failed.
      */
-    @Nullable private FileDescriptor getFileDescriptor(GridGgfsPath path) throws GridException {
+    @Nullable private FileDescriptor getFileDescriptor(IgniteFsPath path) throws GridException {
         List<IgniteUuid> ids = meta.fileIds(path);
         GridGgfsFileInfo fileInfo = meta.info(ids.get(ids.size() - 1));
 
@@ -1632,7 +1632,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
      * @param rmvLocked Whether to remove this entry in case it is has explicit lock.
      * @throws GridException If failed.
      */
-    private void deleteFile(GridGgfsPath path, FileDescriptor desc, boolean rmvLocked) throws GridException {
+    private void deleteFile(IgniteFsPath path, FileDescriptor desc, boolean rmvLocked) throws GridException {
         IgniteUuid parentId = desc.parentId;
         IgniteUuid fileId = desc.fileId;
 
@@ -1668,26 +1668,26 @@ public final class GridGgfsImpl implements GridGgfsEx {
 
     /** {@inheritDoc} */
     @Override public <T, R> R execute(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
-        Collection<GridGgfsPath> paths, @Nullable T arg) throws GridException {
+        Collection<IgniteFsPath> paths, @Nullable T arg) throws GridException {
         return executeAsync(task, rslvr, paths, arg).get();
     }
 
     /** {@inheritDoc} */
     @Override public <T, R> R execute(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
-        Collection<GridGgfsPath> paths, boolean skipNonExistentFiles, long maxRangeLen, @Nullable T arg)
+        Collection<IgniteFsPath> paths, boolean skipNonExistentFiles, long maxRangeLen, @Nullable T arg)
         throws GridException {
         return executeAsync(task, rslvr, paths, skipNonExistentFiles, maxRangeLen, arg).get();
     }
 
     /** {@inheritDoc} */
     @Override public <T, R> R execute(Class<? extends GridGgfsTask<T, R>> taskCls,
-        @Nullable GridGgfsRecordResolver rslvr, Collection<GridGgfsPath> paths, @Nullable T arg) throws GridException {
+        @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, @Nullable T arg) throws GridException {
         return executeAsync(taskCls, rslvr, paths, arg).get();
     }
 
     /** {@inheritDoc} */
     @Override public <T, R> R execute(Class<? extends GridGgfsTask<T, R>> taskCls,
-        @Nullable GridGgfsRecordResolver rslvr, Collection<GridGgfsPath> paths, boolean skipNonExistentFiles,
+        @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, boolean skipNonExistentFiles,
         long maxRangeSize, @Nullable T arg) throws GridException {
         return executeAsync(taskCls, rslvr, paths, skipNonExistentFiles, maxRangeSize, arg).get();
     }
@@ -1702,7 +1702,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
      * @return Execution future.
      */
     <T, R> IgniteFuture<R> executeAsync(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
-        Collection<GridGgfsPath> paths, @Nullable T arg) {
+        Collection<IgniteFsPath> paths, @Nullable T arg) {
         return executeAsync(task, rslvr, paths, true, cfg.getMaximumTaskRangeLength(), arg);
     }
 
@@ -1721,7 +1721,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
      * @return Execution future.
      */
     <T, R> IgniteFuture<R> executeAsync(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
-        Collection<GridGgfsPath> paths, boolean skipNonExistentFiles, long maxRangeLen, @Nullable T arg) {
+        Collection<IgniteFsPath> paths, boolean skipNonExistentFiles, long maxRangeLen, @Nullable T arg) {
         return ggfsCtx.kernalContext().task().execute(task, new GridGgfsTaskArgsImpl<>(cfg.getName(), paths, rslvr,
             skipNonExistentFiles, maxRangeLen, arg));
     }
@@ -1736,7 +1736,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
      * @return Execution future.
      */
     <T, R> IgniteFuture<R> executeAsync(Class<? extends GridGgfsTask<T, R>> taskCls,
-        @Nullable GridGgfsRecordResolver rslvr, Collection<GridGgfsPath> paths, @Nullable T arg) {
+        @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, @Nullable T arg) {
         return executeAsync(taskCls, rslvr, paths, true, cfg.getMaximumTaskRangeLength(), arg);
     }
 
@@ -1754,14 +1754,14 @@ public final class GridGgfsImpl implements GridGgfsEx {
      * @return Execution future.
      */
     <T, R> IgniteFuture<R> executeAsync(Class<? extends GridGgfsTask<T, R>> taskCls,
-        @Nullable GridGgfsRecordResolver rslvr, Collection<GridGgfsPath> paths, boolean skipNonExistentFiles,
+        @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, boolean skipNonExistentFiles,
         long maxRangeLen, @Nullable T arg) {
         return ggfsCtx.kernalContext().task().execute((Class<GridGgfsTask<T, R>>)taskCls,
             new GridGgfsTaskArgsImpl<>(cfg.getName(), paths, rslvr, skipNonExistentFiles, maxRangeLen, arg));
     }
 
     /** {@inheritDoc} */
-    @Override public boolean evictExclude(GridGgfsPath path, boolean primary) {
+    @Override public boolean evictExclude(IgniteFsPath path, boolean primary) {
         assert path != null;
 
         try {
@@ -1783,7 +1783,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
      * @return File info or {@code null} in case file is not found.
      * @throws GridException If failed.
      */
-    private GridGgfsFileInfo resolveFileInfo(GridGgfsPath path, GridGgfsMode mode) throws GridException {
+    private GridGgfsFileInfo resolveFileInfo(IgniteFsPath path, GridGgfsMode mode) throws GridException {
         assert path != null;
         assert mode != null;
 
@@ -1914,7 +1914,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
          * @param batch Optional secondary file system batch.
          * @throws GridException In case of error.
          */
-        GgfsEventAwareOutputStream(GridGgfsPath path, GridGgfsFileInfo fileInfo,
+        GgfsEventAwareOutputStream(IgniteFsPath path, GridGgfsFileInfo fileInfo,
             IgniteUuid parentId, int bufSize, GridGgfsMode mode, @Nullable GridGgfsFileWorkerBatch batch)
             throws GridException {
             super(ggfsCtx, path, fileInfo, parentId, bufSize, mode, batch, metrics);
@@ -1954,8 +1954,8 @@ public final class GridGgfsImpl implements GridGgfsEx {
          * @param secReader Optional secondary file system reader.
          * @param metrics Metrics.
          */
-        GgfsEventAwareInputStream(GridGgfsContext ggfsCtx, GridGgfsPath path, GridGgfsFileInfo fileInfo,
-            int prefetchBlocks, int seqReadsBeforePrefetch, @Nullable GridGgfsReader secReader,
+        GgfsEventAwareInputStream(GridGgfsContext ggfsCtx, IgniteFsPath path, GridGgfsFileInfo fileInfo,
+            int prefetchBlocks, int seqReadsBeforePrefetch, @Nullable IgniteFsReader secReader,
             GridGgfsLocalMetrics metrics) {
             super(ggfsCtx, path, fileInfo, prefetchBlocks, seqReadsBeforePrefetch, secReader, metrics);
 
@@ -2138,7 +2138,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     /** {@inheritDoc} */
     @Override public boolean isProxy(URI path) {
         GridGgfsMode mode = F.isEmpty(cfg.getPathModes()) ? cfg.getDefaultMode() :
-            modeRslvr.resolveMode(new GridGgfsPath(path));
+            modeRslvr.resolveMode(new IgniteFsPath(path));
 
         return mode == PROXY;
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java
index 2a0240f..5fa2366 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java
@@ -37,13 +37,13 @@ public class GridGgfsInputStreamImpl extends GridGgfsInputStreamAdapter {
 
     /** Secondary file system reader. */
     @SuppressWarnings("FieldAccessedSynchronizedAndUnsynchronized")
-    private final GridGgfsReader secReader;
+    private final IgniteFsReader secReader;
 
     /** Logger. */
     private IgniteLogger log;
 
     /** Path to file. */
-    protected final GridGgfsPath path;
+    protected final IgniteFsPath path;
 
     /** File descriptor. */
     private volatile GridGgfsFileInfo fileInfo;
@@ -101,8 +101,8 @@ public class GridGgfsInputStreamImpl extends GridGgfsInputStreamAdapter {
      * @param secReader Optional secondary file system reader.
      * @param metrics Local GGFS metrics.
      */
-    GridGgfsInputStreamImpl(GridGgfsContext ggfsCtx, GridGgfsPath path, GridGgfsFileInfo fileInfo, int prefetchBlocks,
-        int seqReadsBeforePrefetch, @Nullable GridGgfsReader secReader, GridGgfsLocalMetrics metrics) {
+    GridGgfsInputStreamImpl(GridGgfsContext ggfsCtx, IgniteFsPath path, GridGgfsFileInfo fileInfo, int prefetchBlocks,
+        int seqReadsBeforePrefetch, @Nullable IgniteFsReader secReader, GridGgfsLocalMetrics metrics) {
         assert ggfsCtx != null;
         assert path != null;
         assert fileInfo != null;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
index 246187a..3ef20fe 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
@@ -33,7 +33,7 @@ public class GridGgfsJobImpl implements ComputeJob, GridInternalWrapper<GridGgfs
     private String ggfsName;
 
     /** GGFS path. */
-    private GridGgfsPath path;
+    private IgniteFsPath path;
 
     /** Start. */
     private long start;
@@ -60,7 +60,7 @@ public class GridGgfsJobImpl implements ComputeJob, GridInternalWrapper<GridGgfs
      * @param len Split length.
      * @param rslvr GGFS split resolver.
      */
-    public GridGgfsJobImpl(GridGgfsJob job, String ggfsName, GridGgfsPath path, long start, long len,
+    public GridGgfsJobImpl(GridGgfsJob job, String ggfsName, IgniteFsPath path, long start, long len,
         GridGgfsRecordResolver rslvr) {
         this.job = job;
         this.ggfsName = ggfsName;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
index e1b1391..cff85d0 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
@@ -160,7 +160,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return File ID for specified path or {@code null} if such file doesn't exist.
      * @throws GridException If failed.
      */
-    @Nullable public IgniteUuid fileId(GridGgfsPath path) throws GridException {
+    @Nullable public IgniteUuid fileId(IgniteFsPath path) throws GridException {
         if (busyLock.enterBusy()) {
             try {
                 assert validTxState(false);
@@ -183,7 +183,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return File ID for specified path or {@code null} if such file doesn't exist.
      * @throws GridException If failed.
      */
-    @Nullable private IgniteUuid fileId(GridGgfsPath path, boolean skipTx) throws GridException {
+    @Nullable private IgniteUuid fileId(IgniteFsPath path, boolean skipTx) throws GridException {
         List<IgniteUuid> ids = fileIds(path, skipTx);
 
         assert ids != null && !ids.isEmpty() : "Invalid file IDs [path=" + path + ", ids=" + ids + ']';
@@ -243,7 +243,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return Collection of file IDs for components of specified path.
      * @throws GridException If failed.
      */
-    public List<IgniteUuid> fileIds(GridGgfsPath path) throws GridException {
+    public List<IgniteUuid> fileIds(IgniteFsPath path) throws GridException {
         if (busyLock.enterBusy()) {
             try {
                 assert validTxState(false);
@@ -268,7 +268,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return Collection of file IDs for components of specified path.
      * @throws GridException If failed.
      */
-    private List<IgniteUuid> fileIds(GridGgfsPath path, boolean skipTx) throws GridException {
+    private List<IgniteUuid> fileIds(IgniteFsPath path, boolean skipTx) throws GridException {
         assert path != null;
 
         // Path components.
@@ -885,7 +885,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @throws GridException If failed.
      */
     @Nullable public GridGgfsFileInfo removeIfEmpty(IgniteUuid parentId, String fileName, IgniteUuid fileId,
-        GridGgfsPath path, boolean rmvLocked)
+        IgniteFsPath path, boolean rmvLocked)
         throws GridException {
         if (busyLock.enterBusy()) {
             try {
@@ -932,7 +932,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @throws GridException If failed.
      */
     @Nullable private GridGgfsFileInfo removeIfEmptyNonTx(@Nullable IgniteUuid parentId, String fileName, IgniteUuid fileId,
-        GridGgfsPath path, boolean rmvLocked)
+        IgniteFsPath path, boolean rmvLocked)
         throws GridException {
         assert validTxState(true);
         assert parentId != null;
@@ -1577,7 +1577,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return Output stream descriptor.
      * @throws GridException If file creation failed.
      */
-    public GridGgfsSecondaryOutputStreamDescriptor createDual(final GridGgfsFileSystem fs, final GridGgfsPath path,
+    public GridGgfsSecondaryOutputStreamDescriptor createDual(final GridGgfsFileSystem fs, final IgniteFsPath path,
         final boolean simpleCreate, @Nullable final Map<String, String> props, final boolean overwrite, final int bufSize,
         final short replication, final long blockSize, final IgniteUuid affKey)
         throws GridException {
@@ -1594,14 +1594,14 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                         /** Output stream to the secondary file system. */
                         private OutputStream out;
 
-                        @Override public GridGgfsSecondaryOutputStreamDescriptor onSuccess(Map<GridGgfsPath,
+                        @Override public GridGgfsSecondaryOutputStreamDescriptor onSuccess(Map<IgniteFsPath,
                             GridGgfsFileInfo> infos) throws Exception {
                             assert !infos.isEmpty();
 
                             // Determine the first existing parent.
-                            GridGgfsPath parentPath = null;
+                            IgniteFsPath parentPath = null;
 
-                            for (GridGgfsPath curPath : infos.keySet()) {
+                            for (IgniteFsPath curPath : infos.keySet()) {
                                 if (parentPath == null || curPath.isSubDirectoryOf(parentPath))
                                     parentPath = curPath;
                             }
@@ -1614,7 +1614,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                             out = simpleCreate ? fs.create(path, overwrite) :
                                 fs.create(path, bufSize, overwrite, replication, blockSize, props);
 
-                            GridGgfsPath parent0 = path.parent();
+                            IgniteFsPath parent0 = path.parent();
 
                             assert parent0 != null : "path.parent() is null (are we creating ROOT?): " + path;
 
@@ -1624,7 +1624,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
 
                                 // Fire notification about missing directories creation.
                                 if (evts.isRecordable(EVT_GGFS_DIR_CREATED)) {
-                                    GridGgfsPath evtPath = parent0;
+                                    IgniteFsPath evtPath = parent0;
 
                                     while (!parentPath.equals(evtPath)) {
                                         pendingEvts.addFirst(new IgniteFsEvent(evtPath, locNode, EVT_GGFS_DIR_CREATED));
@@ -1737,7 +1737,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return Output stream descriptor.
      * @throws GridException If output stream open for append has failed.
      */
-    public GridGgfsSecondaryOutputStreamDescriptor appendDual(final GridGgfsFileSystem fs, final GridGgfsPath path,
+    public GridGgfsSecondaryOutputStreamDescriptor appendDual(final GridGgfsFileSystem fs, final IgniteFsPath path,
         final int bufSize) throws GridException {
         if (busyLock.enterBusy()) {
             try {
@@ -1749,7 +1749,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                         /** Output stream to the secondary file system. */
                         private OutputStream out;
 
-                        @Override public GridGgfsSecondaryOutputStreamDescriptor onSuccess(Map<GridGgfsPath,
+                        @Override public GridGgfsSecondaryOutputStreamDescriptor onSuccess(Map<IgniteFsPath,
                             GridGgfsFileInfo> infos) throws Exception {
                             GridGgfsFileInfo info = infos.get(path);
 
@@ -1768,7 +1768,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                             if (remainder > 0) {
                                 int blockIdx = (int)(len / blockSize);
 
-                                GridGgfsReader reader = fs.open(path, bufSize);
+                                IgniteFsReader reader = fs.open(path, bufSize);
 
                                 try {
                                     ggfsCtx.data().dataBlock(info, path, blockIdx, reader).get();
@@ -1820,7 +1820,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return Input stream descriptor.
      * @throws GridException If input stream open has failed.
      */
-    public GridGgfsSecondaryInputStreamDescriptor openDual(final GridGgfsFileSystem fs, final GridGgfsPath path,
+    public GridGgfsSecondaryInputStreamDescriptor openDual(final GridGgfsFileSystem fs, final IgniteFsPath path,
         final int bufSize)
         throws GridException {
         if (busyLock.enterBusy()) {
@@ -1842,7 +1842,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                 SynchronizationTask<GridGgfsSecondaryInputStreamDescriptor> task =
                     new SynchronizationTask<GridGgfsSecondaryInputStreamDescriptor>() {
                         @Override public GridGgfsSecondaryInputStreamDescriptor onSuccess(
-                            Map<GridGgfsPath, GridGgfsFileInfo> infos) throws Exception {
+                            Map<IgniteFsPath, GridGgfsFileInfo> infos) throws Exception {
                             GridGgfsFileInfo info = infos.get(path);
 
                             if (info == null)
@@ -1884,7 +1884,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return File info or {@code null} if file not found.
      * @throws GridException If sync task failed.
      */
-    @Nullable public GridGgfsFileInfo synchronizeFileDual(final GridGgfsFileSystem fs, final GridGgfsPath path)
+    @Nullable public GridGgfsFileInfo synchronizeFileDual(final GridGgfsFileSystem fs, final IgniteFsPath path)
         throws GridException {
         assert fs != null;
         assert path != null;
@@ -1900,7 +1900,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                 // If failed, try synchronize.
                 SynchronizationTask<GridGgfsFileInfo> task =
                     new SynchronizationTask<GridGgfsFileInfo>() {
-                        @Override public GridGgfsFileInfo onSuccess(Map<GridGgfsPath, GridGgfsFileInfo> infos)
+                        @Override public GridGgfsFileInfo onSuccess(Map<IgniteFsPath, GridGgfsFileInfo> infos)
                             throws Exception {
                             return infos.get(path);
                         }
@@ -1935,7 +1935,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return {@code True} in case rename was successful.
      * @throws GridException If directory creation failed.
      */
-    public boolean mkdirsDual(final GridGgfsFileSystem fs, final GridGgfsPath path, final Map<String, String> props)
+    public boolean mkdirsDual(final GridGgfsFileSystem fs, final IgniteFsPath path, final Map<String, String> props)
         throws GridException {
         if (busyLock.enterBusy()) {
             try {
@@ -1950,15 +1950,15 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                 final Deque<IgniteFsEvent> pendingEvts = new LinkedList<>();
 
                 SynchronizationTask<Boolean> task = new SynchronizationTask<Boolean>() {
-                    @Override public Boolean onSuccess(Map<GridGgfsPath, GridGgfsFileInfo> infos) throws Exception {
+                    @Override public Boolean onSuccess(Map<IgniteFsPath, GridGgfsFileInfo> infos) throws Exception {
                         fs.mkdirs(path, props);
 
                         assert !infos.isEmpty();
 
                         // Now perform synchronization again starting with the last created parent.
-                        GridGgfsPath parentPath = null;
+                        IgniteFsPath parentPath = null;
 
-                        for (GridGgfsPath curPath : infos.keySet()) {
+                        for (IgniteFsPath curPath : infos.keySet()) {
                             if (parentPath == null || curPath.isSubDirectoryOf(parentPath))
                                 parentPath = curPath;
                         }
@@ -1970,7 +1970,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                         synchronize(fs, parentPath, parentPathInfo, path, true, null);
 
                         if (evts.isRecordable(EVT_GGFS_DIR_CREATED)) {
-                            GridGgfsPath evtPath = path;
+                            IgniteFsPath evtPath = path;
 
                             while (!parentPath.equals(evtPath)) {
                                 pendingEvts.addFirst(new IgniteFsEvent(evtPath, locNode, EVT_GGFS_DIR_CREATED));
@@ -2019,7 +2019,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return Operation result.
      * @throws GridException If failed.
      */
-    public boolean renameDual(final GridGgfsFileSystem fs, final GridGgfsPath src, final GridGgfsPath dest) throws
+    public boolean renameDual(final GridGgfsFileSystem fs, final IgniteFsPath src, final IgniteFsPath dest) throws
         GridException {
         if (busyLock.enterBusy()) {
             try {
@@ -2034,7 +2034,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                 final Collection<IgniteFsEvent> pendingEvts = new LinkedList<>();
 
                 SynchronizationTask<Boolean> task = new SynchronizationTask<Boolean>() {
-                    @Override public Boolean onSuccess(Map<GridGgfsPath, GridGgfsFileInfo> infos) throws Exception {
+                    @Override public Boolean onSuccess(Map<IgniteFsPath, GridGgfsFileInfo> infos) throws Exception {
                         GridGgfsFileInfo srcInfo = infos.get(src);
                         GridGgfsFileInfo srcParentInfo = infos.get(src.parent());
                         GridGgfsFileInfo destInfo = infos.get(dest);
@@ -2072,7 +2072,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                             if (evts.isRecordable(EVT_GGFS_FILE_RENAMED))
                                 pendingEvts.add(new IgniteFsEvent(
                                     src,
-                                    destInfo == null ? dest : new GridGgfsPath(dest, src.name()),
+                                    destInfo == null ? dest : new IgniteFsPath(dest, src.name()),
                                     locNode,
                                     EVT_GGFS_FILE_RENAMED));
                         }
@@ -2120,7 +2120,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return Operation result.
      * @throws GridException If delete failed.
      */
-    public boolean deleteDual(final GridGgfsFileSystem fs, final GridGgfsPath path, final boolean recursive)
+    public boolean deleteDual(final GridGgfsFileSystem fs, final IgniteFsPath path, final boolean recursive)
         throws GridException {
         if (busyLock.enterBusy()) {
             try {
@@ -2128,7 +2128,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                 assert path != null;
 
                 SynchronizationTask<Boolean> task = new SynchronizationTask<Boolean>() {
-                    @Override public Boolean onSuccess(Map<GridGgfsPath, GridGgfsFileInfo> infos) throws Exception {
+                    @Override public Boolean onSuccess(Map<IgniteFsPath, GridGgfsFileInfo> infos) throws Exception {
                         GridGgfsFileInfo info = infos.get(path);
 
                         if (info == null)
@@ -2186,7 +2186,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return Update file info.
      * @throws GridException If update failed.
      */
-    public GridGgfsFileInfo updateDual(final GridGgfsFileSystem fs, final GridGgfsPath path, final Map<String, String> props)
+    public GridGgfsFileInfo updateDual(final GridGgfsFileSystem fs, final IgniteFsPath path, final Map<String, String> props)
         throws GridException {
         assert fs != null;
         assert path != null;
@@ -2195,7 +2195,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
         if (busyLock.enterBusy()) {
             try {
                 SynchronizationTask<GridGgfsFileInfo> task = new SynchronizationTask<GridGgfsFileInfo>() {
-                    @Override public GridGgfsFileInfo onSuccess(Map<GridGgfsPath, GridGgfsFileInfo> infos)
+                    @Override public GridGgfsFileInfo onSuccess(Map<IgniteFsPath, GridGgfsFileInfo> infos)
                         throws Exception {
                         if (infos.get(path) == null)
                             return null;
@@ -2239,8 +2239,8 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return File info of the end path.
      * @throws GridException If failed.
      */
-    private GridGgfsFileInfo synchronize(GridGgfsFileSystem fs, GridGgfsPath startPath, GridGgfsFileInfo startPathInfo,
-        GridGgfsPath endPath, boolean strict, @Nullable Map<GridGgfsPath, GridGgfsFileInfo> created)
+    private GridGgfsFileInfo synchronize(GridGgfsFileSystem fs, IgniteFsPath startPath, GridGgfsFileInfo startPathInfo,
+        IgniteFsPath endPath, boolean strict, @Nullable Map<IgniteFsPath, GridGgfsFileInfo> created)
         throws GridException {
         assert fs != null;
         assert startPath != null && startPathInfo != null && endPath != null;
@@ -2251,10 +2251,10 @@ public class GridGgfsMetaManager extends GridGgfsManager {
 
         List<String> components = endPath.components();
 
-        GridGgfsPath curPath = startPath;
+        IgniteFsPath curPath = startPath;
 
         for (int i = startPath.components().size(); i < components.size(); i++) {
-            curPath = new GridGgfsPath(curPath, components.get(i));
+            curPath = new IgniteFsPath(curPath, components.get(i));
 
             if (created != null && created.containsKey(curPath))
                 // Re-use already created info.
@@ -2312,7 +2312,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @throws GridException If failed.
      */
     private <T> T synchronizeAndExecute(SynchronizationTask<T> task, GridGgfsFileSystem fs, boolean strict,
-        GridGgfsPath... paths)
+        IgniteFsPath... paths)
         throws GridException {
         return synchronizeAndExecute(task, fs, strict, null, paths);
     }
@@ -2330,7 +2330,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @throws GridException If failed.
      */
     private <T> T synchronizeAndExecute(SynchronizationTask<T> task, GridGgfsFileSystem fs, boolean strict,
-        @Nullable Collection<IgniteUuid> extraLockIds, GridGgfsPath... paths) throws GridException {
+        @Nullable Collection<IgniteUuid> extraLockIds, IgniteFsPath... paths) throws GridException {
         assert task != null;
         assert fs != null;
         assert paths != null && paths.length > 0;
@@ -2347,7 +2347,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
             // Obtain existing IDs outside the transaction.
             List<List<IgniteUuid>> pathIds = new ArrayList<>(paths.length);
 
-            for (GridGgfsPath path : paths)
+            for (IgniteFsPath path : paths)
                 pathIds.add(fileIds(path));
 
             // Start pessimistic.
@@ -2355,19 +2355,19 @@ public class GridGgfsMetaManager extends GridGgfsManager {
 
             try {
                 // Lock the very first existing parents and possibly the leaf as well.
-                Map<GridGgfsPath, GridGgfsPath> pathToParent = new HashMap<>();
+                Map<IgniteFsPath, IgniteFsPath> pathToParent = new HashMap<>();
 
-                Map<GridGgfsPath, IgniteUuid> pathToId = new HashMap<>();
+                Map<IgniteFsPath, IgniteUuid> pathToId = new HashMap<>();
 
                 for (int i = 0; i < paths.length; i++) {
-                    GridGgfsPath path = paths[i];
+                    IgniteFsPath path = paths[i];
 
                     // Determine the very first existing parent
                     List<IgniteUuid> ids = pathIds.get(i);
 
                     if (ids.size() > 1) {
                         // The path is not root.
-                        GridGgfsPath parentPath = path.parent();
+                        IgniteFsPath parentPath = path.parent();
                         IgniteUuid parentId = ids.get(ids.size() - 2);
 
                         for (int j = ids.size() - 3; j >= 0; j--) {
@@ -2413,9 +2413,9 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                 }
 
                 // Ensure that locked IDs still point to expected paths.
-                GridGgfsPath changed = null;
+                IgniteFsPath changed = null;
 
-                for (Map.Entry<GridGgfsPath, IgniteUuid> entry : pathToId.entrySet()) {
+                for (Map.Entry<IgniteFsPath, IgniteUuid> entry : pathToId.entrySet()) {
                     if (!idToInfo.containsKey(entry.getValue()) ||
                         !F.eq(entry.getValue(), fileId(entry.getKey(), true))) {
                         changed = entry.getKey();
@@ -2447,12 +2447,12 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                         continue; // Release all locks and try again.
                     else {
                         // Perform synchronization.
-                        Map<GridGgfsPath, GridGgfsFileInfo> infos = new HashMap<>();
+                        Map<IgniteFsPath, GridGgfsFileInfo> infos = new HashMap<>();
 
-                        TreeMap<GridGgfsPath, GridGgfsFileInfo> created = new TreeMap<>();
+                        TreeMap<IgniteFsPath, GridGgfsFileInfo> created = new TreeMap<>();
 
-                        for (GridGgfsPath path : paths) {
-                            GridGgfsPath parentPath = path.parent();
+                        for (IgniteFsPath path : paths) {
+                            IgniteFsPath parentPath = path.parent();
 
                             if (pathToId.containsKey(path)) {
                                 infos.put(path, info(pathToId.get(path)));
@@ -2461,7 +2461,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                                     infos.put(parentPath, info(pathToId.get(parentPath)));
                             }
                             else {
-                                GridGgfsPath firstParentPath = pathToParent.get(path);
+                                IgniteFsPath firstParentPath = pathToParent.get(path);
 
                                 assert firstParentPath != null;
                                 assert pathToId.get(firstParentPath) != null;
@@ -2634,7 +2634,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
          * @return Task result.
          * @throws Exception If failed.
          */
-        public T onSuccess(Map<GridGgfsPath, GridGgfsFileInfo> infos) throws Exception;
+        public T onSuccess(Map<IgniteFsPath, GridGgfsFileInfo> infos) throws Exception;
 
         /**
          * Callback handler in case synchronization failed.
@@ -2651,13 +2651,13 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      */
     private static class PathDescriptor {
         /** Path. */
-        private final GridGgfsPath path;
+        private final IgniteFsPath path;
 
         /** Resolved IDs. */
         private final List<IgniteUuid> ids;
 
         /** Parent path. */
-        private GridGgfsPath parentPath;
+        private IgniteFsPath parentPath;
 
         /** Parent path info. */
         private GridGgfsFileInfo parentInfo;
@@ -2670,7 +2670,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
          * @param parentPath Parent path.
          * @param parentInfo Parent info.
          */
-        PathDescriptor(GridGgfsPath path, List<IgniteUuid> ids, GridGgfsPath parentPath, GridGgfsFileInfo parentInfo) {
+        PathDescriptor(IgniteFsPath path, List<IgniteUuid> ids, IgniteFsPath parentPath, GridGgfsFileInfo parentInfo) {
             assert path != null;
             assert ids != null && !ids.isEmpty();
             assert parentPath == null && parentInfo == null || parentPath != null && parentInfo != null;
@@ -2707,7 +2707,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
          * @param newParentPath New parent path.
          * @param newParentInfo New parent info.
          */
-        private void updateParent(GridGgfsPath newParentPath, GridGgfsFileInfo newParentInfo) {
+        private void updateParent(IgniteFsPath newParentPath, GridGgfsFileInfo newParentInfo) {
             assert newParentPath != null;
             assert newParentInfo != null;
             assert path.isSubDirectoryOf(newParentPath);
@@ -2723,7 +2723,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
          *
          * @return Parent path.
          */
-        private GridGgfsPath parentPath() {
+        private IgniteFsPath parentPath() {
             return parentPath;
         }
 
@@ -2929,12 +2929,12 @@ public class GridGgfsMetaManager extends GridGgfsManager {
         private static final long serialVersionUID = 0L;
 
         /** New path. */
-        private GridGgfsPath path;
+        private IgniteFsPath path;
 
         /**
          * @param path Path.
          */
-        private UpdatePath(GridGgfsPath path) {
+        private UpdatePath(IgniteFsPath path) {
             this.path = path;
         }
 
@@ -2956,7 +2956,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
 
         /** {@inheritDoc} */
         @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
-            path = (GridGgfsPath)in.readObject();
+            path = (IgniteFsPath)in.readObject();
         }
 
         /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolver.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolver.java
index 004a796..022ca75 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolver.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolver.java
@@ -27,30 +27,30 @@ public class GridGgfsModeResolver {
     private final GridGgfsMode dfltMode;
 
     /** Modes for particular paths. Ordered from longest to shortest. */
-    private ArrayList<T2<GridGgfsPath, GridGgfsMode>> modes;
+    private ArrayList<T2<IgniteFsPath, GridGgfsMode>> modes;
 
     /** Cached modes per path. */
-    private Map<GridGgfsPath, GridGgfsMode> modesCache;
+    private Map<IgniteFsPath, GridGgfsMode> modesCache;
 
     /** Cached children modes per path. */
-    private Map<GridGgfsPath, Set<GridGgfsMode>> childrenModesCache;
+    private Map<IgniteFsPath, Set<GridGgfsMode>> childrenModesCache;
 
     /**
      * @param dfltMode Default GGFS mode.
      * @param modes List of configured modes.
      */
-    public GridGgfsModeResolver(GridGgfsMode dfltMode, @Nullable List<T2<GridGgfsPath, GridGgfsMode>> modes) {
+    public GridGgfsModeResolver(GridGgfsMode dfltMode, @Nullable List<T2<IgniteFsPath, GridGgfsMode>> modes) {
         assert dfltMode != null;
 
         this.dfltMode = dfltMode;
 
         if (modes != null) {
-            ArrayList<T2<GridGgfsPath, GridGgfsMode>> modes0 = new ArrayList<>(modes);
+            ArrayList<T2<IgniteFsPath, GridGgfsMode>> modes0 = new ArrayList<>(modes);
 
             // Sort paths, longest first.
-            Collections.sort(modes0, new Comparator<Map.Entry<GridGgfsPath, GridGgfsMode>>() {
-                @Override public int compare(Map.Entry<GridGgfsPath, GridGgfsMode> o1,
-                    Map.Entry<GridGgfsPath, GridGgfsMode> o2) {
+            Collections.sort(modes0, new Comparator<Map.Entry<IgniteFsPath, GridGgfsMode>>() {
+                @Override public int compare(Map.Entry<IgniteFsPath, GridGgfsMode> o1,
+                    Map.Entry<IgniteFsPath, GridGgfsMode> o2) {
                     return o2.getKey().components().size() - o1.getKey().components().size();
                 }
             });
@@ -68,7 +68,7 @@ public class GridGgfsModeResolver {
      * @param path GGFS path.
      * @return GGFS mode.
      */
-    public GridGgfsMode resolveMode(GridGgfsPath path) {
+    public GridGgfsMode resolveMode(IgniteFsPath path) {
         assert path != null;
 
         if (modes == null)
@@ -77,7 +77,7 @@ public class GridGgfsModeResolver {
             GridGgfsMode mode = modesCache.get(path);
 
             if (mode == null) {
-                for (T2<GridGgfsPath, GridGgfsMode> entry : modes) {
+                for (T2<IgniteFsPath, GridGgfsMode> entry : modes) {
                     if (startsWith(path, entry.getKey())) {
                         // As modes ordered from most specific to least specific first mode found is ours.
                         mode = entry.getValue();
@@ -100,7 +100,7 @@ public class GridGgfsModeResolver {
      * @param path Path.
      * @return Set of all modes that children paths could have.
      */
-    public Set<GridGgfsMode> resolveChildrenModes(GridGgfsPath path) {
+    public Set<GridGgfsMode> resolveChildrenModes(IgniteFsPath path) {
         assert path != null;
 
         if (modes == null)
@@ -113,7 +113,7 @@ public class GridGgfsModeResolver {
 
                 GridGgfsMode pathDefault = dfltMode;
 
-                for (T2<GridGgfsPath, GridGgfsMode> child : modes) {
+                for (T2<IgniteFsPath, GridGgfsMode> child : modes) {
                     if (startsWith(path, child.getKey())) {
                         pathDefault = child.getValue();
 
@@ -136,7 +136,7 @@ public class GridGgfsModeResolver {
      * @return Unmodifiable copy of properly ordered modes prefixes
      *  or {@code null} if no modes set.
      */
-    @Nullable public List<T2<GridGgfsPath, GridGgfsMode>> modesOrdered() {
+    @Nullable public List<T2<IgniteFsPath, GridGgfsMode>> modesOrdered() {
         return modes != null ? Collections.unmodifiableList(modes) : null;
     }
 
@@ -147,7 +147,7 @@ public class GridGgfsModeResolver {
      * @param prefix Prefix.
      * @return {@code true} if path starts with prefix, {@code false} if not.
      */
-    private static boolean startsWith(GridGgfsPath path, GridGgfsPath prefix) {
+    private static boolean startsWith(IgniteFsPath path, IgniteFsPath prefix) {
         List<String> p1Comps = path.components();
         List<String> p2Comps = prefix.components();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamAdapter.java
index 7137d52..40334fc 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamAdapter.java
@@ -23,7 +23,7 @@ import java.nio.*;
 @SuppressWarnings("NonPrivateFieldAccessedInSynchronizedContext")
 abstract class GridGgfsOutputStreamAdapter extends GridGgfsOutputStream {
     /** Path to file. */
-    protected final GridGgfsPath path;
+    protected final IgniteFsPath path;
 
     /** Buffer size. */
     private final int bufSize;
@@ -47,7 +47,7 @@ abstract class GridGgfsOutputStreamAdapter extends GridGgfsOutputStream {
      * @param path Path to stored file.
      * @param bufSize The size of the buffer to be used.
      */
-    GridGgfsOutputStreamAdapter(GridGgfsPath path, int bufSize) {
+    GridGgfsOutputStreamAdapter(IgniteFsPath path, int bufSize) {
         assert path != null;
         assert bufSize > 0;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java
index eca6e9b..7e9c001 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java
@@ -90,7 +90,7 @@ class GridGgfsOutputStreamImpl extends GridGgfsOutputStreamAdapter {
      * @param metrics Local GGFs metrics.
      * @throws GridException If stream creation failed.
      */
-    GridGgfsOutputStreamImpl(GridGgfsContext ggfsCtx, GridGgfsPath path, GridGgfsFileInfo fileInfo, IgniteUuid parentId,
+    GridGgfsOutputStreamImpl(GridGgfsContext ggfsCtx, IgniteFsPath path, GridGgfsFileInfo fileInfo, IgniteUuid parentId,
         int bufSize, GridGgfsMode mode, @Nullable GridGgfsFileWorkerBatch batch, GridGgfsLocalMetrics metrics)
         throws GridException {
         super(path, optimizeBufferSize(bufSize, fileInfo));


[06/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientMetaDataResponse.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientMetaDataResponse.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientMetaDataResponse.java
index 2cb89ce..4326b7a 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientMetaDataResponse.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientMetaDataResponse.java
@@ -19,25 +19,25 @@ import java.util.*;
  */
 public class GridClientMetaDataResponse implements PortableMarshalAware {
     /** */
-    private Map<Integer, GridPortableMetadata> meta;
+    private Map<Integer, PortableMetadata> meta;
 
     /**
      * @param meta Portable objects metadata.
      */
-    public void metaData(Map<Integer, GridPortableMetadata> meta) {
+    public void metaData(Map<Integer, PortableMetadata> meta) {
         this.meta = meta;
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
-        GridPortableRawWriter raw = writer.rawWriter();
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
+        PortableRawWriter raw = writer.rawWriter();
 
         raw.writeMap(meta);
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
-        GridPortableRawReader raw = reader.rawReader();
+    @Override public void readPortable(PortableReader reader) throws PortableException {
+        PortableRawReader raw = reader.rawReader();
 
         meta = raw.readMap();
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeBean.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeBean.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeBean.java
index 74fcb6e..406da1a 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeBean.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeBean.java
@@ -247,8 +247,8 @@ public class GridClientNodeBean implements Externalizable, PortableMarshalAware
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
-        GridPortableRawWriter raw = writer.rawWriter();
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
+        PortableRawWriter raw = writer.rawWriter();
 
         raw.writeInt(tcpPort);
         raw.writeInt(replicaCnt);
@@ -263,8 +263,8 @@ public class GridClientNodeBean implements Externalizable, PortableMarshalAware
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
-        GridPortableRawReader raw = reader.rawReader();
+    @Override public void readPortable(PortableReader reader) throws PortableException {
+        PortableRawReader raw = reader.rawReader();
 
         tcpPort = raw.readInt();
         replicaCnt = raw.readInt();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeMetricsBean.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeMetricsBean.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeMetricsBean.java
index 1be72ef..0ad18b1 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeMetricsBean.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientNodeMetricsBean.java
@@ -1341,8 +1341,8 @@ public class GridClientNodeMetricsBean implements Externalizable, PortableMarsha
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
-        GridPortableRawWriter raw = writer.rawWriter();
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
+        PortableRawWriter raw = writer.rawWriter();
 
         raw.writeLong(lastUpdateTime);
         raw.writeInt(maxActiveJobs);
@@ -1399,8 +1399,8 @@ public class GridClientNodeMetricsBean implements Externalizable, PortableMarsha
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
-        GridPortableRawReader raw = reader.rawReader();
+    @Override public void readPortable(PortableReader reader) throws PortableException {
+        PortableRawReader raw = reader.rawReader();
 
         lastUpdateTime = raw.readLong();
         maxActiveJobs = raw.readInt();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPortableMetaData.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPortableMetaData.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPortableMetaData.java
index a256051..daa72ed 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPortableMetaData.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPortableMetaData.java
@@ -59,8 +59,8 @@ public class GridClientPortableMetaData implements PortableMarshalAware {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
-        GridPortableRawWriter raw = writer.rawWriter();
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
+        PortableRawWriter raw = writer.rawWriter();
 
         raw.writeInt(typeId);
         raw.writeString(typeName);
@@ -69,8 +69,8 @@ public class GridClientPortableMetaData implements PortableMarshalAware {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
-        GridPortableRawReader raw = reader.rawReader();
+    @Override public void readPortable(PortableReader reader) throws PortableException {
+        PortableRawReader raw = reader.rawReader();
 
         typeId = raw.readInt();
         typeName = raw.readString();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPutMetaDataRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPutMetaDataRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPutMetaDataRequest.java
index 3699913..43f7f3f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPutMetaDataRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientPutMetaDataRequest.java
@@ -32,19 +32,19 @@ public class GridClientPutMetaDataRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
-        GridPortableRawWriter raw = writer.rawWriter();
+        PortableRawWriter raw = writer.rawWriter();
 
         raw.writeCollection(meta);
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
+    @Override public void readPortable(PortableReader reader) throws PortableException {
         super.readPortable(reader);
 
-        GridPortableRawReader raw = reader.rawReader();
+        PortableRawReader raw = reader.rawReader();
 
         meta = raw.readCollection();
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientResponse.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientResponse.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientResponse.java
index 6bc1db9..b228d7f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientResponse.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientResponse.java
@@ -85,10 +85,10 @@ public class GridClientResponse extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
-        GridPortableRawWriter raw = writer.rawWriter();
+        PortableRawWriter raw = writer.rawWriter();
 
         raw.writeInt(successStatus);
         raw.writeString(errorMsg);
@@ -96,10 +96,10 @@ public class GridClientResponse extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
+    @Override public void readPortable(PortableReader reader) throws PortableException {
         super.readPortable(reader);
 
-        GridPortableRawReader raw = reader.rawReader();
+        PortableRawReader raw = reader.rawReader();
 
         successStatus = raw.readInt();
         errorMsg = raw.readString();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskRequest.java
index e8d452e..21a9b27 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskRequest.java
@@ -94,10 +94,10 @@ public class GridClientTaskRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
-        GridPortableRawWriterEx raw = (GridPortableRawWriterEx)writer.rawWriter();
+        PortableRawWriterEx raw = (PortableRawWriterEx)writer.rawWriter();
 
         raw.writeString(taskName);
         raw.writeBoolean(keepPortables);
@@ -109,10 +109,10 @@ public class GridClientTaskRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
+    @Override public void readPortable(PortableReader reader) throws PortableException {
         super.readPortable(reader);
 
-        GridPortableRawReaderEx raw = (GridPortableRawReaderEx)reader.rawReader();
+        PortableRawReaderEx raw = (PortableRawReaderEx)reader.rawReader();
 
         taskName = raw.readString();
         keepPortables = raw.readBoolean();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskResultBean.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskResultBean.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskResultBean.java
index 666a0dc..ed00f8a 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskResultBean.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTaskResultBean.java
@@ -92,8 +92,8 @@ public class GridClientTaskResultBean implements Externalizable, PortableMarshal
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
-        GridPortableRawWriterEx raw = (GridPortableRawWriterEx)writer.rawWriter();
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
+        PortableRawWriterEx raw = (PortableRawWriterEx)writer.rawWriter();
 
         raw.writeString(id);
         raw.writeBoolean(finished);
@@ -104,8 +104,8 @@ public class GridClientTaskResultBean implements Externalizable, PortableMarshal
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
-        GridPortableRawReaderEx raw = (GridPortableRawReaderEx)reader.rawReader();
+    @Override public void readPortable(PortableReader reader) throws PortableException {
+        PortableRawReaderEx raw = (PortableRawReaderEx)reader.rawReader();
 
         id = raw.readString();
         finished = raw.readBoolean();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTopologyRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTopologyRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTopologyRequest.java
index 761bcbd..1672cbf 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTopologyRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientTopologyRequest.java
@@ -111,10 +111,10 @@ public class GridClientTopologyRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
-        GridPortableRawWriter raw = writer.rawWriter();
+        PortableRawWriter raw = writer.rawWriter();
 
         raw.writeUuid(nodeId);
         raw.writeString(nodeIp);
@@ -123,10 +123,10 @@ public class GridClientTopologyRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
+    @Override public void readPortable(PortableReader reader) throws PortableException {
         super.readPortable(reader);
 
-        GridPortableRawReader raw = reader.rawReader();
+        PortableRawReader raw = reader.rawReader();
 
         nodeId = raw.readUuid();
         nodeIp = raw.readString();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/cache/GridCacheClientQueryResult.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/cache/GridCacheClientQueryResult.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/cache/GridCacheClientQueryResult.java
index 1200d97..d8c2afa 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/cache/GridCacheClientQueryResult.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/cache/GridCacheClientQueryResult.java
@@ -90,8 +90,8 @@ public class GridCacheClientQueryResult implements PortableMarshalAware, Seriali
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
-        GridPortableRawWriter rawWriter = writer.rawWriter();
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
+        PortableRawWriter rawWriter = writer.rawWriter();
 
         rawWriter.writeBoolean(last);
         rawWriter.writeLong(qryId);
@@ -100,8 +100,8 @@ public class GridCacheClientQueryResult implements PortableMarshalAware, Seriali
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
-        GridPortableRawReader rawReader = reader.rawReader();
+    @Override public void readPortable(PortableReader reader) throws PortableException {
+        PortableRawReader rawReader = reader.rawReader();
 
         last = rawReader.readBoolean();
         qryId = rawReader.readLong();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/metadata/GridPortableMetadataHandler.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/metadata/GridPortableMetadataHandler.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/metadata/GridPortableMetadataHandler.java
index c55651f..f1825dd 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/metadata/GridPortableMetadataHandler.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/metadata/GridPortableMetadataHandler.java
@@ -56,7 +56,7 @@ public class GridPortableMetadataHandler extends GridRestCommandHandlerAdapter {
 
                 GridRestResponse res = new GridRestResponse();
 
-                Map<Integer, GridPortableMetadata> meta = ctx.portable().metadata(metaReq.typeIds());
+                Map<Integer, PortableMetadata> meta = ctx.portable().metadata(metaReq.typeIds());
 
                 GridClientMetaDataResponse metaRes = new GridClientMetaDataResponse();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/visor/portable/VisorPortableMetadataCollectorTask.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/portable/VisorPortableMetadataCollectorTask.java b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/portable/VisorPortableMetadataCollectorTask.java
index d9a608b..ef87b58 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/portable/VisorPortableMetadataCollectorTask.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/portable/VisorPortableMetadataCollectorTask.java
@@ -48,7 +48,7 @@ public class VisorPortableMetadataCollectorTask extends VisorOneNodeTask<Long, I
 
             final Collection<VisorPortableMetadata> data = new ArrayList<>(p.metadata().size());
 
-            for(GridPortableMetadata metadata: p.metadata()) {
+            for(PortableMetadata metadata: p.metadata()) {
                 final VisorPortableMetadata type = new VisorPortableMetadata();
 
                 type.typeName(metadata.typeName());

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/security/GridSecurityCredentials.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/security/GridSecurityCredentials.java b/modules/core/src/main/java/org/gridgain/grid/security/GridSecurityCredentials.java
index 299e9f9..2cccfbc 100644
--- a/modules/core/src/main/java/org/gridgain/grid/security/GridSecurityCredentials.java
+++ b/modules/core/src/main/java/org/gridgain/grid/security/GridSecurityCredentials.java
@@ -176,14 +176,14 @@ public class GridSecurityCredentials implements Externalizable, PortableMarshalA
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
         writer.rawWriter().writeObject(login);
         writer.rawWriter().writeObject(password);
         writer.rawWriter().writeObject(userObj);
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
+    @Override public void readPortable(PortableReader reader) throws PortableException {
         login = reader.rawReader().readObject();
         password = reader.rawReader().readObject();
         userObj = reader.rawReader().readObject();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/util/GridUtils.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/util/GridUtils.java b/modules/core/src/main/java/org/gridgain/grid/util/GridUtils.java
index 47dfb92..fc1a530 100644
--- a/modules/core/src/main/java/org/gridgain/grid/util/GridUtils.java
+++ b/modules/core/src/main/java/org/gridgain/grid/util/GridUtils.java
@@ -8617,7 +8617,7 @@ public abstract class GridUtils {
     public static boolean isPortableType(Class<?> cls) {
         assert cls != null;
 
-        return GridPortableObject.class.isAssignableFrom(cls) ||
+        return PortableObject.class.isAssignableFrom(cls) ||
             PORTABLE_CLS.contains(cls) ||
             cls.isEnum() ||
             (cls.isArray() && cls.getComponentType().isEnum());

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawReaderEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawReaderEx.java b/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawReaderEx.java
deleted file mode 100644
index 2367147..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawReaderEx.java
+++ /dev/null
@@ -1,24 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.util.portable;
-
-import org.apache.ignite.portables.*;
-import org.jetbrains.annotations.*;
-
-/**
- * Extended reader interface.
- */
-public interface GridPortableRawReaderEx extends GridPortableRawReader {
-    /**
-     * @return Object.
-     * @throws org.apache.ignite.portables.PortableException In case of error.
-     */
-    @Nullable public Object readObjectDetached() throws PortableException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawWriterEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawWriterEx.java b/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawWriterEx.java
deleted file mode 100644
index 7e8dd85..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawWriterEx.java
+++ /dev/null
@@ -1,35 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.util.portable;
-
-import org.apache.ignite.portables.*;
-import org.gridgain.grid.kernal.processors.portable.*;
-import org.jetbrains.annotations.*;
-
-/**
- * Extended writer interface.
- */
-public interface GridPortableRawWriterEx extends GridPortableRawWriter, AutoCloseable {
-    /**
-     * @param obj Object to write.
-     * @throws org.apache.ignite.portables.PortableException In case of error.
-     */
-    public void writeObjectDetached(@Nullable Object obj) throws PortableException;
-
-    /**
-     * @return Output stream.
-     */
-    public GridPortableOutputStream out();
-
-    /**
-     * Cleans resources.
-     */
-    @Override public void close();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/util/portable/PortableRawReaderEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/util/portable/PortableRawReaderEx.java b/modules/core/src/main/java/org/gridgain/grid/util/portable/PortableRawReaderEx.java
new file mode 100644
index 0000000..fe69fd2
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/util/portable/PortableRawReaderEx.java
@@ -0,0 +1,24 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.util.portable;
+
+import org.apache.ignite.portables.*;
+import org.jetbrains.annotations.*;
+
+/**
+ * Extended reader interface.
+ */
+public interface PortableRawReaderEx extends PortableRawReader {
+    /**
+     * @return Object.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
+     */
+    @Nullable public Object readObjectDetached() throws PortableException;
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/util/portable/PortableRawWriterEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/util/portable/PortableRawWriterEx.java b/modules/core/src/main/java/org/gridgain/grid/util/portable/PortableRawWriterEx.java
new file mode 100644
index 0000000..c8afcb6
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/util/portable/PortableRawWriterEx.java
@@ -0,0 +1,35 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.util.portable;
+
+import org.apache.ignite.portables.*;
+import org.gridgain.grid.kernal.processors.portable.*;
+import org.jetbrains.annotations.*;
+
+/**
+ * Extended writer interface.
+ */
+public interface PortableRawWriterEx extends PortableRawWriter, AutoCloseable {
+    /**
+     * @param obj Object to write.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
+     */
+    public void writeObjectDetached(@Nullable Object obj) throws PortableException;
+
+    /**
+     * @return Output stream.
+     */
+    public GridPortableOutputStream out();
+
+    /**
+     * Cleans resources.
+     */
+    @Override public void close();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/GridCacheOffHeapTieredEvictionAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/GridCacheOffHeapTieredEvictionAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/GridCacheOffHeapTieredEvictionAbstractSelfTest.java
index aabd175..b25fcbd 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/GridCacheOffHeapTieredEvictionAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/GridCacheOffHeapTieredEvictionAbstractSelfTest.java
@@ -296,7 +296,7 @@ public abstract class GridCacheOffHeapTieredEvictionAbstractSelfTest extends Gri
 
         /** {@inheritDoc} */
         @Override void checkValue(Object val) {
-            GridPortableObject obj = (GridPortableObject)val;
+            PortableObject obj = (PortableObject)val;
 
             assertEquals(expVal, obj.field("val"));
         }
@@ -377,7 +377,7 @@ public abstract class GridCacheOffHeapTieredEvictionAbstractSelfTest extends Gri
 
         /** {@inheritDoc} */
         @Override void checkValue(Object val) {
-            GridPortableObject obj = (GridPortableObject)val;
+            PortableObject obj = (PortableObject)val;
 
             assertEquals(expVal, obj.field("val"));
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/query/GridCacheSwapScanQueryAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/query/GridCacheSwapScanQueryAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/query/GridCacheSwapScanQueryAbstractSelfTest.java
index 299a2a3..1f81b42 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/query/GridCacheSwapScanQueryAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/query/GridCacheSwapScanQueryAbstractSelfTest.java
@@ -187,8 +187,8 @@ public abstract class GridCacheSwapScanQueryAbstractSelfTest extends GridCommonA
         GridCacheProjection prj;
 
         if (portableEnabled()) {
-            prj = cache.projection(new IgnitePredicate<GridCacheEntry<GridPortableObject, GridPortableObject>>() {
-                @Override public boolean apply(GridCacheEntry<GridPortableObject, GridPortableObject> e) {
+            prj = cache.projection(new IgnitePredicate<GridCacheEntry<PortableObject, PortableObject>>() {
+                @Override public boolean apply(GridCacheEntry<PortableObject, PortableObject> e) {
                     Key key = e.getKey().deserialize();
                     Person val = e.peek().deserialize();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/test/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderImplSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderImplSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderImplSelfTest.java
index 3e6b207..8f6bdcf 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderImplSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderImplSelfTest.java
@@ -58,7 +58,7 @@ public class GridDataLoaderImplSelfTest extends GridCommonAbstractTest {
             PortableConfiguration portableCfg = new PortableConfiguration();
 
             portableCfg.setTypeConfigurations(Arrays.asList(
-                new GridPortableTypeConfiguration(TestObject.class.getName())));
+                new PortableTypeConfiguration(TestObject.class.getName())));
 
             cfg.setPortableConfiguration(portableCfg);
         }
@@ -283,12 +283,12 @@ public class GridDataLoaderImplSelfTest extends GridCommonAbstractTest {
         }
 
         /** {@inheritDoc} */
-        @Override public void writePortable(GridPortableWriter writer) throws PortableException {
+        @Override public void writePortable(PortableWriter writer) throws PortableException {
             writer.writeInt("val", val);
         }
 
         /** {@inheritDoc} */
-        @Override public void readPortable(GridPortableReader reader) throws PortableException {
+        @Override public void readPortable(PortableReader reader) throws PortableException {
             val = reader.readInt("val");
         }
     }


[25/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
# Renaming


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

Branch: refs/heads/master
Commit: b7479ede167d989d6a5ba32b63fc473edb0fed95
Parents: 5e4cd4d
Author: sboikov <sb...@gridgain.com>
Authored: Fri Dec 5 11:23:33 2014 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Dec 5 11:23:33 2014 +0300

----------------------------------------------------------------------
 .../examples/ggfs/GgfsMapReduceExample.java     |  4 +-
 .../grid/ggfs/IgniteFsConfiguration.java        |  2 +-
 .../grid/ggfs/mapreduce/GridGgfsFileRange.java  | 72 --------------------
 .../GridGgfsInputStreamJobAdapter.java          | 45 ------------
 .../grid/ggfs/mapreduce/GridGgfsJob.java        | 62 -----------------
 .../grid/ggfs/mapreduce/GridGgfsJobAdapter.java | 20 ------
 .../mapreduce/GridGgfsRangeInputStream.java     |  6 +-
 .../ggfs/mapreduce/GridGgfsRecordResolver.java  |  8 +--
 .../grid/ggfs/mapreduce/GridGgfsTask.java       | 10 +--
 .../grid/ggfs/mapreduce/GridGgfsTaskArgs.java   |  2 +-
 .../grid/ggfs/mapreduce/IgniteFsFileRange.java  | 72 ++++++++++++++++++++
 .../IgniteFsInputStreamJobAdapter.java          | 45 ++++++++++++
 .../grid/ggfs/mapreduce/IgniteFsJob.java        | 62 +++++++++++++++++
 .../grid/ggfs/mapreduce/IgniteFsJobAdapter.java | 20 ++++++
 .../GridGgfsByteDelimiterRecordResolver.java    |  6 +-
 .../GridGgfsFixedLengthRecordResolver.java      |  6 +-
 .../kernal/processors/ggfs/GridGgfsJobImpl.java | 12 ++--
 .../processors/ggfs/GridGgfsProcessor.java      |  2 +-
 .../ggfs/GridGgfsProcessorAdapter.java          |  2 +-
 .../processors/ggfs/GridNoopGgfsProcessor.java  |  2 +-
 .../processors/ggfs/GridGgfsTaskSelfTest.java   |  6 +-
 .../GridGgfsAbstractRecordResolverSelfTest.java |  4 +-
 ...GgfsByteDelimiterRecordResolverSelfTest.java |  4 +-
 ...idGgfsFixedLengthRecordResolverSelfTest.java |  4 +-
 ...sNewLineDelimiterRecordResolverSelfTest.java |  4 +-
 ...fsStringDelimiterRecordResolverSelfTest.java |  4 +-
 26 files changed, 243 insertions(+), 243 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
index c006641..85f103d 100644
--- a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
+++ b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
@@ -121,7 +121,7 @@ public class GgfsMapReduceExample {
      */
     private static class GrepTask extends GridGgfsTask<String, Collection<Line>> {
         /** {@inheritDoc} */
-        @Override public GridGgfsJob createJob(IgniteFsPath path, GridGgfsFileRange range,
+        @Override public IgniteFsJob createJob(IgniteFsPath path, IgniteFsFileRange range,
             GridGgfsTaskArgs<String> args) throws GridException {
             return new GrepJob(args.userArgument());
         }
@@ -152,7 +152,7 @@ public class GgfsMapReduceExample {
     /**
      * Grep job.
      */
-    private static class GrepJob extends GridGgfsInputStreamJobAdapter {
+    private static class GrepJob extends IgniteFsInputStreamJobAdapter {
         /** Regex string. */
         private final String regex;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
index d86049d..287e93c 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
@@ -756,7 +756,7 @@ public class IgniteFsConfiguration {
 
     /**
      * Get maximum default range size of a file being split during GGFS task execution. When GGFS task is about to
-     * be executed, it requests file block locations first. Each location is defined as {@link GridGgfsFileRange} which
+     * be executed, it requests file block locations first. Each location is defined as {@link org.gridgain.grid.ggfs.mapreduce.IgniteFsFileRange} which
      * has length. In case this parameter is set to positive value, then GGFS will split single file range into smaller
      * ranges with length not greater that this parameter. The only exception to this case is when maximum task range
      * length is smaller than file block size. In this case maximum task range size will be overridden and set to file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsFileRange.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsFileRange.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsFileRange.java
deleted file mode 100644
index e37def7..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsFileRange.java
+++ /dev/null
@@ -1,72 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-import org.gridgain.grid.ggfs.*;
-import org.gridgain.grid.util.typedef.internal.*;
-
-/**
- * Entity representing part of GGFS file identified by file path, start position, and length.
- */
-public class GridGgfsFileRange {
-    /** File path. */
-    private IgniteFsPath path;
-
-    /** Start position. */
-    private long start;
-
-    /** Length. */
-    private long len;
-
-    /**
-     * Creates file range.
-     *
-     * @param path File path.
-     * @param start Start position.
-     * @param len Length.
-     */
-    public GridGgfsFileRange(IgniteFsPath path, long start, long len) {
-        this.path = path;
-        this.start = start;
-        this.len = len;
-    }
-
-    /**
-     * Gets file path.
-     *
-     * @return File path.
-     */
-    public IgniteFsPath path() {
-        return path;
-    }
-
-    /**
-     * Gets range start position.
-     *
-     * @return Start position.
-     */
-    public long start() {
-        return start;
-    }
-
-    /**
-     * Gets range length.
-     *
-     * @return Length.
-     */
-    public long length() {
-        return len;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridGgfsFileRange.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsInputStreamJobAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsInputStreamJobAdapter.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsInputStreamJobAdapter.java
deleted file mode 100644
index a5ac21d..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsInputStreamJobAdapter.java
+++ /dev/null
@@ -1,45 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-import org.apache.ignite.*;
-import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
-import org.gridgain.grid.util.*;
-
-import java.io.*;
-
-/**
- * Convenient {@link GridGgfsJob} adapter. It limits data returned from {@link org.gridgain.grid.ggfs.IgniteFsInputStream} to bytes within
- * the {@link GridGgfsFileRange} assigned to the job.
- * <p>
- * Under the covers it simply puts job's {@code GridGgfsInputStream} position to range start and wraps in into
- * {@link GridFixedSizeInputStream} limited to range length.
- */
-public abstract class GridGgfsInputStreamJobAdapter extends GridGgfsJobAdapter {
-    /** {@inheritDoc} */
-    @Override public final Object execute(IgniteFs ggfs, GridGgfsFileRange range, IgniteFsInputStream in)
-        throws GridException, IOException {
-        in.seek(range.start());
-
-        return execute(ggfs, new GridGgfsRangeInputStream(in, range));
-    }
-
-    /**
-     * Executes this job.
-     *
-     * @param ggfs GGFS instance.
-     * @param in Input stream.
-     * @return Execution result.
-     * @throws GridException If execution failed.
-     * @throws IOException If IO exception encountered while working with stream.
-     */
-    public abstract Object execute(IgniteFs ggfs, GridGgfsRangeInputStream in) throws GridException, IOException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsJob.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsJob.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsJob.java
deleted file mode 100644
index 84617dd..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsJob.java
+++ /dev/null
@@ -1,62 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-import org.apache.ignite.*;
-import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
-
-import java.io.*;
-
-/**
- * Defines executable unit for {@link GridGgfsTask}. Before this job is executed, it is assigned one of the
- * ranges provided by the {@link GridGgfsRecordResolver} passed to one of the {@code GridGgfs.execute(...)} methods.
- * <p>
- * {@link #execute(org.apache.ignite.IgniteFs, GridGgfsFileRange, org.gridgain.grid.ggfs.IgniteFsInputStream)} method is given {@link GridGgfsFileRange} this
- * job is expected to operate on, and already opened {@link org.gridgain.grid.ggfs.IgniteFsInputStream} for the file this range belongs to.
- * <p>
- * Note that provided input stream has position already adjusted to range start. However, it will not
- * automatically stop on range end. This is done to provide capability in some cases to look beyond
- * the range end or seek position before the reange start.
- * <p>
- * In majority of the cases, when you want to process only provided range, you should explicitly control amount
- * of returned data and stop at range end. You can also use {@link GridGgfsInputStreamJobAdapter}, which operates
- * on {@link GridGgfsRangeInputStream} bounded to range start and end, or manually wrap provided input stream with
- * {@link GridGgfsRangeInputStream}.
- * <p>
- * You can inject any resources in concrete implementation, just as with regular {@link org.apache.ignite.compute.ComputeJob} implementations.
- */
-public interface GridGgfsJob {
-    /**
-     * Executes this job.
-     *
-     * @param ggfs GGFS instance.
-     * @param range File range aligned to record boundaries.
-     * @param in Input stream for split file. This input stream is not aligned to range and points to file start
-     *     by default.
-     * @return Execution result.
-     * @throws GridException If execution failed.
-     * @throws IOException If file system operation resulted in IO exception.
-     */
-    public Object execute(IgniteFs ggfs, GridGgfsFileRange range, IgniteFsInputStream in) throws GridException,
-        IOException;
-
-    /**
-     * This method is called when system detects that completion of this
-     * job can no longer alter the overall outcome (for example, when parent task
-     * has already reduced the results). Job is also cancelled when
-     * {@link org.apache.ignite.compute.ComputeTaskFuture#cancel()} is called.
-     * <p>
-     * Note that job cancellation is only a hint, and just like with
-     * {@link Thread#interrupt()}  method, it is really up to the actual job
-     * instance to gracefully finish execution and exit.
-     */
-    public void cancel();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsJobAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsJobAdapter.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsJobAdapter.java
deleted file mode 100644
index e347339..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsJobAdapter.java
+++ /dev/null
@@ -1,20 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-/**
- * Adapter for {@link GridGgfsJob} with no-op implementation of {@link #cancel()} method.
- */
-public abstract class GridGgfsJobAdapter implements GridGgfsJob {
-    /** {@inheritDoc} */
-    @Override public void cancel() {
-        // No-op.
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRangeInputStream.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRangeInputStream.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRangeInputStream.java
index fc0e6be..ac96c68 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRangeInputStream.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRangeInputStream.java
@@ -17,9 +17,9 @@ import java.io.*;
 
 /**
  * Decorator for regular {@link org.gridgain.grid.ggfs.IgniteFsInputStream} which streams only data within the given range.
- * This stream is used for {@link GridGgfsInputStreamJobAdapter} convenience adapter to create
+ * This stream is used for {@link IgniteFsInputStreamJobAdapter} convenience adapter to create
  * jobs which will be working only with the assigned range. You can also use it explicitly when
- * working with {@link GridGgfsJob} directly.
+ * working with {@link IgniteFsJob} directly.
  */
 public final class GridGgfsRangeInputStream extends IgniteFsInputStream {
     /** Base input stream. */
@@ -77,7 +77,7 @@ public final class GridGgfsRangeInputStream extends IgniteFsInputStream {
      * @param range File range.
      * @throws IOException In case of exception.
      */
-    public GridGgfsRangeInputStream(IgniteFsInputStream is, GridGgfsFileRange range) throws IOException {
+    public GridGgfsRangeInputStream(IgniteFsInputStream is, IgniteFsFileRange range) throws IOException {
         this(is, range.start(), range.length());
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRecordResolver.java
index e8d64d0..e128776 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRecordResolver.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRecordResolver.java
@@ -18,8 +18,8 @@ import org.jetbrains.annotations.*;
 import java.io.*;
 
 /**
- * GGFS record resolver. When {@link GridGgfsTask} is split into {@link GridGgfsJob}s each produced job will obtain
- * {@link GridGgfsFileRange} based on file data location. Record resolver is invoked in each job before actual
+ * GGFS record resolver. When {@link GridGgfsTask} is split into {@link IgniteFsJob}s each produced job will obtain
+ * {@link IgniteFsFileRange} based on file data location. Record resolver is invoked in each job before actual
  * execution in order to adjust record boundaries in a way consistent with user data.
  * <p>
  * E.g., you may want to split your task into jobs so that each job process zero, one or several lines from that file.
@@ -45,6 +45,6 @@ public interface GridGgfsRecordResolver extends Serializable {
      * @throws GridException If resolve failed.
      * @throws IOException If resolve failed.
      */
-    @Nullable public GridGgfsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
-        GridGgfsFileRange suggestedRecord) throws GridException, IOException;
+    @Nullable public IgniteFsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
+        IgniteFsFileRange suggestedRecord) throws GridException, IOException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
index 055ef09..35e16de 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
@@ -26,15 +26,15 @@ import java.util.*;
  * GGFS task which can be executed on the grid using one of {@code GridGgfs.execute()} methods. Essentially GGFS task
  * is regular {@link org.apache.ignite.compute.ComputeTask} with different map logic. Instead of implementing
  * {@link org.apache.ignite.compute.ComputeTask#map(List, Object)} method to split task into jobs, you must implement
- * {@link GridGgfsTask#createJob(org.gridgain.grid.ggfs.IgniteFsPath, GridGgfsFileRange, GridGgfsTaskArgs)} method.
+ * {@link GridGgfsTask#createJob(org.gridgain.grid.ggfs.IgniteFsPath, IgniteFsFileRange, GridGgfsTaskArgs)} method.
  * <p>
- * Each file participating in GGFS task is split into {@link GridGgfsFileRange}s first. Normally range is a number of
+ * Each file participating in GGFS task is split into {@link IgniteFsFileRange}s first. Normally range is a number of
  * consequent bytes located on a single node (see {@code GridGgfsGroupDataBlocksKeyMapper}). In case maximum range size
  * is provided (either through {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()} or {@code GridGgfs.execute()}
  * argument), then ranges could be further divided into smaller chunks.
  * <p>
  * Once file is split into ranges, each range is passed to {@code GridGgfsTask.createJob()} method in order to create a
- * {@link GridGgfsJob}.
+ * {@link IgniteFsJob}.
  * <p>
  * Finally all generated jobs are sent to Grid nodes for execution.
  * <p>
@@ -116,7 +116,7 @@ public abstract class GridGgfsTask<T, R> extends ComputeTaskAdapter<GridGgfsTask
                     throw new GridException("Failed to find any of block affinity nodes in subgrid [loc=" + loc +
                         ", subgrid=" + subgrid + ']');
 
-                GridGgfsJob job = createJob(path, new GridGgfsFileRange(file.path(), loc.start(), loc.length()), args);
+                IgniteFsJob job = createJob(path, new IgniteFsFileRange(file.path(), loc.start(), loc.length()), args);
 
                 if (job != null) {
                     ComputeJob jobImpl = ggfsProc.createJob(job, ggfs.name(), file.path(), loc.start(),
@@ -145,7 +145,7 @@ public abstract class GridGgfsTask<T, R> extends ComputeTaskAdapter<GridGgfsTask
      * @return GGFS job. If {@code null} is returned, the passed in file range will be skipped.
      * @throws GridException If job creation failed.
      */
-    @Nullable public abstract GridGgfsJob createJob(IgniteFsPath path, GridGgfsFileRange range,
+    @Nullable public abstract IgniteFsJob createJob(IgniteFsPath path, IgniteFsFileRange range,
         GridGgfsTaskArgs<T> args) throws GridException;
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
index 2b321c7..fd36ffe 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
@@ -16,7 +16,7 @@ import java.util.*;
 /**
  * GGFS task arguments. When you initiate new GGFS task execution using one of {@code GridGgfs.execute(...)} methods,
  * all passed parameters are encapsulated in a single {@code GridGgfsTaskArgs} object. Later on this object is
- * passed to {@link GridGgfsTask#createJob(org.gridgain.grid.ggfs.IgniteFsPath, GridGgfsFileRange, GridGgfsTaskArgs)} method.
+ * passed to {@link GridGgfsTask#createJob(org.gridgain.grid.ggfs.IgniteFsPath, IgniteFsFileRange, GridGgfsTaskArgs)} method.
  * <p>
  * Task arguments encapsulates the following data:
  * <ul>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsFileRange.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsFileRange.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsFileRange.java
new file mode 100644
index 0000000..1e1f27a
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsFileRange.java
@@ -0,0 +1,72 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs.mapreduce;
+
+import org.gridgain.grid.ggfs.*;
+import org.gridgain.grid.util.typedef.internal.*;
+
+/**
+ * Entity representing part of GGFS file identified by file path, start position, and length.
+ */
+public class IgniteFsFileRange {
+    /** File path. */
+    private IgniteFsPath path;
+
+    /** Start position. */
+    private long start;
+
+    /** Length. */
+    private long len;
+
+    /**
+     * Creates file range.
+     *
+     * @param path File path.
+     * @param start Start position.
+     * @param len Length.
+     */
+    public IgniteFsFileRange(IgniteFsPath path, long start, long len) {
+        this.path = path;
+        this.start = start;
+        this.len = len;
+    }
+
+    /**
+     * Gets file path.
+     *
+     * @return File path.
+     */
+    public IgniteFsPath path() {
+        return path;
+    }
+
+    /**
+     * Gets range start position.
+     *
+     * @return Start position.
+     */
+    public long start() {
+        return start;
+    }
+
+    /**
+     * Gets range length.
+     *
+     * @return Length.
+     */
+    public long length() {
+        return len;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsFileRange.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java
new file mode 100644
index 0000000..ddc04b3
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java
@@ -0,0 +1,45 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs.mapreduce;
+
+import org.apache.ignite.*;
+import org.gridgain.grid.*;
+import org.gridgain.grid.ggfs.*;
+import org.gridgain.grid.util.*;
+
+import java.io.*;
+
+/**
+ * Convenient {@link IgniteFsJob} adapter. It limits data returned from {@link org.gridgain.grid.ggfs.IgniteFsInputStream} to bytes within
+ * the {@link IgniteFsFileRange} assigned to the job.
+ * <p>
+ * Under the covers it simply puts job's {@code GridGgfsInputStream} position to range start and wraps in into
+ * {@link GridFixedSizeInputStream} limited to range length.
+ */
+public abstract class IgniteFsInputStreamJobAdapter extends IgniteFsJobAdapter {
+    /** {@inheritDoc} */
+    @Override public final Object execute(IgniteFs ggfs, IgniteFsFileRange range, IgniteFsInputStream in)
+        throws GridException, IOException {
+        in.seek(range.start());
+
+        return execute(ggfs, new GridGgfsRangeInputStream(in, range));
+    }
+
+    /**
+     * Executes this job.
+     *
+     * @param ggfs GGFS instance.
+     * @param in Input stream.
+     * @return Execution result.
+     * @throws GridException If execution failed.
+     * @throws IOException If IO exception encountered while working with stream.
+     */
+    public abstract Object execute(IgniteFs ggfs, GridGgfsRangeInputStream in) throws GridException, IOException;
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java
new file mode 100644
index 0000000..4aa33ec
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java
@@ -0,0 +1,62 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs.mapreduce;
+
+import org.apache.ignite.*;
+import org.gridgain.grid.*;
+import org.gridgain.grid.ggfs.*;
+
+import java.io.*;
+
+/**
+ * Defines executable unit for {@link GridGgfsTask}. Before this job is executed, it is assigned one of the
+ * ranges provided by the {@link GridGgfsRecordResolver} passed to one of the {@code GridGgfs.execute(...)} methods.
+ * <p>
+ * {@link #execute(org.apache.ignite.IgniteFs, IgniteFsFileRange, org.gridgain.grid.ggfs.IgniteFsInputStream)} method is given {@link IgniteFsFileRange} this
+ * job is expected to operate on, and already opened {@link org.gridgain.grid.ggfs.IgniteFsInputStream} for the file this range belongs to.
+ * <p>
+ * Note that provided input stream has position already adjusted to range start. However, it will not
+ * automatically stop on range end. This is done to provide capability in some cases to look beyond
+ * the range end or seek position before the reange start.
+ * <p>
+ * In majority of the cases, when you want to process only provided range, you should explicitly control amount
+ * of returned data and stop at range end. You can also use {@link IgniteFsInputStreamJobAdapter}, which operates
+ * on {@link GridGgfsRangeInputStream} bounded to range start and end, or manually wrap provided input stream with
+ * {@link GridGgfsRangeInputStream}.
+ * <p>
+ * You can inject any resources in concrete implementation, just as with regular {@link org.apache.ignite.compute.ComputeJob} implementations.
+ */
+public interface IgniteFsJob {
+    /**
+     * Executes this job.
+     *
+     * @param ggfs GGFS instance.
+     * @param range File range aligned to record boundaries.
+     * @param in Input stream for split file. This input stream is not aligned to range and points to file start
+     *     by default.
+     * @return Execution result.
+     * @throws GridException If execution failed.
+     * @throws IOException If file system operation resulted in IO exception.
+     */
+    public Object execute(IgniteFs ggfs, IgniteFsFileRange range, IgniteFsInputStream in) throws GridException,
+        IOException;
+
+    /**
+     * This method is called when system detects that completion of this
+     * job can no longer alter the overall outcome (for example, when parent task
+     * has already reduced the results). Job is also cancelled when
+     * {@link org.apache.ignite.compute.ComputeTaskFuture#cancel()} is called.
+     * <p>
+     * Note that job cancellation is only a hint, and just like with
+     * {@link Thread#interrupt()}  method, it is really up to the actual job
+     * instance to gracefully finish execution and exit.
+     */
+    public void cancel();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJobAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJobAdapter.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJobAdapter.java
new file mode 100644
index 0000000..e8aa1ea
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJobAdapter.java
@@ -0,0 +1,20 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs.mapreduce;
+
+/**
+ * Adapter for {@link IgniteFsJob} with no-op implementation of {@link #cancel()} method.
+ */
+public abstract class IgniteFsJobAdapter implements IgniteFsJob {
+    /** {@inheritDoc} */
+    @Override public void cancel() {
+        // No-op.
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java
index fb9cf0e..eb9de8d 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java
@@ -70,8 +70,8 @@ public class GridGgfsByteDelimiterRecordResolver implements GridGgfsRecordResolv
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
-        GridGgfsFileRange suggestedRecord) throws GridException, IOException {
+    @Override public IgniteFsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
+        IgniteFsFileRange suggestedRecord) throws GridException, IOException {
         long suggestedStart = suggestedRecord.start();
         long suggestedEnd = suggestedStart + suggestedRecord.length();
 
@@ -102,7 +102,7 @@ public class GridGgfsByteDelimiterRecordResolver implements GridGgfsRecordResolv
 
             long end = curDelim != null ? curDelim.end : stream.position();
 
-            return new GridGgfsFileRange(suggestedRecord.path(), start, end - start);
+            return new IgniteFsFileRange(suggestedRecord.path(), start, end - start);
         }
         else
             // We failed to find any delimiters up to the EOS.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java
index 212b780..3230062 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java
@@ -45,8 +45,8 @@ public class GridGgfsFixedLengthRecordResolver implements GridGgfsRecordResolver
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
-        GridGgfsFileRange suggestedRecord)
+    @Override public IgniteFsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
+        IgniteFsFileRange suggestedRecord)
         throws GridException, IOException {
         long suggestedEnd = suggestedRecord.start() + suggestedRecord.length();
 
@@ -59,7 +59,7 @@ public class GridGgfsFixedLengthRecordResolver implements GridGgfsRecordResolver
 
         assert end >= start;
 
-        return start != end ? new GridGgfsFileRange(suggestedRecord.path(), start, end - start) : null;
+        return start != end ? new IgniteFsFileRange(suggestedRecord.path(), start, end - start) : null;
     }
 
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
index f460d5d..2abbef7 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
@@ -22,12 +22,12 @@ import java.io.*;
 /**
  * GGFS job implementation.
  */
-public class GridGgfsJobImpl implements ComputeJob, GridInternalWrapper<GridGgfsJob> {
+public class GridGgfsJobImpl implements ComputeJob, GridInternalWrapper<IgniteFsJob> {
     /** */
     private static final long serialVersionUID = 0L;
 
     /** GGFS job. */
-    private GridGgfsJob job;
+    private IgniteFsJob job;
 
     /** GGFS name. */
     private String ggfsName;
@@ -60,7 +60,7 @@ public class GridGgfsJobImpl implements ComputeJob, GridInternalWrapper<GridGgfs
      * @param len Split length.
      * @param rslvr GGFS split resolver.
      */
-    public GridGgfsJobImpl(GridGgfsJob job, String ggfsName, IgniteFsPath path, long start, long len,
+    public GridGgfsJobImpl(IgniteFsJob job, String ggfsName, IgniteFsPath path, long start, long len,
         GridGgfsRecordResolver rslvr) {
         this.job = job;
         this.ggfsName = ggfsName;
@@ -75,7 +75,7 @@ public class GridGgfsJobImpl implements ComputeJob, GridInternalWrapper<GridGgfs
         IgniteFs ggfs = ignite.fileSystem(ggfsName);
 
         try (IgniteFsInputStream in = ggfs.open(path)) {
-            GridGgfsFileRange split = new GridGgfsFileRange(path, start, len);
+            IgniteFsFileRange split = new IgniteFsFileRange(path, start, len);
 
             if (rslvr != null) {
                 split = rslvr.resolveRecords(ggfs, in, split);
@@ -90,7 +90,7 @@ public class GridGgfsJobImpl implements ComputeJob, GridInternalWrapper<GridGgfs
 
             in.seek(split.start());
 
-            return job.execute(ggfs, new GridGgfsFileRange(path, split.start(), split.length()), in);
+            return job.execute(ggfs, new IgniteFsFileRange(path, split.start(), split.length()), in);
         }
         catch (IOException e) {
             throw new GridException("Failed to execute GGFS job for file split [ggfsName=" + ggfsName +
@@ -104,7 +104,7 @@ public class GridGgfsJobImpl implements ComputeJob, GridInternalWrapper<GridGgfs
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsJob userObject() {
+    @Override public IgniteFsJob userObject() {
         return job;
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
index 3d26dcd..8a73665 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
@@ -222,7 +222,7 @@ public class GridGgfsProcessor extends GridGgfsProcessorAdapter {
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public ComputeJob createJob(GridGgfsJob job, @Nullable String ggfsName, IgniteFsPath path,
+    @Nullable @Override public ComputeJob createJob(IgniteFsJob job, @Nullable String ggfsName, IgniteFsPath path,
         long start, long length, GridGgfsRecordResolver recRslv) {
         return new GridGgfsJobImpl(job, ggfsName, path, start, length, recRslv);
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
index f2dd046..85ef324 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
@@ -67,6 +67,6 @@ public abstract class GridGgfsProcessorAdapter extends GridProcessorAdapter {
      * @param recRslv Record resolver.
      * @return Compute job.
      */
-    @Nullable public abstract ComputeJob createJob(GridGgfsJob job, @Nullable String ggfsName, IgniteFsPath path,
+    @Nullable public abstract ComputeJob createJob(IgniteFsJob job, @Nullable String ggfsName, IgniteFsPath path,
         long start, long length, GridGgfsRecordResolver recRslv);
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
index 0c3887b..5654a95 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
@@ -56,7 +56,7 @@ public class GridNoopGgfsProcessor extends GridGgfsProcessorAdapter {
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public ComputeJob createJob(GridGgfsJob job, @Nullable String ggfsName, IgniteFsPath path,
+    @Nullable @Override public ComputeJob createJob(IgniteFsJob job, @Nullable String ggfsName, IgniteFsPath path,
         long start, long length, GridGgfsRecordResolver recRslv) {
         return null;
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
index 641977a..9e3838a 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
@@ -230,7 +230,7 @@ public class GridGgfsTaskSelfTest extends GridGgfsCommonAbstractTest {
      */
     private static class Task extends GridGgfsTask<String, IgniteBiTuple<Long, Integer>> {
         /** {@inheritDoc} */
-        @Override public GridGgfsJob createJob(IgniteFsPath path, GridGgfsFileRange range,
+        @Override public IgniteFsJob createJob(IgniteFsPath path, IgniteFsFileRange range,
             GridGgfsTaskArgs<String> args) throws GridException {
             return new Job();
         }
@@ -256,7 +256,7 @@ public class GridGgfsTaskSelfTest extends GridGgfsCommonAbstractTest {
     /**
      * Job.
      */
-    private static class Job implements GridGgfsJob, Serializable {
+    private static class Job implements IgniteFsJob, Serializable {
         @IgniteInstanceResource
         private Ignite ignite;
 
@@ -267,7 +267,7 @@ public class GridGgfsTaskSelfTest extends GridGgfsCommonAbstractTest {
         private ComputeJobContext ctx;
 
         /** {@inheritDoc} */
-        @Override public Object execute(IgniteFs ggfs, GridGgfsFileRange range, IgniteFsInputStream in)
+        @Override public Object execute(IgniteFs ggfs, IgniteFsFileRange range, IgniteFsInputStream in)
             throws GridException, IOException {
             assert ignite != null;
             assert ses != null;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
index 9199576..afa008d 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
@@ -173,7 +173,7 @@ public class GridGgfsAbstractRecordResolverSelfTest extends GridCommonAbstractTe
      * @param len Length.
      * @return Split.
      */
-    protected GridGgfsFileRange split(long start, long len) {
-        return new GridGgfsFileRange(FILE, start, len);
+    protected IgniteFsFileRange split(long start, long len) {
+        return new IgniteFsFileRange(FILE, start, len);
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
index 3ae1929..b88ccc2 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
@@ -280,7 +280,7 @@ public class GridGgfsByteDelimiterRecordResolverSelfTest extends GridGgfsAbstrac
 
         GridGgfsByteDelimiterRecordResolver rslvr = resolver(delims);
 
-        GridGgfsFileRange split;
+        IgniteFsFileRange split;
 
         try (IgniteFsInputStream is = read()) {
             split = rslvr.resolveRecords(ggfs, is, split(suggestedStart, suggestedLen));
@@ -306,7 +306,7 @@ public class GridGgfsByteDelimiterRecordResolverSelfTest extends GridGgfsAbstrac
 
         GridGgfsByteDelimiterRecordResolver rslvr = resolver(delims);
 
-        GridGgfsFileRange split;
+        IgniteFsFileRange split;
 
         try (IgniteFsInputStream is = read()) {
             split = rslvr.resolveRecords(ggfs, is, split(suggestedStart, suggestedLen));

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
index 7170831..287e119 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
@@ -92,7 +92,7 @@ public class GridGgfsFixedLengthRecordResolverSelfTest extends GridGgfsAbstractR
 
         GridGgfsFixedLengthRecordResolver rslvr = resolver(len);
 
-        GridGgfsFileRange split;
+        IgniteFsFileRange split;
 
         try (IgniteFsInputStream is = read()) {
             split = rslvr.resolveRecords(ggfs, is, split(suggestedStart, suggestedLen));
@@ -118,7 +118,7 @@ public class GridGgfsFixedLengthRecordResolverSelfTest extends GridGgfsAbstractR
 
         GridGgfsFixedLengthRecordResolver rslvr = resolver(len);
 
-        GridGgfsFileRange split;
+        IgniteFsFileRange split;
 
         try (IgniteFsInputStream is = read()) {
             split = rslvr.resolveRecords(ggfs, is, split(suggestedStart, suggestedLen));

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
index 7ed1a6a..49328bb 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
@@ -76,7 +76,7 @@ public class GridGgfsNewLineDelimiterRecordResolverSelfTest extends GridGgfsAbst
 
         GridGgfsNewLineRecordResolver rslvr = resolver();
 
-        GridGgfsFileRange split;
+        IgniteFsFileRange split;
 
         try (IgniteFsInputStream is = read()) {
             split = rslvr.resolveRecords(ggfs, is, split(suggestedStart, suggestedLen));
@@ -101,7 +101,7 @@ public class GridGgfsNewLineDelimiterRecordResolverSelfTest extends GridGgfsAbst
 
         GridGgfsNewLineRecordResolver rslvr = resolver();
 
-        GridGgfsFileRange split;
+        IgniteFsFileRange split;
 
         try (IgniteFsInputStream is = read()) {
             split = rslvr.resolveRecords(ggfs, is, split(suggestedStart, suggestedLen));

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b7479ede/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
index b9e0f7a..bf31792 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
@@ -82,7 +82,7 @@ public class GridGgfsStringDelimiterRecordResolverSelfTest extends GridGgfsAbstr
 
         GridGgfsByteDelimiterRecordResolver rslvr = resolver(delims);
 
-        GridGgfsFileRange split;
+        IgniteFsFileRange split;
 
         try (IgniteFsInputStream is = read()) {
             split = rslvr.resolveRecords(ggfs, is, split(suggestedStart, suggestedLen));
@@ -108,7 +108,7 @@ public class GridGgfsStringDelimiterRecordResolverSelfTest extends GridGgfsAbstr
 
         GridGgfsStringDelimiterRecordResolver rslvr = resolver(delims);
 
-        GridGgfsFileRange split;
+        IgniteFsFileRange split;
 
         try (IgniteFsInputStream is = read()) {
             split = rslvr.resolveRecords(ggfs, is, split(suggestedStart, suggestedLen));


[36/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
# Renaming


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

Branch: refs/heads/master
Commit: 5068cc6e54fd000bc7e67496f2213a1ee806c549
Parents: f106170
Author: sboikov <sb...@gridgain.com>
Authored: Fri Dec 5 11:35:58 2014 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Dec 5 11:35:58 2014 +0300

----------------------------------------------------------------------
 .../src/test/resources/spring-server-node.xml   |   4 +-
 .../test/resources/spring-server-ssl-node.xml   |   4 +-
 .../sender/store/fs/GridDrSenderHubFsStore.java |   2 +-
 .../org/gridgain/grid/kernal/GridGainEx.java    |  14 +-
 .../discovery/GridDiscoveryManager.java         |   8 +-
 .../cache/GridCacheEvictionManager.java         |   4 +-
 .../GridCachePartitionExchangeManager.java      |   2 +-
 .../processors/cache/GridCacheTtlManager.java   |   2 +-
 .../cache/GridCacheWriteBehindStore.java        |   2 +-
 .../preloader/GridDhtPartitionDemandPool.java   |   2 +-
 .../preloader/GridDhtPartitionSupplyPool.java   |   2 +-
 .../processors/clock/GridClockServer.java       |   2 +-
 .../clock/GridClockSyncProcessor.java           |   2 +-
 .../continuous/GridContinuousProcessor.java     |   4 +-
 .../dataload/GridDataLoaderProcessor.java       |   2 +-
 .../processors/ggfs/GridGgfsDataManager.java    |   2 +-
 .../ggfs/GridGgfsFragmentizerManager.java       |   4 +-
 .../kernal/processors/ggfs/GridGgfsServer.java  |   4 +-
 .../processors/ggfs/GridGgfsServerManager.java  |   2 +-
 .../service/GridServiceProcessor.java           |   2 +-
 .../processors/streamer/IgniteStreamerImpl.java |   2 +-
 .../timeout/GridTimeoutProcessor.java           |   4 +-
 .../tcp/GridTcpCommunicationSpi.java            |   4 +-
 .../thread/GridStripedThreadPoolExecutor.java   | 216 -----------------
 .../org/gridgain/grid/thread/GridThread.java    | 100 --------
 .../gridgain/grid/thread/GridThreadFactory.java |  53 ----
 .../grid/thread/GridThreadPoolExecutor.java     | 242 -------------------
 .../thread/IgniteStripedThreadPoolExecutor.java | 216 +++++++++++++++++
 .../org/gridgain/grid/thread/IgniteThread.java  | 100 ++++++++
 .../grid/thread/IgniteThreadFactory.java        |  53 ++++
 .../grid/thread/IgniteThreadPoolExecutor.java   | 242 +++++++++++++++++++
 .../GridIpcSharedMemoryServerEndpoint.java      |   2 +-
 .../util/nio/GridNioBackPressureControl.java    |   8 +-
 .../gridgain/grid/util/nio/GridNioServer.java   |  12 +-
 .../src/test/config/job-loadtest/client.xml     |   6 +-
 .../src/test/config/job-loadtest/server.xml     |   2 +-
 modules/core/src/test/config/jobs-load-base.xml |   4 +-
 .../core/src/test/config/load/dsi-load-base.xml |   4 +-
 .../src/test/config/load/merge-sort-base.xml    |   6 +-
 .../test/config/load/mongo-multinode-foster.xml |   2 +-
 .../core/src/test/config/spring-multicache.xml  |   6 +-
 .../GridCachePreloadLifecycleAbstractTest.java  |   6 +-
 .../marshaller/GridMarshallerResourceBean.java  |   2 +-
 .../GridThreadPoolExecutorServiceSelfTest.java  |  10 +-
 .../gridgain/grid/thread/GridThreadTest.java    |  10 +-
 .../cache/GridCacheSingleNodeLoadTest.java      |   4 +-
 .../loadtests/colocation/GridTestMain.java      |   2 +-
 .../loadtests/colocation/spring-colocation.xml  |   4 +-
 ...ridSingleSplitsNewNodesAbstractLoadTest.java |   2 +-
 .../testframework/junits/GridTestResources.java |   2 +-
 .../processors/email/GridEmailProcessor.java    |   4 +-
 .../hadoop/shuffle/GridHadoopShuffleJob.java    |   2 +-
 .../taskexecutor/GridHadoopExecutorService.java |   2 +-
 .../GridHadoopExternalCommunication.java        |   6 +-
 .../main/scala/org/gridgain/visor/visor.scala   |   6 +-
 55 files changed, 708 insertions(+), 708 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/clients/src/test/resources/spring-server-node.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-server-node.xml b/modules/clients/src/test/resources/spring-server-node.xml
index de7db25..2fb48ae 100644
--- a/modules/clients/src/test/resources/spring-server-node.xml
+++ b/modules/clients/src/test/resources/spring-server-node.xml
@@ -319,7 +319,7 @@
             possible started nodes count in one VM.
         -->
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg value="SERVER"/>
                 <constructor-arg type="int" value="15"/>
                 <constructor-arg type="int" value="15"/>
@@ -335,7 +335,7 @@
         <property name="executorServiceShutdown" value="true"/>
 
         <property name="systemExecutorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg value="SYS-SERVER"/>
                 <constructor-arg type="int" value="15"/>
                 <constructor-arg type="int" value="15"/>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/clients/src/test/resources/spring-server-ssl-node.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-server-ssl-node.xml b/modules/clients/src/test/resources/spring-server-ssl-node.xml
index 3d50ace..af9421c 100644
--- a/modules/clients/src/test/resources/spring-server-ssl-node.xml
+++ b/modules/clients/src/test/resources/spring-server-ssl-node.xml
@@ -286,7 +286,7 @@
             possible started nodes count in one VM.
         -->
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg value="SERVER"/>
                 <constructor-arg type="int" value="15"/>
                 <constructor-arg type="int" value="15"/>
@@ -302,7 +302,7 @@
         <property name="executorServiceShutdown" value="true"/>
 
         <property name="systemExecutorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg value="SYS-SERVER"/>
                 <constructor-arg type="int" value="15"/>
                 <constructor-arg type="int" value="15"/>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/dr/hub/sender/store/fs/GridDrSenderHubFsStore.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/dr/hub/sender/store/fs/GridDrSenderHubFsStore.java b/modules/core/src/main/java/org/gridgain/grid/dr/hub/sender/store/fs/GridDrSenderHubFsStore.java
index 5571bde..38ee4ad 100644
--- a/modules/core/src/main/java/org/gridgain/grid/dr/hub/sender/store/fs/GridDrSenderHubFsStore.java
+++ b/modules/core/src/main/java/org/gridgain/grid/dr/hub/sender/store/fs/GridDrSenderHubFsStore.java
@@ -364,7 +364,7 @@ public class GridDrSenderHubFsStore implements GridDrSenderHubStore, LifecycleAw
 
         checkPntWorker = new CheckPointWorker(gridName, log, checkPoints);
 
-        new GridThread(checkPntWorker).start();
+        new IgniteThread(checkPntWorker).start();
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java b/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java
index 703840b..0515da4 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java
@@ -1484,7 +1484,7 @@ public class GridGainEx {
             if (execSvc == null) {
                 isAutoExecSvc = true;
 
-                execSvc = new GridThreadPoolExecutor(
+                execSvc = new IgniteThreadPoolExecutor(
                     "pub-" + cfg.getGridName(),
                     DFLT_PUBLIC_CORE_THREAD_CNT,
                     DFLT_PUBLIC_MAX_THREAD_CNT,
@@ -1500,7 +1500,7 @@ public class GridGainEx {
 
                 // Note that since we use 'LinkedBlockingQueue', number of
                 // maximum threads has no effect.
-                sysExecSvc = new GridThreadPoolExecutor(
+                sysExecSvc = new IgniteThreadPoolExecutor(
                     "sys-" + cfg.getGridName(),
                     DFLT_SYSTEM_CORE_THREAD_CNT,
                     DFLT_SYSTEM_MAX_THREAD_CNT,
@@ -1518,7 +1518,7 @@ public class GridGainEx {
                 // maximum threads has no effect.
                 // Note, that we do not pre-start threads here as management pool may
                 // not be needed.
-                mgmtExecSvc = new GridThreadPoolExecutor(
+                mgmtExecSvc = new IgniteThreadPoolExecutor(
                     "mgmt-" + cfg.getGridName(),
                     DFLT_MGMT_THREAD_CNT,
                     DFLT_MGMT_THREAD_CNT,
@@ -1533,7 +1533,7 @@ public class GridGainEx {
                 // maximum threads has no effect.
                 // Note, that we do not pre-start threads here as class loading pool may
                 // not be needed.
-                p2pExecSvc = new GridThreadPoolExecutor(
+                p2pExecSvc = new IgniteThreadPoolExecutor(
                     "p2p-" + cfg.getGridName(),
                     DFLT_P2P_THREAD_CNT,
                     DFLT_P2P_THREAD_CNT,
@@ -1547,7 +1547,7 @@ public class GridGainEx {
                 int procCnt = Runtime.getRuntime().availableProcessors();
 
                 // Note that we do not pre-start threads here as ggfs pool may not be needed.
-                ggfsExecSvc = new GridThreadPoolExecutor(
+                ggfsExecSvc = new IgniteThreadPoolExecutor(
                     "ggfs-" + cfg.getGridName(),
                     procCnt,
                     procCnt,
@@ -1564,7 +1564,7 @@ public class GridGainEx {
             else if (restExecSvc == null && clientCfg != null) {
                 isAutoRestSvc = true;
 
-                restExecSvc = new GridThreadPoolExecutor(
+                restExecSvc = new IgniteThreadPoolExecutor(
                     "rest-" + cfg.getGridName(),
                     DFLT_REST_CORE_THREAD_CNT,
                     DFLT_REST_MAX_THREAD_CNT,
@@ -1575,7 +1575,7 @@ public class GridGainEx {
                 clientCfg.setRestExecutorService(restExecSvc);
             }
 
-            utilityCacheExecSvc = new GridThreadPoolExecutor(
+            utilityCacheExecSvc = new IgniteThreadPoolExecutor(
                 "utility-" + cfg.getGridName(),
                 DFLT_SYSTEM_CORE_THREAD_CNT,
                 DFLT_SYSTEM_MAX_THREAD_CNT,

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/managers/discovery/GridDiscoveryManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/managers/discovery/GridDiscoveryManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/managers/discovery/GridDiscoveryManager.java
index 106308f..74ae650 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/managers/discovery/GridDiscoveryManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/managers/discovery/GridDiscoveryManager.java
@@ -102,7 +102,7 @@ public class GridDiscoveryManager extends GridManagerAdapter<GridDiscoverySpi> {
     private SegmentCheckWorker segChkWrk;
 
     /** Network segment check thread. */
-    private GridThread segChkThread;
+    private IgniteThread segChkThread;
 
     /** Last logged topology. */
     private final AtomicLong lastLoggedTop = new AtomicLong();
@@ -228,7 +228,7 @@ public class GridDiscoveryManager extends GridManagerAdapter<GridDiscoverySpi> {
             checkSegmentOnStart();
         }
 
-        new GridThread(metricsUpdater).start();
+        new IgniteThread(metricsUpdater).start();
 
         getSpi().setMetricsProvider(createMetricsProvider());
 
@@ -378,7 +378,7 @@ public class GridDiscoveryManager extends GridManagerAdapter<GridDiscoverySpi> {
         if (hasRslvrs && segChkFreq > 0) {
             segChkWrk = new SegmentCheckWorker();
 
-            segChkThread = new GridThread(segChkWrk);
+            segChkThread = new IgniteThread(segChkWrk);
 
             segChkThread.start();
         }
@@ -395,7 +395,7 @@ public class GridDiscoveryManager extends GridManagerAdapter<GridDiscoverySpi> {
         }
 
         // Start discovery worker.
-        new GridThread(discoWrk).start();
+        new IgniteThread(discoWrk).start();
 
         if (log.isDebugEnabled())
             log.debug(startInfo());

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheEvictionManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheEvictionManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheEvictionManager.java
index 1a56e5d..b44bccf 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheEvictionManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheEvictionManager.java
@@ -101,7 +101,7 @@ public class GridCacheEvictionManager<K, V> extends GridCacheManagerAdapter<K, V
     private BackupWorker backupWorker;
 
     /** Backup entries worker thread. */
-    private GridThread backupWorkerThread;
+    private IgniteThread backupWorkerThread;
 
     /** Busy lock. */
     private final GridBusyLock busyLock = new GridBusyLock();
@@ -245,7 +245,7 @@ public class GridCacheEvictionManager<K, V> extends GridCacheManagerAdapter<K, V
             backupWorker.addEvent(new IgniteDiscoveryEvent(cctx.localNode(), "Dummy event.",
                 EVT_NODE_JOINED, cctx.localNode()));
 
-            backupWorkerThread = new GridThread(backupWorker);
+            backupWorkerThread = new IgniteThread(backupWorker);
             backupWorkerThread.start();
         }
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCachePartitionExchangeManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCachePartitionExchangeManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCachePartitionExchangeManager.java
index 5187960..e56ca45 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCachePartitionExchangeManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCachePartitionExchangeManager.java
@@ -200,7 +200,7 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
 
         GridDhtPartitionsExchangeFuture<K, V> fut = exchangeFuture(exchId, discoEvt);
 
-        new GridThread(cctx.gridName(), "exchange-worker", exchWorker).start();
+        new IgniteThread(cctx.gridName(), "exchange-worker", exchWorker).start();
 
         onDiscoveryEvent(cctx.localNodeId(), fut);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTtlManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTtlManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTtlManager.java
index e7d8524..827665c 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTtlManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTtlManager.java
@@ -44,7 +44,7 @@ public class GridCacheTtlManager<K, V> extends GridCacheManagerAdapter<K, V> {
     /** {@inheritDoc} */
     @Override protected void onKernalStart0() throws GridException {
         if (cleanupWorker != null)
-            new GridThread(cleanupWorker).start();
+            new IgniteThread(cleanupWorker).start();
     }
 
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheWriteBehindStore.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheWriteBehindStore.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheWriteBehindStore.java
index 5896389..a8b2ffc 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheWriteBehindStore.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheWriteBehindStore.java
@@ -274,7 +274,7 @@ public class GridCacheWriteBehindStore<K, V> implements GridCacheStore<K, V>, Li
             for (int i = 0; i < flushThreads.length; i++) {
                 flushThreads[i] = new Flusher(gridName, "flusher-" + i, log);
 
-                new GridThread(flushThreads[i]).start();
+                new IgniteThread(flushThreads[i]).start();
             }
         }
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
index 7e72404..6c2e31f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
@@ -134,7 +134,7 @@ public class GridDhtPartitionDemandPool<K, V> {
     void start() {
         if (poolSize > 0) {
             for (DemandWorker w : dmdWorkers)
-                new GridThread(cctx.gridName(), "preloader-demand-worker", w).start();
+                new IgniteThread(cctx.gridName(), "preloader-demand-worker", w).start();
         }
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionSupplyPool.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionSupplyPool.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionSupplyPool.java
index 6aac752..bbba8b2 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionSupplyPool.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionSupplyPool.java
@@ -93,7 +93,7 @@ class GridDhtPartitionSupplyPool<K, V> {
      */
     void start() {
         for (SupplyWorker w : workers)
-            new GridThread(cctx.gridName(), "preloader-supply-worker", w).start();
+            new IgniteThread(cctx.gridName(), "preloader-supply-worker", w).start();
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockServer.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockServer.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockServer.java
index cb5028e..5d17e7f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockServer.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockServer.java
@@ -90,7 +90,7 @@ public class GridClockServer {
     public void afterStart() {
         readWorker = new ReadWorker();
 
-        GridThread th = new GridThread(readWorker);
+        IgniteThread th = new IgniteThread(readWorker);
 
         th.setPriority(Thread.MAX_PRIORITY);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockSyncProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockSyncProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockSyncProcessor.java
index c614737..38720c9 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockSyncProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/clock/GridClockSyncProcessor.java
@@ -230,7 +230,7 @@ public class GridClockSyncProcessor extends GridProcessorAdapter {
                         if (timeCoord == null && !stopping) {
                             timeCoord = new TimeCoordinator(discoEvt);
 
-                            GridThread th = new GridThread(timeCoord);
+                            IgniteThread th = new IgniteThread(timeCoord);
 
                             th.setPriority(Thread.MAX_PRIORITY);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/continuous/GridContinuousProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/continuous/GridContinuousProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/continuous/GridContinuousProcessor.java
index 2e5b1c9..969b34d 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/continuous/GridContinuousProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/continuous/GridContinuousProcessor.java
@@ -63,7 +63,7 @@ public class GridContinuousProcessor extends GridProcessorAdapter {
     private final ConcurrentMap<UUID, Collection<UUID>> waitForStopAck = new ConcurrentHashMap8<>();
 
     /** Threads started by this processor. */
-    private final Collection<GridThread> threads = new GridConcurrentHashSet<>();
+    private final Collection<IgniteThread> threads = new GridConcurrentHashSet<>();
 
     /** Pending start requests. */
     private final Map<UUID, Collection<GridContinuousMessage>> pending = new HashMap<>();
@@ -895,7 +895,7 @@ public class GridContinuousProcessor extends GridProcessorAdapter {
 
         if (doRegister) {
             if (interval > 0) {
-                GridThread checker = new GridThread(new GridWorker(ctx.gridName(), "continuous-buffer-checker", log) {
+                IgniteThread checker = new IgniteThread(new GridWorker(ctx.gridName(), "continuous-buffer-checker", log) {
                     @SuppressWarnings("ConstantConditions")
                     @Override protected void body() {
                         long interval0 = interval;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderProcessor.java
index 2227f72..fb65bb8 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderProcessor.java
@@ -72,7 +72,7 @@ public class GridDataLoaderProcessor<K, V> extends GridProcessorAdapter {
         if (ctx.config().isDaemon())
             return;
 
-        flusher = new GridThread(new GridWorker(ctx.gridName(), "grid-data-loader-flusher", log) {
+        flusher = new IgniteThread(new GridWorker(ctx.gridName(), "grid-data-loader-flusher", log) {
             @Override protected void body() throws InterruptedException, GridInterruptedException {
                 while (!isCancelled()) {
                     IgniteDataLoaderImpl<K, V> ldr = flushQ.take();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
index 1e15bbb..bd70a69 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
@@ -202,7 +202,7 @@ public class GridGgfsDataManager extends GridGgfsManager {
             int coresCnt = Runtime.getRuntime().availableProcessors();
 
             // Note that we do not pre-start threads here as GGFS pool may not be needed.
-            putExecSvc = new GridThreadPoolExecutor(coresCnt, coresCnt, 0, new LinkedBlockingDeque<Runnable>());
+            putExecSvc = new IgniteThreadPoolExecutor(coresCnt, coresCnt, 0, new LinkedBlockingDeque<Runnable>());
 
             putExecSvcShutdown = true;
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFragmentizerManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFragmentizerManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFragmentizerManager.java
index 4136d3f..11c53d6 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFragmentizerManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFragmentizerManager.java
@@ -91,7 +91,7 @@ public class GridGgfsFragmentizerManager extends GridGgfsManager {
 
         ggfsCtx.kernalContext().io().addMessageListener(topic, fragmentizerWorker);
 
-        new GridThread(fragmentizerWorker).start();
+        new IgniteThread(fragmentizerWorker).start();
     }
 
     /** {@inheritDoc} */
@@ -205,7 +205,7 @@ public class GridGgfsFragmentizerManager extends GridGgfsManager {
                         if (fragmentizerCrd == null && !stopping) {
                             fragmentizerCrd = new FragmentizerCoordinator();
 
-                            new GridThread(fragmentizerCrd).start();
+                            new IgniteThread(fragmentizerCrd).start();
                         }
                     }
                 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServer.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServer.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServer.java
index 48b337e..03ba200 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServer.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServer.java
@@ -133,7 +133,7 @@ public class GridGgfsServer {
     public void onKernalStart() {
         // Accept connections only when grid is ready.
         if (srvEndpoint != null)
-            new GridThread(acceptWorker).start();
+            new IgniteThread(acceptWorker).start();
     }
 
     /**
@@ -392,7 +392,7 @@ public class GridGgfsServer {
 
                     ClientWorker worker = new ClientWorker(client, acceptCnt++);
 
-                    GridThread workerThread = new GridThread(worker);
+                    IgniteThread workerThread = new IgniteThread(worker);
 
                     ConcurrentLinkedDeque8.Node<ClientWorker> node = clientWorkers.addx(worker);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java
index 4b2063f..1dc8b19 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java
@@ -65,7 +65,7 @@ public class GridGgfsServerManager extends GridGgfsManager {
         }
 
         if (bindWorker != null)
-            new GridThread(bindWorker).start();
+            new IgniteThread(bindWorker).start();
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessor.java
index 3fb43a5..8cbae3f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/service/GridServiceProcessor.java
@@ -66,7 +66,7 @@ public class GridServiceProcessor extends GridProcessorAdapter {
     private final GridSpinBusyLock busyLock = new GridSpinBusyLock();
 
     /** Thread factory. */
-    private ThreadFactory threadFactory = new GridThreadFactory(ctx.gridName());
+    private ThreadFactory threadFactory = new IgniteThreadFactory(ctx.gridName());
 
     /** Thread local for service name. */
     private ThreadLocal<String> svcName = new ThreadLocal<>();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerImpl.java
index 49eab46..8ee317f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerImpl.java
@@ -241,7 +241,7 @@ public class IgniteStreamerImpl implements IgniteStreamerEx, Externalizable {
         execSvc = c.getExecutorService();
 
         if (execSvc == null) {
-            execSvc = new GridThreadPoolExecutor(
+            execSvc = new IgniteThreadPoolExecutor(
                 ctx.gridName(),
                 Runtime.getRuntime().availableProcessors(),
                 Runtime.getRuntime().availableProcessors(),

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/kernal/processors/timeout/GridTimeoutProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/timeout/GridTimeoutProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/timeout/GridTimeoutProcessor.java
index c6c13fa..79ee81a 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/timeout/GridTimeoutProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/timeout/GridTimeoutProcessor.java
@@ -24,7 +24,7 @@ import java.util.*;
  */
 public class GridTimeoutProcessor extends GridProcessorAdapter {
     /** */
-    private final GridThread timeoutWorker;
+    private final IgniteThread timeoutWorker;
 
     /** Time-based sorted set for timeout objects. */
     private final GridConcurrentSkipListSet<GridTimeoutObject> timeoutObjs =
@@ -47,7 +47,7 @@ public class GridTimeoutProcessor extends GridProcessorAdapter {
     public GridTimeoutProcessor(GridKernalContext ctx) {
         super(ctx);
 
-        timeoutWorker = new GridThread(ctx.config().getGridName(), "grid-timeout-worker",
+        timeoutWorker = new IgniteThread(ctx.config().getGridName(), "grid-timeout-worker",
             new TimeoutWorker());
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/spi/communication/tcp/GridTcpCommunicationSpi.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/spi/communication/tcp/GridTcpCommunicationSpi.java b/modules/core/src/main/java/org/gridgain/grid/spi/communication/tcp/GridTcpCommunicationSpi.java
index 62b596d..0fd2328 100644
--- a/modules/core/src/main/java/org/gridgain/grid/spi/communication/tcp/GridTcpCommunicationSpi.java
+++ b/modules/core/src/main/java/org/gridgain/grid/spi/communication/tcp/GridTcpCommunicationSpi.java
@@ -1152,7 +1152,7 @@ public class GridTcpCommunicationSpi extends GridSpiAdapter
         if (shmemSrv != null) {
             shmemAcceptWorker = new ShmemAcceptWorker(shmemSrv);
 
-            new GridThread(shmemAcceptWorker).start();
+            new IgniteThread(shmemAcceptWorker).start();
         }
 
         nioSrvr.start();
@@ -1938,7 +1938,7 @@ public class GridTcpCommunicationSpi extends GridSpiAdapter
 
                     shmemWorkers.add(e);
 
-                    new GridThread(e).start();
+                    new IgniteThread(e).start();
                 }
             }
             catch (GridException e) {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/thread/GridStripedThreadPoolExecutor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/thread/GridStripedThreadPoolExecutor.java b/modules/core/src/main/java/org/gridgain/grid/thread/GridStripedThreadPoolExecutor.java
deleted file mode 100644
index 64a5174..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/thread/GridStripedThreadPoolExecutor.java
+++ /dev/null
@@ -1,216 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.thread;
-
-import org.gridgain.grid.util.typedef.internal.*;
-
-import java.util.*;
-import java.util.concurrent.*;
-
-/**
- * An {@link ExecutorService} that executes submitted tasks using pooled grid threads.
- */
-public class GridStripedThreadPoolExecutor implements ExecutorService {
-    /** */
-    public static final int DFLT_SEG_POOL_SIZE = 8;
-
-    /** */
-    public static final int DFLT_CONCUR_LVL = 16;
-
-    /** */
-    private final ExecutorService[] execs;
-
-    /** */
-    private final int segShift;
-
-    /** */
-    private final int segMask;
-
-    /**
-     *
-     */
-    public GridStripedThreadPoolExecutor() {
-        execs = new ExecutorService[DFLT_CONCUR_LVL];
-
-        ThreadFactory factory = new GridThreadFactory(null);
-
-        for (int i = 0; i < DFLT_CONCUR_LVL; i++)
-            execs[i] = Executors.newFixedThreadPool(DFLT_SEG_POOL_SIZE, factory);
-
-        // Find power-of-two sizes best matching arguments
-        int sshift = 0;
-        int ssize = 1;
-
-        while (ssize < DFLT_CONCUR_LVL) {
-            ++sshift;
-
-            ssize <<= 1;
-        }
-
-        segShift = 32 - sshift;
-        segMask = ssize - 1;
-
-    }
-
-    /** {@inheritDoc} */
-    @Override public void shutdown() {
-        for (ExecutorService exec : execs)
-            exec.shutdown();
-    }
-
-    /** {@inheritDoc} */
-    @Override public List<Runnable> shutdownNow() {
-        List<Runnable> res = new LinkedList<>();
-
-        for (ExecutorService exec : execs) {
-            for (Runnable r : exec.shutdownNow())
-                res.add(r);
-        }
-
-        return res;
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean isShutdown() {
-        for (ExecutorService exec : execs) {
-            if (!exec.isShutdown())
-                return false;
-        }
-
-        return true;
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean isTerminated() {
-        for (ExecutorService exec : execs) {
-            if (!exec.isTerminated())
-                return false;
-        }
-
-        return true;
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean awaitTermination(long timeout, TimeUnit unit) throws InterruptedException {
-        boolean res = true;
-
-        for (ExecutorService exec : execs)
-            res &= exec.awaitTermination(timeout, unit);
-
-        return res;
-    }
-
-    /** {@inheritDoc} */
-    @Override public <T> Future<T> submit(Callable<T> task) {
-        return execForTask(task).submit(task);
-    }
-
-    /** {@inheritDoc} */
-    @Override public <T> Future<T> submit(Runnable task, T result) {
-        return execForTask(task).submit(task, result);
-    }
-
-    /** {@inheritDoc} */
-    @Override public Future<?> submit(Runnable task) {
-        return execForTask(task).submit(task);
-    }
-
-    /** {@inheritDoc} */
-    @Override public <T> List<Future<T>> invokeAll(Collection<? extends Callable<T>> tasks)
-        throws InterruptedException {
-        List<Future<T>> futs = new LinkedList<>();
-
-        for (Callable<T> task : tasks)
-            futs.add(execForTask(task).submit(task));
-
-        boolean done = false;
-
-        try {
-            for (Future<T> fut : futs) {
-                try {
-                    fut.get();
-                }
-                catch (ExecutionException | InterruptedException ignored) {
-                    // No-op.
-                }
-            }
-
-            done = true;
-
-            return futs;
-        }
-        finally {
-            if (!done) {
-                for (Future<T> fut : futs)
-                    fut.cancel(true);
-            }
-        }
-    }
-
-    /** {@inheritDoc} */
-    @Override public <T> List<Future<T>> invokeAll(Collection<? extends Callable<T>> tasks, long timeout,
-        TimeUnit unit) throws InterruptedException {
-        throw new RuntimeException("Not implemented.");
-    }
-
-    /** {@inheritDoc} */
-    @Override public <T> T invokeAny(Collection<? extends Callable<T>> tasks) throws InterruptedException,
-        ExecutionException {
-        throw new RuntimeException("Not implemented.");
-    }
-
-    /** {@inheritDoc} */
-    @Override public <T> T invokeAny(Collection<? extends Callable<T>> tasks, long timeout, TimeUnit unit)
-        throws InterruptedException, ExecutionException, TimeoutException {
-        throw new RuntimeException("Not implemented.");
-    }
-
-    /** {@inheritDoc} */
-    @Override public void execute(Runnable cmd) {
-        execForTask(cmd).execute(cmd);
-    }
-
-    /**
-     * Applies a supplemental hash function to a given hashCode, which
-     * defends against poor quality hash functions.  This is critical
-     * because ConcurrentHashMap uses power-of-two length hash tables,
-     * that otherwise encounter collisions for hashCodes that do not
-     * differ in lower or upper bits.
-     *
-     * @param h Hash code.
-     * @return Enhanced hash code.
-     */
-    private int hash(int h) {
-        // Spread bits to regularize both segment and index locations,
-        // using variant of single-word Wang/Jenkins hash.
-        h += (h <<  15) ^ 0xffffcd7d;
-        h ^= (h >>> 10);
-        h += (h <<   3);
-        h ^= (h >>>  6);
-        h += (h <<   2) + (h << 14);
-        return h ^ (h >>> 16);
-    }
-
-    /**
-     * @param cmd Command.
-     * @return Service.
-     */
-    private <T> ExecutorService execForTask(T cmd) {
-        assert cmd != null;
-
-        //return execs[ThreadLocalRandom8.current().nextInt(DFLT_CONCUR_LVL)];
-        return execs[(hash(cmd.hashCode()) >>> segShift) & segMask];
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridStripedThreadPoolExecutor.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/thread/GridThread.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/thread/GridThread.java b/modules/core/src/main/java/org/gridgain/grid/thread/GridThread.java
deleted file mode 100644
index 73a3d7e..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/thread/GridThread.java
+++ /dev/null
@@ -1,100 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.thread;
-
-import org.gridgain.grid.util.typedef.internal.*;
-import org.gridgain.grid.util.worker.*;
-
-import java.util.concurrent.atomic.*;
-
-/**
- * This class adds some necessary plumbing on top of the {@link Thread} class.
- * Specifically, it adds:
- * <ul>
- *      <li>Consistent naming of threads</li>
- *      <li>Dedicated parent thread group</li>
- *      <li>Backing interrupted flag</li>
- * </ul>
- * <b>Note</b>: this class is intended for internal use only.
- */
-public class GridThread extends Thread {
-    /** Default thread's group. */
-    private static final ThreadGroup DFLT_GRP = new ThreadGroup("gridgain");
-
-    /** Number of all grid threads in the system. */
-    private static final AtomicLong threadCntr = new AtomicLong(0);
-
-    /** Boolean flag indicating of this thread is currently processing message. */
-    private boolean procMsg;
-
-    /**
-     * Creates thread with given worker.
-     *
-     * @param worker Runnable to create thread with.
-     */
-    public GridThread(GridWorker worker) {
-        this(DFLT_GRP, worker.gridName(), worker.name(), worker);
-    }
-
-    /**
-     * Creates grid thread with given name for a given grid.
-     *
-     * @param gridName Name of grid this thread is created for.
-     * @param threadName Name of thread.
-     * @param r Runnable to execute.
-     */
-    public GridThread(String gridName, String threadName, Runnable r) {
-        this(DFLT_GRP, gridName, threadName, r);
-    }
-
-    /**
-     * Creates grid thread with given name for a given grid with specified
-     * thread group.
-     *
-     * @param grp Thread group.
-     * @param gridName Name of grid this thread is created for.
-     * @param threadName Name of thread.
-     * @param r Runnable to execute.
-     */
-    public GridThread(ThreadGroup grp, String gridName, String threadName, Runnable r) {
-        super(grp, r, createName(threadCntr.incrementAndGet(), threadName, gridName));
-    }
-
-    /**
-     * Creates new thread name.
-     *
-     * @param num Thread number.
-     * @param threadName Thread name.
-     * @param gridName Grid name.
-     * @return New thread name.
-     */
-    private static String createName(long num, String threadName, String gridName) {
-        return threadName + "-#" + num + '%' + gridName + '%';
-    }
-
-    /**
-     * @param procMsg Flag indicating whether thread is currently processing message.
-     */
-    public void processingMessage(boolean procMsg) {
-        this.procMsg = procMsg;
-    }
-
-    /**
-     * @return Flag indicating whether thread is currently processing message.
-     */
-    public boolean processingMessage() {
-        return procMsg;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridThread.class, this, "name", getName());
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/thread/GridThreadFactory.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/thread/GridThreadFactory.java b/modules/core/src/main/java/org/gridgain/grid/thread/GridThreadFactory.java
deleted file mode 100644
index 1eecb0f..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/thread/GridThreadFactory.java
+++ /dev/null
@@ -1,53 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.thread;
-
-import org.jetbrains.annotations.*;
-
-import java.util.concurrent.*;
-
-/**
- * This class provides implementation of {@link ThreadFactory} factory
- * for creating grid threads.
- */
-public class GridThreadFactory implements ThreadFactory {
-    /** Grid name. */
-    private final String gridName;
-
-    /** Thread name. */
-    private final String threadName;
-
-    /**
-     * Constructs new thread factory for given grid. All threads will belong
-     * to the same default thread group.
-     *
-     * @param gridName Grid name.
-     */
-    public GridThreadFactory(String gridName) {
-        this(gridName, "gridgain");
-    }
-
-    /**
-     * Constructs new thread factory for given grid. All threads will belong
-     * to the same default thread group.
-     *
-     * @param gridName Grid name.
-     * @param threadName Thread name.
-     */
-    public GridThreadFactory(String gridName, String threadName) {
-        this.gridName = gridName;
-        this.threadName = threadName;
-    }
-
-    /** {@inheritDoc} */
-    @Override public Thread newThread(@NotNull Runnable r) {
-        return new GridThread(gridName, threadName, r);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/thread/GridThreadPoolExecutor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/thread/GridThreadPoolExecutor.java b/modules/core/src/main/java/org/gridgain/grid/thread/GridThreadPoolExecutor.java
deleted file mode 100644
index e43e084..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/thread/GridThreadPoolExecutor.java
+++ /dev/null
@@ -1,242 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.thread;
-
-import org.jetbrains.annotations.*;
-
-import java.util.concurrent.*;
-
-/**
- * An {@link ExecutorService} that executes submitted tasks using pooled grid threads.
- */
-public class GridThreadPoolExecutor extends ThreadPoolExecutor {
-    /** Default core pool size (value is {@code 100}). */
-    public static final int DFLT_CORE_POOL_SIZE = 100;
-
-    /**
-     * Creates a new service with default initial parameters.
-     * Default values are:
-     * <table class="doctable">
-     * <tr>
-     *      <th>Name</th>
-     *      <th>Default Value</th>
-     * </tr>
-     * <tr>
-     *      <td>Core Pool Size</td>
-     *      <td>{@code 100} (see {@link #DFLT_CORE_POOL_SIZE}).</td>
-     * </tr>
-     * <tr>
-     *      <td>Maximum Pool Size</td>
-     *      <td>None, is it is not used for unbounded queues.</td>
-     * </tr>
-     * <tr>
-     *      <td>Keep alive time</td>
-     *      <td>No limit (see {@link Long#MAX_VALUE}).</td>
-     * </tr>
-     * <tr>
-     *      <td>Blocking Queue (see {@link BlockingQueue}).</td>
-     *      <td>Unbounded linked blocking queue (see {@link LinkedBlockingDeque}).</td>
-     * </tr>
-     * </table>
-     */
-    public GridThreadPoolExecutor() {
-        this(
-            DFLT_CORE_POOL_SIZE,
-            DFLT_CORE_POOL_SIZE,
-            0,
-            new LinkedBlockingDeque<Runnable>(),
-            new GridThreadFactory(null),
-            null
-        );
-    }
-
-    /**
-     * Creates a new service with the given initial parameters.
-     *
-     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
-     * @param maxPoolSize The maximum number of threads to allow in the pool.
-     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
-     *      that excess idle threads will wait for new tasks before terminating.
-     * @param workQueue The queue to use for holding tasks before they are executed. This queue will hold only
-     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
-     */
-    public GridThreadPoolExecutor(
-        int corePoolSize,
-        int maxPoolSize,
-        long keepAliveTime,
-        BlockingQueue<Runnable> workQueue) {
-        this(
-            corePoolSize,
-            maxPoolSize,
-            keepAliveTime,
-            workQueue,
-            new GridThreadFactory(null),
-            null
-        );
-    }
-
-    /**
-     * Creates a new service with the given initial parameters.
-     *
-     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
-     * @param maxPoolSize The maximum number of threads to allow in the pool.
-     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
-     *      that excess idle threads will wait for new tasks before terminating.
-     * @param workQ The queue to use for holding tasks before they are executed. This queue will hold only the
-     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
-     * @param hnd Optional handler to use when execution is blocked because the thread bounds and queue
-     *      capacities are reached. If {@code null} then {@code AbortPolicy}
-     *      handler is used by default.
-     */
-    public GridThreadPoolExecutor(
-        int corePoolSize,
-        int maxPoolSize,
-        long keepAliveTime,
-        BlockingQueue<Runnable> workQ,
-        RejectedExecutionHandler hnd) {
-        this(
-            corePoolSize,
-            maxPoolSize,
-            keepAliveTime,
-            workQ,
-            new GridThreadFactory(null),
-            hnd
-        );
-    }
-
-    /**
-     * Creates a new service with default initial parameters.
-     * Default values are:
-     * <table class="doctable">
-     * <tr>
-     *      <th>Name</th>
-     *      <th>Default Value</th>
-     * </tr>
-     * <tr>
-     *      <td>Core Pool Size</td>
-     *      <td>{@code 100} (see {@link #DFLT_CORE_POOL_SIZE}).</td>
-     * </tr>
-     * <tr>
-     *      <td>Maximum Pool Size</td>
-     *      <td>None, is it is not used for unbounded queues.</td>
-     * </tr>
-     * <tr>
-     *      <td>Keep alive time</td>
-     *      <td>No limit (see {@link Long#MAX_VALUE}).</td>
-     * </tr>
-     * <tr>
-     *      <td>Blocking Queue (see {@link BlockingQueue}).</td>
-     *      <td>Unbounded linked blocking queue (see {@link LinkedBlockingDeque}).</td>
-     * </tr>
-     * </table>
-     *
-     * @param gridName Name of the grid.
-     */
-    public GridThreadPoolExecutor(String gridName) {
-        this(
-            DFLT_CORE_POOL_SIZE,
-            DFLT_CORE_POOL_SIZE,
-            0,
-            new LinkedBlockingDeque<Runnable>(),
-            new GridThreadFactory(gridName),
-            null
-        );
-    }
-
-    /**
-     * Creates a new service with the given initial parameters.
-     *
-     * @param gridName Name of the grid
-     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
-     * @param maxPoolSize The maximum number of threads to allow in the pool.
-     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
-     *      that excess idle threads will wait for new tasks before terminating.
-     * @param workQ The queue to use for holding tasks before they are executed. This queue will hold only
-     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
-     */
-    public GridThreadPoolExecutor(
-        String gridName,
-        int corePoolSize,
-        int maxPoolSize,
-        long keepAliveTime,
-        BlockingQueue<Runnable> workQ) {
-        super(
-            corePoolSize,
-            maxPoolSize,
-            keepAliveTime,
-            TimeUnit.MILLISECONDS,
-            workQ,
-            new GridThreadFactory(gridName)
-        );
-    }
-
-    /**
-     * Creates a new service with the given initial parameters.
-     *
-     * @param gridName Name of the grid.
-     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
-     * @param maxPoolSize The maximum number of threads to allow in the pool.
-     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
-     *      that excess idle threads will wait for new tasks before terminating.
-     * @param workQ The queue to use for holding tasks before they are executed. This queue will hold only the
-     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
-     * @param hnd Optional handler to use when execution is blocked because the thread bounds and queue
-     *      capacities are reached. If {@code null} then {@code AbortPolicy}
-     *      handler is used by default.
-     */
-    public GridThreadPoolExecutor(
-        String gridName,
-        int corePoolSize,
-        int maxPoolSize,
-        long keepAliveTime,
-        BlockingQueue<Runnable> workQ,
-        RejectedExecutionHandler hnd) {
-        this(
-            corePoolSize,
-            maxPoolSize,
-            keepAliveTime,
-            workQ,
-            new GridThreadFactory(gridName),
-            hnd
-        );
-    }
-
-    /**
-     * Creates a new service with the given initial parameters.
-     *
-     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
-     * @param maxPoolSize The maximum number of threads to allow in the pool.
-     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
-     *      that excess idle threads will wait for new tasks before terminating.
-     * @param workQ The queue to use for holding tasks before they are executed. This queue will hold only the
-     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
-     * @param threadFactory Thread factory.
-     * @param hnd Optional handler to use when execution is blocked because the thread bounds and queue
-     *      capacities are reached. If {@code null} then {@code AbortPolicy}
-     *      handler is used by default.
-     */
-    public GridThreadPoolExecutor(
-        int corePoolSize,
-        int maxPoolSize,
-        long keepAliveTime,
-        BlockingQueue<Runnable> workQ,
-        ThreadFactory threadFactory,
-        @Nullable RejectedExecutionHandler hnd) {
-        super(
-            corePoolSize,
-            maxPoolSize,
-            keepAliveTime,
-            TimeUnit.MILLISECONDS,
-            workQ,
-            threadFactory,
-            hnd == null ? new AbortPolicy() : hnd
-        );
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/thread/IgniteStripedThreadPoolExecutor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/thread/IgniteStripedThreadPoolExecutor.java b/modules/core/src/main/java/org/gridgain/grid/thread/IgniteStripedThreadPoolExecutor.java
new file mode 100644
index 0000000..dcd7094
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/thread/IgniteStripedThreadPoolExecutor.java
@@ -0,0 +1,216 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.thread;
+
+import org.gridgain.grid.util.typedef.internal.*;
+
+import java.util.*;
+import java.util.concurrent.*;
+
+/**
+ * An {@link ExecutorService} that executes submitted tasks using pooled grid threads.
+ */
+public class IgniteStripedThreadPoolExecutor implements ExecutorService {
+    /** */
+    public static final int DFLT_SEG_POOL_SIZE = 8;
+
+    /** */
+    public static final int DFLT_CONCUR_LVL = 16;
+
+    /** */
+    private final ExecutorService[] execs;
+
+    /** */
+    private final int segShift;
+
+    /** */
+    private final int segMask;
+
+    /**
+     *
+     */
+    public IgniteStripedThreadPoolExecutor() {
+        execs = new ExecutorService[DFLT_CONCUR_LVL];
+
+        ThreadFactory factory = new IgniteThreadFactory(null);
+
+        for (int i = 0; i < DFLT_CONCUR_LVL; i++)
+            execs[i] = Executors.newFixedThreadPool(DFLT_SEG_POOL_SIZE, factory);
+
+        // Find power-of-two sizes best matching arguments
+        int sshift = 0;
+        int ssize = 1;
+
+        while (ssize < DFLT_CONCUR_LVL) {
+            ++sshift;
+
+            ssize <<= 1;
+        }
+
+        segShift = 32 - sshift;
+        segMask = ssize - 1;
+
+    }
+
+    /** {@inheritDoc} */
+    @Override public void shutdown() {
+        for (ExecutorService exec : execs)
+            exec.shutdown();
+    }
+
+    /** {@inheritDoc} */
+    @Override public List<Runnable> shutdownNow() {
+        List<Runnable> res = new LinkedList<>();
+
+        for (ExecutorService exec : execs) {
+            for (Runnable r : exec.shutdownNow())
+                res.add(r);
+        }
+
+        return res;
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean isShutdown() {
+        for (ExecutorService exec : execs) {
+            if (!exec.isShutdown())
+                return false;
+        }
+
+        return true;
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean isTerminated() {
+        for (ExecutorService exec : execs) {
+            if (!exec.isTerminated())
+                return false;
+        }
+
+        return true;
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean awaitTermination(long timeout, TimeUnit unit) throws InterruptedException {
+        boolean res = true;
+
+        for (ExecutorService exec : execs)
+            res &= exec.awaitTermination(timeout, unit);
+
+        return res;
+    }
+
+    /** {@inheritDoc} */
+    @Override public <T> Future<T> submit(Callable<T> task) {
+        return execForTask(task).submit(task);
+    }
+
+    /** {@inheritDoc} */
+    @Override public <T> Future<T> submit(Runnable task, T result) {
+        return execForTask(task).submit(task, result);
+    }
+
+    /** {@inheritDoc} */
+    @Override public Future<?> submit(Runnable task) {
+        return execForTask(task).submit(task);
+    }
+
+    /** {@inheritDoc} */
+    @Override public <T> List<Future<T>> invokeAll(Collection<? extends Callable<T>> tasks)
+        throws InterruptedException {
+        List<Future<T>> futs = new LinkedList<>();
+
+        for (Callable<T> task : tasks)
+            futs.add(execForTask(task).submit(task));
+
+        boolean done = false;
+
+        try {
+            for (Future<T> fut : futs) {
+                try {
+                    fut.get();
+                }
+                catch (ExecutionException | InterruptedException ignored) {
+                    // No-op.
+                }
+            }
+
+            done = true;
+
+            return futs;
+        }
+        finally {
+            if (!done) {
+                for (Future<T> fut : futs)
+                    fut.cancel(true);
+            }
+        }
+    }
+
+    /** {@inheritDoc} */
+    @Override public <T> List<Future<T>> invokeAll(Collection<? extends Callable<T>> tasks, long timeout,
+        TimeUnit unit) throws InterruptedException {
+        throw new RuntimeException("Not implemented.");
+    }
+
+    /** {@inheritDoc} */
+    @Override public <T> T invokeAny(Collection<? extends Callable<T>> tasks) throws InterruptedException,
+        ExecutionException {
+        throw new RuntimeException("Not implemented.");
+    }
+
+    /** {@inheritDoc} */
+    @Override public <T> T invokeAny(Collection<? extends Callable<T>> tasks, long timeout, TimeUnit unit)
+        throws InterruptedException, ExecutionException, TimeoutException {
+        throw new RuntimeException("Not implemented.");
+    }
+
+    /** {@inheritDoc} */
+    @Override public void execute(Runnable cmd) {
+        execForTask(cmd).execute(cmd);
+    }
+
+    /**
+     * Applies a supplemental hash function to a given hashCode, which
+     * defends against poor quality hash functions.  This is critical
+     * because ConcurrentHashMap uses power-of-two length hash tables,
+     * that otherwise encounter collisions for hashCodes that do not
+     * differ in lower or upper bits.
+     *
+     * @param h Hash code.
+     * @return Enhanced hash code.
+     */
+    private int hash(int h) {
+        // Spread bits to regularize both segment and index locations,
+        // using variant of single-word Wang/Jenkins hash.
+        h += (h <<  15) ^ 0xffffcd7d;
+        h ^= (h >>> 10);
+        h += (h <<   3);
+        h ^= (h >>>  6);
+        h += (h <<   2) + (h << 14);
+        return h ^ (h >>> 16);
+    }
+
+    /**
+     * @param cmd Command.
+     * @return Service.
+     */
+    private <T> ExecutorService execForTask(T cmd) {
+        assert cmd != null;
+
+        //return execs[ThreadLocalRandom8.current().nextInt(DFLT_CONCUR_LVL)];
+        return execs[(hash(cmd.hashCode()) >>> segShift) & segMask];
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteStripedThreadPoolExecutor.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThread.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThread.java b/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThread.java
new file mode 100644
index 0000000..e6c5c23
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThread.java
@@ -0,0 +1,100 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.thread;
+
+import org.gridgain.grid.util.typedef.internal.*;
+import org.gridgain.grid.util.worker.*;
+
+import java.util.concurrent.atomic.*;
+
+/**
+ * This class adds some necessary plumbing on top of the {@link Thread} class.
+ * Specifically, it adds:
+ * <ul>
+ *      <li>Consistent naming of threads</li>
+ *      <li>Dedicated parent thread group</li>
+ *      <li>Backing interrupted flag</li>
+ * </ul>
+ * <b>Note</b>: this class is intended for internal use only.
+ */
+public class IgniteThread extends Thread {
+    /** Default thread's group. */
+    private static final ThreadGroup DFLT_GRP = new ThreadGroup("gridgain");
+
+    /** Number of all grid threads in the system. */
+    private static final AtomicLong threadCntr = new AtomicLong(0);
+
+    /** Boolean flag indicating of this thread is currently processing message. */
+    private boolean procMsg;
+
+    /**
+     * Creates thread with given worker.
+     *
+     * @param worker Runnable to create thread with.
+     */
+    public IgniteThread(GridWorker worker) {
+        this(DFLT_GRP, worker.gridName(), worker.name(), worker);
+    }
+
+    /**
+     * Creates grid thread with given name for a given grid.
+     *
+     * @param gridName Name of grid this thread is created for.
+     * @param threadName Name of thread.
+     * @param r Runnable to execute.
+     */
+    public IgniteThread(String gridName, String threadName, Runnable r) {
+        this(DFLT_GRP, gridName, threadName, r);
+    }
+
+    /**
+     * Creates grid thread with given name for a given grid with specified
+     * thread group.
+     *
+     * @param grp Thread group.
+     * @param gridName Name of grid this thread is created for.
+     * @param threadName Name of thread.
+     * @param r Runnable to execute.
+     */
+    public IgniteThread(ThreadGroup grp, String gridName, String threadName, Runnable r) {
+        super(grp, r, createName(threadCntr.incrementAndGet(), threadName, gridName));
+    }
+
+    /**
+     * Creates new thread name.
+     *
+     * @param num Thread number.
+     * @param threadName Thread name.
+     * @param gridName Grid name.
+     * @return New thread name.
+     */
+    private static String createName(long num, String threadName, String gridName) {
+        return threadName + "-#" + num + '%' + gridName + '%';
+    }
+
+    /**
+     * @param procMsg Flag indicating whether thread is currently processing message.
+     */
+    public void processingMessage(boolean procMsg) {
+        this.procMsg = procMsg;
+    }
+
+    /**
+     * @return Flag indicating whether thread is currently processing message.
+     */
+    public boolean processingMessage() {
+        return procMsg;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteThread.class, this, "name", getName());
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThreadFactory.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThreadFactory.java b/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThreadFactory.java
new file mode 100644
index 0000000..7caa5b2
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThreadFactory.java
@@ -0,0 +1,53 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.thread;
+
+import org.jetbrains.annotations.*;
+
+import java.util.concurrent.*;
+
+/**
+ * This class provides implementation of {@link ThreadFactory} factory
+ * for creating grid threads.
+ */
+public class IgniteThreadFactory implements ThreadFactory {
+    /** Grid name. */
+    private final String gridName;
+
+    /** Thread name. */
+    private final String threadName;
+
+    /**
+     * Constructs new thread factory for given grid. All threads will belong
+     * to the same default thread group.
+     *
+     * @param gridName Grid name.
+     */
+    public IgniteThreadFactory(String gridName) {
+        this(gridName, "gridgain");
+    }
+
+    /**
+     * Constructs new thread factory for given grid. All threads will belong
+     * to the same default thread group.
+     *
+     * @param gridName Grid name.
+     * @param threadName Thread name.
+     */
+    public IgniteThreadFactory(String gridName, String threadName) {
+        this.gridName = gridName;
+        this.threadName = threadName;
+    }
+
+    /** {@inheritDoc} */
+    @Override public Thread newThread(@NotNull Runnable r) {
+        return new IgniteThread(gridName, threadName, r);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThreadPoolExecutor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThreadPoolExecutor.java b/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThreadPoolExecutor.java
new file mode 100644
index 0000000..500d50e
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/thread/IgniteThreadPoolExecutor.java
@@ -0,0 +1,242 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.thread;
+
+import org.jetbrains.annotations.*;
+
+import java.util.concurrent.*;
+
+/**
+ * An {@link ExecutorService} that executes submitted tasks using pooled grid threads.
+ */
+public class IgniteThreadPoolExecutor extends ThreadPoolExecutor {
+    /** Default core pool size (value is {@code 100}). */
+    public static final int DFLT_CORE_POOL_SIZE = 100;
+
+    /**
+     * Creates a new service with default initial parameters.
+     * Default values are:
+     * <table class="doctable">
+     * <tr>
+     *      <th>Name</th>
+     *      <th>Default Value</th>
+     * </tr>
+     * <tr>
+     *      <td>Core Pool Size</td>
+     *      <td>{@code 100} (see {@link #DFLT_CORE_POOL_SIZE}).</td>
+     * </tr>
+     * <tr>
+     *      <td>Maximum Pool Size</td>
+     *      <td>None, is it is not used for unbounded queues.</td>
+     * </tr>
+     * <tr>
+     *      <td>Keep alive time</td>
+     *      <td>No limit (see {@link Long#MAX_VALUE}).</td>
+     * </tr>
+     * <tr>
+     *      <td>Blocking Queue (see {@link BlockingQueue}).</td>
+     *      <td>Unbounded linked blocking queue (see {@link LinkedBlockingDeque}).</td>
+     * </tr>
+     * </table>
+     */
+    public IgniteThreadPoolExecutor() {
+        this(
+            DFLT_CORE_POOL_SIZE,
+            DFLT_CORE_POOL_SIZE,
+            0,
+            new LinkedBlockingDeque<Runnable>(),
+            new IgniteThreadFactory(null),
+            null
+        );
+    }
+
+    /**
+     * Creates a new service with the given initial parameters.
+     *
+     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
+     * @param maxPoolSize The maximum number of threads to allow in the pool.
+     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
+     *      that excess idle threads will wait for new tasks before terminating.
+     * @param workQueue The queue to use for holding tasks before they are executed. This queue will hold only
+     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
+     */
+    public IgniteThreadPoolExecutor(
+        int corePoolSize,
+        int maxPoolSize,
+        long keepAliveTime,
+        BlockingQueue<Runnable> workQueue) {
+        this(
+            corePoolSize,
+            maxPoolSize,
+            keepAliveTime,
+            workQueue,
+            new IgniteThreadFactory(null),
+            null
+        );
+    }
+
+    /**
+     * Creates a new service with the given initial parameters.
+     *
+     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
+     * @param maxPoolSize The maximum number of threads to allow in the pool.
+     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
+     *      that excess idle threads will wait for new tasks before terminating.
+     * @param workQ The queue to use for holding tasks before they are executed. This queue will hold only the
+     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
+     * @param hnd Optional handler to use when execution is blocked because the thread bounds and queue
+     *      capacities are reached. If {@code null} then {@code AbortPolicy}
+     *      handler is used by default.
+     */
+    public IgniteThreadPoolExecutor(
+        int corePoolSize,
+        int maxPoolSize,
+        long keepAliveTime,
+        BlockingQueue<Runnable> workQ,
+        RejectedExecutionHandler hnd) {
+        this(
+            corePoolSize,
+            maxPoolSize,
+            keepAliveTime,
+            workQ,
+            new IgniteThreadFactory(null),
+            hnd
+        );
+    }
+
+    /**
+     * Creates a new service with default initial parameters.
+     * Default values are:
+     * <table class="doctable">
+     * <tr>
+     *      <th>Name</th>
+     *      <th>Default Value</th>
+     * </tr>
+     * <tr>
+     *      <td>Core Pool Size</td>
+     *      <td>{@code 100} (see {@link #DFLT_CORE_POOL_SIZE}).</td>
+     * </tr>
+     * <tr>
+     *      <td>Maximum Pool Size</td>
+     *      <td>None, is it is not used for unbounded queues.</td>
+     * </tr>
+     * <tr>
+     *      <td>Keep alive time</td>
+     *      <td>No limit (see {@link Long#MAX_VALUE}).</td>
+     * </tr>
+     * <tr>
+     *      <td>Blocking Queue (see {@link BlockingQueue}).</td>
+     *      <td>Unbounded linked blocking queue (see {@link LinkedBlockingDeque}).</td>
+     * </tr>
+     * </table>
+     *
+     * @param gridName Name of the grid.
+     */
+    public IgniteThreadPoolExecutor(String gridName) {
+        this(
+            DFLT_CORE_POOL_SIZE,
+            DFLT_CORE_POOL_SIZE,
+            0,
+            new LinkedBlockingDeque<Runnable>(),
+            new IgniteThreadFactory(gridName),
+            null
+        );
+    }
+
+    /**
+     * Creates a new service with the given initial parameters.
+     *
+     * @param gridName Name of the grid
+     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
+     * @param maxPoolSize The maximum number of threads to allow in the pool.
+     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
+     *      that excess idle threads will wait for new tasks before terminating.
+     * @param workQ The queue to use for holding tasks before they are executed. This queue will hold only
+     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
+     */
+    public IgniteThreadPoolExecutor(
+        String gridName,
+        int corePoolSize,
+        int maxPoolSize,
+        long keepAliveTime,
+        BlockingQueue<Runnable> workQ) {
+        super(
+            corePoolSize,
+            maxPoolSize,
+            keepAliveTime,
+            TimeUnit.MILLISECONDS,
+            workQ,
+            new IgniteThreadFactory(gridName)
+        );
+    }
+
+    /**
+     * Creates a new service with the given initial parameters.
+     *
+     * @param gridName Name of the grid.
+     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
+     * @param maxPoolSize The maximum number of threads to allow in the pool.
+     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
+     *      that excess idle threads will wait for new tasks before terminating.
+     * @param workQ The queue to use for holding tasks before they are executed. This queue will hold only the
+     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
+     * @param hnd Optional handler to use when execution is blocked because the thread bounds and queue
+     *      capacities are reached. If {@code null} then {@code AbortPolicy}
+     *      handler is used by default.
+     */
+    public IgniteThreadPoolExecutor(
+        String gridName,
+        int corePoolSize,
+        int maxPoolSize,
+        long keepAliveTime,
+        BlockingQueue<Runnable> workQ,
+        RejectedExecutionHandler hnd) {
+        this(
+            corePoolSize,
+            maxPoolSize,
+            keepAliveTime,
+            workQ,
+            new IgniteThreadFactory(gridName),
+            hnd
+        );
+    }
+
+    /**
+     * Creates a new service with the given initial parameters.
+     *
+     * @param corePoolSize The number of threads to keep in the pool, even if they are idle.
+     * @param maxPoolSize The maximum number of threads to allow in the pool.
+     * @param keepAliveTime When the number of threads is greater than the core, this is the maximum time
+     *      that excess idle threads will wait for new tasks before terminating.
+     * @param workQ The queue to use for holding tasks before they are executed. This queue will hold only the
+     *      runnable tasks submitted by the {@link #execute(Runnable)} method.
+     * @param threadFactory Thread factory.
+     * @param hnd Optional handler to use when execution is blocked because the thread bounds and queue
+     *      capacities are reached. If {@code null} then {@code AbortPolicy}
+     *      handler is used by default.
+     */
+    public IgniteThreadPoolExecutor(
+        int corePoolSize,
+        int maxPoolSize,
+        long keepAliveTime,
+        BlockingQueue<Runnable> workQ,
+        ThreadFactory threadFactory,
+        @Nullable RejectedExecutionHandler hnd) {
+        super(
+            corePoolSize,
+            maxPoolSize,
+            keepAliveTime,
+            TimeUnit.MILLISECONDS,
+            workQ,
+            threadFactory,
+            hnd == null ? new AbortPolicy() : hnd
+        );
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryServerEndpoint.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryServerEndpoint.java b/modules/core/src/main/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryServerEndpoint.java
index 5fcdc26..f2c74ed 100644
--- a/modules/core/src/main/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryServerEndpoint.java
+++ b/modules/core/src/main/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryServerEndpoint.java
@@ -179,7 +179,7 @@ public class GridIpcSharedMemoryServerEndpoint implements GridIpcServerEndpoint
 
         gcWorker = new GcWorker(gridName, "ipc-shmem-gc", log);
 
-        new GridThread(gcWorker).start();
+        new IgniteThread(gcWorker).start();
 
         if (log.isInfoEnabled())
             log.info("IPC shared memory server endpoint started [port=" + port +

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioBackPressureControl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioBackPressureControl.java b/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioBackPressureControl.java
index 4a1eba6..98d452f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioBackPressureControl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioBackPressureControl.java
@@ -28,8 +28,8 @@ public class GridNioBackPressureControl {
     public static boolean threadProcessingMessage() {
         Thread th = Thread.currentThread();
 
-        if (th instanceof GridThread)
-            return ((GridThread)th).processingMessage();
+        if (th instanceof IgniteThread)
+            return ((IgniteThread)th).processingMessage();
 
         return threadProcMsg.get();
     }
@@ -40,8 +40,8 @@ public class GridNioBackPressureControl {
     public static void threadProcessingMessage(boolean processing) {
         Thread th = Thread.currentThread();
 
-        if (th instanceof GridThread)
-            ((GridThread)th).processingMessage(processing);
+        if (th instanceof IgniteThread)
+            ((IgniteThread)th).processingMessage(processing);
         else
             threadProcMsg.set(processing);
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioServer.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioServer.java b/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioServer.java
index 0f6acb4..f279ef7 100644
--- a/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioServer.java
+++ b/modules/core/src/main/java/org/gridgain/grid/util/nio/GridNioServer.java
@@ -66,10 +66,10 @@ public class GridNioServer<T> {
 
     /** Accept worker thread. */
     @GridToStringExclude
-    private final GridThread acceptThread;
+    private final IgniteThread acceptThread;
 
     /** Read worker threads. */
-    private final GridThread[] clientThreads;
+    private final IgniteThread[] clientThreads;
 
     /** Read workers. */
     private final List<AbstractNioClientWorker> clientWorkers;
@@ -222,7 +222,7 @@ public class GridNioServer<T> {
             // This method will throw exception if address already in use.
             Selector acceptSelector = createSelector(locAddr);
 
-            acceptThread = new GridThread(new GridNioAcceptWorker(gridName, "nio-acceptor", log, acceptSelector));
+            acceptThread = new IgniteThread(new GridNioAcceptWorker(gridName, "nio-acceptor", log, acceptSelector));
         }
         else {
             locAddr = null;
@@ -230,7 +230,7 @@ public class GridNioServer<T> {
         }
 
         clientWorkers = new ArrayList<>(selectorCnt);
-        clientThreads = new GridThread[selectorCnt];
+        clientThreads = new IgniteThread[selectorCnt];
 
         for (int i = 0; i < selectorCnt; i++) {
             AbstractNioClientWorker worker = directMode ?
@@ -239,7 +239,7 @@ public class GridNioServer<T> {
 
             clientWorkers.add(worker);
 
-            clientThreads[i] = new GridThread(worker);
+            clientThreads[i] = new IgniteThread(worker);
 
             clientThreads[i].setDaemon(daemon);
         }
@@ -267,7 +267,7 @@ public class GridNioServer<T> {
         if (acceptThread != null)
             acceptThread.start();
 
-        for (GridThread thread : clientThreads)
+        for (IgniteThread thread : clientThreads)
             thread.start();
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/test/config/job-loadtest/client.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/job-loadtest/client.xml b/modules/core/src/test/config/job-loadtest/client.xml
index 6abfb76..32fc339 100644
--- a/modules/core/src/test/config/job-loadtest/client.xml
+++ b/modules/core/src/test/config/job-loadtest/client.xml
@@ -45,7 +45,7 @@
 
         <!-- Disable pools -->
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="20"/>
                 <constructor-arg type="int" value="20"/>
                 <constructor-arg type="long">
@@ -58,7 +58,7 @@
         </property>
 
         <property name="systemExecutorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="20"/>
                 <constructor-arg type="int" value="20"/>
                 <constructor-arg type="long">
@@ -71,7 +71,7 @@
         </property>
 
         <property name="peerClassLoadingExecutorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="2"/>
                 <constructor-arg type="int" value="2"/>
                 <constructor-arg type="long">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/test/config/job-loadtest/server.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/job-loadtest/server.xml b/modules/core/src/test/config/job-loadtest/server.xml
index 122d4aa..9723503 100644
--- a/modules/core/src/test/config/job-loadtest/server.xml
+++ b/modules/core/src/test/config/job-loadtest/server.xml
@@ -23,7 +23,7 @@
         <property name="deploymentMode" value="CONTINUOUS"/>
 
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="300"/>
                 <constructor-arg type="int" value="300"/>
                 <constructor-arg type="long">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5068cc6e/modules/core/src/test/config/jobs-load-base.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/jobs-load-base.xml b/modules/core/src/test/config/jobs-load-base.xml
index a5b83c7..2b721f6 100644
--- a/modules/core/src/test/config/jobs-load-base.xml
+++ b/modules/core/src/test/config/jobs-load-base.xml
@@ -71,7 +71,7 @@
         <property name="deploymentMode" value="SHARED"/>
 
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() / 2}"/>
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() / 2}"/>
                 <constructor-arg type="long">
@@ -84,7 +84,7 @@
         </property>
 
         <property name="systemExecutorService">
-            <bean class="org.gridgain.grid.thread.GridThreadPoolExecutor">
+            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() / 2}"/>
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() / 2}"/>
                 <constructor-arg type="long">


[14/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsTestSuite.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsTestSuite.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsTestSuite.java
index d0344a3..176ba85 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsTestSuite.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsTestSuite.java
@@ -68,8 +68,8 @@ public class GridGgfsEventsTestSuite extends TestSuite {
      */
     public static class ShmemPrivate extends GridGgfsEventsAbstractSelfTest {
         /** {@inheritDoc} */
-        @Override protected GridGgfsConfiguration getGgfsConfiguration() throws GridException {
-            GridGgfsConfiguration ggfsCfg = super.getGgfsConfiguration();
+        @Override protected IgniteFsConfiguration getGgfsConfiguration() throws GridException {
+            IgniteFsConfiguration ggfsCfg = super.getGgfsConfiguration();
 
             ggfsCfg.setIpcEndpointConfiguration(GridGgfsTestUtils.jsonToMap("{type:'shmem', port:" +
                 (GridIpcSharedMemoryServerEndpoint.DFLT_IPC_PORT + 1) + "}"));
@@ -83,8 +83,8 @@ public class GridGgfsEventsTestSuite extends TestSuite {
      */
     public static class LoopbackPrivate extends GridGgfsEventsAbstractSelfTest {
         /** {@inheritDoc} */
-        @Override protected GridGgfsConfiguration getGgfsConfiguration() throws GridException {
-            GridGgfsConfiguration ggfsCfg = super.getGgfsConfiguration();
+        @Override protected IgniteFsConfiguration getGgfsConfiguration() throws GridException {
+            IgniteFsConfiguration ggfsCfg = super.getGgfsConfiguration();
 
             ggfsCfg.setIpcEndpointConfiguration(GridGgfsTestUtils.jsonToMap("{type:'tcp', port:" +
                 (GridIpcSharedMemoryServerEndpoint.DFLT_IPC_PORT + 1) + "}"));
@@ -101,8 +101,8 @@ public class GridGgfsEventsTestSuite extends TestSuite {
         private static IgniteFs ggfsSec;
 
         /** {@inheritDoc} */
-        @Override protected GridGgfsConfiguration getGgfsConfiguration() throws GridException {
-            GridGgfsConfiguration ggfsCfg = super.getGgfsConfiguration();
+        @Override protected IgniteFsConfiguration getGgfsConfiguration() throws GridException {
+            IgniteFsConfiguration ggfsCfg = super.getGgfsConfiguration();
 
             ggfsCfg.setSecondaryFileSystem(new GridGgfsHadoopFileSystemWrapper(
                 "ggfs://ggfs-secondary:grid-secondary@127.0.0.1:11500/",
@@ -114,8 +114,8 @@ public class GridGgfsEventsTestSuite extends TestSuite {
         /**
          * @return GGFS configuration for secondary file system.
          */
-        protected GridGgfsConfiguration getSecondaryGgfsConfiguration() throws GridException {
-            GridGgfsConfiguration ggfsCfg = super.getGgfsConfiguration();
+        protected IgniteFsConfiguration getSecondaryGgfsConfiguration() throws GridException {
+            IgniteFsConfiguration ggfsCfg = super.getGgfsConfiguration();
 
             ggfsCfg.setName("ggfs-secondary");
             ggfsCfg.setDefaultMode(PRIMARY);
@@ -169,8 +169,8 @@ public class GridGgfsEventsTestSuite extends TestSuite {
      */
     public static class ShmemDualSync extends PrimarySecondaryTest {
         /** {@inheritDoc} */
-        @Override protected GridGgfsConfiguration getGgfsConfiguration() throws GridException {
-            GridGgfsConfiguration ggfsCfg = super.getGgfsConfiguration();
+        @Override protected IgniteFsConfiguration getGgfsConfiguration() throws GridException {
+            IgniteFsConfiguration ggfsCfg = super.getGgfsConfiguration();
 
             ggfsCfg.setDefaultMode(DUAL_SYNC);
 
@@ -183,8 +183,8 @@ public class GridGgfsEventsTestSuite extends TestSuite {
      */
     public static class ShmemDualAsync extends PrimarySecondaryTest {
         /** {@inheritDoc} */
-        @Override protected GridGgfsConfiguration getGgfsConfiguration() throws GridException {
-            GridGgfsConfiguration ggfsCfg = super.getGgfsConfiguration();
+        @Override protected IgniteFsConfiguration getGgfsConfiguration() throws GridException {
+            IgniteFsConfiguration ggfsCfg = super.getGgfsConfiguration();
 
             ggfsCfg.setDefaultMode(DUAL_ASYNC);
 
@@ -197,8 +197,8 @@ public class GridGgfsEventsTestSuite extends TestSuite {
      */
     public abstract static class LoopbackPrimarySecondaryTest extends PrimarySecondaryTest {
         /** {@inheritDoc} */
-        @Override protected GridGgfsConfiguration getGgfsConfiguration() throws GridException {
-            GridGgfsConfiguration ggfsCfg = super.getGgfsConfiguration();
+        @Override protected IgniteFsConfiguration getGgfsConfiguration() throws GridException {
+            IgniteFsConfiguration ggfsCfg = super.getGgfsConfiguration();
 
             ggfsCfg.setSecondaryFileSystem(new GridGgfsHadoopFileSystemWrapper(
                 "ggfs://ggfs-secondary:grid-secondary@127.0.0.1:11500/",
@@ -208,8 +208,8 @@ public class GridGgfsEventsTestSuite extends TestSuite {
         }
 
         /** {@inheritDoc} */
-        @Override protected GridGgfsConfiguration getSecondaryGgfsConfiguration() throws GridException {
-            GridGgfsConfiguration ggfsCfg = super.getSecondaryGgfsConfiguration();
+        @Override protected IgniteFsConfiguration getSecondaryGgfsConfiguration() throws GridException {
+            IgniteFsConfiguration ggfsCfg = super.getSecondaryGgfsConfiguration();
 
             ggfsCfg.setName("ggfs-secondary");
             ggfsCfg.setDefaultMode(PRIMARY);
@@ -224,8 +224,8 @@ public class GridGgfsEventsTestSuite extends TestSuite {
      */
     public static class LoopbackDualSync extends LoopbackPrimarySecondaryTest {
         /** {@inheritDoc} */
-        @Override protected GridGgfsConfiguration getGgfsConfiguration() throws GridException {
-            GridGgfsConfiguration ggfsCfg = super.getGgfsConfiguration();
+        @Override protected IgniteFsConfiguration getGgfsConfiguration() throws GridException {
+            IgniteFsConfiguration ggfsCfg = super.getGgfsConfiguration();
 
             ggfsCfg.setDefaultMode(DUAL_SYNC);
 
@@ -238,8 +238,8 @@ public class GridGgfsEventsTestSuite extends TestSuite {
      */
     public static class LoopbackDualAsync extends LoopbackPrimarySecondaryTest {
         /** {@inheritDoc} */
-        @Override protected GridGgfsConfiguration getGgfsConfiguration() throws GridException {
-            GridGgfsConfiguration ggfsCfg = super.getGgfsConfiguration();
+        @Override protected IgniteFsConfiguration getGgfsConfiguration() throws GridException {
+            IgniteFsConfiguration ggfsCfg = super.getGgfsConfiguration();
 
             ggfsCfg.setDefaultMode(DUAL_ASYNC);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
index 8edd67f..06c0a07 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
@@ -136,7 +136,7 @@ public abstract class GridGgfsHadoop20FileSystemAbstractSelfTest extends GridGgf
     private void startNodes() throws Exception {
         if (mode != PRIMARY) {
             // Start secondary GGFS.
-            GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+            IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
             ggfsCfg.setDataCacheName("partitioned");
             ggfsCfg.setMetaCacheName("replicated");
@@ -244,8 +244,8 @@ public abstract class GridGgfsHadoop20FileSystemAbstractSelfTest extends GridGgf
      * @param gridName Grid name.
      * @return GGFS configuration.
      */
-    protected GridGgfsConfiguration ggfsConfiguration(String gridName) throws GridException {
-        GridGgfsConfiguration cfg = new GridGgfsConfiguration();
+    protected IgniteFsConfiguration ggfsConfiguration(String gridName) throws GridException {
+        IgniteFsConfiguration cfg = new IgniteFsConfiguration();
 
         cfg.setDataCacheName("partitioned");
         cfg.setMetaCacheName("replicated");
@@ -459,7 +459,7 @@ public abstract class GridGgfsHadoop20FileSystemAbstractSelfTest extends GridGgf
         FSDataOutputStream os = fs.create(file, EnumSet.noneOf(CreateFlag.class),
             Options.CreateOpts.perms(FsPermission.getDefault()));
 
-        final int cnt = 5 * GridGgfsConfiguration.DFLT_BLOCK_SIZE; // Write 5 blocks.
+        final int cnt = 5 * IgniteFsConfiguration.DFLT_BLOCK_SIZE; // Write 5 blocks.
 
         for (int i = 0; i < cnt; i++)
             os.writeInt(i);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
index 2528cd4..efb8b1c 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
@@ -108,7 +108,7 @@ public abstract class GridGgfsHadoopDualAbstractSelfTest extends GridGgfsCommonA
      */
     protected Ignite startGridWithGgfs(String gridName, String ggfsName, GridGgfsMode mode,
         @Nullable GridGgfsFileSystem secondaryFs, @Nullable String restCfg) throws Exception {
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("dataCache");
         ggfsCfg.setMetaCacheName("metaCache");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
index 9300aaa..3136908 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
@@ -162,7 +162,7 @@ public abstract class GridGgfsHadoopFileSystemAbstractSelfTest extends GridGgfsC
     private void startNodes() throws Exception {
         if (mode != PRIMARY) {
             // Start secondary GGFS.
-            GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+            IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
             ggfsCfg.setDataCacheName("partitioned");
             ggfsCfg.setMetaCacheName("replicated");
@@ -308,8 +308,8 @@ public abstract class GridGgfsHadoopFileSystemAbstractSelfTest extends GridGgfsC
      * @param gridName Grid name.
      * @return GGFS configuration.
      */
-    protected GridGgfsConfiguration ggfsConfiguration(String gridName) throws GridException {
-        GridGgfsConfiguration cfg = new GridGgfsConfiguration();
+    protected IgniteFsConfiguration ggfsConfiguration(String gridName) throws GridException {
+        IgniteFsConfiguration cfg = new IgniteFsConfiguration();
 
         cfg.setDataCacheName("partitioned");
         cfg.setMetaCacheName("replicated");
@@ -642,7 +642,7 @@ public abstract class GridGgfsHadoopFileSystemAbstractSelfTest extends GridGgfsC
 
         FSDataOutputStream os = fs.create(file, false, 128);
 
-        final int cnt = 5 * GridGgfsConfiguration.DFLT_BLOCK_SIZE; // Write 5 blocks.
+        final int cnt = 5 * IgniteFsConfiguration.DFLT_BLOCK_SIZE; // Write 5 blocks.
 
         for (int i = 0; i < cnt; i++)
             os.writeInt(i);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java
index 7095ded..e1aba0b 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java
@@ -60,7 +60,7 @@ public class GridGgfsHadoopFileSystemClientSelfTest extends GridGgfsCommonAbstra
 
         cfg.setDiscoverySpi(discoSpi);
 
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("partitioned");
         ggfsCfg.setMetaCacheName("replicated");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
index 560b343..9f3284f 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
@@ -218,7 +218,7 @@ public class GridGgfsHadoopFileSystemHandshakeSelfTest extends GridGgfsCommonAbs
 
         cfg.setCacheConfiguration(metaCacheCfg, dataCacheCfg);
 
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("partitioned");
         ggfsCfg.setMetaCacheName("replicated");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemIpcCacheSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemIpcCacheSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemIpcCacheSelfTest.java
index f19ad35..40cdaf0 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemIpcCacheSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemIpcCacheSelfTest.java
@@ -58,12 +58,12 @@ public class GridGgfsHadoopFileSystemIpcCacheSelfTest extends GridGgfsCommonAbst
 
         cfg.setDiscoverySpi(discoSpi);
 
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("partitioned");
         ggfsCfg.setMetaCacheName("replicated");
         ggfsCfg.setName("ggfs");
-        ggfsCfg.setManagementPort(GridGgfsConfiguration.DFLT_MGMT_PORT + cnt);
+        ggfsCfg.setManagementPort(IgniteFsConfiguration.DFLT_MGMT_PORT + cnt);
 
         ggfsCfg.setIpcEndpointConfiguration(GridGgfsTestUtils.jsonToMap(
             "{type:'shmem', port:" + (GridIpcSharedMemoryServerEndpoint.DFLT_IPC_PORT + cnt) + "}"));

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java
index aabc67b..afb5081 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java
@@ -67,7 +67,7 @@ public class GridGgfsHadoopFileSystemLoggerStateSelfTest extends GridGgfsCommonA
      * @throws Exception If failed.
      */
     private void startUp() throws Exception {
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("partitioned");
         ggfsCfg.setMetaCacheName("replicated");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java
index 3f5db0c..0f156761 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java
@@ -76,7 +76,7 @@ public class GridGgfsHadoopFileSystemSecondaryModeSelfTest extends GridGgfsCommo
     private void startUp() throws Exception {
         startUpSecondary();
 
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("partitioned");
         ggfsCfg.setMetaCacheName("replicated");
@@ -140,7 +140,7 @@ public class GridGgfsHadoopFileSystemSecondaryModeSelfTest extends GridGgfsCommo
      * @throws Exception If failed.
      */
     private void startUpSecondary() throws Exception {
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("partitioned");
         ggfsCfg.setMetaCacheName("replicated");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java
index f0f0ec4..727716f 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java
@@ -68,7 +68,7 @@ public class GridGgfsNearOnlyMultiNodeSelfTest extends GridCommonAbstractTest {
 
         cfg.setDiscoverySpi(discoSpi);
 
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("partitioned");
         ggfsCfg.setMetaCacheName("partitioned");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractSelfTest.java
index f4ddd80..43238c0 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractSelfTest.java
@@ -119,8 +119,8 @@ public abstract class GridHadoopAbstractSelfTest extends GridCommonAbstractTest
     /**
      * @return GGFS configuration.
      */
-    public GridGgfsConfiguration ggfsConfiguration() {
-        GridGgfsConfiguration cfg = new GridGgfsConfiguration();
+    public IgniteFsConfiguration ggfsConfiguration() {
+        IgniteFsConfiguration cfg = new IgniteFsConfiguration();
 
         cfg.setName(ggfsName);
         cfg.setBlockSize(ggfsBlockSize);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
index f8a603b..66797cd 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
@@ -752,7 +752,7 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
         }
 
         /** {@inheritDoc} */
-        @Override public GridGgfsConfiguration configuration() {
+        @Override public IgniteFsConfiguration configuration() {
             return null;
         }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTaskExecutionSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTaskExecutionSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTaskExecutionSelfTest.java
index 4355101..7615293 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTaskExecutionSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTaskExecutionSelfTest.java
@@ -64,8 +64,8 @@ public class GridHadoopTaskExecutionSelfTest extends GridHadoopAbstractSelfTest
 
 
     /** {@inheritDoc} */
-    @Override public GridGgfsConfiguration ggfsConfiguration() {
-        GridGgfsConfiguration cfg = super.ggfsConfiguration();
+    @Override public IgniteFsConfiguration ggfsConfiguration() {
+        IgniteFsConfiguration cfg = super.ggfsConfiguration();
 
         cfg.setFragmentizerEnabled(false);
 


[37/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/test/config/load/merge-sort-base.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/load/merge-sort-base.xml b/modules/core/src/test/config/load/merge-sort-base.xml
index 130bfe3..a105f99 100644
--- a/modules/core/src/test/config/load/merge-sort-base.xml
+++ b/modules/core/src/test/config/load/merge-sort-base.xml
@@ -57,7 +57,7 @@
 
         <!-- Disable pools -->
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="100"/>
                 <constructor-arg type="int" value="100"/>
                 <constructor-arg type="long">
@@ -70,7 +70,7 @@
         </property>
 
         <property name="systemExecutorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="100"/>
                 <constructor-arg type="int" value="100"/>
                 <constructor-arg type="long">
@@ -83,7 +83,7 @@
         </property>
 
         <property name="peerClassLoadingExecutorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="100"/>
                 <constructor-arg type="int" value="100"/>
                 <constructor-arg type="long">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/test/config/load/mongo-multinode-foster.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/load/mongo-multinode-foster.xml b/modules/core/src/test/config/load/mongo-multinode-foster.xml
index 3235a6f..e4ebf4f 100644
--- a/modules/core/src/test/config/load/mongo-multinode-foster.xml
+++ b/modules/core/src/test/config/load/mongo-multinode-foster.xml
@@ -115,7 +115,7 @@
         <property name="peerClassLoadingEnabled" value="false"/>
 
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() * 2}"/>
                 <constructor-arg type="int" value="#{T(java.lang.Runtime).getRuntime().availableProcessors() * 2}"/>
                 <constructor-arg type="long">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/test/config/spring-multicache.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/spring-multicache.xml b/modules/core/src/test/config/spring-multicache.xml
index c60c6b3..4819bdc 100644
--- a/modules/core/src/test/config/spring-multicache.xml
+++ b/modules/core/src/test/config/spring-multicache.xml
@@ -288,7 +288,7 @@
             All threads are pre-started and are available for use.
         -->
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="10"/>
                 <constructor-arg type="int" value="10"/>
                 <constructor-arg type="long">
@@ -306,7 +306,7 @@
             Threads are not started unless used.
         -->
         <property name="systemExecutorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="10"/>
                 <constructor-arg type="int" value="10"/>
                 <constructor-arg type="long">
@@ -324,7 +324,7 @@
             Threads are not started unless used.
         -->
         <property name="peerClassLoadingExecutorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="2"/>
                 <constructor-arg type="int" value="2"/>
                 <constructor-arg type="long">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/distributed/GridCachePreloadLifecycleAbstractTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/distributed/GridCachePreloadLifecycleAbstractTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/distributed/GridCachePreloadLifecycleAbstractTest.java
index 2bfefff..e9f88cc 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/distributed/GridCachePreloadLifecycleAbstractTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/distributed/GridCachePreloadLifecycleAbstractTest.java
@@ -12,12 +12,12 @@ package org.gridgain.grid.kernal.processors.cache.distributed;
 import org.apache.ignite.configuration.*;
 import org.apache.ignite.lifecycle.*;
 import org.apache.ignite.marshaller.optimized.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.vm.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.gridgain.testframework.junits.common.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/test/java/org/gridgain/grid/marshaller/GridMarshallerResourceBean.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/marshaller/GridMarshallerResourceBean.java b/modules/core/src/test/java/org/gridgain/grid/marshaller/GridMarshallerResourceBean.java
index af48d70..d1e4e15 100644
--- a/modules/core/src/test/java/org/gridgain/grid/marshaller/GridMarshallerResourceBean.java
+++ b/modules/core/src/test/java/org/gridgain/grid/marshaller/GridMarshallerResourceBean.java
@@ -15,9 +15,9 @@ import org.apache.ignite.compute.*;
 import org.apache.ignite.logger.java.*;
 import org.apache.ignite.marshaller.*;
 import org.apache.ignite.marshaller.jdk.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.managers.loadbalancer.*;
-import org.gridgain.grid.thread.*;
 import org.springframework.context.*;
 import org.springframework.context.support.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadPoolExecutorServiceSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadPoolExecutorServiceSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadPoolExecutorServiceSelfTest.java
index 469014b..3a3ad17 100644
--- a/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadPoolExecutorServiceSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadPoolExecutorServiceSelfTest.java
@@ -9,6 +9,7 @@
 
 package org.gridgain.grid.thread;
 
+import org.apache.ignite.thread.*;
 import org.gridgain.testframework.junits.common.*;
 
 import java.util.concurrent.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadTest.java b/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadTest.java
index f99ceae..17d12a4 100644
--- a/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/thread/GridThreadTest.java
@@ -9,12 +9,13 @@
 
 package org.gridgain.grid.thread;
 
+import org.apache.ignite.thread.*;
 import org.gridgain.testframework.junits.common.*;
 
 import java.util.*;
 
 /**
- * Test for {@link IgniteThread}.
+ * Test for {@link org.apache.ignite.thread.IgniteThread}.
  */
 @GridCommonTest(group = "Utils")
 public class GridThreadTest extends GridCommonAbstractTest {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/test/java/org/gridgain/loadtests/cache/GridCacheSingleNodeLoadTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/loadtests/cache/GridCacheSingleNodeLoadTest.java b/modules/core/src/test/java/org/gridgain/loadtests/cache/GridCacheSingleNodeLoadTest.java
index 2264ced..0904502 100644
--- a/modules/core/src/test/java/org/gridgain/loadtests/cache/GridCacheSingleNodeLoadTest.java
+++ b/modules/core/src/test/java/org/gridgain/loadtests/cache/GridCacheSingleNodeLoadTest.java
@@ -10,12 +10,12 @@
 package org.gridgain.loadtests.cache;
 
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.cache.eviction.lru.*;
 import org.gridgain.grid.spi.collision.fifoqueue.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.vm.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.gridgain.testframework.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/test/java/org/gridgain/loadtests/colocation/GridTestMain.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/loadtests/colocation/GridTestMain.java b/modules/core/src/test/java/org/gridgain/loadtests/colocation/GridTestMain.java
index 900e418..37b7373 100644
--- a/modules/core/src/test/java/org/gridgain/loadtests/colocation/GridTestMain.java
+++ b/modules/core/src/test/java/org/gridgain/loadtests/colocation/GridTestMain.java
@@ -12,9 +12,9 @@ package org.gridgain.loadtests.colocation;
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
 import org.apache.ignite.lang.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.typedef.*;
 import org.springframework.beans.factory.*;
 import org.springframework.context.support.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/test/java/org/gridgain/loadtests/colocation/spring-colocation.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/loadtests/colocation/spring-colocation.xml b/modules/core/src/test/java/org/gridgain/loadtests/colocation/spring-colocation.xml
index e0c8cc8..f52bd2a 100644
--- a/modules/core/src/test/java/org/gridgain/loadtests/colocation/spring-colocation.xml
+++ b/modules/core/src/test/java/org/gridgain/loadtests/colocation/spring-colocation.xml
@@ -70,7 +70,7 @@
             All threads are pre-started and are available for use.
         -->
         <property name="executorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="400"/>
                 <constructor-arg type="int" value="400"/>
                 <constructor-arg type="long">
@@ -88,7 +88,7 @@
             Threads are not started unless used.
         -->
         <property name="systemExecutorService">
-            <bean class="org.gridgain.grid.thread.IgniteThreadPoolExecutor">
+            <bean class="org.apache.ignite.thread.IgniteThreadPoolExecutor">
                 <constructor-arg type="int" value="400"/>
                 <constructor-arg type="int" value="400"/>
                 <constructor-arg type="long">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/test/java/org/gridgain/loadtests/direct/newnodes/GridSingleSplitsNewNodesAbstractLoadTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/loadtests/direct/newnodes/GridSingleSplitsNewNodesAbstractLoadTest.java b/modules/core/src/test/java/org/gridgain/loadtests/direct/newnodes/GridSingleSplitsNewNodesAbstractLoadTest.java
index 4c3dc2f..e23a224 100644
--- a/modules/core/src/test/java/org/gridgain/loadtests/direct/newnodes/GridSingleSplitsNewNodesAbstractLoadTest.java
+++ b/modules/core/src/test/java/org/gridgain/loadtests/direct/newnodes/GridSingleSplitsNewNodesAbstractLoadTest.java
@@ -12,10 +12,10 @@ package org.gridgain.loadtests.direct.newnodes;
 import org.apache.ignite.*;
 import org.apache.ignite.compute.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.loadtest.*;
 import org.gridgain.grid.spi.communication.tcp.*;
 import org.gridgain.grid.spi.discovery.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.testframework.*;
 import org.gridgain.testframework.config.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/core/src/test/java/org/gridgain/testframework/junits/GridTestResources.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/testframework/junits/GridTestResources.java b/modules/core/src/test/java/org/gridgain/testframework/junits/GridTestResources.java
index bea8f4c..7ce5bc1 100644
--- a/modules/core/src/test/java/org/gridgain/testframework/junits/GridTestResources.java
+++ b/modules/core/src/test/java/org/gridgain/testframework/junits/GridTestResources.java
@@ -13,9 +13,9 @@ import org.apache.ignite.*;
 import org.apache.ignite.marshaller.*;
 import org.apache.ignite.marshaller.optimized.*;
 import org.apache.ignite.resources.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.processors.resource.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.gridgain.testframework.config.*;
 import org.gridgain.testframework.junits.logger.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/email/src/main/java/org/gridgain/grid/kernal/processors/email/GridEmailProcessor.java
----------------------------------------------------------------------
diff --git a/modules/email/src/main/java/org/gridgain/grid/kernal/processors/email/GridEmailProcessor.java b/modules/email/src/main/java/org/gridgain/grid/kernal/processors/email/GridEmailProcessor.java
index c5403d4..f25755d 100644
--- a/modules/email/src/main/java/org/gridgain/grid/kernal/processors/email/GridEmailProcessor.java
+++ b/modules/email/src/main/java/org/gridgain/grid/kernal/processors/email/GridEmailProcessor.java
@@ -11,9 +11,9 @@ package org.gridgain.grid.kernal.processors.email;
 
 import org.apache.ignite.configuration.*;
 import org.apache.ignite.lang.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.gridgain.grid.util.future.*;
 import org.gridgain.grid.util.worker.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/shuffle/GridHadoopShuffleJob.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/shuffle/GridHadoopShuffleJob.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/shuffle/GridHadoopShuffleJob.java
index 533f939..e0af2fa 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/shuffle/GridHadoopShuffleJob.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/shuffle/GridHadoopShuffleJob.java
@@ -11,11 +11,11 @@ package org.gridgain.grid.kernal.processors.hadoop.shuffle;
 
 import org.apache.ignite.*;
 import org.apache.ignite.lang.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.hadoop.*;
 import org.gridgain.grid.kernal.processors.hadoop.counter.*;
 import org.gridgain.grid.kernal.processors.hadoop.shuffle.collections.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.future.*;
 import org.gridgain.grid.util.io.*;
 import org.gridgain.grid.util.lang.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/GridHadoopExecutorService.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/GridHadoopExecutorService.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/GridHadoopExecutorService.java
index bd4fb1b..dde9850 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/GridHadoopExecutorService.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/GridHadoopExecutorService.java
@@ -11,9 +11,9 @@ package org.gridgain.grid.kernal.processors.hadoop.taskexecutor;
 
 
 import org.apache.ignite.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.hadoop.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.worker.*;
 import org.jdk8.backport.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/communication/GridHadoopExternalCommunication.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/communication/GridHadoopExternalCommunication.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/communication/GridHadoopExternalCommunication.java
index b9fc2ca..2997d46 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/communication/GridHadoopExternalCommunication.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/communication/GridHadoopExternalCommunication.java
@@ -11,10 +11,10 @@ package org.gridgain.grid.kernal.processors.hadoop.taskexecutor.external.communi
 
 import org.apache.ignite.*;
 import org.apache.ignite.marshaller.*;
+import org.apache.ignite.thread.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.kernal.processors.hadoop.message.*;
 import org.gridgain.grid.kernal.processors.hadoop.taskexecutor.external.*;
-import org.gridgain.grid.thread.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.ipc.*;
 import org.gridgain.grid.util.ipc.shmem.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c6781a1c/modules/visor-console/src/main/scala/org/gridgain/visor/visor.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/gridgain/visor/visor.scala b/modules/visor-console/src/main/scala/org/gridgain/visor/visor.scala
index 8f67380..d752de4 100644
--- a/modules/visor-console/src/main/scala/org/gridgain/visor/visor.scala
+++ b/modules/visor-console/src/main/scala/org/gridgain/visor/visor.scala
@@ -11,6 +11,7 @@
 
 package org.gridgain.visor
 
+import org.apache.ignite.thread.IgniteThreadPoolExecutor
 import org.apache.ignite.{IgniteState, Ignition}
 import org.apache.ignite.cluster.{ClusterGroup, ClusterMetrics, ClusterNode}
 import org.apache.ignite.configuration.IgniteConfiguration


[07/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/PortableRawReader.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableRawReader.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableRawReader.java
new file mode 100644
index 0000000..a4fe957
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableRawReader.java
@@ -0,0 +1,214 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.portables;
+
+import org.jetbrains.annotations.*;
+
+import java.sql.*;
+import java.util.*;
+import java.util.Date;
+
+/**
+ * Raw reader for portable objects. Raw reader does not use field name hash codes, therefore,
+ * making the format even more compact. However, if the raw reader is used,
+ * dynamic structure changes to the portable objects are not supported.
+ */
+public interface PortableRawReader {
+    /**
+     * @return Byte value.
+     * @throws PortableException In case of error.
+     */
+    public byte readByte() throws PortableException;
+
+    /**
+     * @return Short value.
+     * @throws PortableException In case of error.
+     */
+    public short readShort() throws PortableException;
+
+    /**
+     * @return Integer value.
+     * @throws PortableException In case of error.
+     */
+    public int readInt() throws PortableException;
+
+    /**
+     * @return Long value.
+     * @throws PortableException In case of error.
+     */
+    public long readLong() throws PortableException;
+
+    /**
+     * @return Float value.
+     * @throws PortableException In case of error.
+     */
+    public float readFloat() throws PortableException;
+
+    /**
+     * @return Double value.
+     * @throws PortableException In case of error.
+     */
+    public double readDouble() throws PortableException;
+
+    /**
+     * @return Char value.
+     * @throws PortableException In case of error.
+     */
+    public char readChar() throws PortableException;
+
+    /**
+     * @return Boolean value.
+     * @throws PortableException In case of error.
+     */
+    public boolean readBoolean() throws PortableException;
+
+    /**
+     * @return String value.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public String readString() throws PortableException;
+
+    /**
+     * @return UUID.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public UUID readUuid() throws PortableException;
+
+    /**
+     * @return Date.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public Date readDate() throws PortableException;
+
+    /**
+     * @return Timestamp.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public Timestamp readTimestamp() throws PortableException;
+
+    /**
+     * @return Object.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public Object readObject() throws PortableException;
+
+    /**
+     * @return Byte array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public byte[] readByteArray() throws PortableException;
+
+    /**
+     * @return Short array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public short[] readShortArray() throws PortableException;
+
+    /**
+     * @return Integer array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public int[] readIntArray() throws PortableException;
+
+    /**
+     * @return Long array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public long[] readLongArray() throws PortableException;
+
+    /**
+     * @return Float array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public float[] readFloatArray() throws PortableException;
+
+    /**
+     * @return Byte array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public double[] readDoubleArray() throws PortableException;
+
+    /**
+     * @return Char array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public char[] readCharArray() throws PortableException;
+
+    /**
+     * @return Boolean array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public boolean[] readBooleanArray() throws PortableException;
+
+    /**
+     * @return String array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public String[] readStringArray() throws PortableException;
+
+    /**
+     * @return UUID array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public UUID[] readUuidArray() throws PortableException;
+
+    /**
+     * @return Date array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public Date[] readDateArray() throws PortableException;
+
+    /**
+     * @return Object array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public Object[] readObjectArray() throws PortableException;
+
+    /**
+     * @return Collection.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public <T> Collection<T> readCollection() throws PortableException;
+
+    /**
+     * @param colCls Collection class.
+     * @return Collection.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public <T> Collection<T> readCollection(Class<? extends Collection<T>> colCls)
+        throws PortableException;
+
+    /**
+     * @return Map.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public <K, V> Map<K, V> readMap() throws PortableException;
+
+    /**
+     * @param mapCls Map class.
+     * @return Map.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public <K, V> Map<K, V> readMap(Class<? extends Map<K, V>> mapCls) throws PortableException;
+
+    /**
+     * @param enumCls Enum class.
+     * @return Value.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public <T extends Enum<?>> T readEnum(Class<T> enumCls) throws PortableException;
+
+    /**
+     * @param enumCls Enum class.
+     * @return Value.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public <T extends Enum<?>> T[] readEnumArray(Class<T> enumCls) throws PortableException;
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/PortableRawWriter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableRawWriter.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableRawWriter.java
new file mode 100644
index 0000000..f3c884b
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableRawWriter.java
@@ -0,0 +1,197 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.portables;
+
+import org.jetbrains.annotations.*;
+
+import java.sql.*;
+import java.util.*;
+import java.util.Date;
+
+/**
+ * Raw writer for portable object. Raw writer does not write field name hash codes, therefore,
+ * making the format even more compact. However, if the raw writer is used,
+ * dynamic structure changes to the portable objects are not supported.
+ */
+public interface PortableRawWriter {
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeByte(byte val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeShort(short val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeInt(int val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeLong(long val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeFloat(float val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeDouble(double val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeChar(char val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeBoolean(boolean val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeString(@Nullable String val) throws PortableException;
+
+    /**
+     * @param val UUID to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeUuid(@Nullable UUID val) throws PortableException;
+
+    /**
+     * @param val Date to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeDate(@Nullable Date val) throws PortableException;
+
+    /**
+     * @param val Timestamp to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeTimestamp(@Nullable Timestamp val) throws PortableException;
+
+    /**
+     * @param obj Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeObject(@Nullable Object obj) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeByteArray(@Nullable byte[] val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeShortArray(@Nullable short[] val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeIntArray(@Nullable int[] val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeLongArray(@Nullable long[] val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeFloatArray(@Nullable float[] val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeDoubleArray(@Nullable double[] val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeCharArray(@Nullable char[] val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeBooleanArray(@Nullable boolean[] val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeStringArray(@Nullable String[] val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeUuidArray(@Nullable UUID[] val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeDateArray(@Nullable Date[] val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeObjectArray(@Nullable Object[] val) throws PortableException;
+
+    /**
+     * @param col Collection to write.
+     * @throws PortableException In case of error.
+     */
+    public <T> void writeCollection(@Nullable Collection<T> col) throws PortableException;
+
+    /**
+     * @param map Map to write.
+     * @throws PortableException In case of error.
+     */
+    public <K, V> void writeMap(@Nullable Map<K, V> map) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public <T extends Enum<?>> void writeEnum(T val) throws PortableException;
+
+    /**
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public <T extends Enum<?>> void writeEnumArray(T[] val) throws PortableException;
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/PortableReader.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableReader.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableReader.java
new file mode 100644
index 0000000..5cef5a3
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableReader.java
@@ -0,0 +1,263 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.portables;
+
+import org.jetbrains.annotations.*;
+
+import java.sql.*;
+import java.util.*;
+import java.util.Date;
+
+/**
+ * Reader for portable objects used in {@link PortableMarshalAware} implementations.
+ * Useful for the cases when user wants a fine-grained control over serialization.
+ * <p>
+ * Note that GridGain never writes full strings for field or type names. Instead,
+ * for performance reasons, GridGain writes integer hash codes for type and field names.
+ * It has been tested that hash code conflicts for the type names or the field names
+ * within the same type are virtually non-existent and, to gain performance, it is safe
+ * to work with hash codes. For the cases when hash codes for different types or fields
+ * actually do collide, GridGain provides {@link PortableIdMapper} which
+ * allows to override the automatically generated hash code IDs for the type and field names.
+ */
+public interface PortableReader {
+    /**
+     * @param fieldName Field name.
+     * @return Byte value.
+     * @throws PortableException In case of error.
+     */
+    public byte readByte(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Short value.
+     * @throws PortableException In case of error.
+     */
+    public short readShort(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Integer value.
+     * @throws PortableException In case of error.
+     */
+    public int readInt(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Long value.
+     * @throws PortableException In case of error.
+     */
+    public long readLong(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @throws PortableException In case of error.
+     * @return Float value.
+     */
+    public float readFloat(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Double value.
+     * @throws PortableException In case of error.
+     */
+    public double readDouble(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Char value.
+     * @throws PortableException In case of error.
+     */
+    public char readChar(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Boolean value.
+     * @throws PortableException In case of error.
+     */
+    public boolean readBoolean(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return String value.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public String readString(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return UUID.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public UUID readUuid(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Date.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public Date readDate(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Timestamp.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public Timestamp readTimestamp(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Object.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public <T> T readObject(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Byte array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public byte[] readByteArray(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Short array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public short[] readShortArray(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Integer array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public int[] readIntArray(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Long array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public long[] readLongArray(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Float array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public float[] readFloatArray(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Byte array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public double[] readDoubleArray(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Char array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public char[] readCharArray(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Boolean array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public boolean[] readBooleanArray(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return String array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public String[] readStringArray(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return UUID array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public UUID[] readUuidArray(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Date array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public Date[] readDateArray(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Object array.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public Object[] readObjectArray(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Collection.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public <T> Collection<T> readCollection(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param colCls Collection class.
+     * @return Collection.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public <T> Collection<T> readCollection(String fieldName, Class<? extends Collection<T>> colCls)
+        throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @return Map.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public <K, V> Map<K, V> readMap(String fieldName) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param mapCls Map class.
+     * @return Map.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public <K, V> Map<K, V> readMap(String fieldName, Class<? extends Map<K, V>> mapCls)
+        throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param enumCls Enum class.
+     * @return Value.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public <T extends Enum<?>> T readEnum(String fieldName, Class<T> enumCls) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param enumCls Enum class.
+     * @return Value.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public <T extends Enum<?>> T[] readEnumArray(String fieldName, Class<T> enumCls)
+        throws PortableException;
+
+    /**
+     * Gets raw reader. Raw reader does not use field name hash codes, therefore,
+     * making the format even more compact. However, if the raw reader is used,
+     * dynamic structure changes to the portable objects are not supported.
+     *
+     * @return Raw reader.
+     */
+    public PortableRawReader rawReader();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/PortableSerializer.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableSerializer.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableSerializer.java
new file mode 100644
index 0000000..8ebe14e
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableSerializer.java
@@ -0,0 +1,39 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.portables;
+
+/**
+ * Interface that allows to implement custom serialization logic for portable objects.
+ * Can be used instead of {@link PortableMarshalAware} in case if the class
+ * cannot be changed directly.
+ * <p>
+ * Portable serializer can be configured for all portable objects via
+ * {@link PortableConfiguration#getSerializer()} method, or for a specific
+ * portable type via {@link PortableTypeConfiguration#getSerializer()} method.
+ */
+public interface PortableSerializer {
+    /**
+     * Writes fields to provided writer.
+     *
+     * @param obj Empty object.
+     * @param writer Portable object writer.
+     * @throws PortableException In case of error.
+     */
+    public void writePortable(Object obj, PortableWriter writer) throws PortableException;
+
+    /**
+     * Reads fields from provided reader.
+     *
+     * @param obj Empty object
+     * @param reader Portable object reader.
+     * @throws PortableException In case of error.
+     */
+    public void readPortable(Object obj, PortableReader reader) throws PortableException;
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/PortableTypeConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableTypeConfiguration.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableTypeConfiguration.java
new file mode 100644
index 0000000..e1e33e1
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableTypeConfiguration.java
@@ -0,0 +1,187 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.portables;
+
+import org.gridgain.grid.util.typedef.internal.*;
+
+import java.sql.*;
+
+/**
+ * Defines configuration properties for a specific portable type. Providing per-type
+ * configuration is optional, as it is generally enough to provide global
+ * portable configuration in {@link PortableConfiguration} instance. However,
+ * this class allows you to change configuration properties for a specific
+ * portable type without affecting configuration for other portable types.
+ * <p>
+ * Per-type portable configuration can be specified in
+ * {@link PortableConfiguration#getTypeConfigurations()} method.
+ */
+public class PortableTypeConfiguration {
+    /** Class name. */
+    private String clsName;
+
+    /** ID mapper. */
+    private PortableIdMapper idMapper;
+
+    /** Serializer. */
+    private PortableSerializer serializer;
+
+    /** Use timestamp flag. */
+    private Boolean useTs;
+
+    /** Meta data enabled flag. */
+    private Boolean metaDataEnabled;
+
+    /** Keep deserialized flag. */
+    private Boolean keepDeserialized;
+
+    /** Affinity key field name. */
+    private String affKeyFieldName;
+
+    /**
+     */
+    public PortableTypeConfiguration() {
+        // No-op.
+    }
+
+    /**
+     * @param clsName Class name.
+     */
+    public PortableTypeConfiguration(String clsName) {
+        this.clsName = clsName;
+    }
+
+    /**
+     * Gets type name.
+     *
+     * @return Type name.
+     */
+    public String getClassName() {
+        return clsName;
+    }
+
+    /**
+     * Sets type name.
+     *
+     * @param clsName Type name.
+     */
+    public void setClassName(String clsName) {
+        this.clsName = clsName;
+    }
+
+    /**
+     * Gets ID mapper.
+     *
+     * @return ID mapper.
+     */
+    public PortableIdMapper getIdMapper() {
+        return idMapper;
+    }
+
+    /**
+     * Sets ID mapper.
+     *
+     * @param idMapper ID mapper.
+     */
+    public void setIdMapper(PortableIdMapper idMapper) {
+        this.idMapper = idMapper;
+    }
+
+    /**
+     * Gets serializer.
+     *
+     * @return Serializer.
+     */
+    public PortableSerializer getSerializer() {
+        return serializer;
+    }
+
+    /**
+     * Sets serializer.
+     *
+     * @param serializer Serializer.
+     */
+    public void setSerializer(PortableSerializer serializer) {
+        this.serializer = serializer;
+    }
+
+    /**
+     * If {@code true} then date values converted to {@link Timestamp} during unmarshalling.
+     *
+     * @return Flag indicating whether date values converted to {@link Timestamp} during unmarshalling.
+     */
+    public Boolean isUseTimestamp() {
+        return useTs;
+    }
+
+    /**
+     * @param useTs Flag indicating whether date values converted to {@link Timestamp} during unmarshalling.
+     */
+    public void setUseTimestamp(Boolean useTs) {
+        this.useTs = useTs;
+    }
+
+    /**
+     * Defines whether meta data is collected for this type. If provided, this value will override
+     * {@link PortableConfiguration#isMetaDataEnabled()} property.
+     *
+     * @return Whether meta data is collected.
+     */
+    public Boolean isMetaDataEnabled() {
+        return metaDataEnabled;
+    }
+
+    /**
+     * @param metaDataEnabled Whether meta data is collected.
+     */
+    public void setMetaDataEnabled(Boolean metaDataEnabled) {
+        this.metaDataEnabled = metaDataEnabled;
+    }
+
+    /**
+     * Defines whether {@link PortableObject} should cache deserialized instance. If provided,
+     * this value will override {@link PortableConfiguration#isKeepDeserialized()} property.
+     *
+     * @return Whether deserialized value is kept.
+     */
+    public Boolean isKeepDeserialized() {
+        return keepDeserialized;
+    }
+
+    /**
+     * @param keepDeserialized Whether deserialized value is kept.
+     */
+    public void setKeepDeserialized(Boolean keepDeserialized) {
+        this.keepDeserialized = keepDeserialized;
+    }
+
+    /**
+     * Gets affinity key field name.
+     *
+     * @return Affinity key field name.
+     */
+    public String getAffinityKeyFieldName() {
+        return affKeyFieldName;
+    }
+
+    /**
+     * Sets affinity key field name.
+     *
+     * @param affKeyFieldName Affinity key field name.
+     */
+    public void setAffinityKeyFieldName(String affKeyFieldName) {
+        this.affKeyFieldName = affKeyFieldName;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(PortableTypeConfiguration.class, this, super.toString());
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/PortableWriter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableWriter.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableWriter.java
new file mode 100644
index 0000000..d29ef3d
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableWriter.java
@@ -0,0 +1,242 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.portables;
+
+import org.jetbrains.annotations.*;
+
+import java.sql.*;
+import java.util.*;
+import java.util.Date;
+
+/**
+ * Writer for portable object used in {@link PortableMarshalAware} implementations.
+ * Useful for the cases when user wants a fine-grained control over serialization.
+ * <p>
+ * Note that GridGain never writes full strings for field or type names. Instead,
+ * for performance reasons, GridGain writes integer hash codes for type and field names.
+ * It has been tested that hash code conflicts for the type names or the field names
+ * within the same type are virtually non-existent and, to gain performance, it is safe
+ * to work with hash codes. For the cases when hash codes for different types or fields
+ * actually do collide, GridGain provides {@link PortableIdMapper} which
+ * allows to override the automatically generated hash code IDs for the type and field names.
+ */
+public interface PortableWriter {
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeByte(String fieldName, byte val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeShort(String fieldName, short val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeInt(String fieldName, int val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeLong(String fieldName, long val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeFloat(String fieldName, float val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeDouble(String fieldName, double val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeChar(String fieldName, char val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeBoolean(String fieldName, boolean val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeString(String fieldName, @Nullable String val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val UUID to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeUuid(String fieldName, @Nullable UUID val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Date to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeDate(String fieldName, @Nullable Date val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Timestamp to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeTimestamp(String fieldName, @Nullable Timestamp val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param obj Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeObject(String fieldName, @Nullable Object obj) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeByteArray(String fieldName, @Nullable byte[] val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeShortArray(String fieldName, @Nullable short[] val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeIntArray(String fieldName, @Nullable int[] val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeLongArray(String fieldName, @Nullable long[] val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeFloatArray(String fieldName, @Nullable float[] val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeDoubleArray(String fieldName, @Nullable double[] val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeCharArray(String fieldName, @Nullable char[] val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeBooleanArray(String fieldName, @Nullable boolean[] val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeStringArray(String fieldName, @Nullable String[] val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeUuidArray(String fieldName, @Nullable UUID[] val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeDateArray(String fieldName, @Nullable Date[] val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public void writeObjectArray(String fieldName, @Nullable Object[] val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param col Collection to write.
+     * @throws PortableException In case of error.
+     */
+    public <T> void writeCollection(String fieldName, @Nullable Collection<T> col) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param map Map to write.
+     * @throws PortableException In case of error.
+     */
+    public <K, V> void writeMap(String fieldName, @Nullable Map<K, V> map) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public <T extends Enum<?>> void writeEnum(String fieldName, T val) throws PortableException;
+
+    /**
+     * @param fieldName Field name.
+     * @param val Value to write.
+     * @throws PortableException In case of error.
+     */
+    public <T extends Enum<?>> void writeEnumArray(String fieldName, T[] val) throws PortableException;
+
+    /**
+     * Gets raw writer. Raw writer does not write field name hash codes, therefore,
+     * making the format even more compact. However, if the raw writer is used,
+     * dynamic structure changes to the portable objects are not supported.
+     *
+     * @return Raw writer.
+     */
+    public PortableRawWriter rawWriter();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/client/GridClientCacheFlag.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/client/GridClientCacheFlag.java b/modules/core/src/main/java/org/gridgain/client/GridClientCacheFlag.java
index 263ed17..b56e888 100644
--- a/modules/core/src/main/java/org/gridgain/client/GridClientCacheFlag.java
+++ b/modules/core/src/main/java/org/gridgain/client/GridClientCacheFlag.java
@@ -35,7 +35,7 @@ public enum GridClientCacheFlag {
      * Disable deserialization of portable objects on get operations.
      * If set and portable marshaller is used, {@link GridClientData#get(Object)}
      * and {@link GridClientData#getAll(Collection)} methods will return
-     * instances of {@link org.apache.ignite.portables.GridPortableObject} class instead of user objects.
+     * instances of {@link org.apache.ignite.portables.PortableObject} class instead of user objects.
      * Use this flag if you don't have corresponding class on your client of
      * if you want to get access to some individual fields, but do not want to
      * fully deserialize the object.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/cache/GridCacheConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/cache/GridCacheConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/cache/GridCacheConfiguration.java
index 79da6ad..2875721 100644
--- a/modules/core/src/main/java/org/gridgain/grid/cache/GridCacheConfiguration.java
+++ b/modules/core/src/main/java/org/gridgain/grid/cache/GridCacheConfiguration.java
@@ -1788,7 +1788,7 @@ public class GridCacheConfiguration {
 
     /**
      * Flag indicating whether GridGain should store portable keys and values
-     * as instances of {@link org.apache.ignite.portables.GridPortableObject}.
+     * as instances of {@link org.apache.ignite.portables.PortableObject}.
      *
      * @return Portable enabled flag.
      */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/cache/GridCacheProjection.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/cache/GridCacheProjection.java b/modules/core/src/main/java/org/gridgain/grid/cache/GridCacheProjection.java
index 3b402a0..b3cdf0a 100644
--- a/modules/core/src/main/java/org/gridgain/grid/cache/GridCacheProjection.java
+++ b/modules/core/src/main/java/org/gridgain/grid/cache/GridCacheProjection.java
@@ -278,7 +278,7 @@ public interface GridCacheProjection<K, V> extends Iterable<GridCacheEntry<K, V>
      * so keys and values will be returned from cache API methods without changes. Therefore,
      * signature of the projection can contain only following types:
      * <ul>
-     *     <li>{@link org.apache.ignite.portables.GridPortableObject} for portable classes</li>
+     *     <li>{@link org.apache.ignite.portables.PortableObject} for portable classes</li>
      *     <li>All primitives (byte, int, ...) and there boxed versions (Byte, Integer, ...)</li>
      *     <li>Arrays of primitives (byte[], int[], ...)</li>
      *     <li>{@link String} and array of {@link String}s</li>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/cache/store/GridCacheStore.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/cache/store/GridCacheStore.java b/modules/core/src/main/java/org/gridgain/grid/cache/store/GridCacheStore.java
index 2bdbb7a..ba1be4f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/cache/store/GridCacheStore.java
+++ b/modules/core/src/main/java/org/gridgain/grid/cache/store/GridCacheStore.java
@@ -57,7 +57,7 @@ import java.util.Date;
  * </pre>
  * <h1 class="header">Working With Portable Objects</h1>
  * When portables are enabled for cache by setting {@link GridCacheConfiguration#isPortableEnabled()} to
- * {@code true}), all portable keys and values are converted to instances of {@link org.apache.ignite.portables.GridPortableObject}.
+ * {@code true}), all portable keys and values are converted to instances of {@link org.apache.ignite.portables.PortableObject}.
  * Therefore, all cache store methods will take parameters in portable format. To avoid class
  * cast exceptions, store must have signature compatible with portables. E.g., if you use {@link Integer}
  * as a key and {@code Value} class as a value (which will be converted to portable format), cache store
@@ -71,7 +71,7 @@ import java.util.Date;
  *     ...
  * }
  * </pre>
- * Note that only portable classes are converted to {@link org.apache.ignite.portables.GridPortableObject} format. Following
+ * Note that only portable classes are converted to {@link org.apache.ignite.portables.PortableObject} format. Following
  * types are stored in cache without changes and therefore should not affect cache store signature:
  * <ul>
  *     <li>All primitives (byte, int, ...) and there boxed versions (Byte, Integer, ...)</li>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetConfiguration.java
index fcc83ac..524b528 100644
--- a/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetConfiguration.java
+++ b/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetConfiguration.java
@@ -73,16 +73,16 @@ public class GridDotNetConfiguration implements PortableMarshalAware {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
-        GridPortableRawWriter rawWriter = writer.rawWriter();
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
+        PortableRawWriter rawWriter = writer.rawWriter();
 
         rawWriter.writeObject(portableCfg);
         rawWriter.writeCollection(assemblies);
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
-        GridPortableRawReader rawReader = reader.rawReader();
+    @Override public void readPortable(PortableReader reader) throws PortableException {
+        PortableRawReader rawReader = reader.rawReader();
 
         portableCfg = (GridDotNetPortableConfiguration)rawReader.readObject();
         assemblies = (List<String>)rawReader.<String>readCollection();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableConfiguration.java
index cbe2348..b012220 100644
--- a/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableConfiguration.java
+++ b/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableConfiguration.java
@@ -167,8 +167,8 @@ public class GridDotNetPortableConfiguration implements PortableMarshalAware {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
-        GridPortableRawWriter rawWriter = writer.rawWriter();
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
+        PortableRawWriter rawWriter = writer.rawWriter();
 
         rawWriter.writeCollection(typesCfg);
 
@@ -186,8 +186,8 @@ public class GridDotNetPortableConfiguration implements PortableMarshalAware {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
-        GridPortableRawReader rawReader = reader.rawReader();
+    @Override public void readPortable(PortableReader reader) throws PortableException {
+        PortableRawReader rawReader = reader.rawReader();
 
         typesCfg = rawReader.readCollection();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableTypeConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableTypeConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableTypeConfiguration.java
index a984966..3dd475f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableTypeConfiguration.java
+++ b/modules/core/src/main/java/org/gridgain/grid/dotnet/GridDotNetPortableTypeConfiguration.java
@@ -175,8 +175,8 @@ public class GridDotNetPortableTypeConfiguration implements PortableMarshalAware
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
-        GridPortableRawWriter rawWriter = writer.rawWriter();
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
+        PortableRawWriter rawWriter = writer.rawWriter();
 
         rawWriter.writeString(assemblyName);
 
@@ -196,8 +196,8 @@ public class GridDotNetPortableTypeConfiguration implements PortableMarshalAware
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
-        GridPortableRawReader rawReader = reader.rawReader();
+    @Override public void readPortable(PortableReader reader) throws PortableException {
+        PortableRawReader rawReader = reader.rawReader();
 
         assemblyName = rawReader.readString();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/GridPortablesImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/GridPortablesImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/GridPortablesImpl.java
index 5bdf615..8e217a3 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/GridPortablesImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/GridPortablesImpl.java
@@ -84,7 +84,7 @@ public class GridPortablesImpl implements IgnitePortables {
     }
 
     /** {@inheritDoc} */
-    @Override public PortableBuilder builder(GridPortableObject portableObj) {
+    @Override public PortableBuilder builder(PortableObject portableObj) {
         guard();
 
         try {
@@ -96,7 +96,7 @@ public class GridPortablesImpl implements IgnitePortables {
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public GridPortableMetadata metadata(Class<?> cls) throws PortableException {
+    @Nullable @Override public PortableMetadata metadata(Class<?> cls) throws PortableException {
         guard();
 
         try {
@@ -108,7 +108,7 @@ public class GridPortablesImpl implements IgnitePortables {
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public GridPortableMetadata metadata(String typeName) throws PortableException {
+    @Nullable @Override public PortableMetadata metadata(String typeName) throws PortableException {
         guard();
 
         try {
@@ -120,7 +120,7 @@ public class GridPortablesImpl implements IgnitePortables {
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public GridPortableMetadata metadata(int typeId) throws PortableException {
+    @Nullable @Override public PortableMetadata metadata(int typeId) throws PortableException {
         guard();
 
         try {
@@ -132,7 +132,7 @@ public class GridPortablesImpl implements IgnitePortables {
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridPortableMetadata> metadata() throws PortableException {
+    @Override public Collection<PortableMetadata> metadata() throws PortableException {
         guard();
 
         try {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/managers/indexing/GridIndexingManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/managers/indexing/GridIndexingManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/managers/indexing/GridIndexingManager.java
index 02104ee..ef92518 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/managers/indexing/GridIndexingManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/managers/indexing/GridIndexingManager.java
@@ -326,8 +326,8 @@ public class GridIndexingManager extends GridManagerAdapter<GridIndexingSpi> {
             }
 
             if (id == null) {
-                if (val instanceof GridPortableObject) {
-                    GridPortableObject portable = (GridPortableObject)val;
+                if (val instanceof PortableObject) {
+                    PortableObject portable = (PortableObject)val;
 
                     int typeId = portable.typeId();
 
@@ -361,8 +361,8 @@ public class GridIndexingManager extends GridManagerAdapter<GridIndexingSpi> {
                         d.keyClass(keyCls);
                         d.valueClass(valCls);
 
-                        if (key instanceof GridPortableObject) {
-                            GridPortableObject portableKey = (GridPortableObject)key;
+                        if (key instanceof PortableObject) {
+                            PortableObject portableKey = (PortableObject)key;
 
                             String typeName = portableName(portableKey.typeId());
 
@@ -382,8 +382,8 @@ public class GridIndexingManager extends GridManagerAdapter<GridIndexingSpi> {
                                 processClassMeta(true, d.keyCls, keyMeta, d);
                         }
 
-                        if (val instanceof GridPortableObject) {
-                            GridPortableObject portableVal = (GridPortableObject)val;
+                        if (val instanceof PortableObject) {
+                            PortableObject portableVal = (PortableObject)val;
 
                             String typeName = portableName(portableVal.typeId());
 
@@ -1341,12 +1341,12 @@ public class GridIndexingManager extends GridManagerAdapter<GridIndexingSpi> {
             if (obj == null)
                 return null;
 
-            if (!(obj instanceof GridPortableObject))
+            if (!(obj instanceof PortableObject))
                 throw new GridSpiException("Non-portable object received as a result of property extraction " +
                     "[parent=" + parent + ", propName=" + propName + ", obj=" + obj + ']');
 
             try {
-                return ((GridPortableObject)obj).field(propName);
+                return ((PortableObject)obj).field(propName);
             }
             catch (PortableException e) {
                 throw new GridSpiException(e);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
index d10beaa..7f88e83 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
@@ -408,7 +408,7 @@ public abstract class GridCacheAdapter<K, V> extends GridMetadataAwareAdapter im
         Class<? super K1> keyType,
         Class<? super V1> valType
     ) {
-        if (GridPortableObject.class.isAssignableFrom(keyType) || GridPortableObject.class.isAssignableFrom(valType))
+        if (PortableObject.class.isAssignableFrom(keyType) || PortableObject.class.isAssignableFrom(valType))
             throw new IllegalStateException("Failed to create cache projection for portable objects. " +
                 "Use keepPortable() method instead.");
 
@@ -645,8 +645,8 @@ public abstract class GridCacheAdapter<K, V> extends GridMetadataAwareAdapter im
                 if (peek != null) {
                     V v = peek.get();
 
-                    if (ctx.portableEnabled() && !ctx.keepPortable() && v instanceof GridPortableObject)
-                        v = ((GridPortableObject)v).deserialize();
+                    if (ctx.portableEnabled() && !ctx.keepPortable() && v instanceof PortableObject)
+                        v = ((PortableObject)v).deserialize();
 
                     return F.t(ctx.cloneOnFlag(v));
                 }
@@ -660,8 +660,8 @@ public abstract class GridCacheAdapter<K, V> extends GridMetadataAwareAdapter im
                 if (peek != null) {
                     V v = peek.get();
 
-                    if (ctx.portableEnabled() && !ctx.keepPortable() && v instanceof GridPortableObject)
-                        v = ((GridPortableObject)v).deserialize();
+                    if (ctx.portableEnabled() && !ctx.keepPortable() && v instanceof PortableObject)
+                        v = ((PortableObject)v).deserialize();
 
                     return F.t(ctx.cloneOnFlag(v));
                 }
@@ -1809,8 +1809,8 @@ public abstract class GridCacheAdapter<K, V> extends GridMetadataAwareAdapter im
                             else {
                                 val = ctx.cloneOnFlag(val);
 
-                                if (ctx.portableEnabled() && deserializePortable && val instanceof GridPortableObject)
-                                    val = ((GridPortableObject)val).deserialize();
+                                if (ctx.portableEnabled() && deserializePortable && val instanceof PortableObject)
+                                    val = ((PortableObject)val).deserialize();
 
                                 map.put(key, val);
 
@@ -3480,8 +3480,8 @@ public abstract class GridCacheAdapter<K, V> extends GridMetadataAwareAdapter im
 
         V val = unswapped.value();
 
-        if (ctx.portableEnabled() && deserializePortable && val instanceof GridPortableObject)
-            return (V)((GridPortableObject)val).deserialize();
+        if (ctx.portableEnabled() && deserializePortable && val instanceof PortableObject)
+            return (V)((PortableObject)val).deserialize();
         else
             return ctx.cloneOnFlag(val);
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheContext.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheContext.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheContext.java
index d893403..e62b86d 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheContext.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheContext.java
@@ -1578,7 +1578,7 @@ public class GridCacheContext<K, V> implements Externalizable {
         if (obj == null)
             return null;
 
-        if (obj instanceof GridPortableObject || obj instanceof GridCacheInternal)
+        if (obj instanceof PortableObject || obj instanceof GridCacheInternal)
             return obj;
 
         GridPortableProcessor proc = kernalContext().portable();
@@ -1680,16 +1680,16 @@ public class GridCacheContext<K, V> implements Externalizable {
 
             boolean unwrapped = false;
 
-            if (key instanceof GridPortableObject) {
-                key = ((GridPortableObject)key).deserialize();
+            if (key instanceof PortableObject) {
+                key = ((PortableObject)key).deserialize();
 
                 unwrapped = true;
             }
 
             Object val = entry.getValue();
 
-            if (val instanceof GridPortableObject) {
-                val = ((GridPortableObject)val).deserialize();
+            if (val instanceof PortableObject) {
+                val = ((PortableObject)val).deserialize();
 
                 unwrapped = true;
             }
@@ -1699,8 +1699,8 @@ public class GridCacheContext<K, V> implements Externalizable {
         else {
             if (o instanceof Collection)
                 return unwrapPortablesIfNeeded((Collection<Object>)o, false);
-            else if (o instanceof GridPortableObject)
-                return ((GridPortableObject)o).deserialize();
+            else if (o instanceof PortableObject)
+                return ((PortableObject)o).deserialize();
         }
 
         return o;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDefaultAffinityKeyMapper.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDefaultAffinityKeyMapper.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDefaultAffinityKeyMapper.java
index 86dc530..b69d389 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDefaultAffinityKeyMapper.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDefaultAffinityKeyMapper.java
@@ -78,11 +78,11 @@ public class GridCacheDefaultAffinityKeyMapper implements GridCacheAffinityKeyMa
     @Override public Object affinityKey(Object key) {
         GridArgumentCheck.notNull(key, "key");
 
-        if (key instanceof GridPortableObject) {
-            GridPortableObject po = (GridPortableObject)key;
+        if (key instanceof PortableObject) {
+            PortableObject po = (PortableObject)key;
 
             try {
-                GridPortableMetadata meta = po.metaData();
+                PortableMetadata meta = po.metaData();
 
                 if (meta != null) {
                     String affKeyFieldName = meta.affinityKeyFieldName();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProjectionImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProjectionImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProjectionImpl.java
index f9b89f2..e2fd5a6 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProjectionImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProjectionImpl.java
@@ -390,8 +390,8 @@ public class GridCacheProjectionImpl<K, V> implements GridCacheProjectionEx<K, V
     ) {
         A.notNull(keyType, "keyType", valType, "valType");
 
-        if (!keepPortable && (GridPortableObject.class.isAssignableFrom(keyType) ||
-            GridPortableObject.class.isAssignableFrom(valType)))
+        if (!keepPortable && (PortableObject.class.isAssignableFrom(keyType) ||
+            PortableObject.class.isAssignableFrom(valType)))
             throw new IllegalStateException("Failed to create cache projection for portable objects. " +
                 "Use keepPortable() method instead.");
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTxLocalAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTxLocalAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTxLocalAdapter.java
index 9e4ff88..26b85cb 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTxLocalAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheTxLocalAdapter.java
@@ -1051,8 +1051,8 @@ public abstract class GridCacheTxLocalAdapter<K, V> extends GridCacheTxAdapter<K
                         if (val != null) {
                             V val0 = val;
 
-                            if (cacheCtx.portableEnabled() && deserializePortable && val instanceof GridPortableObject)
-                                val0 = ((GridPortableObject)val).deserialize();
+                            if (cacheCtx.portableEnabled() && deserializePortable && val instanceof PortableObject)
+                                val0 = ((PortableObject)val).deserialize();
 
                             map.put(key, val0);
                         }
@@ -1090,8 +1090,8 @@ public abstract class GridCacheTxLocalAdapter<K, V> extends GridCacheTxAdapter<K
 
                                     V val0 = val;
 
-                                    if (cacheCtx.portableEnabled() && deserializePortable && val instanceof GridPortableObject)
-                                        val0 = ((GridPortableObject)val).deserialize();
+                                    if (cacheCtx.portableEnabled() && deserializePortable && val instanceof PortableObject)
+                                        val0 = ((PortableObject)val).deserialize();
 
                                     map.put(key, val0);
                                 }
@@ -1156,8 +1156,8 @@ public abstract class GridCacheTxLocalAdapter<K, V> extends GridCacheTxAdapter<K
                             if (val != null) {
                                 V val0 = val;
 
-                                if (cacheCtx.portableEnabled() && deserializePortable && val instanceof GridPortableObject)
-                                    val0 = ((GridPortableObject)val).deserialize();
+                                if (cacheCtx.portableEnabled() && deserializePortable && val instanceof PortableObject)
+                                    val0 = ((PortableObject)val).deserialize();
 
                                 map.put(key, val0);
                             }
@@ -1511,8 +1511,8 @@ public abstract class GridCacheTxLocalAdapter<K, V> extends GridCacheTxAdapter<K
                                         }
 
                                         if (cacheCtx.portableEnabled() && deserializePortable &&
-                                            val instanceof GridPortableObject)
-                                            val = ((GridPortableObject)val).deserialize();
+                                            val instanceof PortableObject)
+                                            val = ((PortableObject)val).deserialize();
 
                                         retMap.put(key, val);
                                     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/GridPartitionedGetFuture.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/GridPartitionedGetFuture.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/GridPartitionedGetFuture.java
index 3060093..6544f3e 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/GridPartitionedGetFuture.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/GridPartitionedGetFuture.java
@@ -416,8 +416,8 @@ public class GridPartitionedGetFuture<K, V> extends GridCompoundIdentityFuture<M
                                     colocated.removeIfObsolete(key);
                             }
                             else {
-                                if (cctx.portableEnabled() && deserializePortable && v instanceof GridPortableObject)
-                                    v = ((GridPortableObject)v).deserialize();
+                                if (cctx.portableEnabled() && deserializePortable && v instanceof PortableObject)
+                                    v = ((PortableObject)v).deserialize();
 
                                 locVals.put(key, v);
 
@@ -499,8 +499,8 @@ public class GridPartitionedGetFuture<K, V> extends GridCompoundIdentityFuture<M
 
                     V val = info.value();
 
-                    if (cctx.portableEnabled() && deserializePortable && val instanceof GridPortableObject)
-                        val = ((GridPortableObject)val).deserialize();
+                    if (cctx.portableEnabled() && deserializePortable && val instanceof PortableObject)
+                        val = ((PortableObject)val).deserialize();
 
                     map.put(info.key(), val);
                 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java
index 0b2d3a7..96d8308 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java
@@ -743,8 +743,8 @@ public class GridDhtAtomicCache<K, V> extends GridDhtCacheAdapter<K, V> {
                                 success = false;
                             }
                             else {
-                                if (ctx.portableEnabled() && deserializePortable && v instanceof GridPortableObject)
-                                    v = ((GridPortableObject)v).deserialize();
+                                if (ctx.portableEnabled() && deserializePortable && v instanceof PortableObject)
+                                    v = ((PortableObject)v).deserialize();
 
                                 locVals.put(key, v);
                             }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/colocated/GridDhtColocatedCache.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/colocated/GridDhtColocatedCache.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/colocated/GridDhtColocatedCache.java
index 3899ca6..cd737a8 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/colocated/GridDhtColocatedCache.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/colocated/GridDhtColocatedCache.java
@@ -261,8 +261,8 @@ public class GridDhtColocatedCache<K, V> extends GridDhtTransactionalCacheAdapte
                                 success = false;
                             }
                             else {
-                                if (ctx.portableEnabled() && deserializePortable && v instanceof GridPortableObject)
-                                    v = ((GridPortableObject)v).deserialize();
+                                if (ctx.portableEnabled() && deserializePortable && v instanceof PortableObject)
+                                    v = ((PortableObject)v).deserialize();
 
                                 locVals.put(key, v);
                             }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/near/GridNearGetFuture.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/near/GridNearGetFuture.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/near/GridNearGetFuture.java
index a62b37b..bc4d077 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/near/GridNearGetFuture.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/near/GridNearGetFuture.java
@@ -457,8 +457,8 @@ public final class GridNearGetFuture<K, V> extends GridCompoundIdentityFuture<Ma
                 }
 
                 if (v != null && !reload) {
-                    if (cctx.portableEnabled() && deserializePortable && v instanceof GridPortableObject)
-                        v = ((GridPortableObject)v).deserialize();
+                    if (cctx.portableEnabled() && deserializePortable && v instanceof PortableObject)
+                        v = ((PortableObject)v).deserialize();
 
                     add(new GridFinishedFuture<>(cctx.kernalContext(), Collections.singletonMap(key, v)));
                 }
@@ -587,8 +587,8 @@ public final class GridNearGetFuture<K, V> extends GridCompoundIdentityFuture<Ma
 
                     V val = info.value();
 
-                    if (cctx.portableEnabled() && deserializePortable && val instanceof GridPortableObject)
-                        val = ((GridPortableObject)val).deserialize();
+                    if (cctx.portableEnabled() && deserializePortable && val instanceof PortableObject)
+                        val = ((PortableObject)val).deserialize();
 
                     map.put(info.key(), val);
                 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/GridPortableProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/GridPortableProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/GridPortableProcessor.java
index 51cfe01..3c7f5ab 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/GridPortableProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/GridPortableProcessor.java
@@ -101,14 +101,14 @@ public interface GridPortableProcessor extends GridProcessor {
      * @param portableObj Portable object to edit.
      * @return Portable builder.
      */
-    public PortableBuilder builder(GridPortableObject portableObj);
+    public PortableBuilder builder(PortableObject portableObj);
 
     /**
      * @param typeId Type ID.
      * @param newMeta New meta data.
      * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    public void addMeta(int typeId, final GridPortableMetadata newMeta) throws PortableException;
+    public void addMeta(int typeId, final PortableMetadata newMeta) throws PortableException;
 
     /**
      * @param typeId Type ID.
@@ -125,18 +125,18 @@ public interface GridPortableProcessor extends GridProcessor {
      * @return Meta data.
      * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    @Nullable public GridPortableMetadata metadata(int typeId) throws PortableException;
+    @Nullable public PortableMetadata metadata(int typeId) throws PortableException;
 
     /**
      * @param typeIds Type ID.
      * @return Meta data.
      * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    public Map<Integer, GridPortableMetadata> metadata(Collection<Integer> typeIds) throws PortableException;
+    public Map<Integer, PortableMetadata> metadata(Collection<Integer> typeIds) throws PortableException;
 
     /**
      * @return Metadata for all types.
      * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    public Collection<GridPortableMetadata> metadata() throws PortableException;
+    public Collection<PortableMetadata> metadata() throws PortableException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/os/GridOsPortableProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/os/GridOsPortableProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/os/GridOsPortableProcessor.java
index 0f2f951..afe4cb9 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/os/GridOsPortableProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/portable/os/GridOsPortableProcessor.java
@@ -86,12 +86,12 @@ public class GridOsPortableProcessor extends GridProcessorAdapter implements Gri
     }
 
     /** {@inheritDoc} */
-    @Override public PortableBuilder builder(GridPortableObject portableObj) {
+    @Override public PortableBuilder builder(PortableObject portableObj) {
         return null;
     }
 
     /** {@inheritDoc} */
-    @Override public void addMeta(int typeId, GridPortableMetadata newMeta) throws PortableException {
+    @Override public void addMeta(int typeId, PortableMetadata newMeta) throws PortableException {
         // No-op.
     }
 
@@ -102,17 +102,17 @@ public class GridOsPortableProcessor extends GridProcessorAdapter implements Gri
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public GridPortableMetadata metadata(int typeId) {
+    @Nullable @Override public PortableMetadata metadata(int typeId) {
         return null;
     }
 
     /** {@inheritDoc} */
-    @Override public Map<Integer, GridPortableMetadata> metadata(Collection<Integer> typeIds) {
+    @Override public Map<Integer, PortableMetadata> metadata(Collection<Integer> typeIds) {
         return null;
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridPortableMetadata> metadata() throws PortableException {
+    @Override public Collection<PortableMetadata> metadata() throws PortableException {
         return Collections.emptyList();
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAbstractMessage.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAbstractMessage.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAbstractMessage.java
index 35316dc..8e790e9 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAbstractMessage.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAbstractMessage.java
@@ -88,15 +88,15 @@ public abstract class GridClientAbstractMessage implements GridClientMessage, Ex
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
-        GridPortableRawWriter raw = writer.rawWriter();
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
+        PortableRawWriter raw = writer.rawWriter();
 
         raw.writeByteArray(sesTok);
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
-        GridPortableRawReader raw = reader.rawReader();
+    @Override public void readPortable(PortableReader reader) throws PortableException {
+        PortableRawReader raw = reader.rawReader();
 
         sesTok = raw.readByteArray();
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAuthenticationRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAuthenticationRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAuthenticationRequest.java
index d388b53..a84ade8 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAuthenticationRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientAuthenticationRequest.java
@@ -53,19 +53,19 @@ public class GridClientAuthenticationRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
-        GridPortableRawWriter raw = writer.rawWriter();
+        PortableRawWriter raw = writer.rawWriter();
 
         raw.writeObject(cred);
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
+    @Override public void readPortable(PortableReader reader) throws PortableException {
         super.readPortable(reader);
 
-        GridPortableRawReader raw = reader.rawReader();
+        PortableRawReader raw = reader.rawReader();
 
         cred = raw.readObject();
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheQueryRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheQueryRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheQueryRequest.java
index e05a92c..b3fe36e 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheQueryRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheQueryRequest.java
@@ -316,10 +316,10 @@ public class GridClientCacheQueryRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
+    @Override public void readPortable(PortableReader reader) throws PortableException {
         super.readPortable(reader);
 
-        GridPortableRawReader rawReader = reader.rawReader();
+        PortableRawReader rawReader = reader.rawReader();
 
         qryId = rawReader.readLong();
         op = GridQueryOperation.fromOrdinal(rawReader.readInt());
@@ -338,10 +338,10 @@ public class GridClientCacheQueryRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
-        GridPortableRawWriter rawWriter = writer.rawWriter();
+        PortableRawWriter rawWriter = writer.rawWriter();
 
         rawWriter.writeLong(qryId);
         rawWriter.writeInt(op.ordinal());

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheRequest.java
index c2c2e83..c357d25 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientCacheRequest.java
@@ -221,10 +221,10 @@ public class GridClientCacheRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
-        GridPortableRawWriterEx raw = (GridPortableRawWriterEx)writer.rawWriter();
+        PortableRawWriterEx raw = (PortableRawWriterEx)writer.rawWriter();
 
         raw.writeInt(op.ordinal());
         raw.writeString(cacheName);
@@ -244,10 +244,10 @@ public class GridClientCacheRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
+    @Override public void readPortable(PortableReader reader) throws PortableException {
         super.readPortable(reader);
 
-        GridPortableRawReaderEx raw = (GridPortableRawReaderEx)reader.rawReader();
+        PortableRawReaderEx raw = (PortableRawReaderEx)reader.rawReader();
 
         op = GridCacheOperation.fromOrdinal(raw.readInt());
         cacheName = raw.readString();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientGetMetaDataRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientGetMetaDataRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientGetMetaDataRequest.java
index 6fd6da0..09cb800 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientGetMetaDataRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientGetMetaDataRequest.java
@@ -32,19 +32,19 @@ public class GridClientGetMetaDataRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
-        GridPortableRawWriter raw = writer.rawWriter();
+        PortableRawWriter raw = writer.rawWriter();
 
         raw.writeCollection(typeIds);
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
+    @Override public void readPortable(PortableReader reader) throws PortableException {
         super.readPortable(reader);
 
-        GridPortableRawReader raw = reader.rawReader();
+        PortableRawReader raw = reader.rawReader();
 
         typeIds = raw.readCollection();
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientLogRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientLogRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientLogRequest.java
index 01de166..467aa14 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientLogRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/client/message/GridClientLogRequest.java
@@ -73,10 +73,10 @@ public class GridClientLogRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
         super.writePortable(writer);
 
-        GridPortableRawWriter raw = writer.rawWriter();
+        PortableRawWriter raw = writer.rawWriter();
 
         raw.writeString(path);
         raw.writeInt(from);
@@ -84,10 +84,10 @@ public class GridClientLogRequest extends GridClientAbstractMessage {
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
+    @Override public void readPortable(PortableReader reader) throws PortableException {
         super.readPortable(reader);
 
-        GridPortableRawReader raw = reader.rawReader();
+        PortableRawReader raw = reader.rawReader();
 
         path = raw.readString();
         from = raw.readInt();


[28/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualSyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualSyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualSyncSelfTest.java
index f970dd7..0c8582c 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualSyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalDualSyncSelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC loopback self test in DUAL_SYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalPrimarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalPrimarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalPrimarySelfTest.java
index b350feb..e63bb11 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalPrimarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalPrimarySelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC loopback self test in PRIMARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalSecondarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalSecondarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalSecondarySelfTest.java
index 9682207..1b20ac7 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalSecondarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoopbackExternalSecondarySelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC loopback self test in SECONDARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java
index 15270d3..0767b7a 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java
@@ -12,6 +12,7 @@ package org.gridgain.grid.ggfs;
 import org.apache.hadoop.conf.*;
 import org.apache.hadoop.fs.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.ggfs.hadoop.v1.*;
@@ -28,7 +29,7 @@ import java.util.*;
 
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * Ensures correct modes resolution for SECONDARY paths.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemAbstractSelfTest.java
index d0693e4..629d7b9 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemAbstractSelfTest.java
@@ -9,6 +9,7 @@
 
 package org.gridgain.grid.ggfs;
 
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.util.ipc.*;
 import org.gridgain.grid.util.typedef.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualAsyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualAsyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualAsyncSelfTest.java
index e89885c..faa3138 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualAsyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualAsyncSelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC shmem self test in DUAL_ASYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualSyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualSyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualSyncSelfTest.java
index f03a997..e522c57 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualSyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedDualSyncSelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC shmem self test in DUAL_SYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedPrimarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedPrimarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedPrimarySelfTest.java
index d97dde7..ca9d486 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedPrimarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedPrimarySelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC shmem self test in PRIMARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedSecondarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedSecondarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedSecondarySelfTest.java
index 27ac2e3..2ec343c 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedSecondarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemEmbeddedSecondarySelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC shmem self test in SECONDARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualAsyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualAsyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualAsyncSelfTest.java
index fd70c03..48a3bec 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualAsyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualAsyncSelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC shmem self test in DUAL_ASYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualSyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualSyncSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualSyncSelfTest.java
index 4e6a53f..e6386c5 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualSyncSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalDualSyncSelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC shmem self test in DUAL_SYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalPrimarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalPrimarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalPrimarySelfTest.java
index 8f14dde..ca95b82 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalPrimarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalPrimarySelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC shmem self test in PRIMARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalSecondarySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalSecondarySelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalSecondarySelfTest.java
index 7e602e5..6bc841f 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalSecondarySelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemShmemExternalSecondarySelfTest.java
@@ -7,7 +7,7 @@
 
 package org.gridgain.grid.ggfs;
 
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
  * GGFS Hadoop file system IPC shmem self test in SECONDARY mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java
index 33a2863..6e909b0 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java
@@ -13,6 +13,7 @@ import org.apache.hadoop.conf.*;
 import org.apache.hadoop.fs.*;
 import org.apache.hadoop.fs.FileSystem;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.spi.discovery.tcp.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractSelfTest.java
index 5aa8c15..34496f7 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractSelfTest.java
@@ -11,8 +11,8 @@ package org.gridgain.grid.kernal.processors.hadoop;
 
 import org.apache.hadoop.conf.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.hadoop.*;
 import org.gridgain.grid.kernal.processors.hadoop.fs.*;
 import org.gridgain.grid.spi.communication.tcp.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractWordCountTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractWordCountTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractWordCountTest.java
index 66e2fd0..426b79f 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractWordCountTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractWordCountTest.java
@@ -12,7 +12,7 @@ package org.gridgain.grid.kernal.processors.hadoop;
 import com.google.common.base.*;
 import org.apache.hadoop.conf.*;
 import org.apache.hadoop.fs.*;
-import org.gridgain.grid.ggfs.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;
 
 import java.io.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopCommandLineTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopCommandLineTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopCommandLineTest.java
index f9c0498..9826363 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopCommandLineTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopCommandLineTest.java
@@ -11,8 +11,8 @@ package org.gridgain.grid.kernal.processors.hadoop;
 
 import com.google.common.base.Joiner;
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.hadoop.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;
 import org.gridgain.grid.kernal.processors.hadoop.counter.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
index eca987f..51424f4 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
@@ -11,10 +11,10 @@ package org.gridgain.grid.kernal.processors.hadoop;
 
 import org.apache.ignite.*;
 import org.apache.ignite.cluster.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.hadoop.*;
 import org.gridgain.grid.kernal.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceEmbeddedSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceEmbeddedSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceEmbeddedSelfTest.java
index 26b17d0..02a2ea5 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceEmbeddedSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceEmbeddedSelfTest.java
@@ -17,8 +17,8 @@ import org.apache.hadoop.mapred.*;
 import org.apache.hadoop.mapreduce.*;
 import org.apache.hadoop.mapreduce.lib.input.FileInputFormat;
 import org.apache.hadoop.mapreduce.lib.output.FileOutputFormat;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.hadoop.*;
 import org.gridgain.grid.kernal.processors.hadoop.examples.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceTest.java
index 75aefb2..464ea35 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopMapReduceTest.java
@@ -15,9 +15,9 @@ import org.apache.hadoop.mapred.*;
 import org.apache.hadoop.mapreduce.*;
 import org.apache.hadoop.mapreduce.lib.input.FileInputFormat;
 import org.apache.hadoop.mapreduce.lib.output.FileOutputFormat;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.hadoop.*;
 import org.gridgain.grid.kernal.processors.hadoop.counter.*;
 import org.gridgain.grid.kernal.processors.hadoop.examples.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTaskExecutionSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTaskExecutionSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTaskExecutionSelfTest.java
index 7615293..e95016f 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTaskExecutionSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTaskExecutionSelfTest.java
@@ -16,9 +16,9 @@ import org.apache.hadoop.mapreduce.*;
 import org.apache.hadoop.mapreduce.lib.input.*;
 import org.apache.hadoop.mapreduce.lib.output.*;
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.ggfs.hadoop.v1.*;
 import org.gridgain.grid.hadoop.*;
 import org.gridgain.grid.util.lang.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTasksAllVersionsTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTasksAllVersionsTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTasksAllVersionsTest.java
index 7aa11b8..973ee43 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTasksAllVersionsTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopTasksAllVersionsTest.java
@@ -11,8 +11,8 @@ package org.gridgain.grid.kernal.processors.hadoop;
 
 import com.google.common.base.*;
 import org.apache.hadoop.io.*;
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.hadoop.*;
 import org.gridgain.grid.kernal.processors.hadoop.examples.*;
 import org.gridgain.grid.kernal.processors.hadoop.v2.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/GridHadoopExternalTaskExecutionSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/GridHadoopExternalTaskExecutionSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/GridHadoopExternalTaskExecutionSelfTest.java
index 352a185..26aee6a 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/GridHadoopExternalTaskExecutionSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/taskexecutor/external/GridHadoopExternalTaskExecutionSelfTest.java
@@ -16,9 +16,9 @@ import org.apache.hadoop.mapreduce.*;
 import org.apache.hadoop.mapreduce.lib.input.FileInputFormat;
 import org.apache.hadoop.mapreduce.lib.output.*;
 import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.hadoop.*;
 import org.gridgain.grid.kernal.processors.hadoop.*;
 import org.gridgain.grid.util.typedef.*;


[20/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
index e425bc8..3175792 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
@@ -569,7 +569,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
 
         // Validate renamed during reading.
 
-        try (GridGgfsInputStream in0 = ggfs.open(path("/A/a"))) {
+        try (IgniteFsInputStream in0 = ggfs.open(path("/A/a"))) {
             // Rename file.
             ggfs.rename(path("/A/a"), path("/b"));
 
@@ -812,7 +812,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
 
         byte[] readBuf = new byte[chunkSize];
 
-        try (GridGgfsInputStream in = ggfs.open(path)) {
+        try (IgniteFsInputStream in = ggfs.open(path)) {
             long pos = 0;
 
             for (int k = 0; k < 2 * cnt; k++) {
@@ -875,7 +875,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
      */
     private String read(String path) throws Exception {
 
-        try (GridGgfsInputStream in = ggfs.open(path(path))) {
+        try (IgniteFsInputStream in = ggfs.open(path(path))) {
             return IOUtils.toString(in, UTF_8);
         }
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
index 730338a..eff53d1 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
@@ -341,7 +341,7 @@ public class GridGgfsSizeSelfTest extends GridGgfsCommonAbstractTest {
             for (int i = 0; i < GRID_CNT; i++) {
                 int total = 0;
 
-                GridGgfsInputStream is = ggfs(i).open(file.path());
+                IgniteFsInputStream is = ggfs(i).open(file.path());
 
                 while (true) {
                     int read = is.read(buf);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
index e4f5145..d9f6f15 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
@@ -265,7 +265,7 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
             assertTrue(ranges.get(1).endOffset() == 3 * CFG_BLOCK_SIZE - 1);
 
             // Validate data read after colocated writes.
-            try (GridGgfsInputStream in = fs2.open(path)) {
+            try (IgniteFsInputStream in = fs2.open(path)) {
                 // Validate first part of file.
                 for (int i = 0; i < CFG_BLOCK_SIZE * 3 / 2; i++)
                     assertEquals((byte)1, in.read());
@@ -340,7 +340,7 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
         info("Read and validate saved file: " + path);
 
         final InputStream expIn = new GridGgfsTestInputStream(size, salt);
-        final GridGgfsInputStream actIn = fs.open(path, CFG_BLOCK_SIZE * READING_THREADS_CNT * 11 / 10);
+        final IgniteFsInputStream actIn = fs.open(path, CFG_BLOCK_SIZE * READING_THREADS_CNT * 11 / 10);
 
         // Validate continuous reading of whole file.
         assertEqualStreams(expIn, actIn, size, null);
@@ -403,7 +403,7 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
      * @param seek Seek to use async position-based reading or {@code null} to use simple continuous reading.
      * @throws IOException In case of any IO exception.
      */
-    private void assertEqualStreams(InputStream expIn, GridGgfsInputStream actIn,
+    private void assertEqualStreams(InputStream expIn, IgniteFsInputStream actIn,
         @Nullable Long expSize, @Nullable Long seek) throws IOException {
         if (seek != null)
             expIn.skip(seek);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
index 35f5c9a..8eb4dbb 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
@@ -267,7 +267,7 @@ public class GridGgfsTaskSelfTest extends GridGgfsCommonAbstractTest {
         private ComputeJobContext ctx;
 
         /** {@inheritDoc} */
-        @Override public Object execute(IgniteFs ggfs, GridGgfsFileRange range, GridGgfsInputStream in)
+        @Override public Object execute(IgniteFs ggfs, GridGgfsFileRange range, IgniteFsInputStream in)
             throws GridException, IOException {
             assert ignite != null;
             assert ses != null;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
index fcbb563..d348944 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
@@ -145,7 +145,7 @@ public class GridGgfsAbstractRecordResolverSelfTest extends GridCommonAbstractTe
      * @return Input stream.
      * @throws Exception In case of exception.
      */
-    protected GridGgfsInputStream read() throws Exception {
+    protected IgniteFsInputStream read() throws Exception {
         return ggfs.open(FILE);
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
index a187551..3ae1929 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
@@ -282,7 +282,7 @@ public class GridGgfsByteDelimiterRecordResolverSelfTest extends GridGgfsAbstrac
 
         GridGgfsFileRange split;
 
-        try (GridGgfsInputStream is = read()) {
+        try (IgniteFsInputStream is = read()) {
             split = rslvr.resolveRecords(ggfs, is, split(suggestedStart, suggestedLen));
         }
 
@@ -308,7 +308,7 @@ public class GridGgfsByteDelimiterRecordResolverSelfTest extends GridGgfsAbstrac
 
         GridGgfsFileRange split;
 
-        try (GridGgfsInputStream is = read()) {
+        try (IgniteFsInputStream is = read()) {
             split = rslvr.resolveRecords(ggfs, is, split(suggestedStart, suggestedLen));
         }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
index 035e5ac..7170831 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
@@ -94,7 +94,7 @@ public class GridGgfsFixedLengthRecordResolverSelfTest extends GridGgfsAbstractR
 
         GridGgfsFileRange split;
 
-        try (GridGgfsInputStream is = read()) {
+        try (IgniteFsInputStream is = read()) {
             split = rslvr.resolveRecords(ggfs, is, split(suggestedStart, suggestedLen));
         }
 
@@ -120,7 +120,7 @@ public class GridGgfsFixedLengthRecordResolverSelfTest extends GridGgfsAbstractR
 
         GridGgfsFileRange split;
 
-        try (GridGgfsInputStream is = read()) {
+        try (IgniteFsInputStream is = read()) {
             split = rslvr.resolveRecords(ggfs, is, split(suggestedStart, suggestedLen));
         }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
index a2a2a97..7ed1a6a 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
@@ -78,7 +78,7 @@ public class GridGgfsNewLineDelimiterRecordResolverSelfTest extends GridGgfsAbst
 
         GridGgfsFileRange split;
 
-        try (GridGgfsInputStream is = read()) {
+        try (IgniteFsInputStream is = read()) {
             split = rslvr.resolveRecords(ggfs, is, split(suggestedStart, suggestedLen));
         }
 
@@ -103,7 +103,7 @@ public class GridGgfsNewLineDelimiterRecordResolverSelfTest extends GridGgfsAbst
 
         GridGgfsFileRange split;
 
-        try (GridGgfsInputStream is = read()) {
+        try (IgniteFsInputStream is = read()) {
             split = rslvr.resolveRecords(ggfs, is, split(suggestedStart, suggestedLen));
         }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
index c62fdda..b9e0f7a 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
@@ -84,7 +84,7 @@ public class GridGgfsStringDelimiterRecordResolverSelfTest extends GridGgfsAbstr
 
         GridGgfsFileRange split;
 
-        try (GridGgfsInputStream is = read()) {
+        try (IgniteFsInputStream is = read()) {
             split = rslvr.resolveRecords(ggfs, is, split(suggestedStart, suggestedLen));
         }
 
@@ -110,7 +110,7 @@ public class GridGgfsStringDelimiterRecordResolverSelfTest extends GridGgfsAbstr
 
         GridGgfsFileRange split;
 
-        try (GridGgfsInputStream is = read()) {
+        try (IgniteFsInputStream is = read()) {
             split = rslvr.resolveRecords(ggfs, is, split(suggestedStart, suggestedLen));
         }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
index c3e0dae..091091a 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
@@ -94,7 +94,7 @@ public class GridGgfsHadoopFileSystemWrapper implements IgniteFsFileSystem, Auto
             (e.getMessage() != null && e.getMessage().contains("Failed on local"));
 
         IgniteFsException ggfsErr = !wrongVer ? cast(detailMsg, e) :
-            new GridGgfsInvalidHdfsVersionException("HDFS version you are connecting to differs from local " +
+            new IgniteFsInvalidHdfsVersionException("HDFS version you are connecting to differs from local " +
                 "version.", e);
 
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
index 5e70bd3..edeec58 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
@@ -322,7 +322,7 @@ public abstract class GridGgfsHadoop20FileSystemAbstractSelfTest extends GridGgf
         for (int i = 0; i < 4; i++) {
             IgniteFs ggfs = grid(i).fileSystem("ggfs");
 
-            GridGgfsMetrics metrics = ggfs.metrics();
+            IgniteFsMetrics metrics = ggfs.metrics();
 
             used += metrics.localSpaceSize();
             max += metrics.maxSpaceSize();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
index 516fd23..1f05f16 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
@@ -269,7 +269,7 @@ public abstract class GridGgfsHadoopDualAbstractSelfTest extends GridGgfsCommonA
         // Try reading the third block. Should fail.
         GridTestUtils.assertThrows(log, new Callable<Object>() {
             @Override public Object call() throws Exception {
-                GridGgfsInputStream in0 = ggfs.open(FILE);
+                IgniteFsInputStream in0 = ggfs.open(FILE);
 
                 in0.seek(blockSize * 2);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
index 0c75e80..1679f80 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
@@ -852,7 +852,7 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
         }
 
         /** {@inheritDoc} */
-        @Override public GridGgfsMetrics metrics() throws GridException {
+        @Override public IgniteFsMetrics metrics() throws GridException {
             return null;
         }
 


[15/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
index e8ac409..ebf758a 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
@@ -30,7 +30,7 @@ import java.util.*;
  * <p>
  * Each file participating in GGFS task is split into {@link GridGgfsFileRange}s first. Normally range is a number of
  * consequent bytes located on a single node (see {@code GridGgfsGroupDataBlocksKeyMapper}). In case maximum range size
- * is provided (either through {@link GridGgfsConfiguration#getMaximumTaskRangeLength()} or {@code GridGgfs.execute()}
+ * is provided (either through {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()} or {@code GridGgfs.execute()}
  * argument), then ranges could be further divided into smaller chunks.
  * <p>
  * Once file is split into ranges, each range is passed to {@code GridGgfsTask.createJob()} method in order to create a

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
index 469e703..2b321c7 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
@@ -25,7 +25,7 @@ import java.util.*;
  *     <li>{@link GridGgfsRecordResolver} for that task</li>
  *     <li>Flag indicating whether to skip non-existent file paths or throw an exception</li>
  *     <li>User-defined task argument</li>
- *     <li>Maximum file range length for that task (see {@link GridGgfsConfiguration#getMaximumTaskRangeLength()})</li>
+ *     <li>Maximum file range length for that task (see {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()})</li>
  * </ul>
  */
 public interface GridGgfsTaskArgs<T> {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java b/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java
index 7193c1c..a79aa15 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/GridGainEx.java
@@ -1634,13 +1634,13 @@ public class GridGainEx {
             myCfg.setGgfsExecutorServiceShutdown(ggfsSvcShutdown);
             myCfg.setNodeId(nodeId);
 
-            GridGgfsConfiguration[] ggfsCfgs = cfg.getGgfsConfiguration();
+            IgniteFsConfiguration[] ggfsCfgs = cfg.getGgfsConfiguration();
 
             if (ggfsCfgs != null) {
-                GridGgfsConfiguration[] clone = ggfsCfgs.clone();
+                IgniteFsConfiguration[] clone = ggfsCfgs.clone();
 
                 for (int i = 0; i < ggfsCfgs.length; i++)
-                    clone[i] = new GridGgfsConfiguration(ggfsCfgs[i]);
+                    clone[i] = new IgniteFsConfiguration(ggfsCfgs[i]);
 
                 myCfg.setGgfsConfiguration(clone);
             }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
index 216e888..00919ee 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
@@ -265,7 +265,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
         else if (errCode == ERR_CORRUPTED_FILE)
             throw new GridGgfsCorruptedFileException(err);
         else if (errCode == ERR_GGFS_GENERIC)
-            throw new GridGgfsException(err);
+            throw new IgniteFsException(err);
 
         throw new GridException(err);
     }
@@ -337,7 +337,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
         else if (X.hasCause(e, GridGgfsCorruptedFileException.class))
             return ERR_CORRUPTED_FILE;
             // This check should be the last.
-        else if (GridGgfsException.class.isInstance(e))
+        else if (IgniteFsException.class.isInstance(e))
             return ERR_GGFS_GENERIC;
 
         return ERR_GENERIC;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
index 7f88e83..4a99bc4 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
@@ -216,10 +216,10 @@ public abstract class GridCacheAdapter<K, V> extends GridMetadataAwareAdapter im
 
         metrics = new GridCacheMetricsAdapter();
 
-        GridGgfsConfiguration[] ggfsCfgs = gridCfg.getGgfsConfiguration();
+        IgniteFsConfiguration[] ggfsCfgs = gridCfg.getGgfsConfiguration();
 
         if (ggfsCfgs != null) {
-            for (GridGgfsConfiguration ggfsCfg : ggfsCfgs) {
+            for (IgniteFsConfiguration ggfsCfg : ggfsCfgs) {
                 if (F.eq(ctx.name(), ggfsCfg.getDataCacheName())) {
                     if (!ctx.isNear()) {
                         ggfsDataCache = true;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProcessor.java
index 5f2d224..b266c57 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProcessor.java
@@ -510,10 +510,10 @@ public class GridCacheProcessor extends GridProcessorAdapter {
         maxPreloadOrder = validatePreloadOrder(ctx.config().getCacheConfiguration());
 
         // Internal caches which should not be returned to user.
-        GridGgfsConfiguration[] ggfsCfgs = ctx.grid().configuration().getGgfsConfiguration();
+        IgniteFsConfiguration[] ggfsCfgs = ctx.grid().configuration().getGgfsConfiguration();
 
         if (ggfsCfgs != null) {
-            for (GridGgfsConfiguration ggfsCfg : ggfsCfgs) {
+            for (IgniteFsConfiguration ggfsCfg : ggfsCfgs) {
                 sysCaches.add(ggfsCfg.getMetaCacheName());
                 sysCaches.add(ggfsCfg.getDataCacheName());
             }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheUtils.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheUtils.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheUtils.java
index b3e399c..0a335ee 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheUtils.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheUtils.java
@@ -1565,10 +1565,10 @@ public class GridCacheUtils {
      * @return {@code True} in this is GGFS data or meta cache.
      */
     public static boolean isGgfsCache(IgniteConfiguration cfg, @Nullable String cacheName) {
-        GridGgfsConfiguration[] ggfsCfgs = cfg.getGgfsConfiguration();
+        IgniteFsConfiguration[] ggfsCfgs = cfg.getGgfsConfiguration();
 
         if (ggfsCfgs != null) {
-            for (GridGgfsConfiguration ggfsCfg : ggfsCfgs) {
+            for (IgniteFsConfiguration ggfsCfg : ggfsCfgs) {
                 // GGFS config probably has not been validated yet => possible NPE, so we check for null.
                 if (ggfsCfg != null &&
                     (F.eq(cacheName, ggfsCfg.getDataCacheName()) || F.eq(cacheName, ggfsCfg.getMetaCacheName())))

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
index e4230f5..a38de0d 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
@@ -163,7 +163,7 @@ public class GridGgfsAsyncImpl extends IgniteAsyncSupportAdapter implements Grid
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsConfiguration configuration() {
+    @Override public IgniteFsConfiguration configuration() {
         return ggfs.configuration();
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsContext.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsContext.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsContext.java
index 3dadf71..a5f105c 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsContext.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsContext.java
@@ -29,7 +29,7 @@ public class GridGgfsContext {
     private final GridKernalContext ctx;
 
     /** Configuration. */
-    private final GridGgfsConfiguration cfg;
+    private final IgniteFsConfiguration cfg;
 
     /** Managers. */
     private List<GridGgfsManager> mgrs = new LinkedList<>();
@@ -60,7 +60,7 @@ public class GridGgfsContext {
      */
     public GridGgfsContext(
         GridKernalContext ctx,
-        GridGgfsConfiguration cfg,
+        IgniteFsConfiguration cfg,
         GridGgfsMetaManager metaMgr,
         GridGgfsDataManager dataMgr,
         GridGgfsServerManager srvMgr,
@@ -94,7 +94,7 @@ public class GridGgfsContext {
     /**
      * @return GGFS configuration.
      */
-    public GridGgfsConfiguration configuration() {
+    public IgniteFsConfiguration configuration() {
         return cfg;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
index 1e1ff41..e3254b5 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
@@ -295,7 +295,7 @@ public class GridGgfsDataManager extends GridGgfsManager {
         IgniteDataLoader<GridGgfsBlockKey, byte[]> ldr =
             ggfsCtx.kernalContext().<GridGgfsBlockKey, byte[]>dataLoad().dataLoader(dataCachePrj.name());
 
-        GridGgfsConfiguration cfg = ggfsCtx.configuration();
+        IgniteFsConfiguration cfg = ggfsCtx.configuration();
 
         if (cfg.getPerNodeBatchSize() > 0)
             ldr.perNodeBufferSize(cfg.getPerNodeBatchSize());
@@ -860,7 +860,7 @@ public class GridGgfsDataManager extends GridGgfsManager {
         long limitGrpIdx = (start + len + grpBlockSize - 1) / grpBlockSize;
 
         if (limitGrpIdx - firstGrpIdx > Integer.MAX_VALUE)
-            throw new GridGgfsException("Failed to get affinity (range is too wide)" +
+            throw new IgniteFsException("Failed to get affinity (range is too wide)" +
                 " [info=" + info + ", start=" + start + ", len=" + len + ']');
 
         if (log.isDebugEnabled())
@@ -1408,7 +1408,7 @@ public class GridGgfsDataManager extends GridGgfsManager {
             int len = remainderLen + srcLen;
 
             if (len > reservedLen)
-                throw new GridGgfsException("Not enough space reserved to store data [id=" + id +
+                throw new IgniteFsException("Not enough space reserved to store data [id=" + id +
                     ", reservedLen=" + reservedLen + ", remainderLen=" + remainderLen +
                     ", data.length=" + srcLen + ']');
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDirectoryNotEmptyException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDirectoryNotEmptyException.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDirectoryNotEmptyException.java
index 1101e42..9850e35 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDirectoryNotEmptyException.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDirectoryNotEmptyException.java
@@ -14,7 +14,7 @@ import org.gridgain.grid.ggfs.*;
 /**
  * Exception indicating that directory can not be deleted because it is not empty.
  */
-public class GridGgfsDirectoryNotEmptyException extends GridGgfsException {
+public class GridGgfsDirectoryNotEmptyException extends IgniteFsException {
     /** */
     private static final long serialVersionUID = 0L;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileInfo.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileInfo.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileInfo.java
index 5078088..2e2bcc3 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileInfo.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileInfo.java
@@ -90,13 +90,13 @@ public final class GridGgfsFileInfo implements Externalizable {
     }
 
     /**
-     * Constructs directory or file info with {@link GridGgfsConfiguration#DFLT_BLOCK_SIZE default} block size.
+     * Constructs directory or file info with {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#DFLT_BLOCK_SIZE default} block size.
      *
      * @param isDir Constructs directory info if {@code true} or file info if {@code false}.
      * @param props Meta properties to set.
      */
     public GridGgfsFileInfo(boolean isDir, @Nullable Map<String, String> props) {
-        this(isDir, null, isDir ? 0 : GridGgfsConfiguration.DFLT_BLOCK_SIZE, 0, null, null, props, null, false,
+        this(isDir, null, isDir ? 0 : IgniteFsConfiguration.DFLT_BLOCK_SIZE, 0, null, null, props, null, false,
             System.currentTimeMillis(), false);
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
index fca2fdb..e1d75c3 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
@@ -63,7 +63,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     private GridGgfsDataManager data;
 
     /** FS configuration. */
-    private GridGgfsConfiguration cfg;
+    private IgniteFsConfiguration cfg;
 
     /** Ggfs context. */
     private GridGgfsContext ggfsCtx;
@@ -368,7 +368,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsConfiguration configuration() {
+    @Override public IgniteFsConfiguration configuration() {
         return cfg;
     }
 
@@ -883,7 +883,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                             GridGgfsFileInfo stored = meta.info(meta.fileId(parentId, fileName));
 
                             if (stored == null)
-                                throw new GridGgfsException(e);
+                                throw new IgniteFsException(e);
 
                             if (!stored.isDirectory())
                                 throw new GridGgfsParentNotDirectoryException("Failed to create directory (parent " +
@@ -1708,7 +1708,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
 
     /**
      * Executes GGFS task with overridden maximum range length (see
-     * {@link GridGgfsConfiguration#getMaximumTaskRangeLength()} for more information).
+     * {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()} for more information).
      *
      * @param task Task to execute.
      * @param rslvr Optional resolver to control split boundaries.
@@ -1742,7 +1742,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
 
     /**
      * Executes GGFS task asynchronously with overridden maximum range length (see
-     * {@link GridGgfsConfiguration#getMaximumTaskRangeLength()} for more information).
+     * {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()} for more information).
      *
      * @param taskCls Task class to execute.
      * @param rslvr Optional resolver to control split boundaries.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
index cff85d0..79e17de 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
@@ -40,7 +40,7 @@ import static org.gridgain.grid.kernal.processors.ggfs.GridGgfsFileInfo.*;
 @SuppressWarnings("all")
 public class GridGgfsMetaManager extends GridGgfsManager {
     /** GGFS configuration. */
-    private GridGgfsConfiguration cfg;
+    private IgniteFsConfiguration cfg;
 
     /** Metadata cache. */
     private GridCache<Object, Object> metaCache;
@@ -746,7 +746,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
         IgniteUuid fileId = newFileInfo.id();
 
         if (!id2InfoPrj.putxIfAbsent(fileId, newFileInfo))
-            throw new GridGgfsException("Failed to add file details into cache: " + newFileInfo);
+            throw new IgniteFsException("Failed to add file details into cache: " + newFileInfo);
 
         assert metaCache.get(parentId) != null;
 
@@ -963,7 +963,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
         assert parentInfo.isDirectory();
 
         if (!rmvLocked && fileInfo.lockId() != null)
-            throw new GridGgfsException("Failed to remove file (file is opened for writing) [fileName=" +
+            throw new IgniteFsException("Failed to remove file (file is opened for writing) [fileName=" +
                 fileName + ", fileId=" + fileId + ", lockId=" + fileInfo.lockId() + ']');
 
         // Validate own directory listing.
@@ -1467,15 +1467,15 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                     GridGgfsFileInfo newInfo = c.apply(oldInfo);
 
                     if (newInfo == null)
-                        throw new GridGgfsException("Failed to update file info with null value" +
+                        throw new IgniteFsException("Failed to update file info with null value" +
                             " [oldInfo=" + oldInfo + ", newInfo=" + newInfo + ", c=" + c + ']');
 
                     if (!oldInfo.id().equals(newInfo.id()))
-                        throw new GridGgfsException("Failed to update file info (file IDs differ)" +
+                        throw new IgniteFsException("Failed to update file info (file IDs differ)" +
                             " [oldInfo=" + oldInfo + ", newInfo=" + newInfo + ", c=" + c + ']');
 
                     if (oldInfo.isDirectory() != newInfo.isDirectory())
-                        throw new GridGgfsException("Failed to update file info (file types differ)" +
+                        throw new IgniteFsException("Failed to update file info (file types differ)" +
                             " [oldInfo=" + oldInfo + ", newInfo=" + newInfo + ", c=" + c + ']');
 
                     boolean b = metaCache.replace(fileId, oldInfo, newInfo);
@@ -1640,10 +1640,10 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                             GridGgfsFile status = fs.info(path);
 
                             if (status == null)
-                                throw new GridGgfsException("Failed to open output stream to the file created in " +
+                                throw new IgniteFsException("Failed to open output stream to the file created in " +
                                     "the secondary file system because it no longer exists: " + path);
                             else if (status.isDirectory())
-                                throw new GridGgfsException("Failed to open output stream to the file created in " +
+                                throw new IgniteFsException("Failed to open output stream to the file created in " +
                                     "the secondary file system because the path points to a directory: " + path);
 
                             GridGgfsFileInfo newInfo = new GridGgfsFileInfo(status.blockSize(), status.length(), affKey,
@@ -1704,10 +1704,10 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                                 simpleCreate + ", props=" + props + ", overwrite=" + overwrite + ", bufferSize=" +
                                 bufSize + ", replication=" + replication + ", blockSize=" + blockSize + ']', err);
 
-                            if (err instanceof GridGgfsException)
-                                throw (GridGgfsException)err;
+                            if (err instanceof IgniteFsException)
+                                throw (IgniteFsException)err;
                             else
-                                throw new GridGgfsException("Failed to create the file due to secondary file system " +
+                                throw new IgniteFsException("Failed to create the file due to secondary file system " +
                                     "exception: " + path, err);
                         }
                     };
@@ -1754,7 +1754,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                             GridGgfsFileInfo info = infos.get(path);
 
                             if (info.isDirectory())
-                                throw new GridGgfsException("Failed to open output stream to the file in the " +
+                                throw new IgniteFsException("Failed to open output stream to the file in the " +
                                     "secondary file system because the path points to a directory: " + path);
 
                             out = fs.append(path, bufSize, false, null);
@@ -1793,8 +1793,8 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                             U.error(log, "File append in DUAL mode failed [path=" + path + ", bufferSize=" + bufSize +
                                 ']', err);
 
-                            if (err instanceof GridGgfsException)
-                                throw (GridGgfsException)err;
+                            if (err instanceof IgniteFsException)
+                                throw (IgniteFsException)err;
                             else
                                 throw new GridException("Failed to append to the file due to secondary file system " +
                                     "exception: " + path, err);
@@ -1858,7 +1858,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                             U.error(log, "File open in DUAL mode failed [path=" + path + ", bufferSize=" + bufSize +
                                 ']', err);
 
-                            if (err instanceof GridGgfsException)
+                            if (err instanceof IgniteFsException)
                                 throw (GridException)err;
                             else
                                 throw new GridException("Failed to open the path due to secondary file system " +
@@ -1906,7 +1906,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                         }
 
                         @Override public GridGgfsFileInfo onFailure(@Nullable Exception err) throws GridException {
-                            if (err instanceof GridGgfsException)
+                            if (err instanceof IgniteFsException)
                                 throw (GridException)err;
                             else
                                 throw new GridException("Failed to synchronize path due to secondary file system " +
@@ -2061,7 +2061,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                         else {
                             // Move.
                             if (destInfo.isFile())
-                                throw new GridGgfsException("Failed to rename the path in the local file system " +
+                                throw new IgniteFsException("Failed to rename the path in the local file system " +
                                     "because destination path already exists and it is a file: " + dest);
                             else
                                 moveNonTx(srcInfo.id(), src.name(), srcParentInfo.id(), src.name(), destInfo.id());
@@ -2086,7 +2086,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                         U.error(log, "Path rename in DUAL mode failed [source=" + src + ", destination=" + dest + ']',
                             err);
 
-                        if (err instanceof GridGgfsException)
+                        if (err instanceof IgniteFsException)
                             throw (GridException)err;
                         else
                             throw new GridException("Failed to rename the path due to secondary file system " +
@@ -2427,7 +2427,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                 if (changed != null) {
                     finished = true;
 
-                    throw new GridGgfsConcurrentModificationException(changed);
+                    throw new IgniteFsConcurrentModificationException(changed);
                 }
                 else {
                     boolean newParents = false;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java
index 7e9c001..854fda0 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java
@@ -103,7 +103,7 @@ class GridGgfsOutputStreamImpl extends GridGgfsOutputStreamAdapter {
 
         // File hasn't been locked.
         if (fileInfo.lockId() == null)
-            throw new GridGgfsException("Failed to acquire file lock (concurrently modified?): " + path);
+            throw new IgniteFsException("Failed to acquire file lock (concurrently modified?): " + path);
 
         this.ggfsCtx = ggfsCtx;
         meta = ggfsCtx.meta();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
index f1cfeba..dc83ed5 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
@@ -69,7 +69,7 @@ public class GridGgfsProcessor extends GridGgfsProcessorAdapter {
         if (ctx.config().isDaemon())
             return;
 
-        GridGgfsConfiguration[] cfgs = ctx.config().getGgfsConfiguration();
+        IgniteFsConfiguration[] cfgs = ctx.config().getGgfsConfiguration();
 
         assert cfgs != null && cfgs.length > 0;
 
@@ -116,10 +116,10 @@ public class GridGgfsProcessor extends GridGgfsProcessorAdapter {
         validateLocalGgfsConfigurations(cfgs);
 
         // Start GGFS instances.
-        for (GridGgfsConfiguration cfg : cfgs) {
+        for (IgniteFsConfiguration cfg : cfgs) {
             GridGgfsContext ggfsCtx = new GridGgfsContext(
                 ctx,
-                new GridGgfsConfiguration(cfg),
+                new IgniteFsConfiguration(cfg),
                 new GridGgfsMetaManager(),
                 new GridGgfsDataManager(),
                 new GridGgfsServerManager(),
@@ -254,7 +254,7 @@ public class GridGgfsProcessor extends GridGgfsProcessorAdapter {
 
         assert gridCfg.getGgfsConfiguration() != null;
 
-        for (GridGgfsConfiguration ggfsCfg : gridCfg.getGgfsConfiguration()) {
+        for (IgniteFsConfiguration ggfsCfg : gridCfg.getGgfsConfiguration()) {
             GridCacheConfiguration cacheCfg = cacheCfgs.get(ggfsCfg.getDataCacheName());
 
             if (cacheCfg == null)
@@ -294,10 +294,10 @@ public class GridGgfsProcessor extends GridGgfsProcessorAdapter {
      * @param cfgs GGFS configurations
      * @throws GridException If any of GGFS configurations is invalid.
      */
-    private void validateLocalGgfsConfigurations(GridGgfsConfiguration[] cfgs) throws GridException {
+    private void validateLocalGgfsConfigurations(IgniteFsConfiguration[] cfgs) throws GridException {
         Collection<String> cfgNames = new HashSet<>();
 
-        for (GridGgfsConfiguration cfg : cfgs) {
+        for (IgniteFsConfiguration cfg : cfgs) {
             String name = cfg.getName();
 
             if (cfgNames.contains(name))

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java
index 89e9c95..b8f17a9 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManager.java
@@ -21,7 +21,7 @@ import org.gridgain.grid.util.worker.*;
 import java.util.*;
 import java.util.concurrent.*;
 
-import static org.gridgain.grid.ggfs.GridGgfsConfiguration.*;
+import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
 
 /**
  * GGFS server manager.
@@ -41,7 +41,7 @@ public class GridGgfsServerManager extends GridGgfsManager {
 
     /** {@inheritDoc} */
     @Override protected void start0() throws GridException {
-        GridGgfsConfiguration ggfsCfg = ggfsCtx.configuration();
+        IgniteFsConfiguration ggfsCfg = ggfsCtx.configuration();
         Map<String,String> cfg = ggfsCfg.getIpcEndpointConfiguration();
 
         if (F.isEmpty(cfg)) {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java
index 10810a8..fb8d9fc 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java
@@ -116,7 +116,7 @@ public class VisorGgfsConfiguration implements Serializable {
      * @param ggfs GGFS configuration.
      * @return Data transfer object for GGFS configuration properties.
      */
-    public static VisorGgfsConfiguration from(GridGgfsConfiguration ggfs) {
+    public static VisorGgfsConfiguration from(IgniteFsConfiguration ggfs) {
         VisorGgfsConfiguration cfg = new VisorGgfsConfiguration();
 
         cfg.name(ggfs.getName());
@@ -167,13 +167,13 @@ public class VisorGgfsConfiguration implements Serializable {
      * @param ggfss ggfs configurations.
      * @return ggfs configurations properties.
      */
-    public static Iterable<VisorGgfsConfiguration> list(GridGgfsConfiguration[] ggfss) {
+    public static Iterable<VisorGgfsConfiguration> list(IgniteFsConfiguration[] ggfss) {
         if (ggfss == null)
             return Collections.emptyList();
 
         final Collection<VisorGgfsConfiguration> cfgs = new ArrayList<>(ggfss.length);
 
-        for (GridGgfsConfiguration ggfs : ggfss)
+        for (IgniteFsConfiguration ggfs : ggfss)
             cfgs.add(from(ggfs));
 
         return cfgs;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/kernal/visor/util/VisorTaskUtils.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/util/VisorTaskUtils.java b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/util/VisorTaskUtils.java
index bc0c805..b6989c3 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/util/VisorTaskUtils.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/util/VisorTaskUtils.java
@@ -37,7 +37,7 @@ import java.util.concurrent.atomic.*;
 
 import static java.lang.System.*;
 import static org.apache.ignite.events.IgniteEventType.*;
-import static org.gridgain.grid.ggfs.GridGgfsConfiguration.*;
+import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
 
 /**
  * Contains utility methods for Visor tasks and jobs.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/config/ggfs-loopback.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/ggfs-loopback.xml b/modules/core/src/test/config/ggfs-loopback.xml
index 88e8843..1721ae8 100644
--- a/modules/core/src/test/config/ggfs-loopback.xml
+++ b/modules/core/src/test/config/ggfs-loopback.xml
@@ -74,7 +74,7 @@
 
         <property name="ggfsConfiguration">
             <list>
-                <bean class="org.gridgain.grid.ggfs.GridGgfsConfiguration">
+                <bean class="org.gridgain.grid.ggfs.IgniteFsConfiguration">
                     <property name="name" value="ggfs"/>
                     <property name="metaCacheName" value="ggfs-meta"/>
                     <property name="dataCacheName" value="ggfs-data"/>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/config/ggfs-no-endpoint.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/ggfs-no-endpoint.xml b/modules/core/src/test/config/ggfs-no-endpoint.xml
index 25c4381..741edbf 100644
--- a/modules/core/src/test/config/ggfs-no-endpoint.xml
+++ b/modules/core/src/test/config/ggfs-no-endpoint.xml
@@ -75,7 +75,7 @@
 
         <property name="ggfsConfiguration">
             <list>
-                <bean class="org.gridgain.grid.ggfs.GridGgfsConfiguration">
+                <bean class="org.gridgain.grid.ggfs.IgniteFsConfiguration">
                     <property name="name" value="ggfs"/>
                     <property name="metaCacheName" value="ggfs-meta"/>
                     <property name="dataCacheName" value="ggfs-data"/>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/config/ggfs-shmem.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/ggfs-shmem.xml b/modules/core/src/test/config/ggfs-shmem.xml
index 698759f..271ace7 100644
--- a/modules/core/src/test/config/ggfs-shmem.xml
+++ b/modules/core/src/test/config/ggfs-shmem.xml
@@ -74,7 +74,7 @@
 
         <property name="ggfsConfiguration">
             <list>
-                <bean class="org.gridgain.grid.ggfs.GridGgfsConfiguration">
+                <bean class="org.gridgain.grid.ggfs.IgniteFsConfiguration">
                     <property name="name" value="ggfs"/>
                     <property name="metaCacheName" value="ggfs-meta"/>
                     <property name="dataCacheName" value="ggfs-data"/>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
index b6b6cb6..202d168 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
@@ -78,8 +78,8 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
     /**
      * @return GGFS configuration for this test.
      */
-    protected GridGgfsConfiguration getGgfsConfiguration() throws GridException {
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+    protected IgniteFsConfiguration getGgfsConfiguration() throws GridException {
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("dataCache");
         ggfsCfg.setMetaCacheName("metaCache");
@@ -103,7 +103,7 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
      * @return Grid configuration.
      * @throws Exception If failed.
      */
-    protected IgniteConfiguration getConfiguration(String gridName, GridGgfsConfiguration ggfsCfg) throws Exception {
+    protected IgniteConfiguration getConfiguration(String gridName, IgniteFsConfiguration ggfsCfg) throws Exception {
         IgniteConfiguration cfg = GridGainEx.loadConfiguration("config/hadoop/default-config.xml").get1();
 
         assert cfg != null;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java
index fc5a434..d1c6ea9 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java
@@ -55,7 +55,7 @@ public class GridGgfsFragmentizerAbstractSelfTest extends GridGgfsCommonAbstract
 
         cfg.setCacheConfiguration(metaConfiguration(), dataConfiguration());
 
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setName("ggfs");
         ggfsCfg.setMetaCacheName(META_CACHE_NAME);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
index 68e7c6d..d34f6de 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
@@ -74,7 +74,7 @@ public class GridCacheGgfsPerBlockLruEvictionPolicySelfTest extends GridGgfsComm
      * @throws Exception If failed.
      */
     private void startPrimary() throws Exception {
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("dataCache");
         ggfsCfg.setMetaCacheName("metaCache");
@@ -144,7 +144,7 @@ public class GridCacheGgfsPerBlockLruEvictionPolicySelfTest extends GridGgfsComm
      * @throws Exception If failed.
      */
     private void startSecondary() throws Exception {
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("dataCache");
         ggfsCfg.setMetaCacheName("metaCache");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
index 1178dc0..b099ed3 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
@@ -169,7 +169,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      */
     protected Ignite startGridWithGgfs(String gridName, String ggfsName, GridGgfsMode mode,
         @Nullable GridGgfsFileSystem secondaryFs, @Nullable String restCfg) throws Exception {
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("dataCache");
         ggfsCfg.setMetaCacheName("metaCache");
@@ -598,7 +598,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
                 return null;
             }
-        }, GridGgfsException.class, null);
+        }, IgniteFsException.class, null);
 
         checkNotExist(ggfs, ggfsSecondary, SUBDIR, SUBDIR_NEW);
     }
@@ -917,7 +917,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
                 return null;
             }
-        }, GridGgfsException.class, null);
+        }, IgniteFsException.class, null);
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsCacheSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsCacheSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsCacheSelfTest.java
index 13b2bc5..5add5ee 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsCacheSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsCacheSelfTest.java
@@ -48,7 +48,7 @@ public class GridGgfsCacheSelfTest extends GridGgfsCommonAbstractTest {
 
         cfg.setDiscoverySpi(discoSpi);
 
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setMetaCacheName(META_CACHE_NAME);
         ggfsCfg.setDataCacheName(DATA_CACHE_NAME);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java
index 7d5d494..e3e953a 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java
@@ -85,7 +85,7 @@ public class GridGgfsDataManagerSelfTest extends GridGgfsCommonAbstractTest {
 
         cfg.setDiscoverySpi(discoSpi);
 
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setMetaCacheName(META_CACHE_NAME);
         ggfsCfg.setDataCacheName(DATA_CACHE_NAME);
@@ -550,7 +550,7 @@ public class GridGgfsDataManagerSelfTest extends GridGgfsCommonAbstractTest {
 
                 return null;
             }
-        }, GridGgfsException.class, msg);
+        }, IgniteFsException.class, msg);
     }
 
     /**
@@ -566,7 +566,7 @@ public class GridGgfsDataManagerSelfTest extends GridGgfsCommonAbstractTest {
 
                 return null;
             }
-        }, GridGgfsException.class, msg);
+        }, IgniteFsException.class, msg);
     }
 
     /**
@@ -585,6 +585,6 @@ public class GridGgfsDataManagerSelfTest extends GridGgfsCommonAbstractTest {
 
                 return null;
             }
-        }, GridGgfsException.class, msg);
+        }, IgniteFsException.class, msg);
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java
index 2b73c07..b1ea25b 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java
@@ -68,7 +68,7 @@ public class GridGgfsMetaManagerSelfTest extends GridGgfsCommonAbstractTest {
 
         cfg.setDiscoverySpi(discoSpi);
 
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setMetaCacheName(META_CACHE_NAME);
         ggfsCfg.setDataCacheName(DATA_CACHE_NAME);
@@ -412,7 +412,7 @@ public class GridGgfsMetaManagerSelfTest extends GridGgfsCommonAbstractTest {
             @Override public Object call() throws Exception {
                 return mgr.putIfAbsent(parentId, fileName, fileInfo);
             }
-        }, GridGgfsException.class, msg);
+        }, IgniteFsException.class, msg);
     }
 
     /**
@@ -433,7 +433,7 @@ public class GridGgfsMetaManagerSelfTest extends GridGgfsCommonAbstractTest {
 
                 return null;
             }
-        }, GridGgfsException.class, msg);
+        }, IgniteFsException.class, msg);
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
index 1dcca80..db70a00 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
@@ -91,7 +91,7 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
      * @throws Exception If failed.
      */
     private IgniteConfiguration primaryConfiguration(int idx) throws Exception {
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("dataCache");
         ggfsCfg.setMetaCacheName("metaCache");
@@ -149,7 +149,7 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
      * @throws Exception If failed.
      */
     private void startSecondary() throws Exception {
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("dataCache");
         ggfsCfg.setMetaCacheName("metaCache");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
index ebf6b8d..55a7bb9 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
@@ -75,7 +75,7 @@ public class GridGgfsModesSelfTest extends GridGgfsCommonAbstractTest {
     private void startUp() throws Exception {
         startUpSecondary();
 
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("partitioned");
         ggfsCfg.setMetaCacheName("replicated");
@@ -137,7 +137,7 @@ public class GridGgfsModesSelfTest extends GridGgfsCommonAbstractTest {
      * @throws Exception If failed.
      */
     private void startUpSecondary() throws Exception {
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("partitioned");
         ggfsCfg.setMetaCacheName("replicated");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
index 575e955..1f90684 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
@@ -65,7 +65,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
 
         ggfs = grid.fileSystem(ggfsName());
 
-        GridGgfsConfiguration[] cfgs = grid.configuration().getGgfsConfiguration();
+        IgniteFsConfiguration[] cfgs = grid.configuration().getGgfsConfiguration();
 
         assert cfgs.length == 1;
 
@@ -103,7 +103,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
 
         cfg.setDiscoverySpi(discoSpi);
 
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setMetaCacheName(META_CACHE_NAME);
         ggfsCfg.setDataCacheName(DATA_CACHE_NAME);
@@ -369,7 +369,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
 
                 return null;
             }
-        }, GridGgfsException.class, null);
+        }, IgniteFsException.class, null);
 
         ggfs.delete(path("/A1/B1/C1"), false);
         assertNull(ggfs.info(path("/A1/B1/C1")));
@@ -395,7 +395,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
 
                 return null;
             }
-        }, GridGgfsException.class, null);
+        }, IgniteFsException.class, null);
         assertEquals(Arrays.asList(path("/A"), path("/A1"), path("/A2")), sorted(ggfs.listPaths(path("/"))));
 
         ggfs.delete(path("/"), true);
@@ -473,7 +473,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
 
                 return null;
             }
-        }, GridGgfsException.class, null);
+        }, IgniteFsException.class, null);
 
         // Move under itself.
         GridTestUtils.assertThrowsInherited(log, new Callable<Object>() {
@@ -482,7 +482,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
 
                 return null;
             }
-        }, GridGgfsException.class, null);
+        }, IgniteFsException.class, null);
 
         // Move under itself.
         GridTestUtils.assertThrowsInherited(log, new Callable<Object>() {
@@ -492,7 +492,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
 
                 return null;
             }
-        }, GridGgfsException.class, null);
+        }, IgniteFsException.class, null);
 
         ///
         // F6 > Enter > Tab x N times
@@ -530,7 +530,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
 
                     return null;
                 }
-            }, GridGgfsException.class, null);
+            }, IgniteFsException.class, null);
 
             // Test root rename.
             GridTestUtils.assertThrowsInherited(log, new Callable<Object>() {
@@ -539,7 +539,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
 
                     return null;
                 }
-            }, GridGgfsException.class, null);
+            }, IgniteFsException.class, null);
 
             // Test root rename.
             if (!root.equals(p2)) {
@@ -549,7 +549,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
 
                         return null;
                     }
-                }, GridGgfsException.class, null);
+                }, IgniteFsException.class, null);
             }
 
             // Test same rename.
@@ -911,7 +911,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
 
                 return false;
             }
-        }, GridGgfsException.class, msg);
+        }, IgniteFsException.class, msg);
     }
 
     /**
@@ -928,7 +928,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
 
                 return false;
             }
-        }, GridGgfsException.class, msg);
+        }, IgniteFsException.class, msg);
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java
index df0c6a4..de5f837 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java
@@ -30,7 +30,7 @@ import static org.gridgain.grid.ggfs.GridGgfsMode.*;
  * Tests for node validation logic in {@link GridGgfsProcessor}.
  * <p>
  * Tests starting with "testLocal" are checking
- * {@link GridGgfsProcessor#validateLocalGgfsConfigurations(GridGgfsConfiguration[])}.
+ * {@link GridGgfsProcessor#validateLocalGgfsConfigurations(org.gridgain.grid.ggfs.IgniteFsConfiguration[])}.
  * <p>
  * Tests starting with "testRemote" are checking {@link GridGgfsProcessor#checkGgfsOnRemoteNode(org.apache.ignite.cluster.ClusterNode)}.
  */
@@ -54,10 +54,10 @@ public class GridGgfsProcessorValidationSelfTest extends GridGgfsCommonAbstractT
     private static final String metaCache2Name = "metaCache2";
 
     /** First GGFS config in grid #1. */
-    private GridGgfsConfiguration g1GgfsCfg1 = new GridGgfsConfiguration();
+    private IgniteFsConfiguration g1GgfsCfg1 = new IgniteFsConfiguration();
 
     /** Second GGFS config in grid#1. */
-    private GridGgfsConfiguration g1GgfsCfg2 = new GridGgfsConfiguration();
+    private IgniteFsConfiguration g1GgfsCfg2 = new IgniteFsConfiguration();
 
     /** {@inheritDoc} */
     @Override protected void beforeTest() throws Exception {
@@ -271,7 +271,7 @@ public class GridGgfsProcessorValidationSelfTest extends GridGgfsCommonAbstractT
         g1Cfg.setCacheConfiguration(concat(dataCaches(1024), metaCaches(), GridCacheConfiguration.class));
         g2Cfg.setCacheConfiguration(concat(dataCaches(1024), metaCaches(), GridCacheConfiguration.class));
 
-        GridGgfsConfiguration g2GgfsCfg1 = new GridGgfsConfiguration(g1GgfsCfg1);
+        IgniteFsConfiguration g2GgfsCfg1 = new IgniteFsConfiguration(g1GgfsCfg1);
 
         g2GgfsCfg1.setBlockSize(g2GgfsCfg1.getBlockSize() + 100);
 
@@ -303,8 +303,8 @@ public class GridGgfsProcessorValidationSelfTest extends GridGgfsCommonAbstractT
     public void testRemoteIfMetaCacheNameDiffers() throws Exception {
         IgniteConfiguration g2Cfg = getConfiguration("g2");
 
-        GridGgfsConfiguration g2GgfsCfg1 = new GridGgfsConfiguration(g1GgfsCfg1);
-        GridGgfsConfiguration g2GgfsCfg2 = new GridGgfsConfiguration(g1GgfsCfg2);
+        IgniteFsConfiguration g2GgfsCfg1 = new IgniteFsConfiguration(g1GgfsCfg1);
+        IgniteFsConfiguration g2GgfsCfg2 = new IgniteFsConfiguration(g1GgfsCfg2);
 
         g2GgfsCfg1.setMetaCacheName("g2MetaCache1");
         g2GgfsCfg2.setMetaCacheName("g2MetaCache2");
@@ -326,8 +326,8 @@ public class GridGgfsProcessorValidationSelfTest extends GridGgfsCommonAbstractT
     public void testRemoteIfMetaCacheNameEquals() throws Exception {
         IgniteConfiguration g2Cfg = getConfiguration("g2");
 
-        GridGgfsConfiguration g2GgfsCfg1 = new GridGgfsConfiguration(g1GgfsCfg1);
-        GridGgfsConfiguration g2GgfsCfg2 = new GridGgfsConfiguration(g1GgfsCfg2);
+        IgniteFsConfiguration g2GgfsCfg1 = new IgniteFsConfiguration(g1GgfsCfg1);
+        IgniteFsConfiguration g2GgfsCfg2 = new IgniteFsConfiguration(g1GgfsCfg2);
 
         g2GgfsCfg1.setName("g2GgfsCfg1");
         g2GgfsCfg2.setName("g2GgfsCfg2");
@@ -352,8 +352,8 @@ public class GridGgfsProcessorValidationSelfTest extends GridGgfsCommonAbstractT
     public void testRemoteIfDataCacheNameDiffers() throws Exception {
         IgniteConfiguration g2Cfg = getConfiguration("g2");
 
-        GridGgfsConfiguration g2GgfsCfg1 = new GridGgfsConfiguration(g1GgfsCfg1);
-        GridGgfsConfiguration g2GgfsCfg2 = new GridGgfsConfiguration(g1GgfsCfg2);
+        IgniteFsConfiguration g2GgfsCfg1 = new IgniteFsConfiguration(g1GgfsCfg1);
+        IgniteFsConfiguration g2GgfsCfg2 = new IgniteFsConfiguration(g1GgfsCfg2);
 
         g2GgfsCfg1.setDataCacheName("g2DataCache1");
         g2GgfsCfg2.setDataCacheName("g2DataCache2");
@@ -375,8 +375,8 @@ public class GridGgfsProcessorValidationSelfTest extends GridGgfsCommonAbstractT
     public void testRemoteIfDataCacheNameEquals() throws Exception {
         IgniteConfiguration g2Cfg = getConfiguration("g2");
 
-        GridGgfsConfiguration g2GgfsCfg1 = new GridGgfsConfiguration(g1GgfsCfg1);
-        GridGgfsConfiguration g2GgfsCfg2 = new GridGgfsConfiguration(g1GgfsCfg2);
+        IgniteFsConfiguration g2GgfsCfg1 = new IgniteFsConfiguration(g1GgfsCfg1);
+        IgniteFsConfiguration g2GgfsCfg2 = new IgniteFsConfiguration(g1GgfsCfg2);
 
         g2GgfsCfg1.setName("g2GgfsCfg1");
         g2GgfsCfg2.setName("g2GgfsCfg2");
@@ -401,8 +401,8 @@ public class GridGgfsProcessorValidationSelfTest extends GridGgfsCommonAbstractT
     public void testRemoteIfDefaultModeDiffers() throws Exception {
         IgniteConfiguration g2Cfg = getConfiguration("g2");
 
-        GridGgfsConfiguration g2GgfsCfg1 = new GridGgfsConfiguration(g1GgfsCfg1);
-        GridGgfsConfiguration g2GgfsCfg2 = new GridGgfsConfiguration(g1GgfsCfg2);
+        IgniteFsConfiguration g2GgfsCfg1 = new IgniteFsConfiguration(g1GgfsCfg1);
+        IgniteFsConfiguration g2GgfsCfg2 = new IgniteFsConfiguration(g1GgfsCfg2);
 
         g1GgfsCfg1.setDefaultMode(DUAL_ASYNC);
         g1GgfsCfg2.setDefaultMode(DUAL_ASYNC);
@@ -426,8 +426,8 @@ public class GridGgfsProcessorValidationSelfTest extends GridGgfsCommonAbstractT
     public void testRemoteIfPathModeDiffers() throws Exception {
         IgniteConfiguration g2Cfg = getConfiguration("g2");
 
-        GridGgfsConfiguration g2GgfsCfg1 = new GridGgfsConfiguration(g1GgfsCfg1);
-        GridGgfsConfiguration g2GgfsCfg2 = new GridGgfsConfiguration(g1GgfsCfg2);
+        IgniteFsConfiguration g2GgfsCfg1 = new IgniteFsConfiguration(g1GgfsCfg1);
+        IgniteFsConfiguration g2GgfsCfg2 = new IgniteFsConfiguration(g1GgfsCfg2);
 
         g2GgfsCfg1.setPathModes(Collections.singletonMap("/somePath", DUAL_SYNC));
         g2GgfsCfg2.setPathModes(Collections.singletonMap("/somePath", DUAL_SYNC));

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationAbstractSelfTest.java
index 7612b4a..cbc49e2 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationAbstractSelfTest.java
@@ -29,7 +29,7 @@ import java.util.*;
 import java.util.concurrent.atomic.*;
 
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
-import static org.gridgain.grid.ggfs.GridGgfsConfiguration.*;
+import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
 
 /**
  * Base test class for {@link GridGgfsServer} checking IPC endpoint registrations.
@@ -146,8 +146,8 @@ public abstract class GridGgfsServerManagerIpcEndpointRegistrationAbstractSelfTe
      * @param endpointCfg Optional REST endpoint configuration.
      * @return test-purposed GridGgfsConfiguration.
      */
-    protected GridGgfsConfiguration gridGgfsConfiguration(@Nullable String endpointCfg) throws GridException {
-        GridGgfsConfiguration ggfsConfiguration = new GridGgfsConfiguration();
+    protected IgniteFsConfiguration gridGgfsConfiguration(@Nullable String endpointCfg) throws GridException {
+        IgniteFsConfiguration ggfsConfiguration = new IgniteFsConfiguration();
 
         ggfsConfiguration.setDataCacheName("partitioned");
         ggfsConfiguration.setMetaCacheName("replicated");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationOnLinuxAndMacSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationOnLinuxAndMacSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationOnLinuxAndMacSelfTest.java
index 535d472..2b3291d 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationOnLinuxAndMacSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationOnLinuxAndMacSelfTest.java
@@ -12,7 +12,7 @@ package org.gridgain.grid.kernal.processors.ggfs;
 import org.apache.ignite.configuration.*;
 import org.gridgain.grid.util.typedef.*;
 
-import static org.gridgain.grid.ggfs.GridGgfsConfiguration.*;
+import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
 
 /**
  * Tests for {@link GridGgfsServer} that checks all IPC endpoint registration types

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
index cac49b9..c4a08eb 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
@@ -102,7 +102,7 @@ public class GridGgfsSizeSelfTest extends GridGgfsCommonAbstractTest {
     @Override protected IgniteConfiguration getConfiguration(String gridName) throws Exception {
         IgniteConfiguration cfg = super.getConfiguration(gridName);
 
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName(DATA_CACHE_NAME);
         ggfsCfg.setMetaCacheName(META_CACHE_NAME);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
index 3194fdf..34a693d 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
@@ -103,7 +103,7 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
 
         cfg.setDiscoverySpi(discoSpi);
 
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setMetaCacheName(META_CACHE_NAME);
         ggfsCfg.setDataCacheName(DATA_CACHE_NAME);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
index f01b253..88adf6f 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
@@ -90,7 +90,7 @@ public class GridGgfsTaskSelfTest extends GridGgfsCommonAbstractTest {
      * @return Grid configuration
      */
     private IgniteConfiguration config(int idx) {
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("dataCache");
         ggfsCfg.setMetaCacheName("metaCache");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
index affd964..34e5345 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
@@ -43,7 +43,7 @@ public class GridGgfsAbstractRecordResolverSelfTest extends GridCommonAbstractTe
 
     /** {@inheritDoc} */
     @Override protected void beforeTestsStarted() throws Exception {
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("dataCache");
         ggfsCfg.setMetaCacheName("metaCache");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/test/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryNodeStartup.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryNodeStartup.java b/modules/core/src/test/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryNodeStartup.java
index d1290da..96fd35b 100644
--- a/modules/core/src/test/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryNodeStartup.java
+++ b/modules/core/src/test/java/org/gridgain/grid/util/ipc/shmem/GridIpcSharedMemoryNodeStartup.java
@@ -35,7 +35,7 @@ public class GridIpcSharedMemoryNodeStartup {
     public static void main(String[] args) throws Exception{
         IgniteConfiguration cfg = new IgniteConfiguration();
 
-        GridGgfsConfiguration ggfsCfg = new GridGgfsConfiguration();
+        IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         GridTcpDiscoverySpi discoSpi = new GridTcpDiscoverySpi();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/GridGgfsHadoopParameters.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/GridGgfsHadoopParameters.java b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/GridGgfsHadoopParameters.java
index 0c07daf..bbd2d49 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/GridGgfsHadoopParameters.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/GridGgfsHadoopParameters.java
@@ -9,8 +9,6 @@
 
 package org.gridgain.grid.ggfs.hadoop;
 
-import org.gridgain.grid.ggfs.*;
-
 /**
  * This class lists parameters that can be specified in Hadoop configuration.
  * Hadoop configuration can be specified in {@code core-site.xml} file
@@ -18,7 +16,7 @@ import org.gridgain.grid.ggfs.*;
  * <ul>
  *     <li>
  *         {@code fs.ggfs.[name].open.sequential_reads_before_prefetch} - this parameter overrides
- *         the one specified in {@link GridGgfsConfiguration#getSequentialReadsBeforePrefetch()}
+ *         the one specified in {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getSequentialReadsBeforePrefetch()}
  *         GGFS data node configuration property.
  *     </li>
  *     <li>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
index 9fa7c00..8459461 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
@@ -31,7 +31,7 @@ import java.util.*;
 import java.util.concurrent.atomic.*;
 
 import static org.apache.ignite.IgniteFs.*;
-import static org.gridgain.grid.ggfs.GridGgfsConfiguration.*;
+import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
 import static org.gridgain.grid.ggfs.GridGgfsMode.*;
 import static org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.*;
 import static org.gridgain.grid.kernal.ggfs.hadoop.GridGgfsHadoopUtils.*;
@@ -716,7 +716,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
         catch (IOException e) {
             // Intentionally ignore GGFS exceptions here to follow Hadoop contract.
             if (F.eq(IOException.class, e.getClass()) && (e.getCause() == null ||
-                !GridGgfsException.class.isAssignableFrom(e.getCause().getClass())))
+                !IgniteFsException.class.isAssignableFrom(e.getCause().getClass())))
                 throw e;
             else
                 return false;
@@ -767,7 +767,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
         catch (IOException e) {
             // Intentionally ignore GGFS exceptions here to follow Hadoop contract.
             if (F.eq(IOException.class, e.getClass()) && (e.getCause() == null ||
-                !GridGgfsException.class.isAssignableFrom(e.getCause().getClass())))
+                !IgniteFsException.class.isAssignableFrom(e.getCause().getClass())))
                 throw e;
             else
                 return false;
@@ -925,7 +925,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
         catch (IOException e) {
             // Intentionally ignore GGFS exceptions here to follow Hadoop contract.
             if (F.eq(IOException.class, e.getClass()) && (e.getCause() == null ||
-                !GridGgfsException.class.isAssignableFrom(e.getCause().getClass())))
+                !IgniteFsException.class.isAssignableFrom(e.getCause().getClass())))
                 throw e;
             else
                 return false;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
index e7dc2b3..9d320b4 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
@@ -31,7 +31,7 @@ import java.util.*;
 import java.util.concurrent.atomic.*;
 
 import static org.apache.ignite.IgniteFs.*;
-import static org.gridgain.grid.ggfs.GridGgfsConfiguration.*;
+import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
 import static org.gridgain.grid.ggfs.GridGgfsMode.*;
 import static org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.*;
 import static org.gridgain.grid.kernal.ggfs.hadoop.GridGgfsHadoopUtils.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopEndpoint.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopEndpoint.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopEndpoint.java
index d8817c4..c17d26f 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopEndpoint.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopEndpoint.java
@@ -19,7 +19,7 @@ import org.jetbrains.annotations.*;
 import java.io.*;
 import java.net.*;
 
-import static org.gridgain.grid.ggfs.GridGgfsConfiguration.*;
+import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
 
 /**
  * GGFS endpoint abstraction.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
index 09bb563..f07b430 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
@@ -89,11 +89,11 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
      * @param detailMsg Detailed error message.
      * @return Appropriate exception.
      */
-    private GridGgfsException handleSecondaryFsError(IOException e, String detailMsg) {
+    private IgniteFsException handleSecondaryFsError(IOException e, String detailMsg) {
         boolean wrongVer = X.hasCause(e, RemoteException.class) ||
             (e.getMessage() != null && e.getMessage().contains("Failed on local"));
 
-        GridGgfsException ggfsErr = !wrongVer ? cast(detailMsg, e) :
+        IgniteFsException ggfsErr = !wrongVer ? cast(detailMsg, e) :
             new GridGgfsInvalidHdfsVersionException("HDFS version you are connecting to differs from local " +
                 "version.", e);
 
@@ -108,7 +108,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
      * @param e IO exception.
      * @return GGFS exception.
      */
-    public static GridGgfsException cast(String msg, IOException e) {
+    public static IgniteFsException cast(String msg, IOException e) {
         if (e instanceof FileNotFoundException)
             return new GridGgfsFileNotFoundException(e);
         else if (e instanceof ParentNotDirectoryException)
@@ -118,7 +118,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
         else if (e instanceof PathExistsException)
             return new IgniteFsPathAlreadyExistsException(msg, e);
         else
-            return new GridGgfsException(msg, e);
+            return new IgniteFsException(msg, e);
     }
 
     /**
@@ -171,7 +171,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
         // Delegate to the secondary file system.
         try {
             if (!fileSys.rename(convert(src), convert(dest)))
-                throw new GridGgfsException("Failed to rename (secondary file system returned false) " +
+                throw new IgniteFsException("Failed to rename (secondary file system returned false) " +
                     "[src=" + src + ", dest=" + dest + ']');
         }
         catch (IOException e) {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/fs/GridHadoopDistributedFileSystem.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/fs/GridHadoopDistributedFileSystem.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/fs/GridHadoopDistributedFileSystem.java
index 040cd26..e39153a 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/fs/GridHadoopDistributedFileSystem.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/processors/hadoop/fs/GridHadoopDistributedFileSystem.java
@@ -17,7 +17,7 @@ import org.apache.hadoop.mapreduce.*;
 import java.io.*;
 import java.net.*;
 
-import static org.gridgain.grid.ggfs.GridGgfsConfiguration.*;
+import static org.gridgain.grid.ggfs.IgniteFsConfiguration.*;
 
 /**
  * Wrapper of HDFS for support of separated working directory.


[16/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
# Renaming


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

Branch: refs/heads/master
Commit: cd01ed994cbc24dbe143a8517d768dae87c8a312
Parents: f3d9376
Author: sboikov <sb...@gridgain.com>
Authored: Fri Dec 5 11:16:11 2014 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Dec 5 11:16:11 2014 +0300

----------------------------------------------------------------------
 examples/config/filesystem/example-ggfs.xml     |   2 +-
 .../org/gridgain/examples/ggfs/GgfsExample.java |   4 +-
 .../src/main/java/org/apache/ignite/Ignite.java |  13 +-
 .../main/java/org/apache/ignite/IgniteFs.java   |   6 +-
 .../configuration/IgniteConfiguration.java      |   6 +-
 ...GridGgfsConcurrentModificationException.java |  28 -
 .../grid/ggfs/GridGgfsConfiguration.java        | 801 -------------------
 .../ggfs/GridGgfsCorruptedFileException.java    |   2 +-
 .../gridgain/grid/ggfs/GridGgfsException.java   |  49 --
 .../GridGgfsInvalidHdfsVersionException.java    |   2 +-
 .../grid/ggfs/GridGgfsInvalidPathException.java |   2 +-
 .../org/gridgain/grid/ggfs/GridGgfsMetrics.java |   2 +-
 .../org/gridgain/grid/ggfs/GridGgfsMode.java    |   8 +-
 .../grid/ggfs/GridGgfsOutOfSpaceException.java  |   2 +-
 ...IgniteFsConcurrentModificationException.java |  28 +
 .../grid/ggfs/IgniteFsConfiguration.java        | 801 +++++++++++++++++++
 .../gridgain/grid/ggfs/IgniteFsException.java   |  49 ++
 .../grid/ggfs/mapreduce/GridGgfsTask.java       |   2 +-
 .../grid/ggfs/mapreduce/GridGgfsTaskArgs.java   |   2 +-
 .../org/gridgain/grid/kernal/GridGainEx.java    |   6 +-
 .../ggfs/common/GridGgfsControlResponse.java    |   4 +-
 .../processors/cache/GridCacheAdapter.java      |   4 +-
 .../processors/cache/GridCacheProcessor.java    |   4 +-
 .../kernal/processors/cache/GridCacheUtils.java |   4 +-
 .../processors/ggfs/GridGgfsAsyncImpl.java      |   2 +-
 .../kernal/processors/ggfs/GridGgfsContext.java |   6 +-
 .../processors/ggfs/GridGgfsDataManager.java    |   6 +-
 .../GridGgfsDirectoryNotEmptyException.java     |   2 +-
 .../processors/ggfs/GridGgfsFileInfo.java       |   4 +-
 .../kernal/processors/ggfs/GridGgfsImpl.java    |  10 +-
 .../processors/ggfs/GridGgfsMetaManager.java    |  38 +-
 .../ggfs/GridGgfsOutputStreamImpl.java          |   2 +-
 .../processors/ggfs/GridGgfsProcessor.java      |  12 +-
 .../processors/ggfs/GridGgfsServerManager.java  |   4 +-
 .../visor/node/VisorGgfsConfiguration.java      |   6 +-
 .../grid/kernal/visor/util/VisorTaskUtils.java  |   2 +-
 modules/core/src/test/config/ggfs-loopback.xml  |   2 +-
 .../core/src/test/config/ggfs-no-endpoint.xml   |   2 +-
 modules/core/src/test/config/ggfs-shmem.xml     |   2 +-
 .../ggfs/GridGgfsEventsAbstractSelfTest.java    |   6 +-
 .../GridGgfsFragmentizerAbstractSelfTest.java   |   2 +-
 ...heGgfsPerBlockLruEvictionPolicySelfTest.java |   4 +-
 .../ggfs/GridGgfsAbstractSelfTest.java          |   6 +-
 .../processors/ggfs/GridGgfsCacheSelfTest.java  |   2 +-
 .../ggfs/GridGgfsDataManagerSelfTest.java       |   8 +-
 .../ggfs/GridGgfsMetaManagerSelfTest.java       |   6 +-
 .../ggfs/GridGgfsMetricsSelfTest.java           |   4 +-
 .../processors/ggfs/GridGgfsModesSelfTest.java  |   4 +-
 .../ggfs/GridGgfsProcessorSelfTest.java         |  24 +-
 .../GridGgfsProcessorValidationSelfTest.java    |  32 +-
 ...IpcEndpointRegistrationAbstractSelfTest.java |   6 +-
 ...dpointRegistrationOnLinuxAndMacSelfTest.java |   2 +-
 .../processors/ggfs/GridGgfsSizeSelfTest.java   |   2 +-
 .../ggfs/GridGgfsStreamsSelfTest.java           |   2 +-
 .../processors/ggfs/GridGgfsTaskSelfTest.java   |   2 +-
 .../GridGgfsAbstractRecordResolverSelfTest.java |   2 +-
 .../shmem/GridIpcSharedMemoryNodeStartup.java   |   2 +-
 .../ggfs/hadoop/GridGgfsHadoopParameters.java   |   4 +-
 .../hadoop/v1/GridGgfsHadoopFileSystem.java     |   8 +-
 .../hadoop/v2/GridGgfsHadoopFileSystem.java     |   2 +-
 .../ggfs/hadoop/GridGgfsHadoopEndpoint.java     |   2 +-
 .../hadoop/GridGgfsHadoopFileSystemWrapper.java |  10 +-
 .../fs/GridHadoopDistributedFileSystem.java     |   2 +-
 .../grid/ggfs/GridGgfsEventsTestSuite.java      |  40 +-
 ...dGgfsHadoop20FileSystemAbstractSelfTest.java |   8 +-
 .../GridGgfsHadoopDualAbstractSelfTest.java     |   2 +-
 ...ridGgfsHadoopFileSystemAbstractSelfTest.java |   8 +-
 .../GridGgfsHadoopFileSystemClientSelfTest.java |   2 +-
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |   2 +-
 ...ridGgfsHadoopFileSystemIpcCacheSelfTest.java |   4 +-
 ...GgfsHadoopFileSystemLoggerStateSelfTest.java |   2 +-
 ...fsHadoopFileSystemSecondaryModeSelfTest.java |   4 +-
 .../ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java |   2 +-
 .../hadoop/GridHadoopAbstractSelfTest.java      |   4 +-
 ...idHadoopDefaultMapReducePlannerSelfTest.java |   2 +-
 .../hadoop/GridHadoopTaskExecutionSelfTest.java |   4 +-
 76 files changed, 1078 insertions(+), 1081 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/examples/config/filesystem/example-ggfs.xml
----------------------------------------------------------------------
diff --git a/examples/config/filesystem/example-ggfs.xml b/examples/config/filesystem/example-ggfs.xml
index c038506..9c6ec1c 100644
--- a/examples/config/filesystem/example-ggfs.xml
+++ b/examples/config/filesystem/example-ggfs.xml
@@ -62,7 +62,7 @@
 
         <property name="ggfsConfiguration">
             <list>
-                <bean class="org.gridgain.grid.ggfs.GridGgfsConfiguration">
+                <bean class="org.gridgain.grid.ggfs.IgniteFsConfiguration">
                     <property name="name" value="ggfs"/>
                     <property name="metaCacheName" value="ggfs-meta"/>
                     <property name="dataCacheName" value="ggfs-data"/>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java
index 307d582..8049b75 100644
--- a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java
+++ b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java
@@ -113,7 +113,7 @@ public final class GgfsExample {
                 System.out.println();
                 System.out.println(">>> Deleted " + (isFile ? "file" : "directory") + ": " + path);
             }
-            catch (GridGgfsException e) {
+            catch (IgniteFsException e) {
                 System.out.println();
                 System.out.println(">>> Failed to delete " + (isFile ? "file" : "directory") + " [path=" + path +
                     ", msg=" + e.getMessage() + ']');
@@ -142,7 +142,7 @@ public final class GgfsExample {
             System.out.println();
             System.out.println(">>> Created directory: " + path);
         }
-        catch (GridGgfsException e) {
+        catch (IgniteFsException e) {
             System.out.println();
             System.out.println(">>> Failed to create a directory [path=" + path + ", msg=" + e.getMessage() + ']');
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/apache/ignite/Ignite.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/Ignite.java b/modules/core/src/main/java/org/apache/ignite/Ignite.java
index 2cc3f9c..5c387e2 100644
--- a/modules/core/src/main/java/org/apache/ignite/Ignite.java
+++ b/modules/core/src/main/java/org/apache/ignite/Ignite.java
@@ -16,7 +16,6 @@ import org.apache.ignite.product.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.dr.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.hadoop.*;
 import org.gridgain.grid.security.*;
 import org.gridgain.grid.util.typedef.*;
@@ -215,9 +214,9 @@ public interface Ignite extends AutoCloseable {
      * @param <V> Value type.
      * @param name Cache name.
      * @return Cache instance for given name.
-     * @see GridGgfsConfiguration
-     * @see GridGgfsConfiguration#getDataCacheName()
-     * @see GridGgfsConfiguration#getMetaCacheName()
+     * @see org.gridgain.grid.ggfs.IgniteFsConfiguration
+     * @see org.gridgain.grid.ggfs.IgniteFsConfiguration#getDataCacheName()
+     * @see org.gridgain.grid.ggfs.IgniteFsConfiguration#getMetaCacheName()
      */
     public <K, V> GridCache<K, V> cache(@Nullable String name);
 
@@ -225,9 +224,9 @@ public interface Ignite extends AutoCloseable {
      * Gets all configured caches.
      * Caches that are used as GGFS meta and data caches will not be returned in resulting collection.
      *
-     * @see GridGgfsConfiguration
-     * @see GridGgfsConfiguration#getDataCacheName()
-     * @see GridGgfsConfiguration#getMetaCacheName()
+     * @see org.gridgain.grid.ggfs.IgniteFsConfiguration
+     * @see org.gridgain.grid.ggfs.IgniteFsConfiguration#getDataCacheName()
+     * @see org.gridgain.grid.ggfs.IgniteFsConfiguration#getMetaCacheName()
      * @return All configured caches.
      */
     public Collection<GridCache<?, ?>> caches();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
index d50afd2..21b28fb 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
@@ -67,7 +67,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      *
      * @return GGFS configuration.
      */
-    public GridGgfsConfiguration configuration();
+    public IgniteFsConfiguration configuration();
 
     /**
      * Gets summary (total number of files, total number of directories and total length)
@@ -274,7 +274,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
 
     /**
      * Executes GGFS task with overridden maximum range length (see
-     * {@link GridGgfsConfiguration#getMaximumTaskRangeLength()} for more information).
+     * {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()} for more information).
      * <p>
      * Supports asynchronous execution (see {@link IgniteAsyncSupport}).
      *
@@ -310,7 +310,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
 
     /**
      * Executes GGFS task with overridden maximum range length (see
-     * {@link GridGgfsConfiguration#getMaximumTaskRangeLength()} for more information).
+     * {@link org.gridgain.grid.ggfs.IgniteFsConfiguration#getMaximumTaskRangeLength()} for more information).
      * <p>
      * Supports asynchronous execution (see {@link IgniteAsyncSupport}).
      *

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java b/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
index 72d3fda..4bfb26c 100644
--- a/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
@@ -505,7 +505,7 @@ public class IgniteConfiguration {
     private String[] restAccessibleFolders;
 
     /** GGFS configuration. */
-    private GridGgfsConfiguration[] ggfsCfg;
+    private IgniteFsConfiguration[] ggfsCfg;
 
     /** Client message interceptor. */
     private GridClientMessageInterceptor clientMsgInterceptor;
@@ -2983,7 +2983,7 @@ public class IgniteConfiguration {
      *
      * @return GGFS configurations.
      */
-    public GridGgfsConfiguration[] getGgfsConfiguration() {
+    public IgniteFsConfiguration[] getGgfsConfiguration() {
         return ggfsCfg;
     }
 
@@ -2992,7 +2992,7 @@ public class IgniteConfiguration {
      *
      * @param ggfsCfg GGFS configurations.
      */
-    public void setGgfsConfiguration(GridGgfsConfiguration... ggfsCfg) {
+    public void setGgfsConfiguration(IgniteFsConfiguration... ggfsCfg) {
         this.ggfsCfg = ggfsCfg;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsConcurrentModificationException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsConcurrentModificationException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsConcurrentModificationException.java
deleted file mode 100644
index fa7c38d..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsConcurrentModificationException.java
+++ /dev/null
@@ -1,28 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-/**
- * {@code GGFS} exception indicating that file system structure was modified concurrently. This error
- * indicates that an operation performed in DUAL mode cannot proceed due to these changes.
- */
-public class GridGgfsConcurrentModificationException extends GridGgfsException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Creates new exception.
-     *
-     * @param path Affected path.
-     */
-    public GridGgfsConcurrentModificationException(IgniteFsPath path) {
-        super("File system entry has been modified concurrently: " + path, null);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsConfiguration.java
deleted file mode 100644
index dd97e28..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsConfiguration.java
+++ /dev/null
@@ -1,801 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.gridgain.grid.ggfs.mapreduce.*;
-import org.gridgain.grid.util.typedef.internal.*;
-import org.jetbrains.annotations.*;
-
-import java.util.*;
-import java.util.concurrent.*;
-
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
-
-/**
- * {@code GGFS} configuration. More than one file system can be configured within grid.
- * {@code GGFS} configuration is provided via {@link org.apache.ignite.configuration.IgniteConfiguration#getGgfsConfiguration()}
- * method.
- * <p>
- * Refer to {@code config/hadoop/default-config.xml} or {@code config/hadoop/default-config-client.xml}
- * configuration files under GridGain installation to see sample {@code GGFS} configuration.
- */
-public class GridGgfsConfiguration {
-    /** Default file system user name. */
-    public static final String DFLT_USER_NAME = System.getProperty("user.name", "anonymous");
-
-    /** Default IPC port. */
-    public static final int DFLT_IPC_PORT = 10500;
-
-    /** Default fragmentizer throttling block length. */
-    public static final long DFLT_FRAGMENTIZER_THROTTLING_BLOCK_LENGTH = 16 * 1024 * 1024;
-
-    /** Default fragmentizer throttling delay. */
-    public static final long DFLT_FRAGMENTIZER_THROTTLING_DELAY = 200;
-
-    /** Default fragmentizer concurrent files. */
-    public static final int DFLT_FRAGMENTIZER_CONCURRENT_FILES = 0;
-
-    /** Default fragmentizer local writes ratio. */
-    public static final float DFLT_FRAGMENTIZER_LOCAL_WRITES_RATIO = 0.8f;
-
-    /** Fragmentizer enabled property. */
-    public static final boolean DFLT_FRAGMENTIZER_ENABLED = true;
-
-    /** Default batch size for logging. */
-    public static final int DFLT_GGFS_LOG_BATCH_SIZE = 100;
-
-    /** Default {@code GGFS} log directory. */
-    public static final String DFLT_GGFS_LOG_DIR = "work/ggfs/log";
-
-    /** Default per node buffer size. */
-    public static final int DFLT_PER_NODE_BATCH_SIZE = 100;
-
-    /** Default number of per node parallel operations. */
-    public static final int DFLT_PER_NODE_PARALLEL_BATCH_CNT = 8;
-
-    /** Default GGFS mode. */
-    public static final GridGgfsMode DFLT_MODE = DUAL_ASYNC;
-
-    /** Default file's data block size (bytes). */
-    public static final int DFLT_BLOCK_SIZE = 1 << 16;
-
-    /** Default read/write buffers size (bytes). */
-    public static final int DFLT_BUF_SIZE = 1 << 16;
-
-    /** Default trash directory purge await timeout in case data cache oversize is detected. */
-    public static final long DFLT_TRASH_PURGE_TIMEOUT = 1000;
-
-    /** Default management port. */
-    public static final int DFLT_MGMT_PORT = 11400;
-
-    /** Default IPC endpoint enabled flag. */
-    public static final boolean DFLT_IPC_ENDPOINT_ENABLED = true;
-
-    /** GGFS instance name. */
-    private String name;
-
-    /** Cache name to store GGFS meta information. */
-    private String metaCacheName;
-
-    /** Cache name to store file's data blocks. */
-    private String dataCacheName;
-
-    /** File's data block size (bytes). */
-    private int blockSize = DFLT_BLOCK_SIZE;
-
-    /** The number of pre-fetched blocks if specific file's chunk is requested. */
-    private int prefetchBlocks;
-
-    /** Amount of sequential block reads before prefetch is triggered. */
-    private int seqReadsBeforePrefetch;
-
-    /** Read/write buffers size for stream operations (bytes). */
-    private int bufSize = DFLT_BUF_SIZE;
-
-    /** Per node buffer size. */
-    private int perNodeBatchSize = DFLT_PER_NODE_BATCH_SIZE;
-
-    /** Per node parallel operations. */
-    private int perNodeParallelBatchCnt = DFLT_PER_NODE_PARALLEL_BATCH_CNT;
-
-    /** IPC endpoint properties to publish GGFS over. */
-    private Map<String, String> ipcEndpointCfg;
-
-    /** IPC endpoint enabled flag. */
-    private boolean ipcEndpointEnabled = DFLT_IPC_ENDPOINT_ENABLED;
-
-    /** Management port. */
-    private int mgmtPort = DFLT_MGMT_PORT;
-
-    /** Secondary file system */
-    private GridGgfsFileSystem secondaryFs;
-
-    /** GGFS mode. */
-    private GridGgfsMode dfltMode = DFLT_MODE;
-
-    /** Fragmentizer throttling block length. */
-    private long fragmentizerThrottlingBlockLen = DFLT_FRAGMENTIZER_THROTTLING_BLOCK_LENGTH;
-
-    /** Fragmentizer throttling delay. */
-    private long fragmentizerThrottlingDelay = DFLT_FRAGMENTIZER_THROTTLING_DELAY;
-
-    /** Fragmentizer concurrent files. */
-    private int fragmentizerConcurrentFiles = DFLT_FRAGMENTIZER_CONCURRENT_FILES;
-
-    /** Fragmentizer local writes ratio. */
-    private float fragmentizerLocWritesRatio = DFLT_FRAGMENTIZER_LOCAL_WRITES_RATIO;
-
-    /** Fragmentizer enabled flag. */
-    private boolean fragmentizerEnabled = DFLT_FRAGMENTIZER_ENABLED;
-
-    /** Path modes. */
-    private Map<String, GridGgfsMode> pathModes;
-
-    /** Maximum space. */
-    private long maxSpace;
-
-    /** Trash purge await timeout. */
-    private long trashPurgeTimeout = DFLT_TRASH_PURGE_TIMEOUT;
-
-    /** Dual mode PUT operations executor service. */
-    private ExecutorService dualModePutExec;
-
-    /** Dual mode PUT operations executor service shutdown flag. */
-    private boolean dualModePutExecShutdown;
-
-    /** Maximum amount of data in pending puts. */
-    private long dualModeMaxPendingPutsSize;
-
-    /** Maximum range length. */
-    private long maxTaskRangeLen;
-
-    /**
-     * Constructs default configuration.
-     */
-    public GridGgfsConfiguration() {
-        // No-op.
-    }
-
-    /**
-     * Constructs the copy of the configuration.
-     *
-     * @param cfg Configuration to copy.
-     */
-    public GridGgfsConfiguration(GridGgfsConfiguration cfg) {
-        assert cfg != null;
-
-        /*
-         * Must preserve alphabetical order!
-         */
-        blockSize = cfg.getBlockSize();
-        bufSize = cfg.getStreamBufferSize();
-        dataCacheName = cfg.getDataCacheName();
-        dfltMode = cfg.getDefaultMode();
-        dualModeMaxPendingPutsSize = cfg.getDualModeMaxPendingPutsSize();
-        dualModePutExec = cfg.getDualModePutExecutorService();
-        dualModePutExecShutdown = cfg.getDualModePutExecutorServiceShutdown();
-        fragmentizerConcurrentFiles = cfg.getFragmentizerConcurrentFiles();
-        fragmentizerLocWritesRatio = cfg.getFragmentizerLocalWritesRatio();
-        fragmentizerEnabled = cfg.isFragmentizerEnabled();
-        fragmentizerThrottlingBlockLen = cfg.getFragmentizerThrottlingBlockLength();
-        fragmentizerThrottlingDelay = cfg.getFragmentizerThrottlingDelay();
-        secondaryFs = cfg.getSecondaryFileSystem();
-        ipcEndpointCfg = cfg.getIpcEndpointConfiguration();
-        ipcEndpointEnabled = cfg.isIpcEndpointEnabled();
-        maxSpace = cfg.getMaxSpaceSize();
-        maxTaskRangeLen = cfg.getMaximumTaskRangeLength();
-        metaCacheName = cfg.getMetaCacheName();
-        mgmtPort = cfg.getManagementPort();
-        name = cfg.getName();
-        pathModes = cfg.getPathModes();
-        perNodeBatchSize = cfg.getPerNodeBatchSize();
-        perNodeParallelBatchCnt = cfg.getPerNodeParallelBatchCount();
-        prefetchBlocks = cfg.getPrefetchBlocks();
-        seqReadsBeforePrefetch = cfg.getSequentialReadsBeforePrefetch();
-        trashPurgeTimeout = cfg.getTrashPurgeTimeout();
-    }
-
-    /**
-     * Gets GGFS instance name. If {@code null}, then instance with default
-     * name will be used.
-     *
-     * @return GGFS instance name.
-     */
-    @Nullable public String getName() {
-        return name;
-    }
-
-    /**
-     * Sets GGFS instance name.
-     *
-     * @param name GGFS instance name.
-     */
-    public void setName(String name) {
-        this.name = name;
-    }
-
-    /**
-     * Cache name to store GGFS meta information. If {@code null}, then instance
-     * with default meta-cache name will be used.
-     *
-     * @return Cache name to store GGFS meta information.
-     */
-    @Nullable public String getMetaCacheName() {
-        return metaCacheName;
-    }
-
-    /**
-     * Sets cache name to store GGFS meta information.
-     *
-     * @param metaCacheName Cache name to store GGFS meta information.
-     */
-    public void setMetaCacheName(String metaCacheName) {
-        this.metaCacheName = metaCacheName;
-    }
-
-    /**
-     * Cache name to store GGFS data.
-     *
-     * @return Cache name to store GGFS data.
-     */
-    @Nullable public String getDataCacheName() {
-        return dataCacheName;
-    }
-
-    /**
-     * Sets cache name to store GGFS data.
-     *
-     * @param dataCacheName Cache name to store GGFS data.
-     */
-    public void setDataCacheName(String dataCacheName) {
-        this.dataCacheName = dataCacheName;
-    }
-
-    /**
-     * Get file's data block size.
-     *
-     * @return File's data block size.
-     */
-    public int getBlockSize() {
-        return blockSize;
-    }
-
-    /**
-     * Sets file's data block size.
-     *
-     * @param blockSize File's data block size (bytes) or {@code 0} to reset default value.
-     */
-    public void setBlockSize(int blockSize) {
-        A.ensure(blockSize >= 0, "blockSize >= 0");
-
-        this.blockSize = blockSize == 0 ? DFLT_BLOCK_SIZE : blockSize;
-    }
-
-    /**
-     * Get number of pre-fetched blocks if specific file's chunk is requested.
-     *
-     * @return The number of pre-fetched blocks.
-     */
-    public int getPrefetchBlocks() {
-        return prefetchBlocks;
-    }
-
-    /**
-     * Sets the number of pre-fetched blocks if specific file's chunk is requested.
-     *
-     * @param prefetchBlocks New number of pre-fetched blocks.
-     */
-    public void setPrefetchBlocks(int prefetchBlocks) {
-        A.ensure(prefetchBlocks >= 0, "prefetchBlocks >= 0");
-
-        this.prefetchBlocks = prefetchBlocks;
-    }
-
-    /**
-     * Get amount of sequential block reads before prefetch is triggered. The
-     * higher this value, the longer GGFS will wait before starting to prefetch
-     * values ahead of time. Depending on the use case, this can either help
-     * or hurt performance.
-     * <p>
-     * Default is {@code 0} which means that pre-fetching will start right away.
-     * <h1 class="header">Integration With Hadoop</h1>
-     * This parameter can be also overridden for individual Hadoop MapReduce tasks by passing
-     * {@code org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.PARAM_GGFS_SEQ_READS_BEFORE_PREFETCH}
-     * configuration property directly to Hadoop MapReduce task.
-     * <p>
-     * <b>NOTE:</b> Integration with Hadoop is available only in {@code In-Memory Accelerator For Hadoop} edition.
-     *
-     * @return Amount of sequential block reads.
-     */
-    public int getSequentialReadsBeforePrefetch() {
-        return seqReadsBeforePrefetch;
-    }
-
-    /**
-     * Sets amount of sequential block reads before prefetch is triggered. The
-     * higher this value, the longer GGFS will wait before starting to prefetch
-     * values ahead of time. Depending on the use case, this can either help
-     * or hurt performance.
-     * <p>
-     * Default is {@code 0} which means that pre-fetching will start right away.
-     * <h1 class="header">Integration With Hadoop</h1>
-     * This parameter can be also overridden for individual Hadoop MapReduce tasks by passing
-     * {@code org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.PARAM_GGFS_SEQ_READS_BEFORE_PREFETCH}
-     * configuration property directly to Hadoop MapReduce task.
-     * <p>
-     * <b>NOTE:</b> Integration with Hadoop is available only in {@code In-Memory Accelerator For Hadoop} edition.
-     *
-     * @param seqReadsBeforePrefetch Amount of sequential block reads before prefetch is triggered.
-     */
-    public void setSequentialReadsBeforePrefetch(int seqReadsBeforePrefetch) {
-        A.ensure(seqReadsBeforePrefetch >= 0, "seqReadsBeforePrefetch >= 0");
-
-        this.seqReadsBeforePrefetch = seqReadsBeforePrefetch;
-    }
-
-    /**
-     * Get read/write buffer size for {@code GGFS} stream operations in bytes.
-     *
-     * @return Read/write buffers size (bytes).
-     */
-    public int getStreamBufferSize() {
-        return bufSize;
-    }
-
-    /**
-     * Sets read/write buffers size for {@code GGFS} stream operations (bytes).
-     *
-     * @param bufSize Read/write buffers size for stream operations (bytes) or {@code 0} to reset default value.
-     */
-    public void setStreamBufferSize(int bufSize) {
-        A.ensure(bufSize >= 0, "bufSize >= 0");
-
-        this.bufSize = bufSize == 0 ? DFLT_BUF_SIZE : bufSize;
-    }
-
-    /**
-     * Gets number of file blocks buffered on local node before sending batch to remote node.
-     *
-     * @return Per node buffer size.
-     */
-    public int getPerNodeBatchSize() {
-        return perNodeBatchSize;
-    }
-
-    /**
-     * Sets number of file blocks collected on local node before sending batch to remote node.
-     *
-     * @param perNodeBatchSize Per node buffer size.
-     */
-    public void setPerNodeBatchSize(int perNodeBatchSize) {
-        this.perNodeBatchSize = perNodeBatchSize;
-    }
-
-    /**
-     * Gets number of batches that can be concurrently sent to remote node.
-     *
-     * @return Number of batches for each node.
-     */
-    public int getPerNodeParallelBatchCount() {
-        return perNodeParallelBatchCnt;
-    }
-
-    /**
-     * Sets number of file block batches that can be concurrently sent to remote node.
-     *
-     * @param perNodeParallelBatchCnt Per node parallel load operations.
-     */
-    public void setPerNodeParallelBatchCount(int perNodeParallelBatchCnt) {
-        this.perNodeParallelBatchCnt = perNodeParallelBatchCnt;
-    }
-
-    /**
-     * Gets map of IPC endpoint configuration properties. There are 2 different
-     * types of endpoint supported: {@code shared-memory}, and {@code TCP}.
-     * <p>
-     * The following configuration properties are supported for {@code shared-memory}
-     * endpoint:
-     * <ul>
-     *     <li>{@code type} - value is {@code shmem} to specify {@code shared-memory} approach.</li>
-     *     <li>{@code port} - endpoint port.</li>
-     *     <li>{@code size} - memory size allocated for single endpoint communication.</li>
-     *     <li>
-     *         {@code tokenDirectoryPath} - path, either absolute or relative to {@code GRIDGAIN_HOME} to
-     *         store shared memory tokens.
-     *     </li>
-     * </ul>
-     * <p>
-     * The following configuration properties are supported for {@code TCP} approach:
-     * <ul>
-     *     <li>{@code type} - value is {@code tcp} to specify {@code TCP} approach.</li>
-     *     <li>{@code port} - endpoint bind port.</li>
-     *     <li>
-     *         {@code host} - endpoint bind host. If omitted '127.0.0.1' will be used.
-     *     </li>
-     * </ul>
-     * <p>
-     * Note that {@code shared-memory} approach is not supported on Windows environments.
-     * In case GGFS is failed to bind to particular port, further attempts will be performed every 3 seconds.
-     *
-     * @return Map of IPC endpoint configuration properties. In case the value is not set, defaults will be used. Default
-     * type for Windows is "tcp", for all other platforms - "shmem". Default port is {@link #DFLT_IPC_PORT}.
-     */
-    @Nullable public Map<String,String> getIpcEndpointConfiguration() {
-        return ipcEndpointCfg;
-    }
-
-    /**
-     * Sets IPC endpoint configuration to publish GGFS over.
-     *
-     * @param ipcEndpointCfg Map of IPC endpoint config properties.
-     */
-    public void setIpcEndpointConfiguration(@Nullable Map<String,String> ipcEndpointCfg) {
-        this.ipcEndpointCfg = ipcEndpointCfg;
-    }
-
-    /**
-     * Get IPC endpoint enabled flag. In case it is set to {@code true} endpoint will be created and bound to specific
-     * port. Otherwise endpoint will not be created. Default value is {@link #DFLT_IPC_ENDPOINT_ENABLED}.
-     *
-     * @return {@code True} in case endpoint is enabled.
-     */
-    public boolean isIpcEndpointEnabled() {
-        return ipcEndpointEnabled;
-    }
-
-    /**
-     * Set IPC endpoint enabled flag. See {@link #isIpcEndpointEnabled()}.
-     *
-     * @param ipcEndpointEnabled IPC endpoint enabled flag.
-     */
-    public void setIpcEndpointEnabled(boolean ipcEndpointEnabled) {
-        this.ipcEndpointEnabled = ipcEndpointEnabled;
-    }
-
-    /**
-     * Gets port number for management endpoint. All GGFS nodes should have this port open
-     * for Visor Management Console to work with GGFS.
-     * <p>
-     * Default value is {@link #DFLT_MGMT_PORT}
-     *
-     * @return Port number or {@code -1} if management endpoint should be disabled.
-     */
-    public int getManagementPort() {
-        return mgmtPort;
-    }
-
-    /**
-     * Sets management endpoint port.
-     *
-     * @param mgmtPort port number or {@code -1} to disable management endpoint.
-     */
-    public void setManagementPort(int mgmtPort) {
-        this.mgmtPort = mgmtPort;
-    }
-
-    /**
-     * Gets mode to specify how {@code GGFS} interacts with Hadoop file system, like {@code HDFS}.
-     * Secondary Hadoop file system is provided for pass-through, write-through, and read-through
-     * purposes.
-     * <p>
-     * Default mode is {@link GridGgfsMode#DUAL_ASYNC}. If secondary Hadoop file system is
-     * not configured, this mode will work just like {@link GridGgfsMode#PRIMARY} mode.
-     *
-     * @return Mode to specify how GGFS interacts with secondary HDFS file system.
-     */
-    public GridGgfsMode getDefaultMode() {
-        return dfltMode;
-    }
-
-    /**
-     * Sets {@code GGFS} mode to specify how it should interact with secondary
-     * Hadoop file system, like {@code HDFS}. Secondary Hadoop file system is provided
-     * for pass-through, write-through, and read-through purposes.
-     *
-     * @param dfltMode {@code GGFS} mode.
-     */
-    public void setDefaultMode(GridGgfsMode dfltMode) {
-        this.dfltMode = dfltMode;
-    }
-
-    /**
-     * Gets the secondary file system. Secondary file system is provided for pass-through, write-through,
-     * and read-through purposes.
-     *
-     * @return Secondary file system.
-     */
-    public GridGgfsFileSystem getSecondaryFileSystem() {
-        return secondaryFs;
-    }
-
-    /**
-     * Sets the secondary file system. Secondary file system is provided for pass-through, write-through,
-     * and read-through purposes.
-     *
-     * @param fileSystem
-     */
-    public void setSecondaryFileSystem(GridGgfsFileSystem fileSystem) {
-        secondaryFs = fileSystem;
-    }
-
-    /**
-     * Gets map of path prefixes to {@code GGFS} modes used for them.
-     * <p>
-     * If path doesn't correspond to any specified prefix or mappings are not provided, then
-     * {@link #getDefaultMode()} is used.
-     * <p>
-     * Several folders under {@code '/gridgain'} folder have predefined mappings which cannot be overridden.
-     * <li>{@code /gridgain/primary} and all it's sub-folders will always work in {@code PRIMARY} mode.</li>
-     * <p>
-     * And in case secondary file system URI is provided:
-     * <li>{@code /gridgain/proxy} and all it's sub-folders will always work in {@code PROXY} mode.</li>
-     * <li>{@code /gridgain/sync} and all it's sub-folders will always work in {@code DUAL_SYNC} mode.</li>
-     * <li>{@code /gridgain/async} and all it's sub-folders will always work in {@code DUAL_ASYNC} mode.</li>
-     *
-     * @return Map of paths to {@code GGFS} modes.
-     */
-    @Nullable public Map<String, GridGgfsMode> getPathModes() {
-        return pathModes;
-    }
-
-    /**
-     * Sets map of path prefixes to {@code GGFS} modes used for them.
-     * <p>
-     * If path doesn't correspond to any specified prefix or mappings are not provided, then
-     * {@link #getDefaultMode()} is used.
-     *
-     * @param pathModes Map of paths to {@code GGFS} modes.
-     */
-    public void setPathModes(Map<String, GridGgfsMode> pathModes) {
-        this.pathModes = pathModes;
-    }
-
-    /**
-     * Gets the length of file chunk to send before delaying the fragmentizer.
-     *
-     * @return File chunk length in bytes.
-     */
-    public long getFragmentizerThrottlingBlockLength() {
-        return fragmentizerThrottlingBlockLen;
-    }
-
-    /**
-     * Sets length of file chunk to transmit before throttling is delayed.
-     *
-     * @param fragmentizerThrottlingBlockLen Block length in bytes.
-     */
-    public void setFragmentizerThrottlingBlockLength(long fragmentizerThrottlingBlockLen) {
-        this.fragmentizerThrottlingBlockLen = fragmentizerThrottlingBlockLen;
-    }
-
-    /**
-     * Gets throttle delay for fragmentizer.
-     *
-     * @return Throttle delay in milliseconds.
-     */
-    public long getFragmentizerThrottlingDelay() {
-        return fragmentizerThrottlingDelay;
-    }
-
-    /**
-     * Sets delay in milliseconds for which fragmentizer is paused.
-     *
-     * @param fragmentizerThrottlingDelay Delay in milliseconds.
-     */
-    public void setFragmentizerThrottlingDelay(long fragmentizerThrottlingDelay) {
-        this.fragmentizerThrottlingDelay = fragmentizerThrottlingDelay;
-    }
-
-    /**
-     * Gets number of files that can be processed by fragmentizer concurrently.
-     *
-     * @return Number of files to process concurrently.
-     */
-    public int getFragmentizerConcurrentFiles() {
-        return fragmentizerConcurrentFiles;
-    }
-
-    /**
-     * Sets number of files to process concurrently by fragmentizer.
-     *
-     * @param fragmentizerConcurrentFiles Number of files to process concurrently.
-     */
-    public void setFragmentizerConcurrentFiles(int fragmentizerConcurrentFiles) {
-        this.fragmentizerConcurrentFiles = fragmentizerConcurrentFiles;
-    }
-
-    /**
-     * Gets amount of local memory (in % of local GGFS max space size) available for local writes
-     * during file creation.
-     * <p>
-     * If current GGFS space size is less than {@code fragmentizerLocalWritesRatio * maxSpaceSize},
-     * then file blocks will be written to the local node first and then asynchronously distributed
-     * among cluster nodes (fragmentized).
-     * <p>
-     * Default value is {@link #DFLT_FRAGMENTIZER_LOCAL_WRITES_RATIO}.
-     *
-     * @return Ratio for local writes space.
-     */
-    public float getFragmentizerLocalWritesRatio() {
-        return fragmentizerLocWritesRatio;
-    }
-
-    /**
-     * Sets ratio for space available for local file writes.
-     *
-     * @param fragmentizerLocWritesRatio Ratio for local file writes.
-     * @see #getFragmentizerLocalWritesRatio()
-     */
-    public void setFragmentizerLocalWritesRatio(float fragmentizerLocWritesRatio) {
-        this.fragmentizerLocWritesRatio = fragmentizerLocWritesRatio;
-    }
-
-    /**
-     * Gets flag indicating whether GGFS fragmentizer is enabled. If fragmentizer is disabled, files will be
-     * written in distributed fashion.
-     *
-     * @return Flag indicating whether fragmentizer is enabled.
-     */
-    public boolean isFragmentizerEnabled() {
-        return fragmentizerEnabled;
-    }
-
-    /**
-     * Sets property indicating whether fragmentizer is enabled.
-     *
-     * @param fragmentizerEnabled {@code True} if fragmentizer is enabled.
-     */
-    public void setFragmentizerEnabled(boolean fragmentizerEnabled) {
-        this.fragmentizerEnabled = fragmentizerEnabled;
-    }
-
-    /**
-     * Get maximum space available for data cache to store file system entries.
-     *
-     * @return Maximum space available for data cache.
-     */
-    public long getMaxSpaceSize() {
-        return maxSpace;
-    }
-
-    /**
-     * Set maximum space in bytes available in data cache.
-     *
-     * @param maxSpace Maximum space available in data cache.
-     */
-    public void setMaxSpaceSize(long maxSpace) {
-        this.maxSpace = maxSpace;
-    }
-
-    /**
-     * Gets maximum timeout awaiting for trash purging in case data cache oversize is detected.
-     *
-     * @return Maximum timeout awaiting for trash purging in case data cache oversize is detected.
-     */
-    public long getTrashPurgeTimeout() {
-        return trashPurgeTimeout;
-    }
-
-    /**
-     * Sets maximum timeout awaiting for trash purging in case data cache oversize is detected.
-     *
-     * @param trashPurgeTimeout Maximum timeout awaiting for trash purging in case data cache oversize is detected.
-     */
-    public void setTrashPurgeTimeout(long trashPurgeTimeout) {
-        this.trashPurgeTimeout = trashPurgeTimeout;
-    }
-
-    /**
-     * Get DUAL mode put operation executor service. This executor service will process cache PUT requests for
-     * data which came from the secondary file system and about to be written to GGFS data cache.
-     * In case no executor service is provided, default one will be created with maximum amount of threads equals
-     * to amount of processor cores.
-     *
-     * @return Get DUAL mode put operation executor service
-     */
-    @Nullable public ExecutorService getDualModePutExecutorService() {
-        return dualModePutExec;
-    }
-
-    /**
-     * Set DUAL mode put operations executor service.
-     *
-     * @param dualModePutExec Dual mode put operations executor service.
-     */
-    public void setDualModePutExecutorService(ExecutorService dualModePutExec) {
-        this.dualModePutExec = dualModePutExec;
-    }
-
-    /**
-     * Get DUAL mode put operation executor service shutdown flag.
-     *
-     * @return DUAL mode put operation executor service shutdown flag.
-     */
-    public boolean getDualModePutExecutorServiceShutdown() {
-        return dualModePutExecShutdown;
-    }
-
-    /**
-     * Set DUAL mode put operations executor service shutdown flag.
-     *
-     * @param dualModePutExecShutdown Dual mode put operations executor service shutdown flag.
-     */
-    public void setDualModePutExecutorServiceShutdown(boolean dualModePutExecShutdown) {
-        this.dualModePutExecShutdown = dualModePutExecShutdown;
-    }
-
-    /**
-     * Get maximum amount of pending data read from the secondary file system and waiting to be written to data
-     * cache. {@code 0} or negative value stands for unlimited size.
-     * <p>
-     * By default this value is set to {@code 0}. It is recommended to set positive value in case your
-     * application performs frequent reads of large amount of data from the secondary file system in order to
-     * avoid issues with increasing GC pauses or out-of-memory error.
-     *
-     * @return Maximum amount of pending data read from the secondary file system
-     */
-    public long getDualModeMaxPendingPutsSize() {
-        return dualModeMaxPendingPutsSize;
-    }
-
-    /**
-     * Set maximum amount of data in pending put operations.
-     *
-     * @param dualModeMaxPendingPutsSize Maximum amount of data in pending put operations.
-     */
-    public void setDualModeMaxPendingPutsSize(long dualModeMaxPendingPutsSize) {
-        this.dualModeMaxPendingPutsSize = dualModeMaxPendingPutsSize;
-    }
-
-    /**
-     * Get maximum default range size of a file being split during GGFS task execution. When GGFS task is about to
-     * be executed, it requests file block locations first. Each location is defined as {@link GridGgfsFileRange} which
-     * has length. In case this parameter is set to positive value, then GGFS will split single file range into smaller
-     * ranges with length not greater that this parameter. The only exception to this case is when maximum task range
-     * length is smaller than file block size. In this case maximum task range size will be overridden and set to file
-     * block size.
-     * <p>
-     * Note that this parameter is applied when task is split into jobs before {@link GridGgfsRecordResolver} is
-     * applied. Therefore, final file ranges being assigned to particular jobs could be greater than value of this
-     * parameter depending on file data layout and selected resolver type.
-     * <p>
-     * Setting this parameter might be useful when file is highly colocated and have very long consequent data chunks
-     * so that task execution suffers from insufficient parallelism. E.g., in case you have one GGFS node in topology
-     * and want to process 1Gb file, then only single range of length 1Gb will be returned. This will result in
-     * a single job which will be processed in one thread. But in case you provide this configuration parameter and set
-     * maximum range length to 16Mb, then 64 ranges will be returned resulting in 64 jobs which could be executed in
-     * parallel.
-     * <p>
-     * Note that some {@code GridGgfs.execute()} methods can override value of this parameter.
-     * <p>
-     * In case value of this parameter is set to {@code 0} or negative value, it is simply ignored. Default value is
-     * {@code 0}.
-     *
-     * @return Maximum range size of a file being split during GGFS task execution.
-     */
-    public long getMaximumTaskRangeLength() {
-        return maxTaskRangeLen;
-    }
-
-    /**
-     * Set maximum default range size of a file being split during GGFS task execution.
-     * See {@link #getMaximumTaskRangeLength()} for more details.
-     *
-     * @param maxTaskRangeLen Set maximum default range size of a file being split during GGFS task execution.
-     */
-    public void setMaximumTaskRangeLength(long maxTaskRangeLen) {
-        this.maxTaskRangeLen = maxTaskRangeLen;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridGgfsConfiguration.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsCorruptedFileException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsCorruptedFileException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsCorruptedFileException.java
index 63209a2..4159042 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsCorruptedFileException.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsCorruptedFileException.java
@@ -14,7 +14,7 @@ import org.jetbrains.annotations.*;
 /**
  * Exception thrown when target file's block is not found in data cache.
  */
-public class GridGgfsCorruptedFileException extends GridGgfsException {
+public class GridGgfsCorruptedFileException extends IgniteFsException {
     /** */
     private static final long serialVersionUID = 0L;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsException.java
deleted file mode 100644
index dd315ab..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsException.java
+++ /dev/null
@@ -1,49 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.gridgain.grid.*;
-import org.jetbrains.annotations.*;
-
-/**
- * {@code GGFS} exception thrown by file system components.
- */
-public class GridGgfsException extends GridException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Creates an instance of GGFS exception with descriptive error message.
-     *
-     * @param msg Error message.
-     */
-    public GridGgfsException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * Creates an instance of GGFS exception caused by nested exception.
-     *
-     * @param cause Exception cause.
-     */
-    public GridGgfsException(Throwable cause) {
-        super(cause);
-    }
-
-    /**
-     * Creates an instance of GGFS exception with error message and underlying cause.
-     *
-     * @param msg Error message.
-     * @param cause Exception cause.
-     */
-    public GridGgfsException(String msg, @Nullable Throwable cause) {
-        super(msg, cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidHdfsVersionException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidHdfsVersionException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidHdfsVersionException.java
index b0e0b3a..1bb28c2 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidHdfsVersionException.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidHdfsVersionException.java
@@ -13,7 +13,7 @@ package org.gridgain.grid.ggfs;
  * Exception thrown when GridGain detects that remote HDFS version differs from version of HDFS libraries
  * in GridGain classpath.
  */
-public class GridGgfsInvalidHdfsVersionException extends GridGgfsException {
+public class GridGgfsInvalidHdfsVersionException extends IgniteFsException {
     /** */
     private static final long serialVersionUID = 0L;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidPathException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidPathException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidPathException.java
index 9125d53..76627a8 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidPathException.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidPathException.java
@@ -15,7 +15,7 @@ import org.jetbrains.annotations.*;
  * {@code GGFS} exception indicating that operation target is invalid
  * (e.g. not a file while expecting to be a file).
  */
-public class GridGgfsInvalidPathException extends GridGgfsException {
+public class GridGgfsInvalidPathException extends IgniteFsException {
     /** */
     private static final long serialVersionUID = 0L;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMetrics.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMetrics.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMetrics.java
index a50aea7..31fffea 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMetrics.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMetrics.java
@@ -25,7 +25,7 @@ public interface GridGgfsMetrics {
 
     /**
      * Gets maximum amount of data that can be stored on local node. This metrics is either
-     * equal to {@link GridGgfsConfiguration#getMaxSpaceSize()}, or, if it is {@code 0}, equal to
+     * equal to {@link IgniteFsConfiguration#getMaxSpaceSize()}, or, if it is {@code 0}, equal to
      * {@code 80%} of maximum heap size allocated for JVM.
      *
      * @return Maximum GGFS local space size.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMode.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMode.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMode.java
index 7dc44e1..8bca1e5 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMode.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMode.java
@@ -16,7 +16,7 @@ import org.jetbrains.annotations.*;
  * Secondary Hadoop file system is provided for pass-through, write-through, and
  * read-through purposes.
  * <p>
- * This mode is configured via {@link GridGgfsConfiguration#getDefaultMode()}
+ * This mode is configured via {@link IgniteFsConfiguration#getDefaultMode()}
  * configuration property.
  */
 public enum GridGgfsMode {
@@ -31,7 +31,7 @@ public enum GridGgfsMode {
      * through to secondary Hadoop file system. If this mode is enabled, then
      * secondary Hadoop file system must be configured.
      *
-     * @see GridGgfsConfiguration#getSecondaryHadoopFileSystemUri()
+     * @see IgniteFsConfiguration#getSecondaryHadoopFileSystemUri()
      */
     PROXY,
 
@@ -42,7 +42,7 @@ public enum GridGgfsMode {
      * If secondary Hadoop file system is not configured, then this mode behaves like
      * {@link #PRIMARY} mode.
      *
-     * @see GridGgfsConfiguration#getSecondaryHadoopFileSystemUri()
+     * @see IgniteFsConfiguration#getSecondaryHadoopFileSystemUri()
      */
     DUAL_SYNC,
 
@@ -53,7 +53,7 @@ public enum GridGgfsMode {
      * If secondary Hadoop file system is not configured, then this mode behaves like
      * {@link #PRIMARY} mode.
      *
-     * @see GridGgfsConfiguration#getSecondaryHadoopFileSystemUri()
+     * @see IgniteFsConfiguration#getSecondaryHadoopFileSystemUri()
      */
     DUAL_ASYNC;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsOutOfSpaceException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsOutOfSpaceException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsOutOfSpaceException.java
index 6c75f14..ce5ef3d 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsOutOfSpaceException.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsOutOfSpaceException.java
@@ -16,7 +16,7 @@ import org.jetbrains.annotations.*;
  * It is thrown when number of writes written to a {@code GGFS} data nodes exceeds
  * its maximum value (that is configured per-node).
  */
-public class GridGgfsOutOfSpaceException extends GridGgfsException {
+public class GridGgfsOutOfSpaceException extends IgniteFsException {
     /** */
     private static final long serialVersionUID = 0L;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConcurrentModificationException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConcurrentModificationException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConcurrentModificationException.java
new file mode 100644
index 0000000..fa17228
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConcurrentModificationException.java
@@ -0,0 +1,28 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+/**
+ * {@code GGFS} exception indicating that file system structure was modified concurrently. This error
+ * indicates that an operation performed in DUAL mode cannot proceed due to these changes.
+ */
+public class IgniteFsConcurrentModificationException extends IgniteFsException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Creates new exception.
+     *
+     * @param path Affected path.
+     */
+    public IgniteFsConcurrentModificationException(IgniteFsPath path) {
+        super("File system entry has been modified concurrently: " + path, null);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
new file mode 100644
index 0000000..670a3a2
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
@@ -0,0 +1,801 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+import org.gridgain.grid.ggfs.mapreduce.*;
+import org.gridgain.grid.util.typedef.internal.*;
+import org.jetbrains.annotations.*;
+
+import java.util.*;
+import java.util.concurrent.*;
+
+import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+
+/**
+ * {@code GGFS} configuration. More than one file system can be configured within grid.
+ * {@code GGFS} configuration is provided via {@link org.apache.ignite.configuration.IgniteConfiguration#getGgfsConfiguration()}
+ * method.
+ * <p>
+ * Refer to {@code config/hadoop/default-config.xml} or {@code config/hadoop/default-config-client.xml}
+ * configuration files under GridGain installation to see sample {@code GGFS} configuration.
+ */
+public class IgniteFsConfiguration {
+    /** Default file system user name. */
+    public static final String DFLT_USER_NAME = System.getProperty("user.name", "anonymous");
+
+    /** Default IPC port. */
+    public static final int DFLT_IPC_PORT = 10500;
+
+    /** Default fragmentizer throttling block length. */
+    public static final long DFLT_FRAGMENTIZER_THROTTLING_BLOCK_LENGTH = 16 * 1024 * 1024;
+
+    /** Default fragmentizer throttling delay. */
+    public static final long DFLT_FRAGMENTIZER_THROTTLING_DELAY = 200;
+
+    /** Default fragmentizer concurrent files. */
+    public static final int DFLT_FRAGMENTIZER_CONCURRENT_FILES = 0;
+
+    /** Default fragmentizer local writes ratio. */
+    public static final float DFLT_FRAGMENTIZER_LOCAL_WRITES_RATIO = 0.8f;
+
+    /** Fragmentizer enabled property. */
+    public static final boolean DFLT_FRAGMENTIZER_ENABLED = true;
+
+    /** Default batch size for logging. */
+    public static final int DFLT_GGFS_LOG_BATCH_SIZE = 100;
+
+    /** Default {@code GGFS} log directory. */
+    public static final String DFLT_GGFS_LOG_DIR = "work/ggfs/log";
+
+    /** Default per node buffer size. */
+    public static final int DFLT_PER_NODE_BATCH_SIZE = 100;
+
+    /** Default number of per node parallel operations. */
+    public static final int DFLT_PER_NODE_PARALLEL_BATCH_CNT = 8;
+
+    /** Default GGFS mode. */
+    public static final GridGgfsMode DFLT_MODE = DUAL_ASYNC;
+
+    /** Default file's data block size (bytes). */
+    public static final int DFLT_BLOCK_SIZE = 1 << 16;
+
+    /** Default read/write buffers size (bytes). */
+    public static final int DFLT_BUF_SIZE = 1 << 16;
+
+    /** Default trash directory purge await timeout in case data cache oversize is detected. */
+    public static final long DFLT_TRASH_PURGE_TIMEOUT = 1000;
+
+    /** Default management port. */
+    public static final int DFLT_MGMT_PORT = 11400;
+
+    /** Default IPC endpoint enabled flag. */
+    public static final boolean DFLT_IPC_ENDPOINT_ENABLED = true;
+
+    /** GGFS instance name. */
+    private String name;
+
+    /** Cache name to store GGFS meta information. */
+    private String metaCacheName;
+
+    /** Cache name to store file's data blocks. */
+    private String dataCacheName;
+
+    /** File's data block size (bytes). */
+    private int blockSize = DFLT_BLOCK_SIZE;
+
+    /** The number of pre-fetched blocks if specific file's chunk is requested. */
+    private int prefetchBlocks;
+
+    /** Amount of sequential block reads before prefetch is triggered. */
+    private int seqReadsBeforePrefetch;
+
+    /** Read/write buffers size for stream operations (bytes). */
+    private int bufSize = DFLT_BUF_SIZE;
+
+    /** Per node buffer size. */
+    private int perNodeBatchSize = DFLT_PER_NODE_BATCH_SIZE;
+
+    /** Per node parallel operations. */
+    private int perNodeParallelBatchCnt = DFLT_PER_NODE_PARALLEL_BATCH_CNT;
+
+    /** IPC endpoint properties to publish GGFS over. */
+    private Map<String, String> ipcEndpointCfg;
+
+    /** IPC endpoint enabled flag. */
+    private boolean ipcEndpointEnabled = DFLT_IPC_ENDPOINT_ENABLED;
+
+    /** Management port. */
+    private int mgmtPort = DFLT_MGMT_PORT;
+
+    /** Secondary file system */
+    private GridGgfsFileSystem secondaryFs;
+
+    /** GGFS mode. */
+    private GridGgfsMode dfltMode = DFLT_MODE;
+
+    /** Fragmentizer throttling block length. */
+    private long fragmentizerThrottlingBlockLen = DFLT_FRAGMENTIZER_THROTTLING_BLOCK_LENGTH;
+
+    /** Fragmentizer throttling delay. */
+    private long fragmentizerThrottlingDelay = DFLT_FRAGMENTIZER_THROTTLING_DELAY;
+
+    /** Fragmentizer concurrent files. */
+    private int fragmentizerConcurrentFiles = DFLT_FRAGMENTIZER_CONCURRENT_FILES;
+
+    /** Fragmentizer local writes ratio. */
+    private float fragmentizerLocWritesRatio = DFLT_FRAGMENTIZER_LOCAL_WRITES_RATIO;
+
+    /** Fragmentizer enabled flag. */
+    private boolean fragmentizerEnabled = DFLT_FRAGMENTIZER_ENABLED;
+
+    /** Path modes. */
+    private Map<String, GridGgfsMode> pathModes;
+
+    /** Maximum space. */
+    private long maxSpace;
+
+    /** Trash purge await timeout. */
+    private long trashPurgeTimeout = DFLT_TRASH_PURGE_TIMEOUT;
+
+    /** Dual mode PUT operations executor service. */
+    private ExecutorService dualModePutExec;
+
+    /** Dual mode PUT operations executor service shutdown flag. */
+    private boolean dualModePutExecShutdown;
+
+    /** Maximum amount of data in pending puts. */
+    private long dualModeMaxPendingPutsSize;
+
+    /** Maximum range length. */
+    private long maxTaskRangeLen;
+
+    /**
+     * Constructs default configuration.
+     */
+    public IgniteFsConfiguration() {
+        // No-op.
+    }
+
+    /**
+     * Constructs the copy of the configuration.
+     *
+     * @param cfg Configuration to copy.
+     */
+    public IgniteFsConfiguration(IgniteFsConfiguration cfg) {
+        assert cfg != null;
+
+        /*
+         * Must preserve alphabetical order!
+         */
+        blockSize = cfg.getBlockSize();
+        bufSize = cfg.getStreamBufferSize();
+        dataCacheName = cfg.getDataCacheName();
+        dfltMode = cfg.getDefaultMode();
+        dualModeMaxPendingPutsSize = cfg.getDualModeMaxPendingPutsSize();
+        dualModePutExec = cfg.getDualModePutExecutorService();
+        dualModePutExecShutdown = cfg.getDualModePutExecutorServiceShutdown();
+        fragmentizerConcurrentFiles = cfg.getFragmentizerConcurrentFiles();
+        fragmentizerLocWritesRatio = cfg.getFragmentizerLocalWritesRatio();
+        fragmentizerEnabled = cfg.isFragmentizerEnabled();
+        fragmentizerThrottlingBlockLen = cfg.getFragmentizerThrottlingBlockLength();
+        fragmentizerThrottlingDelay = cfg.getFragmentizerThrottlingDelay();
+        secondaryFs = cfg.getSecondaryFileSystem();
+        ipcEndpointCfg = cfg.getIpcEndpointConfiguration();
+        ipcEndpointEnabled = cfg.isIpcEndpointEnabled();
+        maxSpace = cfg.getMaxSpaceSize();
+        maxTaskRangeLen = cfg.getMaximumTaskRangeLength();
+        metaCacheName = cfg.getMetaCacheName();
+        mgmtPort = cfg.getManagementPort();
+        name = cfg.getName();
+        pathModes = cfg.getPathModes();
+        perNodeBatchSize = cfg.getPerNodeBatchSize();
+        perNodeParallelBatchCnt = cfg.getPerNodeParallelBatchCount();
+        prefetchBlocks = cfg.getPrefetchBlocks();
+        seqReadsBeforePrefetch = cfg.getSequentialReadsBeforePrefetch();
+        trashPurgeTimeout = cfg.getTrashPurgeTimeout();
+    }
+
+    /**
+     * Gets GGFS instance name. If {@code null}, then instance with default
+     * name will be used.
+     *
+     * @return GGFS instance name.
+     */
+    @Nullable public String getName() {
+        return name;
+    }
+
+    /**
+     * Sets GGFS instance name.
+     *
+     * @param name GGFS instance name.
+     */
+    public void setName(String name) {
+        this.name = name;
+    }
+
+    /**
+     * Cache name to store GGFS meta information. If {@code null}, then instance
+     * with default meta-cache name will be used.
+     *
+     * @return Cache name to store GGFS meta information.
+     */
+    @Nullable public String getMetaCacheName() {
+        return metaCacheName;
+    }
+
+    /**
+     * Sets cache name to store GGFS meta information.
+     *
+     * @param metaCacheName Cache name to store GGFS meta information.
+     */
+    public void setMetaCacheName(String metaCacheName) {
+        this.metaCacheName = metaCacheName;
+    }
+
+    /**
+     * Cache name to store GGFS data.
+     *
+     * @return Cache name to store GGFS data.
+     */
+    @Nullable public String getDataCacheName() {
+        return dataCacheName;
+    }
+
+    /**
+     * Sets cache name to store GGFS data.
+     *
+     * @param dataCacheName Cache name to store GGFS data.
+     */
+    public void setDataCacheName(String dataCacheName) {
+        this.dataCacheName = dataCacheName;
+    }
+
+    /**
+     * Get file's data block size.
+     *
+     * @return File's data block size.
+     */
+    public int getBlockSize() {
+        return blockSize;
+    }
+
+    /**
+     * Sets file's data block size.
+     *
+     * @param blockSize File's data block size (bytes) or {@code 0} to reset default value.
+     */
+    public void setBlockSize(int blockSize) {
+        A.ensure(blockSize >= 0, "blockSize >= 0");
+
+        this.blockSize = blockSize == 0 ? DFLT_BLOCK_SIZE : blockSize;
+    }
+
+    /**
+     * Get number of pre-fetched blocks if specific file's chunk is requested.
+     *
+     * @return The number of pre-fetched blocks.
+     */
+    public int getPrefetchBlocks() {
+        return prefetchBlocks;
+    }
+
+    /**
+     * Sets the number of pre-fetched blocks if specific file's chunk is requested.
+     *
+     * @param prefetchBlocks New number of pre-fetched blocks.
+     */
+    public void setPrefetchBlocks(int prefetchBlocks) {
+        A.ensure(prefetchBlocks >= 0, "prefetchBlocks >= 0");
+
+        this.prefetchBlocks = prefetchBlocks;
+    }
+
+    /**
+     * Get amount of sequential block reads before prefetch is triggered. The
+     * higher this value, the longer GGFS will wait before starting to prefetch
+     * values ahead of time. Depending on the use case, this can either help
+     * or hurt performance.
+     * <p>
+     * Default is {@code 0} which means that pre-fetching will start right away.
+     * <h1 class="header">Integration With Hadoop</h1>
+     * This parameter can be also overridden for individual Hadoop MapReduce tasks by passing
+     * {@code org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.PARAM_GGFS_SEQ_READS_BEFORE_PREFETCH}
+     * configuration property directly to Hadoop MapReduce task.
+     * <p>
+     * <b>NOTE:</b> Integration with Hadoop is available only in {@code In-Memory Accelerator For Hadoop} edition.
+     *
+     * @return Amount of sequential block reads.
+     */
+    public int getSequentialReadsBeforePrefetch() {
+        return seqReadsBeforePrefetch;
+    }
+
+    /**
+     * Sets amount of sequential block reads before prefetch is triggered. The
+     * higher this value, the longer GGFS will wait before starting to prefetch
+     * values ahead of time. Depending on the use case, this can either help
+     * or hurt performance.
+     * <p>
+     * Default is {@code 0} which means that pre-fetching will start right away.
+     * <h1 class="header">Integration With Hadoop</h1>
+     * This parameter can be also overridden for individual Hadoop MapReduce tasks by passing
+     * {@code org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.PARAM_GGFS_SEQ_READS_BEFORE_PREFETCH}
+     * configuration property directly to Hadoop MapReduce task.
+     * <p>
+     * <b>NOTE:</b> Integration with Hadoop is available only in {@code In-Memory Accelerator For Hadoop} edition.
+     *
+     * @param seqReadsBeforePrefetch Amount of sequential block reads before prefetch is triggered.
+     */
+    public void setSequentialReadsBeforePrefetch(int seqReadsBeforePrefetch) {
+        A.ensure(seqReadsBeforePrefetch >= 0, "seqReadsBeforePrefetch >= 0");
+
+        this.seqReadsBeforePrefetch = seqReadsBeforePrefetch;
+    }
+
+    /**
+     * Get read/write buffer size for {@code GGFS} stream operations in bytes.
+     *
+     * @return Read/write buffers size (bytes).
+     */
+    public int getStreamBufferSize() {
+        return bufSize;
+    }
+
+    /**
+     * Sets read/write buffers size for {@code GGFS} stream operations (bytes).
+     *
+     * @param bufSize Read/write buffers size for stream operations (bytes) or {@code 0} to reset default value.
+     */
+    public void setStreamBufferSize(int bufSize) {
+        A.ensure(bufSize >= 0, "bufSize >= 0");
+
+        this.bufSize = bufSize == 0 ? DFLT_BUF_SIZE : bufSize;
+    }
+
+    /**
+     * Gets number of file blocks buffered on local node before sending batch to remote node.
+     *
+     * @return Per node buffer size.
+     */
+    public int getPerNodeBatchSize() {
+        return perNodeBatchSize;
+    }
+
+    /**
+     * Sets number of file blocks collected on local node before sending batch to remote node.
+     *
+     * @param perNodeBatchSize Per node buffer size.
+     */
+    public void setPerNodeBatchSize(int perNodeBatchSize) {
+        this.perNodeBatchSize = perNodeBatchSize;
+    }
+
+    /**
+     * Gets number of batches that can be concurrently sent to remote node.
+     *
+     * @return Number of batches for each node.
+     */
+    public int getPerNodeParallelBatchCount() {
+        return perNodeParallelBatchCnt;
+    }
+
+    /**
+     * Sets number of file block batches that can be concurrently sent to remote node.
+     *
+     * @param perNodeParallelBatchCnt Per node parallel load operations.
+     */
+    public void setPerNodeParallelBatchCount(int perNodeParallelBatchCnt) {
+        this.perNodeParallelBatchCnt = perNodeParallelBatchCnt;
+    }
+
+    /**
+     * Gets map of IPC endpoint configuration properties. There are 2 different
+     * types of endpoint supported: {@code shared-memory}, and {@code TCP}.
+     * <p>
+     * The following configuration properties are supported for {@code shared-memory}
+     * endpoint:
+     * <ul>
+     *     <li>{@code type} - value is {@code shmem} to specify {@code shared-memory} approach.</li>
+     *     <li>{@code port} - endpoint port.</li>
+     *     <li>{@code size} - memory size allocated for single endpoint communication.</li>
+     *     <li>
+     *         {@code tokenDirectoryPath} - path, either absolute or relative to {@code GRIDGAIN_HOME} to
+     *         store shared memory tokens.
+     *     </li>
+     * </ul>
+     * <p>
+     * The following configuration properties are supported for {@code TCP} approach:
+     * <ul>
+     *     <li>{@code type} - value is {@code tcp} to specify {@code TCP} approach.</li>
+     *     <li>{@code port} - endpoint bind port.</li>
+     *     <li>
+     *         {@code host} - endpoint bind host. If omitted '127.0.0.1' will be used.
+     *     </li>
+     * </ul>
+     * <p>
+     * Note that {@code shared-memory} approach is not supported on Windows environments.
+     * In case GGFS is failed to bind to particular port, further attempts will be performed every 3 seconds.
+     *
+     * @return Map of IPC endpoint configuration properties. In case the value is not set, defaults will be used. Default
+     * type for Windows is "tcp", for all other platforms - "shmem". Default port is {@link #DFLT_IPC_PORT}.
+     */
+    @Nullable public Map<String,String> getIpcEndpointConfiguration() {
+        return ipcEndpointCfg;
+    }
+
+    /**
+     * Sets IPC endpoint configuration to publish GGFS over.
+     *
+     * @param ipcEndpointCfg Map of IPC endpoint config properties.
+     */
+    public void setIpcEndpointConfiguration(@Nullable Map<String,String> ipcEndpointCfg) {
+        this.ipcEndpointCfg = ipcEndpointCfg;
+    }
+
+    /**
+     * Get IPC endpoint enabled flag. In case it is set to {@code true} endpoint will be created and bound to specific
+     * port. Otherwise endpoint will not be created. Default value is {@link #DFLT_IPC_ENDPOINT_ENABLED}.
+     *
+     * @return {@code True} in case endpoint is enabled.
+     */
+    public boolean isIpcEndpointEnabled() {
+        return ipcEndpointEnabled;
+    }
+
+    /**
+     * Set IPC endpoint enabled flag. See {@link #isIpcEndpointEnabled()}.
+     *
+     * @param ipcEndpointEnabled IPC endpoint enabled flag.
+     */
+    public void setIpcEndpointEnabled(boolean ipcEndpointEnabled) {
+        this.ipcEndpointEnabled = ipcEndpointEnabled;
+    }
+
+    /**
+     * Gets port number for management endpoint. All GGFS nodes should have this port open
+     * for Visor Management Console to work with GGFS.
+     * <p>
+     * Default value is {@link #DFLT_MGMT_PORT}
+     *
+     * @return Port number or {@code -1} if management endpoint should be disabled.
+     */
+    public int getManagementPort() {
+        return mgmtPort;
+    }
+
+    /**
+     * Sets management endpoint port.
+     *
+     * @param mgmtPort port number or {@code -1} to disable management endpoint.
+     */
+    public void setManagementPort(int mgmtPort) {
+        this.mgmtPort = mgmtPort;
+    }
+
+    /**
+     * Gets mode to specify how {@code GGFS} interacts with Hadoop file system, like {@code HDFS}.
+     * Secondary Hadoop file system is provided for pass-through, write-through, and read-through
+     * purposes.
+     * <p>
+     * Default mode is {@link GridGgfsMode#DUAL_ASYNC}. If secondary Hadoop file system is
+     * not configured, this mode will work just like {@link GridGgfsMode#PRIMARY} mode.
+     *
+     * @return Mode to specify how GGFS interacts with secondary HDFS file system.
+     */
+    public GridGgfsMode getDefaultMode() {
+        return dfltMode;
+    }
+
+    /**
+     * Sets {@code GGFS} mode to specify how it should interact with secondary
+     * Hadoop file system, like {@code HDFS}. Secondary Hadoop file system is provided
+     * for pass-through, write-through, and read-through purposes.
+     *
+     * @param dfltMode {@code GGFS} mode.
+     */
+    public void setDefaultMode(GridGgfsMode dfltMode) {
+        this.dfltMode = dfltMode;
+    }
+
+    /**
+     * Gets the secondary file system. Secondary file system is provided for pass-through, write-through,
+     * and read-through purposes.
+     *
+     * @return Secondary file system.
+     */
+    public GridGgfsFileSystem getSecondaryFileSystem() {
+        return secondaryFs;
+    }
+
+    /**
+     * Sets the secondary file system. Secondary file system is provided for pass-through, write-through,
+     * and read-through purposes.
+     *
+     * @param fileSystem
+     */
+    public void setSecondaryFileSystem(GridGgfsFileSystem fileSystem) {
+        secondaryFs = fileSystem;
+    }
+
+    /**
+     * Gets map of path prefixes to {@code GGFS} modes used for them.
+     * <p>
+     * If path doesn't correspond to any specified prefix or mappings are not provided, then
+     * {@link #getDefaultMode()} is used.
+     * <p>
+     * Several folders under {@code '/gridgain'} folder have predefined mappings which cannot be overridden.
+     * <li>{@code /gridgain/primary} and all it's sub-folders will always work in {@code PRIMARY} mode.</li>
+     * <p>
+     * And in case secondary file system URI is provided:
+     * <li>{@code /gridgain/proxy} and all it's sub-folders will always work in {@code PROXY} mode.</li>
+     * <li>{@code /gridgain/sync} and all it's sub-folders will always work in {@code DUAL_SYNC} mode.</li>
+     * <li>{@code /gridgain/async} and all it's sub-folders will always work in {@code DUAL_ASYNC} mode.</li>
+     *
+     * @return Map of paths to {@code GGFS} modes.
+     */
+    @Nullable public Map<String, GridGgfsMode> getPathModes() {
+        return pathModes;
+    }
+
+    /**
+     * Sets map of path prefixes to {@code GGFS} modes used for them.
+     * <p>
+     * If path doesn't correspond to any specified prefix or mappings are not provided, then
+     * {@link #getDefaultMode()} is used.
+     *
+     * @param pathModes Map of paths to {@code GGFS} modes.
+     */
+    public void setPathModes(Map<String, GridGgfsMode> pathModes) {
+        this.pathModes = pathModes;
+    }
+
+    /**
+     * Gets the length of file chunk to send before delaying the fragmentizer.
+     *
+     * @return File chunk length in bytes.
+     */
+    public long getFragmentizerThrottlingBlockLength() {
+        return fragmentizerThrottlingBlockLen;
+    }
+
+    /**
+     * Sets length of file chunk to transmit before throttling is delayed.
+     *
+     * @param fragmentizerThrottlingBlockLen Block length in bytes.
+     */
+    public void setFragmentizerThrottlingBlockLength(long fragmentizerThrottlingBlockLen) {
+        this.fragmentizerThrottlingBlockLen = fragmentizerThrottlingBlockLen;
+    }
+
+    /**
+     * Gets throttle delay for fragmentizer.
+     *
+     * @return Throttle delay in milliseconds.
+     */
+    public long getFragmentizerThrottlingDelay() {
+        return fragmentizerThrottlingDelay;
+    }
+
+    /**
+     * Sets delay in milliseconds for which fragmentizer is paused.
+     *
+     * @param fragmentizerThrottlingDelay Delay in milliseconds.
+     */
+    public void setFragmentizerThrottlingDelay(long fragmentizerThrottlingDelay) {
+        this.fragmentizerThrottlingDelay = fragmentizerThrottlingDelay;
+    }
+
+    /**
+     * Gets number of files that can be processed by fragmentizer concurrently.
+     *
+     * @return Number of files to process concurrently.
+     */
+    public int getFragmentizerConcurrentFiles() {
+        return fragmentizerConcurrentFiles;
+    }
+
+    /**
+     * Sets number of files to process concurrently by fragmentizer.
+     *
+     * @param fragmentizerConcurrentFiles Number of files to process concurrently.
+     */
+    public void setFragmentizerConcurrentFiles(int fragmentizerConcurrentFiles) {
+        this.fragmentizerConcurrentFiles = fragmentizerConcurrentFiles;
+    }
+
+    /**
+     * Gets amount of local memory (in % of local GGFS max space size) available for local writes
+     * during file creation.
+     * <p>
+     * If current GGFS space size is less than {@code fragmentizerLocalWritesRatio * maxSpaceSize},
+     * then file blocks will be written to the local node first and then asynchronously distributed
+     * among cluster nodes (fragmentized).
+     * <p>
+     * Default value is {@link #DFLT_FRAGMENTIZER_LOCAL_WRITES_RATIO}.
+     *
+     * @return Ratio for local writes space.
+     */
+    public float getFragmentizerLocalWritesRatio() {
+        return fragmentizerLocWritesRatio;
+    }
+
+    /**
+     * Sets ratio for space available for local file writes.
+     *
+     * @param fragmentizerLocWritesRatio Ratio for local file writes.
+     * @see #getFragmentizerLocalWritesRatio()
+     */
+    public void setFragmentizerLocalWritesRatio(float fragmentizerLocWritesRatio) {
+        this.fragmentizerLocWritesRatio = fragmentizerLocWritesRatio;
+    }
+
+    /**
+     * Gets flag indicating whether GGFS fragmentizer is enabled. If fragmentizer is disabled, files will be
+     * written in distributed fashion.
+     *
+     * @return Flag indicating whether fragmentizer is enabled.
+     */
+    public boolean isFragmentizerEnabled() {
+        return fragmentizerEnabled;
+    }
+
+    /**
+     * Sets property indicating whether fragmentizer is enabled.
+     *
+     * @param fragmentizerEnabled {@code True} if fragmentizer is enabled.
+     */
+    public void setFragmentizerEnabled(boolean fragmentizerEnabled) {
+        this.fragmentizerEnabled = fragmentizerEnabled;
+    }
+
+    /**
+     * Get maximum space available for data cache to store file system entries.
+     *
+     * @return Maximum space available for data cache.
+     */
+    public long getMaxSpaceSize() {
+        return maxSpace;
+    }
+
+    /**
+     * Set maximum space in bytes available in data cache.
+     *
+     * @param maxSpace Maximum space available in data cache.
+     */
+    public void setMaxSpaceSize(long maxSpace) {
+        this.maxSpace = maxSpace;
+    }
+
+    /**
+     * Gets maximum timeout awaiting for trash purging in case data cache oversize is detected.
+     *
+     * @return Maximum timeout awaiting for trash purging in case data cache oversize is detected.
+     */
+    public long getTrashPurgeTimeout() {
+        return trashPurgeTimeout;
+    }
+
+    /**
+     * Sets maximum timeout awaiting for trash purging in case data cache oversize is detected.
+     *
+     * @param trashPurgeTimeout Maximum timeout awaiting for trash purging in case data cache oversize is detected.
+     */
+    public void setTrashPurgeTimeout(long trashPurgeTimeout) {
+        this.trashPurgeTimeout = trashPurgeTimeout;
+    }
+
+    /**
+     * Get DUAL mode put operation executor service. This executor service will process cache PUT requests for
+     * data which came from the secondary file system and about to be written to GGFS data cache.
+     * In case no executor service is provided, default one will be created with maximum amount of threads equals
+     * to amount of processor cores.
+     *
+     * @return Get DUAL mode put operation executor service
+     */
+    @Nullable public ExecutorService getDualModePutExecutorService() {
+        return dualModePutExec;
+    }
+
+    /**
+     * Set DUAL mode put operations executor service.
+     *
+     * @param dualModePutExec Dual mode put operations executor service.
+     */
+    public void setDualModePutExecutorService(ExecutorService dualModePutExec) {
+        this.dualModePutExec = dualModePutExec;
+    }
+
+    /**
+     * Get DUAL mode put operation executor service shutdown flag.
+     *
+     * @return DUAL mode put operation executor service shutdown flag.
+     */
+    public boolean getDualModePutExecutorServiceShutdown() {
+        return dualModePutExecShutdown;
+    }
+
+    /**
+     * Set DUAL mode put operations executor service shutdown flag.
+     *
+     * @param dualModePutExecShutdown Dual mode put operations executor service shutdown flag.
+     */
+    public void setDualModePutExecutorServiceShutdown(boolean dualModePutExecShutdown) {
+        this.dualModePutExecShutdown = dualModePutExecShutdown;
+    }
+
+    /**
+     * Get maximum amount of pending data read from the secondary file system and waiting to be written to data
+     * cache. {@code 0} or negative value stands for unlimited size.
+     * <p>
+     * By default this value is set to {@code 0}. It is recommended to set positive value in case your
+     * application performs frequent reads of large amount of data from the secondary file system in order to
+     * avoid issues with increasing GC pauses or out-of-memory error.
+     *
+     * @return Maximum amount of pending data read from the secondary file system
+     */
+    public long getDualModeMaxPendingPutsSize() {
+        return dualModeMaxPendingPutsSize;
+    }
+
+    /**
+     * Set maximum amount of data in pending put operations.
+     *
+     * @param dualModeMaxPendingPutsSize Maximum amount of data in pending put operations.
+     */
+    public void setDualModeMaxPendingPutsSize(long dualModeMaxPendingPutsSize) {
+        this.dualModeMaxPendingPutsSize = dualModeMaxPendingPutsSize;
+    }
+
+    /**
+     * Get maximum default range size of a file being split during GGFS task execution. When GGFS task is about to
+     * be executed, it requests file block locations first. Each location is defined as {@link GridGgfsFileRange} which
+     * has length. In case this parameter is set to positive value, then GGFS will split single file range into smaller
+     * ranges with length not greater that this parameter. The only exception to this case is when maximum task range
+     * length is smaller than file block size. In this case maximum task range size will be overridden and set to file
+     * block size.
+     * <p>
+     * Note that this parameter is applied when task is split into jobs before {@link GridGgfsRecordResolver} is
+     * applied. Therefore, final file ranges being assigned to particular jobs could be greater than value of this
+     * parameter depending on file data layout and selected resolver type.
+     * <p>
+     * Setting this parameter might be useful when file is highly colocated and have very long consequent data chunks
+     * so that task execution suffers from insufficient parallelism. E.g., in case you have one GGFS node in topology
+     * and want to process 1Gb file, then only single range of length 1Gb will be returned. This will result in
+     * a single job which will be processed in one thread. But in case you provide this configuration parameter and set
+     * maximum range length to 16Mb, then 64 ranges will be returned resulting in 64 jobs which could be executed in
+     * parallel.
+     * <p>
+     * Note that some {@code GridGgfs.execute()} methods can override value of this parameter.
+     * <p>
+     * In case value of this parameter is set to {@code 0} or negative value, it is simply ignored. Default value is
+     * {@code 0}.
+     *
+     * @return Maximum range size of a file being split during GGFS task execution.
+     */
+    public long getMaximumTaskRangeLength() {
+        return maxTaskRangeLen;
+    }
+
+    /**
+     * Set maximum default range size of a file being split during GGFS task execution.
+     * See {@link #getMaximumTaskRangeLength()} for more details.
+     *
+     * @param maxTaskRangeLen Set maximum default range size of a file being split during GGFS task execution.
+     */
+    public void setMaximumTaskRangeLength(long maxTaskRangeLen) {
+        this.maxTaskRangeLen = maxTaskRangeLen;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsConfiguration.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cd01ed99/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsException.java
new file mode 100644
index 0000000..d72ed40
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsException.java
@@ -0,0 +1,49 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+import org.gridgain.grid.*;
+import org.jetbrains.annotations.*;
+
+/**
+ * {@code GGFS} exception thrown by file system components.
+ */
+public class IgniteFsException extends GridException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Creates an instance of GGFS exception with descriptive error message.
+     *
+     * @param msg Error message.
+     */
+    public IgniteFsException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * Creates an instance of GGFS exception caused by nested exception.
+     *
+     * @param cause Exception cause.
+     */
+    public IgniteFsException(Throwable cause) {
+        super(cause);
+    }
+
+    /**
+     * Creates an instance of GGFS exception with error message and underlying cause.
+     *
+     * @param msg Error message.
+     * @param cause Exception cause.
+     */
+    public IgniteFsException(String msg, @Nullable Throwable cause) {
+        super(msg, cause);
+    }
+}


[31/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsInvalidPathException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsInvalidPathException.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsInvalidPathException.java
new file mode 100644
index 0000000..88962cc
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsInvalidPathException.java
@@ -0,0 +1,49 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+import org.jetbrains.annotations.*;
+
+/**
+ * {@code GGFS} exception indicating that operation target is invalid
+ * (e.g. not a file while expecting to be a file).
+ */
+public class IgniteFsInvalidPathException extends IgniteFsException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Creates exception with given error message.
+     *
+     * @param msg Error message.
+     */
+    public IgniteFsInvalidPathException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * Creates exception with given exception cause.
+     *
+     * @param cause Exception cause.
+     */
+    public IgniteFsInvalidPathException(Throwable cause) {
+        super(cause);
+    }
+
+    /**
+     * Creates exception with given error message and exception cause.
+     *
+     * @param msg Error message.
+     * @param cause Error cause.
+     */
+    public IgniteFsInvalidPathException(String msg, @Nullable Throwable cause) {
+        super(msg, cause);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsMetrics.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsMetrics.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsMetrics.java
new file mode 100644
index 0000000..518761c
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsMetrics.java
@@ -0,0 +1,151 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+/**
+ * {@code GGFS} metrics snapshot for the file system. Note, that some metrics are global and
+ * some are local (i.e. per each node).
+ */
+public interface IgniteFsMetrics {
+    /**
+     * Gets local used space in bytes. This is the sum of all file chunks stored on local node.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Node used space in bytes.
+     */
+    public long localSpaceSize();
+
+    /**
+     * Gets maximum amount of data that can be stored on local node. This metrics is either
+     * equal to {@link IgniteFsConfiguration#getMaxSpaceSize()}, or, if it is {@code 0}, equal to
+     * {@code 80%} of maximum heap size allocated for JVM.
+     *
+     * @return Maximum GGFS local space size.
+     */
+    public long maxSpaceSize();
+
+    /**
+    * Get used space in bytes used in the secondary file system.
+    * <p>
+    * This is a global metric.
+    *
+    * @return Used space in the secondary file system or {@code 0} in case no secondary file system is configured.
+    */
+    public long secondarySpaceSize();
+
+    /**
+     * Gets number of directories created in file system.
+     * <p>
+     * This is a global metric.
+     *
+     * @return Number of directories.
+     */
+    public int directoriesCount();
+
+    /**
+     * Gets number of files stored in file system.
+     * <p>
+     * This is a global metric.
+     *
+     * @return Number of files.
+     */
+    public int filesCount();
+
+    /**
+     * Gets number of files that are currently opened for reading.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Number of opened files.
+     */
+    public int filesOpenedForRead();
+
+    /**
+     * Gets number of files that are currently opened for writing.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Number of opened files.
+     */
+    public int filesOpenedForWrite();
+
+    /**
+     * Gets total blocks read, local and remote.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Total blocks read.
+     */
+    public long blocksReadTotal();
+
+    /**
+     * Gets total remote blocks read.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Total blocks remote read.
+     */
+    public long blocksReadRemote();
+
+    /**
+     * Gets total blocks written, local and remote.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Total blocks written.
+     */
+    public long blocksWrittenTotal();
+
+    /**
+     * Gets total remote blocks written.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Total blocks written.
+     */
+    public long blocksWrittenRemote();
+
+    /**
+     * Gets total bytes read.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Total bytes read.
+     */
+    public long bytesRead();
+
+    /**
+     * Gets total bytes read time.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Total bytes read time.
+     */
+    public long bytesReadTime();
+
+    /**
+     * Gets total bytes written.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Total bytes written.
+     */
+    public long bytesWritten();
+
+    /**
+     * Gets total bytes write time.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Total bytes write time.
+     */
+    public long bytesWriteTime();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsMode.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsMode.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsMode.java
new file mode 100644
index 0000000..4443e90
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsMode.java
@@ -0,0 +1,72 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+import org.jetbrains.annotations.*;
+
+/**
+ * {@code GGFS} mode defining interactions with underlying secondary Hadoop file system.
+ * Secondary Hadoop file system is provided for pass-through, write-through, and
+ * read-through purposes.
+ * <p>
+ * This mode is configured via {@link IgniteFsConfiguration#getDefaultMode()}
+ * configuration property.
+ */
+public enum IgniteFsMode {
+    /**
+     * In this mode GGFS will not delegate to secondary Hadoop file system and will
+     * cache all the files in memory only.
+     */
+    PRIMARY,
+
+    /**
+     * In this mode GGFS will not cache any files in memory and will only pass them
+     * through to secondary Hadoop file system. If this mode is enabled, then
+     * secondary Hadoop file system must be configured.
+     *
+     * @see IgniteFsConfiguration#getSecondaryHadoopFileSystemUri()
+     */
+    PROXY,
+
+    /**
+     * In this mode {@code GGFS} will cache files locally and also <i>synchronously</i>
+     * write them through to secondary Hadoop file system.
+     * <p>
+     * If secondary Hadoop file system is not configured, then this mode behaves like
+     * {@link #PRIMARY} mode.
+     *
+     * @see IgniteFsConfiguration#getSecondaryHadoopFileSystemUri()
+     */
+    DUAL_SYNC,
+
+    /**
+     * In this mode {@code GGFS} will cache files locally and also <i>asynchronously</i>
+     * write them through to secondary Hadoop file system.
+     * <p>
+     * If secondary Hadoop file system is not configured, then this mode behaves like
+     * {@link #PRIMARY} mode.
+     *
+     * @see IgniteFsConfiguration#getSecondaryHadoopFileSystemUri()
+     */
+    DUAL_ASYNC;
+
+    /** Enumerated values. */
+    private static final IgniteFsMode[] VALS = values();
+
+    /**
+     * Efficiently gets enumerated value from its ordinal.
+     *
+     * @param ord Ordinal value.
+     * @return Enumerated value or {@code null} if ordinal out of range.
+     */
+    @Nullable public static IgniteFsMode fromOrdinal(int ord) {
+        return ord >= 0 && ord < VALS.length ? VALS[ord] : null;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsOutOfSpaceException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsOutOfSpaceException.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsOutOfSpaceException.java
new file mode 100644
index 0000000..494570a
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsOutOfSpaceException.java
@@ -0,0 +1,50 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+import org.jetbrains.annotations.*;
+
+/**
+ * {@code GGFS} exception that is thrown when it detected out-of-space condition.
+ * It is thrown when number of writes written to a {@code GGFS} data nodes exceeds
+ * its maximum value (that is configured per-node).
+ */
+public class IgniteFsOutOfSpaceException extends IgniteFsException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Creates exception with given error message.
+     *
+     * @param msg Error message.
+     */
+    public IgniteFsOutOfSpaceException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * Creates an instance of exception with given exception cause.
+     *
+     * @param cause Exception cause.
+     */
+    public IgniteFsOutOfSpaceException(Throwable cause) {
+        super(cause);
+    }
+
+    /**
+     * Creates an instance of GGFS exception with given error message and given exception cause.
+     *
+     * @param msg Error message.
+     * @param cause Exception cause.
+     */
+    public IgniteFsOutOfSpaceException(String msg, @Nullable Throwable cause) {
+        super(msg, cause);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsOutputStream.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsOutputStream.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsOutputStream.java
new file mode 100644
index 0000000..3e7b63f
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsOutputStream.java
@@ -0,0 +1,27 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+import java.io.*;
+
+/**
+ * {@code GGFS} output stream to write data into the file system.
+ */
+public abstract class IgniteFsOutputStream extends OutputStream {
+    /**
+     * Transfers specified amount of bytes from data input to this output stream.
+     * This method is optimized to avoid unnecessary temporal buffer creation and byte array copy.
+     *
+     * @param in Data input to copy bytes from.
+     * @param len Data length to copy.
+     * @throws IOException If write failed, read from input failed or there is no enough data in data input.
+     */
+    public abstract void transferFrom(DataInput in, int len) throws IOException;
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsParentNotDirectoryException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsParentNotDirectoryException.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsParentNotDirectoryException.java
new file mode 100644
index 0000000..106704e
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsParentNotDirectoryException.java
@@ -0,0 +1,42 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+import org.jetbrains.annotations.*;
+
+/**
+ * Exception thrown when parent supposed to be a directory is a file.
+ */
+public class IgniteFsParentNotDirectoryException extends IgniteFsInvalidPathException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * @param msg Error message.
+     */
+    public IgniteFsParentNotDirectoryException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * @param cause Exception cause.
+     */
+    public IgniteFsParentNotDirectoryException(Throwable cause) {
+        super(cause);
+    }
+
+    /**
+     * @param msg Error message.
+     * @param cause Exception cause.
+     */
+    public IgniteFsParentNotDirectoryException(String msg, @Nullable Throwable cause) {
+        super(msg, cause);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsPath.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsPath.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsPath.java
new file mode 100644
index 0000000..017d07a
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsPath.java
@@ -0,0 +1,254 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+import org.gridgain.grid.util.io.*;
+import org.gridgain.grid.util.typedef.*;
+import org.gridgain.grid.util.typedef.internal.*;
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+import java.net.*;
+import java.util.*;
+
+/**
+ * {@code GGFS} path to file in the file system. For example, to get information about
+ * a file you would use the following code:
+ * <pre name="code" class="java">
+ *     GridGgfsPath dirPath = new GridGgfsPath("/my/working/dir");
+ *     GridGgfsPath filePath = new GridGgfsPath(dirPath, "file.txt");
+ *
+ *     // Get metadata about file.
+ *     GridGgfsFile file = ggfs.info(filePath);
+ * </pre>
+ */
+public final class IgniteFsPath implements Comparable<IgniteFsPath>, Externalizable {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** The directory separator character. */
+    private static final char SLASH_CHAR = '/';
+
+    /** The directory separator. */
+    private static final String SLASH = "/";
+
+    /** URI representing this path. Should never change after object creation or de-serialization. */
+    private String path;
+
+    /**
+     * Constructs default root path.
+     */
+    public IgniteFsPath() {
+        path = SLASH;
+    }
+
+    /**
+     * Constructs a path from an URI
+     *
+     * @param uri URI to create path from.
+     */
+    public IgniteFsPath(URI uri) {
+        A.notNull(uri, "uri");
+
+        path = normalizePath(uri.getPath());
+    }
+
+    /**
+     * Constructs a path from the URI string.
+     *
+     * @param path URI string.
+     */
+    public IgniteFsPath(String path) {
+        A.ensure(!F.isEmpty(path), "'path' is null or empty");
+
+        this.path = normalizePath(path);
+    }
+
+    /**
+     * Resolve a child path against a parent path.
+     *
+     * @param parentPath Parent path.
+     * @param childPath Child path.
+     */
+    public IgniteFsPath(IgniteFsPath parentPath, String childPath) {
+        A.notNull(parentPath, "parentPath");
+
+        String path = GridFilenameUtils.concat(parentPath.path, childPath);
+
+        if (F.isEmpty(path))
+            throw new IllegalArgumentException("Failed to parse path" +
+                " [parent=" + parentPath + ", childPath=" + childPath + ']');
+
+        this.path = normalizePath(path);
+    }
+
+    /**
+     * Initialize path with (1) not-null, (2) normalized, (3) absolute and (4) unix-format path component.
+     *
+     * @param path Path.
+     * @return Normalized path.
+     */
+    private static String normalizePath(String path) {
+        assert path != null;
+
+        String normalizedPath = GridFilenameUtils.normalizeNoEndSeparator(path, true);
+
+        if (F.isEmpty(normalizedPath))
+            throw new IllegalArgumentException("Failed to normalize path: " + path);
+
+        if (!SLASH.equals(GridFilenameUtils.getPrefix(normalizedPath)))
+            throw new IllegalArgumentException("Path should be absolute: " + path);
+
+        assert !normalizedPath.isEmpty() : "Expects normalized path is not empty.";
+        assert normalizedPath.length() == 1 || !normalizedPath.endsWith(SLASH) :
+            "Expects normalized path is root or don't ends with '/' symbol.";
+
+        return normalizedPath;
+    }
+
+    /**
+     * Returns the final component of this path.
+     *
+     * @return The final component of this path.
+     */
+    public String name() {
+        return GridFilenameUtils.getName(path);
+    }
+
+    /**
+     * Returns a root for this path.
+     *
+     * @return Root for this path.
+     */
+    public IgniteFsPath root() {
+        return new IgniteFsPath();
+    }
+
+    /**
+     * Split full path on components.
+     *
+     * @return Path components.
+     */
+    public List<String> components() {
+        String path = this.path;
+
+        assert path.length() >= 1 : "Path expected to be absolute: " + path;
+
+        // Path is short-living object, so we don't need to cache component's resolution result.
+        return path.length() == 1 ? Collections.<String>emptyList() : Arrays.asList(path.substring(1).split(SLASH));
+    }
+
+    /**
+     * Returns the parent of a path or {@code null} if at root.
+     *
+     * @return The parent of a path or {@code null} if at root.
+     */
+    @Nullable public IgniteFsPath parent() {
+        String path = this.path;
+
+        if (path.length() == 1)
+            return null; // Current path is root.
+
+        path = GridFilenameUtils.getFullPathNoEndSeparator(path);
+
+        return new IgniteFsPath(path);
+    }
+
+    /**
+     * Adds a suffix to the final name in the path.
+     *
+     * @param suffix Suffix.
+     * @return Path with suffix.
+     */
+    public IgniteFsPath suffix(String suffix) {
+        A.ensure(!F.isEmpty(suffix), "'suffix' is null or empty.");
+        A.ensure(!suffix.contains(SLASH), "'suffix' contains file's separator '" + SLASH + "'");
+
+        return new IgniteFsPath(path + suffix);
+    }
+
+    /**
+     * Return the number of elements in this path.
+     *
+     * @return The number of elements in this path, zero depth means root directory.
+     */
+    public int depth() {
+        final String path = this.path;
+        final int size = path.length();
+
+        assert size >= 1 && path.charAt(0) == SLASH_CHAR : "Expects absolute path: " + path;
+
+        if (size == 1)
+            return 0;
+
+        int depth = 1;
+
+        // Ignore the first character.
+        for (int i = 1; i < size; i++)
+            if (path.charAt(i) == SLASH_CHAR)
+                depth++;
+
+        return depth;
+    }
+
+    /**
+     * Checks whether this path is a sub-directory of argument.
+     *
+     * @param path Path to check.
+     * @return {@code True} if argument is same or a sub-directory of this object.
+     */
+    public boolean isSubDirectoryOf(IgniteFsPath path) {
+        A.notNull(path, "path");
+
+        return this.path.startsWith(path.path.endsWith(SLASH) ? path.path : path.path + SLASH);
+    }
+
+    /**
+     * Checks if paths are identical.
+     *
+     * @param path Path to check.
+     * @return {@code True} if paths are identical.
+     */
+    public boolean isSame(IgniteFsPath path) {
+        A.notNull(path, "path");
+
+        return this == path || this.path.equals(path.path);
+    }
+
+    /** {@inheritDoc} */
+    @Override public int compareTo(IgniteFsPath o) {
+        return path.compareTo(o.path);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void writeExternal(ObjectOutput out) throws IOException {
+        U.writeString(out, path);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readExternal(ObjectInput in) throws IOException {
+        path = U.readString(in);
+    }
+
+    /** {@inheritDoc} */
+    @Override public int hashCode() {
+        return path.hashCode();
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean equals(Object o) {
+        return o == this || o != null && getClass() == o.getClass() && path.equals(((IgniteFsPath)o).path);
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return path;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsPathAlreadyExistsException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsPathAlreadyExistsException.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsPathAlreadyExistsException.java
new file mode 100644
index 0000000..51763b1
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsPathAlreadyExistsException.java
@@ -0,0 +1,42 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+import org.jetbrains.annotations.*;
+
+/**
+ * Exception thrown when target path supposed to be created already exists.
+ */
+public class IgniteFsPathAlreadyExistsException extends IgniteFsInvalidPathException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * @param msg Error message.
+     */
+    public IgniteFsPathAlreadyExistsException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * @param cause Exception cause.
+     */
+    public IgniteFsPathAlreadyExistsException(Throwable cause) {
+        super(cause);
+    }
+
+    /**
+     * @param msg Error message.
+     * @param cause Exception cause.
+     */
+    public IgniteFsPathAlreadyExistsException(String msg, @Nullable Throwable cause) {
+        super(msg, cause);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsPathSummary.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsPathSummary.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsPathSummary.java
new file mode 100644
index 0000000..d4f3e36
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsPathSummary.java
@@ -0,0 +1,130 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+import org.gridgain.grid.util.typedef.internal.*;
+
+import java.io.*;
+
+/**
+ * Path summary: total files count, total directories count, total length.
+ */
+public class IgniteFsPathSummary implements Externalizable {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** Path. */
+    private IgniteFsPath path;
+
+    /** File count. */
+    private int filesCnt;
+
+    /** Directories count. */
+    private int dirCnt;
+
+    /** Length consumed. */
+    private long totalLen;
+
+    /**
+     * Empty constructor required by {@link Externalizable}.
+     */
+    public IgniteFsPathSummary() {
+        // No-op.
+    }
+
+    /**
+     * Construct empty path summary.
+     *
+     * @param path Path.
+     */
+    public IgniteFsPathSummary(IgniteFsPath path) {
+        this.path = path;
+    }
+
+    /**
+     * @return Files count.
+     */
+    public int filesCount() {
+        return filesCnt;
+    }
+
+    /**
+     * @param filesCnt Files count.
+     */
+    public void filesCount(int filesCnt) {
+        this.filesCnt = filesCnt;
+    }
+
+    /**
+     * @return Directories count.
+     */
+    public int directoriesCount() {
+        return dirCnt;
+    }
+
+    /**
+     * @param dirCnt Directories count.
+     */
+    public void directoriesCount(int dirCnt) {
+        this.dirCnt = dirCnt;
+    }
+
+    /**
+     * @return Total length.
+     */
+    public long totalLength() {
+        return totalLen;
+    }
+
+    /**
+     * @param totalLen Total length.
+     */
+    public void totalLength(long totalLen) {
+        this.totalLen = totalLen;
+    }
+
+    /**
+     * @return Path for which summary is obtained.
+     */
+    public IgniteFsPath path() {
+        return path;
+    }
+
+    /**
+     * @param path Path for which summary is obtained.
+     */
+    public void path(IgniteFsPath path) {
+        this.path = path;
+    }
+
+    /** {@inheritDoc} */
+    @Override public void writeExternal(ObjectOutput out) throws IOException {
+        out.writeInt(filesCnt);
+        out.writeInt(dirCnt);
+        out.writeLong(totalLen);
+
+        path.writeExternal(out);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
+        filesCnt = in.readInt();
+        dirCnt = in.readInt();
+        totalLen = in.readLong();
+
+        path = new IgniteFsPath();
+        path.readExternal(in);
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsPathSummary.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsReader.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsReader.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsReader.java
new file mode 100644
index 0000000..1729882
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsReader.java
@@ -0,0 +1,30 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs;
+
+import java.io.*;
+
+/**
+ * The simplest data input interface to read from secondary file system in dual modes.
+ */
+public interface IgniteFsReader extends Closeable {
+    /**
+     * Read up to the specified number of bytes, from a given position within a file, and return the number of bytes
+     * read.
+     *
+     * @param pos Position in the input stream to seek.
+     * @param buf Buffer into which data is read.
+     * @param off Offset in the buffer from which stream data should be written.
+     * @param len The number of bytes to read.
+     * @return Total number of bytes read into the buffer, or -1 if there is no more data (EOF).
+     * @throws IOException In case of any exception.
+     */
+    public int read(long pos, byte[] buf, int off, int len) throws IOException;
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/apache/ignite/fs/package.html
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/package.html b/modules/core/src/main/java/org/apache/ignite/fs/package.html
new file mode 100644
index 0000000..7fa7477
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/package.html
@@ -0,0 +1,15 @@
+<!DOCTYPE html PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+    @html.file.header
+    _________        _____ __________________        _____
+    __  ____/___________(_)______  /__  ____/______ ____(_)_______
+    _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+    / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+    \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+-->
+<html>
+<body>
+    <!-- Package description. -->
+    Contains <b>G</b>rid<b>G</b>ain <b>F</b>ile <b>S</b>ystem APIs.
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/cache/eviction/ggfs/GridCacheGgfsPerBlockLruEvictionPolicy.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/cache/eviction/ggfs/GridCacheGgfsPerBlockLruEvictionPolicy.java b/modules/core/src/main/java/org/gridgain/grid/cache/eviction/ggfs/GridCacheGgfsPerBlockLruEvictionPolicy.java
index 266b45c..3d4d710 100644
--- a/modules/core/src/main/java/org/gridgain/grid/cache/eviction/ggfs/GridCacheGgfsPerBlockLruEvictionPolicy.java
+++ b/modules/core/src/main/java/org/gridgain/grid/cache/eviction/ggfs/GridCacheGgfsPerBlockLruEvictionPolicy.java
@@ -9,10 +9,10 @@
 
 package org.gridgain.grid.cache.eviction.ggfs;
 
+import org.apache.ignite.fs.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.cache.eviction.*;
-import org.gridgain.grid.ggfs.*;
 import org.gridgain.grid.kernal.processors.ggfs.*;
 import org.jdk8.backport.*;
 import org.jdk8.backport.ConcurrentLinkedDeque8.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsBlockLocation.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsBlockLocation.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsBlockLocation.java
deleted file mode 100644
index 403ee3c..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsBlockLocation.java
+++ /dev/null
@@ -1,55 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import java.util.*;
-
-/**
- * {@code GGFS} file's data block location in the grid. It is used to determine
- * node affinity of a certain file block within the Grid by calling
- * {@link org.apache.ignite.IgniteFs#affinity(IgniteFsPath, long, long)} method.
- */
-public interface IgniteFsBlockLocation {
-    /**
-     * Start position in the file this block relates to.
-     *
-     * @return Start position in the file this block relates to.
-     */
-    public long start();
-
-    /**
-     * Length of the data block in the file.
-     *
-     * @return Length of the data block in the file.
-     */
-    public long length();
-
-    /**
-     * Nodes this block belongs to. First node id in collection is
-     * primary node id.
-     *
-     * @return Nodes this block belongs to.
-     */
-    public Collection<UUID> nodeIds();
-
-    /**
-     * Compliant with Hadoop interface.
-     *
-     * @return Collection of host:port addresses.
-     */
-    public Collection<String> names();
-
-    /**
-     * Compliant with Hadoop interface.
-     *
-     * @return Collection of host names.
-     */
-    public Collection<String> hosts();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConcurrentModificationException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConcurrentModificationException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConcurrentModificationException.java
deleted file mode 100644
index fa17228..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConcurrentModificationException.java
+++ /dev/null
@@ -1,28 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-/**
- * {@code GGFS} exception indicating that file system structure was modified concurrently. This error
- * indicates that an operation performed in DUAL mode cannot proceed due to these changes.
- */
-public class IgniteFsConcurrentModificationException extends IgniteFsException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Creates new exception.
-     *
-     * @param path Affected path.
-     */
-    public IgniteFsConcurrentModificationException(IgniteFsPath path) {
-        super("File system entry has been modified concurrently: " + path, null);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
deleted file mode 100644
index 45a009a..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
+++ /dev/null
@@ -1,800 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.gridgain.grid.util.typedef.internal.*;
-import org.jetbrains.annotations.*;
-
-import java.util.*;
-import java.util.concurrent.*;
-
-import static org.gridgain.grid.ggfs.IgniteFsMode.*;
-
-/**
- * {@code GGFS} configuration. More than one file system can be configured within grid.
- * {@code GGFS} configuration is provided via {@link org.apache.ignite.configuration.IgniteConfiguration#getGgfsConfiguration()}
- * method.
- * <p>
- * Refer to {@code config/hadoop/default-config.xml} or {@code config/hadoop/default-config-client.xml}
- * configuration files under GridGain installation to see sample {@code GGFS} configuration.
- */
-public class IgniteFsConfiguration {
-    /** Default file system user name. */
-    public static final String DFLT_USER_NAME = System.getProperty("user.name", "anonymous");
-
-    /** Default IPC port. */
-    public static final int DFLT_IPC_PORT = 10500;
-
-    /** Default fragmentizer throttling block length. */
-    public static final long DFLT_FRAGMENTIZER_THROTTLING_BLOCK_LENGTH = 16 * 1024 * 1024;
-
-    /** Default fragmentizer throttling delay. */
-    public static final long DFLT_FRAGMENTIZER_THROTTLING_DELAY = 200;
-
-    /** Default fragmentizer concurrent files. */
-    public static final int DFLT_FRAGMENTIZER_CONCURRENT_FILES = 0;
-
-    /** Default fragmentizer local writes ratio. */
-    public static final float DFLT_FRAGMENTIZER_LOCAL_WRITES_RATIO = 0.8f;
-
-    /** Fragmentizer enabled property. */
-    public static final boolean DFLT_FRAGMENTIZER_ENABLED = true;
-
-    /** Default batch size for logging. */
-    public static final int DFLT_GGFS_LOG_BATCH_SIZE = 100;
-
-    /** Default {@code GGFS} log directory. */
-    public static final String DFLT_GGFS_LOG_DIR = "work/ggfs/log";
-
-    /** Default per node buffer size. */
-    public static final int DFLT_PER_NODE_BATCH_SIZE = 100;
-
-    /** Default number of per node parallel operations. */
-    public static final int DFLT_PER_NODE_PARALLEL_BATCH_CNT = 8;
-
-    /** Default GGFS mode. */
-    public static final IgniteFsMode DFLT_MODE = DUAL_ASYNC;
-
-    /** Default file's data block size (bytes). */
-    public static final int DFLT_BLOCK_SIZE = 1 << 16;
-
-    /** Default read/write buffers size (bytes). */
-    public static final int DFLT_BUF_SIZE = 1 << 16;
-
-    /** Default trash directory purge await timeout in case data cache oversize is detected. */
-    public static final long DFLT_TRASH_PURGE_TIMEOUT = 1000;
-
-    /** Default management port. */
-    public static final int DFLT_MGMT_PORT = 11400;
-
-    /** Default IPC endpoint enabled flag. */
-    public static final boolean DFLT_IPC_ENDPOINT_ENABLED = true;
-
-    /** GGFS instance name. */
-    private String name;
-
-    /** Cache name to store GGFS meta information. */
-    private String metaCacheName;
-
-    /** Cache name to store file's data blocks. */
-    private String dataCacheName;
-
-    /** File's data block size (bytes). */
-    private int blockSize = DFLT_BLOCK_SIZE;
-
-    /** The number of pre-fetched blocks if specific file's chunk is requested. */
-    private int prefetchBlocks;
-
-    /** Amount of sequential block reads before prefetch is triggered. */
-    private int seqReadsBeforePrefetch;
-
-    /** Read/write buffers size for stream operations (bytes). */
-    private int bufSize = DFLT_BUF_SIZE;
-
-    /** Per node buffer size. */
-    private int perNodeBatchSize = DFLT_PER_NODE_BATCH_SIZE;
-
-    /** Per node parallel operations. */
-    private int perNodeParallelBatchCnt = DFLT_PER_NODE_PARALLEL_BATCH_CNT;
-
-    /** IPC endpoint properties to publish GGFS over. */
-    private Map<String, String> ipcEndpointCfg;
-
-    /** IPC endpoint enabled flag. */
-    private boolean ipcEndpointEnabled = DFLT_IPC_ENDPOINT_ENABLED;
-
-    /** Management port. */
-    private int mgmtPort = DFLT_MGMT_PORT;
-
-    /** Secondary file system */
-    private IgniteFsFileSystem secondaryFs;
-
-    /** GGFS mode. */
-    private IgniteFsMode dfltMode = DFLT_MODE;
-
-    /** Fragmentizer throttling block length. */
-    private long fragmentizerThrottlingBlockLen = DFLT_FRAGMENTIZER_THROTTLING_BLOCK_LENGTH;
-
-    /** Fragmentizer throttling delay. */
-    private long fragmentizerThrottlingDelay = DFLT_FRAGMENTIZER_THROTTLING_DELAY;
-
-    /** Fragmentizer concurrent files. */
-    private int fragmentizerConcurrentFiles = DFLT_FRAGMENTIZER_CONCURRENT_FILES;
-
-    /** Fragmentizer local writes ratio. */
-    private float fragmentizerLocWritesRatio = DFLT_FRAGMENTIZER_LOCAL_WRITES_RATIO;
-
-    /** Fragmentizer enabled flag. */
-    private boolean fragmentizerEnabled = DFLT_FRAGMENTIZER_ENABLED;
-
-    /** Path modes. */
-    private Map<String, IgniteFsMode> pathModes;
-
-    /** Maximum space. */
-    private long maxSpace;
-
-    /** Trash purge await timeout. */
-    private long trashPurgeTimeout = DFLT_TRASH_PURGE_TIMEOUT;
-
-    /** Dual mode PUT operations executor service. */
-    private ExecutorService dualModePutExec;
-
-    /** Dual mode PUT operations executor service shutdown flag. */
-    private boolean dualModePutExecShutdown;
-
-    /** Maximum amount of data in pending puts. */
-    private long dualModeMaxPendingPutsSize;
-
-    /** Maximum range length. */
-    private long maxTaskRangeLen;
-
-    /**
-     * Constructs default configuration.
-     */
-    public IgniteFsConfiguration() {
-        // No-op.
-    }
-
-    /**
-     * Constructs the copy of the configuration.
-     *
-     * @param cfg Configuration to copy.
-     */
-    public IgniteFsConfiguration(IgniteFsConfiguration cfg) {
-        assert cfg != null;
-
-        /*
-         * Must preserve alphabetical order!
-         */
-        blockSize = cfg.getBlockSize();
-        bufSize = cfg.getStreamBufferSize();
-        dataCacheName = cfg.getDataCacheName();
-        dfltMode = cfg.getDefaultMode();
-        dualModeMaxPendingPutsSize = cfg.getDualModeMaxPendingPutsSize();
-        dualModePutExec = cfg.getDualModePutExecutorService();
-        dualModePutExecShutdown = cfg.getDualModePutExecutorServiceShutdown();
-        fragmentizerConcurrentFiles = cfg.getFragmentizerConcurrentFiles();
-        fragmentizerLocWritesRatio = cfg.getFragmentizerLocalWritesRatio();
-        fragmentizerEnabled = cfg.isFragmentizerEnabled();
-        fragmentizerThrottlingBlockLen = cfg.getFragmentizerThrottlingBlockLength();
-        fragmentizerThrottlingDelay = cfg.getFragmentizerThrottlingDelay();
-        secondaryFs = cfg.getSecondaryFileSystem();
-        ipcEndpointCfg = cfg.getIpcEndpointConfiguration();
-        ipcEndpointEnabled = cfg.isIpcEndpointEnabled();
-        maxSpace = cfg.getMaxSpaceSize();
-        maxTaskRangeLen = cfg.getMaximumTaskRangeLength();
-        metaCacheName = cfg.getMetaCacheName();
-        mgmtPort = cfg.getManagementPort();
-        name = cfg.getName();
-        pathModes = cfg.getPathModes();
-        perNodeBatchSize = cfg.getPerNodeBatchSize();
-        perNodeParallelBatchCnt = cfg.getPerNodeParallelBatchCount();
-        prefetchBlocks = cfg.getPrefetchBlocks();
-        seqReadsBeforePrefetch = cfg.getSequentialReadsBeforePrefetch();
-        trashPurgeTimeout = cfg.getTrashPurgeTimeout();
-    }
-
-    /**
-     * Gets GGFS instance name. If {@code null}, then instance with default
-     * name will be used.
-     *
-     * @return GGFS instance name.
-     */
-    @Nullable public String getName() {
-        return name;
-    }
-
-    /**
-     * Sets GGFS instance name.
-     *
-     * @param name GGFS instance name.
-     */
-    public void setName(String name) {
-        this.name = name;
-    }
-
-    /**
-     * Cache name to store GGFS meta information. If {@code null}, then instance
-     * with default meta-cache name will be used.
-     *
-     * @return Cache name to store GGFS meta information.
-     */
-    @Nullable public String getMetaCacheName() {
-        return metaCacheName;
-    }
-
-    /**
-     * Sets cache name to store GGFS meta information.
-     *
-     * @param metaCacheName Cache name to store GGFS meta information.
-     */
-    public void setMetaCacheName(String metaCacheName) {
-        this.metaCacheName = metaCacheName;
-    }
-
-    /**
-     * Cache name to store GGFS data.
-     *
-     * @return Cache name to store GGFS data.
-     */
-    @Nullable public String getDataCacheName() {
-        return dataCacheName;
-    }
-
-    /**
-     * Sets cache name to store GGFS data.
-     *
-     * @param dataCacheName Cache name to store GGFS data.
-     */
-    public void setDataCacheName(String dataCacheName) {
-        this.dataCacheName = dataCacheName;
-    }
-
-    /**
-     * Get file's data block size.
-     *
-     * @return File's data block size.
-     */
-    public int getBlockSize() {
-        return blockSize;
-    }
-
-    /**
-     * Sets file's data block size.
-     *
-     * @param blockSize File's data block size (bytes) or {@code 0} to reset default value.
-     */
-    public void setBlockSize(int blockSize) {
-        A.ensure(blockSize >= 0, "blockSize >= 0");
-
-        this.blockSize = blockSize == 0 ? DFLT_BLOCK_SIZE : blockSize;
-    }
-
-    /**
-     * Get number of pre-fetched blocks if specific file's chunk is requested.
-     *
-     * @return The number of pre-fetched blocks.
-     */
-    public int getPrefetchBlocks() {
-        return prefetchBlocks;
-    }
-
-    /**
-     * Sets the number of pre-fetched blocks if specific file's chunk is requested.
-     *
-     * @param prefetchBlocks New number of pre-fetched blocks.
-     */
-    public void setPrefetchBlocks(int prefetchBlocks) {
-        A.ensure(prefetchBlocks >= 0, "prefetchBlocks >= 0");
-
-        this.prefetchBlocks = prefetchBlocks;
-    }
-
-    /**
-     * Get amount of sequential block reads before prefetch is triggered. The
-     * higher this value, the longer GGFS will wait before starting to prefetch
-     * values ahead of time. Depending on the use case, this can either help
-     * or hurt performance.
-     * <p>
-     * Default is {@code 0} which means that pre-fetching will start right away.
-     * <h1 class="header">Integration With Hadoop</h1>
-     * This parameter can be also overridden for individual Hadoop MapReduce tasks by passing
-     * {@code org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.PARAM_GGFS_SEQ_READS_BEFORE_PREFETCH}
-     * configuration property directly to Hadoop MapReduce task.
-     * <p>
-     * <b>NOTE:</b> Integration with Hadoop is available only in {@code In-Memory Accelerator For Hadoop} edition.
-     *
-     * @return Amount of sequential block reads.
-     */
-    public int getSequentialReadsBeforePrefetch() {
-        return seqReadsBeforePrefetch;
-    }
-
-    /**
-     * Sets amount of sequential block reads before prefetch is triggered. The
-     * higher this value, the longer GGFS will wait before starting to prefetch
-     * values ahead of time. Depending on the use case, this can either help
-     * or hurt performance.
-     * <p>
-     * Default is {@code 0} which means that pre-fetching will start right away.
-     * <h1 class="header">Integration With Hadoop</h1>
-     * This parameter can be also overridden for individual Hadoop MapReduce tasks by passing
-     * {@code org.gridgain.grid.ggfs.hadoop.GridGgfsHadoopParameters.PARAM_GGFS_SEQ_READS_BEFORE_PREFETCH}
-     * configuration property directly to Hadoop MapReduce task.
-     * <p>
-     * <b>NOTE:</b> Integration with Hadoop is available only in {@code In-Memory Accelerator For Hadoop} edition.
-     *
-     * @param seqReadsBeforePrefetch Amount of sequential block reads before prefetch is triggered.
-     */
-    public void setSequentialReadsBeforePrefetch(int seqReadsBeforePrefetch) {
-        A.ensure(seqReadsBeforePrefetch >= 0, "seqReadsBeforePrefetch >= 0");
-
-        this.seqReadsBeforePrefetch = seqReadsBeforePrefetch;
-    }
-
-    /**
-     * Get read/write buffer size for {@code GGFS} stream operations in bytes.
-     *
-     * @return Read/write buffers size (bytes).
-     */
-    public int getStreamBufferSize() {
-        return bufSize;
-    }
-
-    /**
-     * Sets read/write buffers size for {@code GGFS} stream operations (bytes).
-     *
-     * @param bufSize Read/write buffers size for stream operations (bytes) or {@code 0} to reset default value.
-     */
-    public void setStreamBufferSize(int bufSize) {
-        A.ensure(bufSize >= 0, "bufSize >= 0");
-
-        this.bufSize = bufSize == 0 ? DFLT_BUF_SIZE : bufSize;
-    }
-
-    /**
-     * Gets number of file blocks buffered on local node before sending batch to remote node.
-     *
-     * @return Per node buffer size.
-     */
-    public int getPerNodeBatchSize() {
-        return perNodeBatchSize;
-    }
-
-    /**
-     * Sets number of file blocks collected on local node before sending batch to remote node.
-     *
-     * @param perNodeBatchSize Per node buffer size.
-     */
-    public void setPerNodeBatchSize(int perNodeBatchSize) {
-        this.perNodeBatchSize = perNodeBatchSize;
-    }
-
-    /**
-     * Gets number of batches that can be concurrently sent to remote node.
-     *
-     * @return Number of batches for each node.
-     */
-    public int getPerNodeParallelBatchCount() {
-        return perNodeParallelBatchCnt;
-    }
-
-    /**
-     * Sets number of file block batches that can be concurrently sent to remote node.
-     *
-     * @param perNodeParallelBatchCnt Per node parallel load operations.
-     */
-    public void setPerNodeParallelBatchCount(int perNodeParallelBatchCnt) {
-        this.perNodeParallelBatchCnt = perNodeParallelBatchCnt;
-    }
-
-    /**
-     * Gets map of IPC endpoint configuration properties. There are 2 different
-     * types of endpoint supported: {@code shared-memory}, and {@code TCP}.
-     * <p>
-     * The following configuration properties are supported for {@code shared-memory}
-     * endpoint:
-     * <ul>
-     *     <li>{@code type} - value is {@code shmem} to specify {@code shared-memory} approach.</li>
-     *     <li>{@code port} - endpoint port.</li>
-     *     <li>{@code size} - memory size allocated for single endpoint communication.</li>
-     *     <li>
-     *         {@code tokenDirectoryPath} - path, either absolute or relative to {@code GRIDGAIN_HOME} to
-     *         store shared memory tokens.
-     *     </li>
-     * </ul>
-     * <p>
-     * The following configuration properties are supported for {@code TCP} approach:
-     * <ul>
-     *     <li>{@code type} - value is {@code tcp} to specify {@code TCP} approach.</li>
-     *     <li>{@code port} - endpoint bind port.</li>
-     *     <li>
-     *         {@code host} - endpoint bind host. If omitted '127.0.0.1' will be used.
-     *     </li>
-     * </ul>
-     * <p>
-     * Note that {@code shared-memory} approach is not supported on Windows environments.
-     * In case GGFS is failed to bind to particular port, further attempts will be performed every 3 seconds.
-     *
-     * @return Map of IPC endpoint configuration properties. In case the value is not set, defaults will be used. Default
-     * type for Windows is "tcp", for all other platforms - "shmem". Default port is {@link #DFLT_IPC_PORT}.
-     */
-    @Nullable public Map<String,String> getIpcEndpointConfiguration() {
-        return ipcEndpointCfg;
-    }
-
-    /**
-     * Sets IPC endpoint configuration to publish GGFS over.
-     *
-     * @param ipcEndpointCfg Map of IPC endpoint config properties.
-     */
-    public void setIpcEndpointConfiguration(@Nullable Map<String,String> ipcEndpointCfg) {
-        this.ipcEndpointCfg = ipcEndpointCfg;
-    }
-
-    /**
-     * Get IPC endpoint enabled flag. In case it is set to {@code true} endpoint will be created and bound to specific
-     * port. Otherwise endpoint will not be created. Default value is {@link #DFLT_IPC_ENDPOINT_ENABLED}.
-     *
-     * @return {@code True} in case endpoint is enabled.
-     */
-    public boolean isIpcEndpointEnabled() {
-        return ipcEndpointEnabled;
-    }
-
-    /**
-     * Set IPC endpoint enabled flag. See {@link #isIpcEndpointEnabled()}.
-     *
-     * @param ipcEndpointEnabled IPC endpoint enabled flag.
-     */
-    public void setIpcEndpointEnabled(boolean ipcEndpointEnabled) {
-        this.ipcEndpointEnabled = ipcEndpointEnabled;
-    }
-
-    /**
-     * Gets port number for management endpoint. All GGFS nodes should have this port open
-     * for Visor Management Console to work with GGFS.
-     * <p>
-     * Default value is {@link #DFLT_MGMT_PORT}
-     *
-     * @return Port number or {@code -1} if management endpoint should be disabled.
-     */
-    public int getManagementPort() {
-        return mgmtPort;
-    }
-
-    /**
-     * Sets management endpoint port.
-     *
-     * @param mgmtPort port number or {@code -1} to disable management endpoint.
-     */
-    public void setManagementPort(int mgmtPort) {
-        this.mgmtPort = mgmtPort;
-    }
-
-    /**
-     * Gets mode to specify how {@code GGFS} interacts with Hadoop file system, like {@code HDFS}.
-     * Secondary Hadoop file system is provided for pass-through, write-through, and read-through
-     * purposes.
-     * <p>
-     * Default mode is {@link IgniteFsMode#DUAL_ASYNC}. If secondary Hadoop file system is
-     * not configured, this mode will work just like {@link IgniteFsMode#PRIMARY} mode.
-     *
-     * @return Mode to specify how GGFS interacts with secondary HDFS file system.
-     */
-    public IgniteFsMode getDefaultMode() {
-        return dfltMode;
-    }
-
-    /**
-     * Sets {@code GGFS} mode to specify how it should interact with secondary
-     * Hadoop file system, like {@code HDFS}. Secondary Hadoop file system is provided
-     * for pass-through, write-through, and read-through purposes.
-     *
-     * @param dfltMode {@code GGFS} mode.
-     */
-    public void setDefaultMode(IgniteFsMode dfltMode) {
-        this.dfltMode = dfltMode;
-    }
-
-    /**
-     * Gets the secondary file system. Secondary file system is provided for pass-through, write-through,
-     * and read-through purposes.
-     *
-     * @return Secondary file system.
-     */
-    public IgniteFsFileSystem getSecondaryFileSystem() {
-        return secondaryFs;
-    }
-
-    /**
-     * Sets the secondary file system. Secondary file system is provided for pass-through, write-through,
-     * and read-through purposes.
-     *
-     * @param fileSystem
-     */
-    public void setSecondaryFileSystem(IgniteFsFileSystem fileSystem) {
-        secondaryFs = fileSystem;
-    }
-
-    /**
-     * Gets map of path prefixes to {@code GGFS} modes used for them.
-     * <p>
-     * If path doesn't correspond to any specified prefix or mappings are not provided, then
-     * {@link #getDefaultMode()} is used.
-     * <p>
-     * Several folders under {@code '/gridgain'} folder have predefined mappings which cannot be overridden.
-     * <li>{@code /gridgain/primary} and all it's sub-folders will always work in {@code PRIMARY} mode.</li>
-     * <p>
-     * And in case secondary file system URI is provided:
-     * <li>{@code /gridgain/proxy} and all it's sub-folders will always work in {@code PROXY} mode.</li>
-     * <li>{@code /gridgain/sync} and all it's sub-folders will always work in {@code DUAL_SYNC} mode.</li>
-     * <li>{@code /gridgain/async} and all it's sub-folders will always work in {@code DUAL_ASYNC} mode.</li>
-     *
-     * @return Map of paths to {@code GGFS} modes.
-     */
-    @Nullable public Map<String, IgniteFsMode> getPathModes() {
-        return pathModes;
-    }
-
-    /**
-     * Sets map of path prefixes to {@code GGFS} modes used for them.
-     * <p>
-     * If path doesn't correspond to any specified prefix or mappings are not provided, then
-     * {@link #getDefaultMode()} is used.
-     *
-     * @param pathModes Map of paths to {@code GGFS} modes.
-     */
-    public void setPathModes(Map<String, IgniteFsMode> pathModes) {
-        this.pathModes = pathModes;
-    }
-
-    /**
-     * Gets the length of file chunk to send before delaying the fragmentizer.
-     *
-     * @return File chunk length in bytes.
-     */
-    public long getFragmentizerThrottlingBlockLength() {
-        return fragmentizerThrottlingBlockLen;
-    }
-
-    /**
-     * Sets length of file chunk to transmit before throttling is delayed.
-     *
-     * @param fragmentizerThrottlingBlockLen Block length in bytes.
-     */
-    public void setFragmentizerThrottlingBlockLength(long fragmentizerThrottlingBlockLen) {
-        this.fragmentizerThrottlingBlockLen = fragmentizerThrottlingBlockLen;
-    }
-
-    /**
-     * Gets throttle delay for fragmentizer.
-     *
-     * @return Throttle delay in milliseconds.
-     */
-    public long getFragmentizerThrottlingDelay() {
-        return fragmentizerThrottlingDelay;
-    }
-
-    /**
-     * Sets delay in milliseconds for which fragmentizer is paused.
-     *
-     * @param fragmentizerThrottlingDelay Delay in milliseconds.
-     */
-    public void setFragmentizerThrottlingDelay(long fragmentizerThrottlingDelay) {
-        this.fragmentizerThrottlingDelay = fragmentizerThrottlingDelay;
-    }
-
-    /**
-     * Gets number of files that can be processed by fragmentizer concurrently.
-     *
-     * @return Number of files to process concurrently.
-     */
-    public int getFragmentizerConcurrentFiles() {
-        return fragmentizerConcurrentFiles;
-    }
-
-    /**
-     * Sets number of files to process concurrently by fragmentizer.
-     *
-     * @param fragmentizerConcurrentFiles Number of files to process concurrently.
-     */
-    public void setFragmentizerConcurrentFiles(int fragmentizerConcurrentFiles) {
-        this.fragmentizerConcurrentFiles = fragmentizerConcurrentFiles;
-    }
-
-    /**
-     * Gets amount of local memory (in % of local GGFS max space size) available for local writes
-     * during file creation.
-     * <p>
-     * If current GGFS space size is less than {@code fragmentizerLocalWritesRatio * maxSpaceSize},
-     * then file blocks will be written to the local node first and then asynchronously distributed
-     * among cluster nodes (fragmentized).
-     * <p>
-     * Default value is {@link #DFLT_FRAGMENTIZER_LOCAL_WRITES_RATIO}.
-     *
-     * @return Ratio for local writes space.
-     */
-    public float getFragmentizerLocalWritesRatio() {
-        return fragmentizerLocWritesRatio;
-    }
-
-    /**
-     * Sets ratio for space available for local file writes.
-     *
-     * @param fragmentizerLocWritesRatio Ratio for local file writes.
-     * @see #getFragmentizerLocalWritesRatio()
-     */
-    public void setFragmentizerLocalWritesRatio(float fragmentizerLocWritesRatio) {
-        this.fragmentizerLocWritesRatio = fragmentizerLocWritesRatio;
-    }
-
-    /**
-     * Gets flag indicating whether GGFS fragmentizer is enabled. If fragmentizer is disabled, files will be
-     * written in distributed fashion.
-     *
-     * @return Flag indicating whether fragmentizer is enabled.
-     */
-    public boolean isFragmentizerEnabled() {
-        return fragmentizerEnabled;
-    }
-
-    /**
-     * Sets property indicating whether fragmentizer is enabled.
-     *
-     * @param fragmentizerEnabled {@code True} if fragmentizer is enabled.
-     */
-    public void setFragmentizerEnabled(boolean fragmentizerEnabled) {
-        this.fragmentizerEnabled = fragmentizerEnabled;
-    }
-
-    /**
-     * Get maximum space available for data cache to store file system entries.
-     *
-     * @return Maximum space available for data cache.
-     */
-    public long getMaxSpaceSize() {
-        return maxSpace;
-    }
-
-    /**
-     * Set maximum space in bytes available in data cache.
-     *
-     * @param maxSpace Maximum space available in data cache.
-     */
-    public void setMaxSpaceSize(long maxSpace) {
-        this.maxSpace = maxSpace;
-    }
-
-    /**
-     * Gets maximum timeout awaiting for trash purging in case data cache oversize is detected.
-     *
-     * @return Maximum timeout awaiting for trash purging in case data cache oversize is detected.
-     */
-    public long getTrashPurgeTimeout() {
-        return trashPurgeTimeout;
-    }
-
-    /**
-     * Sets maximum timeout awaiting for trash purging in case data cache oversize is detected.
-     *
-     * @param trashPurgeTimeout Maximum timeout awaiting for trash purging in case data cache oversize is detected.
-     */
-    public void setTrashPurgeTimeout(long trashPurgeTimeout) {
-        this.trashPurgeTimeout = trashPurgeTimeout;
-    }
-
-    /**
-     * Get DUAL mode put operation executor service. This executor service will process cache PUT requests for
-     * data which came from the secondary file system and about to be written to GGFS data cache.
-     * In case no executor service is provided, default one will be created with maximum amount of threads equals
-     * to amount of processor cores.
-     *
-     * @return Get DUAL mode put operation executor service
-     */
-    @Nullable public ExecutorService getDualModePutExecutorService() {
-        return dualModePutExec;
-    }
-
-    /**
-     * Set DUAL mode put operations executor service.
-     *
-     * @param dualModePutExec Dual mode put operations executor service.
-     */
-    public void setDualModePutExecutorService(ExecutorService dualModePutExec) {
-        this.dualModePutExec = dualModePutExec;
-    }
-
-    /**
-     * Get DUAL mode put operation executor service shutdown flag.
-     *
-     * @return DUAL mode put operation executor service shutdown flag.
-     */
-    public boolean getDualModePutExecutorServiceShutdown() {
-        return dualModePutExecShutdown;
-    }
-
-    /**
-     * Set DUAL mode put operations executor service shutdown flag.
-     *
-     * @param dualModePutExecShutdown Dual mode put operations executor service shutdown flag.
-     */
-    public void setDualModePutExecutorServiceShutdown(boolean dualModePutExecShutdown) {
-        this.dualModePutExecShutdown = dualModePutExecShutdown;
-    }
-
-    /**
-     * Get maximum amount of pending data read from the secondary file system and waiting to be written to data
-     * cache. {@code 0} or negative value stands for unlimited size.
-     * <p>
-     * By default this value is set to {@code 0}. It is recommended to set positive value in case your
-     * application performs frequent reads of large amount of data from the secondary file system in order to
-     * avoid issues with increasing GC pauses or out-of-memory error.
-     *
-     * @return Maximum amount of pending data read from the secondary file system
-     */
-    public long getDualModeMaxPendingPutsSize() {
-        return dualModeMaxPendingPutsSize;
-    }
-
-    /**
-     * Set maximum amount of data in pending put operations.
-     *
-     * @param dualModeMaxPendingPutsSize Maximum amount of data in pending put operations.
-     */
-    public void setDualModeMaxPendingPutsSize(long dualModeMaxPendingPutsSize) {
-        this.dualModeMaxPendingPutsSize = dualModeMaxPendingPutsSize;
-    }
-
-    /**
-     * Get maximum default range size of a file being split during GGFS task execution. When GGFS task is about to
-     * be executed, it requests file block locations first. Each location is defined as {@link org.gridgain.grid.ggfs.mapreduce.IgniteFsFileRange} which
-     * has length. In case this parameter is set to positive value, then GGFS will split single file range into smaller
-     * ranges with length not greater that this parameter. The only exception to this case is when maximum task range
-     * length is smaller than file block size. In this case maximum task range size will be overridden and set to file
-     * block size.
-     * <p>
-     * Note that this parameter is applied when task is split into jobs before {@link org.gridgain.grid.ggfs.mapreduce.IgniteFsRecordResolver} is
-     * applied. Therefore, final file ranges being assigned to particular jobs could be greater than value of this
-     * parameter depending on file data layout and selected resolver type.
-     * <p>
-     * Setting this parameter might be useful when file is highly colocated and have very long consequent data chunks
-     * so that task execution suffers from insufficient parallelism. E.g., in case you have one GGFS node in topology
-     * and want to process 1Gb file, then only single range of length 1Gb will be returned. This will result in
-     * a single job which will be processed in one thread. But in case you provide this configuration parameter and set
-     * maximum range length to 16Mb, then 64 ranges will be returned resulting in 64 jobs which could be executed in
-     * parallel.
-     * <p>
-     * Note that some {@code GridGgfs.execute()} methods can override value of this parameter.
-     * <p>
-     * In case value of this parameter is set to {@code 0} or negative value, it is simply ignored. Default value is
-     * {@code 0}.
-     *
-     * @return Maximum range size of a file being split during GGFS task execution.
-     */
-    public long getMaximumTaskRangeLength() {
-        return maxTaskRangeLen;
-    }
-
-    /**
-     * Set maximum default range size of a file being split during GGFS task execution.
-     * See {@link #getMaximumTaskRangeLength()} for more details.
-     *
-     * @param maxTaskRangeLen Set maximum default range size of a file being split during GGFS task execution.
-     */
-    public void setMaximumTaskRangeLength(long maxTaskRangeLen) {
-        this.maxTaskRangeLen = maxTaskRangeLen;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(IgniteFsConfiguration.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsCorruptedFileException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsCorruptedFileException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsCorruptedFileException.java
deleted file mode 100644
index b3aeaf6..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsCorruptedFileException.java
+++ /dev/null
@@ -1,42 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.jetbrains.annotations.*;
-
-/**
- * Exception thrown when target file's block is not found in data cache.
- */
-public class IgniteFsCorruptedFileException extends IgniteFsException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * @param msg Error message.
-     */
-    public IgniteFsCorruptedFileException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * @param cause Error cause.
-     */
-    public IgniteFsCorruptedFileException(Throwable cause) {
-        super(cause);
-    }
-
-    /**
-     * @param msg Error message.
-     * @param cause Error cause.
-     */
-    public IgniteFsCorruptedFileException(String msg, @Nullable Throwable cause) {
-        super(msg, cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsException.java
deleted file mode 100644
index d72ed40..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsException.java
+++ /dev/null
@@ -1,49 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.gridgain.grid.*;
-import org.jetbrains.annotations.*;
-
-/**
- * {@code GGFS} exception thrown by file system components.
- */
-public class IgniteFsException extends GridException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Creates an instance of GGFS exception with descriptive error message.
-     *
-     * @param msg Error message.
-     */
-    public IgniteFsException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * Creates an instance of GGFS exception caused by nested exception.
-     *
-     * @param cause Exception cause.
-     */
-    public IgniteFsException(Throwable cause) {
-        super(cause);
-    }
-
-    /**
-     * Creates an instance of GGFS exception with error message and underlying cause.
-     *
-     * @param msg Error message.
-     * @param cause Exception cause.
-     */
-    public IgniteFsException(String msg, @Nullable Throwable cause) {
-        super(msg, cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFile.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFile.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFile.java
deleted file mode 100644
index 9e39239..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFile.java
+++ /dev/null
@@ -1,112 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.jetbrains.annotations.*;
-
-import java.util.*;
-
-/**
- * {@code GGFS} file or directory descriptor. For example, to get information about
- * a file you would use the following code:
- * <pre name="code" class="java">
- *     GridGgfsPath filePath = new GridGgfsPath("my/working/dir", "file.txt");
- *
- *     // Get metadata about file.
- *     GridGgfsFile file = ggfs.info(filePath);
- * </pre>
- */
-public interface IgniteFsFile {
-    /**
-     * Gets path to file.
-     *
-     * @return Path to file.
-     */
-    public IgniteFsPath path();
-
-    /**
-     * Check this file is a data file.
-     *
-     * @return {@code True} if this is a data file.
-     */
-    public boolean isFile();
-
-    /**
-     * Check this file is a directory.
-     *
-     * @return {@code True} if this is a directory.
-     */
-    public boolean isDirectory();
-
-    /**
-     * Gets file's length.
-     *
-     * @return File's length or {@code zero} for directories.
-     */
-    public long length();
-
-    /**
-     * Gets file's data block size.
-     *
-     * @return File's data block size or {@code zero} for directories.
-     */
-    public int blockSize();
-
-    /**
-     * Gets file group block size (i.e. block size * group size).
-     *
-     * @return File group block size.
-     */
-    public long groupBlockSize();
-
-    /**
-     * Gets file last access time. File last access time is not updated automatically due to
-     * performance considerations and can be updated on demand with
-     * {@link org.apache.ignite.IgniteFs#setTimes(IgniteFsPath, long, long)} method.
-     * <p>
-     * By default last access time equals file creation time.
-     *
-     * @return Last access time.
-     */
-    public long accessTime();
-
-    /**
-     * Gets file last modification time. File modification time is updated automatically on each file write and
-     * append.
-     *
-     * @return Last modification time.
-     */
-    public long modificationTime();
-
-    /**
-     * Get file's property for specified name.
-     *
-     * @param name Name of the property.
-     * @return File's property for specified name.
-     * @throws IllegalArgumentException If requested property was not found.
-     */
-    public String property(String name) throws IllegalArgumentException;
-
-    /**
-     * Get file's property for specified name.
-     *
-     * @param name Name of the property.
-     * @param dfltVal Default value if requested property was not found.
-     * @return File's property for specified name.
-     */
-    @Nullable public String property(String name, @Nullable String dfltVal);
-
-    /**
-     * Get properties of the file.
-     *
-     * @return Properties of the file.
-     */
-    public Map<String, String> properties();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileNotFoundException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileNotFoundException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileNotFoundException.java
deleted file mode 100644
index def5bc4..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileNotFoundException.java
+++ /dev/null
@@ -1,36 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-/**
- * {@code GGFS} exception indicating that target resource is not found.
- */
-public class IgniteFsFileNotFoundException extends IgniteFsInvalidPathException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Creates exception with error message specified.
-     *
-     * @param msg Error message.
-     */
-    public IgniteFsFileNotFoundException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * Creates exception with given exception cause.
-     *
-     * @param cause Exception cause.
-     */
-    public IgniteFsFileNotFoundException(Throwable cause) {
-        super(cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileSystem.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileSystem.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileSystem.java
deleted file mode 100644
index 26c7f1b..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileSystem.java
+++ /dev/null
@@ -1,208 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.gridgain.grid.*;
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-import java.util.*;
-
-/**
- * Common file system interface. It provides a typical generalized "view" of any file system:
- * <ul>
- *     <li>list directories or get information for a single path</li>
- *     <li>create/move/delete files or directories</li>
- *     <li>write/read data streams into/from files</li>
- * </ul>
- *
- * This is the minimum of functionality that is needed to work as secondary file system in dual modes of GGFS.
- */
-public interface IgniteFsFileSystem {
-    /** File property: user name. */
-    public static final String PROP_USER_NAME = "usrName";
-
-    /** File property: group name. */
-    public static final String PROP_GROUP_NAME = "grpName";
-
-    /** File property: permission. */
-    public static final String PROP_PERMISSION = "permission";
-
-    /**
-     * Checks if the specified path exists in the file system.
-     *
-     * @param path Path to check for existence in the file system.
-     * @return {@code True} if such file exists, otherwise - {@code false}.
-     * @throws GridException In case of error.
-     */
-    public boolean exists(IgniteFsPath path) throws GridException;
-
-    /**
-     * Updates file information for the specified path. Existent properties, not listed in the passed collection,
-     * will not be affected. Other properties will be added or overwritten. Passed properties with {@code null} values
-     * will be removed from the stored properties or ignored if they don't exist in the file info.
-     * <p>
-     * When working in {@code DUAL_SYNC} or {@code DUAL_ASYNC} modes only the following properties will be propagated
-     * to the secondary file system:
-     * <ul>
-     * <li>{@code usrName} - file owner name;</li>
-     * <li>{@code grpName} - file owner group;</li>
-     * <li>{@code permission} - Unix-style string representing file permissions.</li>
-     * </ul>
-     *
-     * @param path File path to set properties for.
-     * @param props Properties to update.
-     * @return File information for specified path or {@code null} if such path does not exist.
-     * @throws GridException In case of error.
-     */
-    @Nullable public IgniteFsFile update(IgniteFsPath path, Map<String, String> props) throws GridException;
-
-    /**
-     * Renames/moves a file.
-     * <p>
-     * You are free to rename/move data files as you wish, but directories can be only renamed.
-     * You cannot move the directory between different parent directories.
-     * <p>
-     * Examples:
-     * <ul>
-     *     <li>"/work/file.txt" => "/home/project/Presentation Scenario.txt"</li>
-     *     <li>"/work" => "/work-2012.bkp"</li>
-     *     <li>"/work" => "<strike>/backups/work</strike>" - such operation is restricted for directories.</li>
-     * </ul>
-     *
-     * @param src Source file path to rename.
-     * @param dest Destination file path. If destination path is a directory, then source file will be placed
-     *     into destination directory with original name.
-     * @throws GridException In case of error.
-     * @throws IgniteFsFileNotFoundException If source file doesn't exist.
-     */
-    public void rename(IgniteFsPath src, IgniteFsPath dest) throws GridException;
-
-    /**
-     * Deletes file.
-     *
-     * @param path File path to delete.
-     * @param recursive Delete non-empty directories recursively.
-     * @return {@code True} in case of success, {@code false} otherwise.
-     * @throws GridException In case of error.
-     */
-    boolean delete(IgniteFsPath path, boolean recursive) throws GridException;
-
-    /**
-     * Creates directories under specified path.
-     *
-     * @param path Path of directories chain to create.
-     * @throws GridException In case of error.
-     */
-    public void mkdirs(IgniteFsPath path) throws GridException;
-
-    /**
-     * Creates directories under specified path with the specified properties.
-     *
-     * @param path Path of directories chain to create.
-     * @param props Metadata properties to set on created directories.
-     * @throws GridException In case of error.
-     */
-    public void mkdirs(IgniteFsPath path, @Nullable Map<String, String> props) throws GridException;
-
-    /**
-     * Lists file paths under the specified path.
-     *
-     * @param path Path to list files under.
-     * @return List of files under the specified path.
-     * @throws GridException In case of error.
-     * @throws IgniteFsFileNotFoundException If path doesn't exist.
-     */
-    public Collection<IgniteFsPath> listPaths(IgniteFsPath path) throws GridException;
-
-    /**
-     * Lists files under the specified path.
-     *
-     * @param path Path to list files under.
-     * @return List of files under the specified path.
-     * @throws GridException In case of error.
-     * @throws IgniteFsFileNotFoundException If path doesn't exist.
-     */
-    public Collection<IgniteFsFile> listFiles(IgniteFsPath path) throws GridException;
-
-    /**
-     * Opens a file for reading.
-     *
-     * @param path File path to read.
-     * @param bufSize Read buffer size (bytes) or {@code zero} to use default value.
-     * @return File input stream to read data from.
-     * @throws GridException In case of error.
-     * @throws IgniteFsFileNotFoundException If path doesn't exist.
-     */
-    public IgniteFsReader open(IgniteFsPath path, int bufSize) throws GridException;
-
-    /**
-     * Creates a file and opens it for writing.
-     *
-     * @param path File path to create.
-     * @param overwrite Overwrite file if it already exists. Note: you cannot overwrite an existent directory.
-     * @return File output stream to write data to.
-     * @throws GridException In case of error.
-     */
-    public OutputStream create(IgniteFsPath path, boolean overwrite) throws GridException;
-
-    /**
-     * Creates a file and opens it for writing.
-     *
-     * @param path File path to create.
-     * @param bufSize Write buffer size (bytes) or {@code zero} to use default value.
-     * @param overwrite Overwrite file if it already exists. Note: you cannot overwrite an existent directory.
-     * @param replication Replication factor.
-     * @param blockSize Block size.
-     * @param props File properties to set.
-     * @return File output stream to write data to.
-     * @throws GridException In case of error.
-     */
-    public OutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication, long blockSize,
-       @Nullable Map<String, String> props) throws GridException;
-
-    /**
-     * Opens an output stream to an existing file for appending data.
-     *
-     * @param path File path to append.
-     * @param bufSize Write buffer size (bytes) or {@code zero} to use default value.
-     * @param create Create file if it doesn't exist yet.
-     * @param props File properties to set only in case it file was just created.
-     * @return File output stream to append data to.
-     * @throws GridException In case of error.
-     * @throws IgniteFsFileNotFoundException If path doesn't exist and create flag is {@code false}.
-     */
-    public OutputStream append(IgniteFsPath path, int bufSize, boolean create, @Nullable Map<String, String> props)
-        throws GridException;
-
-    /**
-     * Gets file information for the specified path.
-     *
-     * @param path Path to get information for.
-     * @return File information for specified path or {@code null} if such path does not exist.
-     * @throws GridException In case of error.
-     */
-    @Nullable public IgniteFsFile info(IgniteFsPath path) throws GridException;
-
-    /**
-     * Gets used space in bytes.
-     *
-     * @return Used space in bytes.
-     * @throws GridException In case of error.
-     */
-    public long usedSpaceSize() throws GridException;
-
-    /**
-     * Gets the implementation specific properties of file system.
-     *
-     * @return Map of properties.
-     */
-    public Map<String,String> properties();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/81e01957/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsGroupDataBlocksKeyMapper.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsGroupDataBlocksKeyMapper.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsGroupDataBlocksKeyMapper.java
deleted file mode 100644
index b8fd433..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsGroupDataBlocksKeyMapper.java
+++ /dev/null
@@ -1,93 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.gridgain.grid.kernal.processors.cache.*;
-import org.gridgain.grid.kernal.processors.ggfs.*;
-import org.gridgain.grid.util.typedef.internal.*;
-
-/**
- * {@code GGFS} class providing ability to group file's data blocks together on one node.
- * All blocks within the same group are guaranteed to be cached together on the same node.
- * Group size parameter controls how many sequential blocks will be cached together on the same node.
- * <p>
- * For example, if block size is {@code 64kb} and group size is {@code 256}, then each group will contain
- * {@code 64kb * 256 = 16Mb}. Larger group sizes would reduce number of splits required to run map-reduce
- * tasks, but will increase inequality of data size being stored on different nodes.
- * <p>
- * Note that {@link #groupSize()} parameter must correlate to Hadoop split size parameter defined
- * in Hadoop via {@code mapred.max.split.size} property. Ideally you want all blocks accessed
- * within one split to be mapped to {@code 1} group, so they can be located on the same grid node.
- * For example, default Hadoop split size is {@code 64mb} and default {@code GGFS} block size
- * is {@code 64kb}. This means that to make sure that each split goes only through blocks on
- * the same node (without hopping between nodes over network), we have to make the {@link #groupSize()}
- * value be equal to {@code 64mb / 64kb = 1024}.
- * <p>
- * It is required for {@code GGFS} data cache to be configured with this mapper. Here is an
- * example of how it can be specified in XML configuration:
- * <pre name="code" class="xml">
- * &lt;bean id="cacheCfgBase" class="org.gridgain.grid.cache.GridCacheConfiguration" abstract="true"&gt;
- *     ...
- *     &lt;property name="affinityMapper"&gt;
- *         &lt;bean class="org.gridgain.grid.ggfs.GridGgfsGroupDataBlocksKeyMapper"&gt;
- *             &lt;!-- How many sequential blocks will be stored on the same node. --&gt;
- *             &lt;constructor-arg value="512"/&gt;
- *         &lt;/bean&gt;
- *     &lt;/property&gt;
- *     ...
- * &lt;/bean&gt;
- * </pre>
- */
-public class IgniteFsGroupDataBlocksKeyMapper extends GridCacheDefaultAffinityKeyMapper {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** Size of the group. */
-    private final int grpSize;
-
-    /***
-     * Constructs affinity mapper to group several data blocks with the same key.
-     *
-     * @param grpSize Size of the group in blocks.
-     */
-    public IgniteFsGroupDataBlocksKeyMapper(int grpSize) {
-        A.ensure(grpSize >= 1, "grpSize >= 1");
-
-        this.grpSize = grpSize;
-    }
-
-    /** {@inheritDoc} */
-    @Override public Object affinityKey(Object key) {
-        if (key != null && GridGgfsBlockKey.class.equals(key.getClass())) {
-            GridGgfsBlockKey blockKey = (GridGgfsBlockKey)key;
-
-            if (blockKey.affinityKey() != null)
-                return blockKey.affinityKey();
-
-            long grpId = blockKey.getBlockId() / grpSize;
-
-            return blockKey.getFileId().hashCode() + (int)(grpId ^ (grpId >>> 32));
-        }
-
-        return super.affinityKey(key);
-    }
-
-    /**
-     * @return Size of the group.
-     */
-    public int groupSize() {
-        return grpSize;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(IgniteFsGroupDataBlocksKeyMapper.class, this);
-    }
-}


[08/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
# Renaming


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

Branch: refs/heads/master
Commit: 1515c5aadbe7f8503386d53b2bd56fed7987299c
Parents: a228c7d
Author: sboikov <sb...@gridgain.com>
Authored: Fri Dec 5 11:05:40 2014 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Dec 5 11:05:40 2014 +0300

----------------------------------------------------------------------
 .../client/GridClientPortableArgumentTask.java  |   2 +-
 .../gridgain/client/GridClientTestPortable.java |   8 +-
 .../GridClientTestPortableAffinityKeyTask.java  |   2 +-
 .../clients/src/test/resources/spring-cache.xml |   2 +-
 .../src/test/resources/spring-server-node.xml   |   8 +-
 .../test/resources/spring-server-ssl-node.xml   |   2 +-
 .../java/org/apache/ignite/IgnitePortables.java |  24 +-
 .../ignite/portables/GridPortableMetadata.java  |  53 ----
 .../ignite/portables/GridPortableObject.java    | 166 ------------
 .../ignite/portables/GridPortableRawReader.java | 214 ---------------
 .../ignite/portables/GridPortableRawWriter.java | 197 --------------
 .../ignite/portables/GridPortableReader.java    | 263 -------------------
 .../portables/GridPortableSerializer.java       |  39 ---
 .../GridPortableTypeConfiguration.java          | 187 -------------
 .../ignite/portables/GridPortableWriter.java    | 242 -----------------
 .../ignite/portables/PortableBuilder.java       |   8 +-
 .../ignite/portables/PortableConfiguration.java |  24 +-
 .../ignite/portables/PortableIdMapper.java      |   2 +-
 .../PortableInvalidClassException.java          |   2 +-
 .../ignite/portables/PortableMarshalAware.java  |   4 +-
 .../ignite/portables/PortableMetadata.java      |  53 ++++
 .../apache/ignite/portables/PortableObject.java | 166 ++++++++++++
 .../ignite/portables/PortableRawReader.java     | 214 +++++++++++++++
 .../ignite/portables/PortableRawWriter.java     | 197 ++++++++++++++
 .../apache/ignite/portables/PortableReader.java | 263 +++++++++++++++++++
 .../ignite/portables/PortableSerializer.java    |  39 +++
 .../portables/PortableTypeConfiguration.java    | 187 +++++++++++++
 .../apache/ignite/portables/PortableWriter.java | 242 +++++++++++++++++
 .../gridgain/client/GridClientCacheFlag.java    |   2 +-
 .../grid/cache/GridCacheConfiguration.java      |   2 +-
 .../grid/cache/GridCacheProjection.java         |   2 +-
 .../grid/cache/store/GridCacheStore.java        |   4 +-
 .../grid/dotnet/GridDotNetConfiguration.java    |   8 +-
 .../dotnet/GridDotNetPortableConfiguration.java |   8 +-
 .../GridDotNetPortableTypeConfiguration.java    |   8 +-
 .../gridgain/grid/kernal/GridPortablesImpl.java |  10 +-
 .../managers/indexing/GridIndexingManager.java  |  16 +-
 .../processors/cache/GridCacheAdapter.java      |  18 +-
 .../processors/cache/GridCacheContext.java      |  14 +-
 .../GridCacheDefaultAffinityKeyMapper.java      |   6 +-
 .../cache/GridCacheProjectionImpl.java          |   4 +-
 .../cache/GridCacheTxLocalAdapter.java          |  16 +-
 .../dht/GridPartitionedGetFuture.java           |   8 +-
 .../dht/atomic/GridDhtAtomicCache.java          |   4 +-
 .../dht/colocated/GridDhtColocatedCache.java    |   4 +-
 .../distributed/near/GridNearGetFuture.java     |   8 +-
 .../portable/GridPortableProcessor.java         |  10 +-
 .../portable/os/GridOsPortableProcessor.java    |  10 +-
 .../message/GridClientAbstractMessage.java      |   8 +-
 .../GridClientAuthenticationRequest.java        |   8 +-
 .../message/GridClientCacheQueryRequest.java    |   8 +-
 .../client/message/GridClientCacheRequest.java  |   8 +-
 .../message/GridClientGetMetaDataRequest.java   |   8 +-
 .../client/message/GridClientLogRequest.java    |   8 +-
 .../message/GridClientMetaDataResponse.java     |  12 +-
 .../rest/client/message/GridClientNodeBean.java |   8 +-
 .../message/GridClientNodeMetricsBean.java      |   8 +-
 .../message/GridClientPortableMetaData.java     |   8 +-
 .../message/GridClientPutMetaDataRequest.java   |   8 +-
 .../rest/client/message/GridClientResponse.java |   8 +-
 .../client/message/GridClientTaskRequest.java   |   8 +-
 .../message/GridClientTaskResultBean.java       |   8 +-
 .../message/GridClientTopologyRequest.java      |   8 +-
 .../cache/GridCacheClientQueryResult.java       |   8 +-
 .../metadata/GridPortableMetadataHandler.java   |   2 +-
 .../VisorPortableMetadataCollectorTask.java     |   2 +-
 .../grid/security/GridSecurityCredentials.java  |   4 +-
 .../java/org/gridgain/grid/util/GridUtils.java  |   2 +-
 .../util/portable/GridPortableRawReaderEx.java  |  24 --
 .../util/portable/GridPortableRawWriterEx.java  |  35 ---
 .../grid/util/portable/PortableRawReaderEx.java |  24 ++
 .../grid/util/portable/PortableRawWriterEx.java |  35 +++
 ...heOffHeapTieredEvictionAbstractSelfTest.java |   4 +-
 .../GridCacheSwapScanQueryAbstractSelfTest.java |   4 +-
 .../dataload/GridDataLoaderImplSelfTest.java    |   6 +-
 75 files changed, 1623 insertions(+), 1623 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/clients/src/test/java/org/gridgain/client/GridClientPortableArgumentTask.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/gridgain/client/GridClientPortableArgumentTask.java b/modules/clients/src/test/java/org/gridgain/client/GridClientPortableArgumentTask.java
index 051c52b..37875f8 100644
--- a/modules/clients/src/test/java/org/gridgain/client/GridClientPortableArgumentTask.java
+++ b/modules/clients/src/test/java/org/gridgain/client/GridClientPortableArgumentTask.java
@@ -31,7 +31,7 @@ public class GridClientPortableArgumentTask extends GridTaskSingleJobSplitAdapte
         GridClientTestPortable p;
 
         if (expPortable) {
-            GridPortableObject obj = (GridPortableObject)it.next();
+            PortableObject obj = (PortableObject)it.next();
 
             p = obj.deserialize();
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/clients/src/test/java/org/gridgain/client/GridClientTestPortable.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/gridgain/client/GridClientTestPortable.java b/modules/clients/src/test/java/org/gridgain/client/GridClientTestPortable.java
index 9836e05..113cb11 100644
--- a/modules/clients/src/test/java/org/gridgain/client/GridClientTestPortable.java
+++ b/modules/clients/src/test/java/org/gridgain/client/GridClientTestPortable.java
@@ -303,7 +303,7 @@ public class GridClientTestPortable implements PortableMarshalAware, Serializabl
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
+    @Override public void writePortable(PortableWriter writer) throws PortableException {
         writer.writeByte("_b", b);
         writer.writeShort("_s", s);
         writer.writeInt("_i", i);
@@ -334,7 +334,7 @@ public class GridClientTestPortable implements PortableMarshalAware, Serializabl
         writer.writeObject("_portable1", portable1);
         writer.writeObject("_portable2", portable2);
 
-        GridPortableRawWriter raw = writer.rawWriter();
+        PortableRawWriter raw = writer.rawWriter();
 
         raw.writeByte(bRaw);
         raw.writeShort(sRaw);
@@ -368,7 +368,7 @@ public class GridClientTestPortable implements PortableMarshalAware, Serializabl
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws PortableException {
+    @Override public void readPortable(PortableReader reader) throws PortableException {
         b = reader.readByte("_b");
         s = reader.readShort("_s");
         i = reader.readInt("_i");
@@ -399,7 +399,7 @@ public class GridClientTestPortable implements PortableMarshalAware, Serializabl
         portable1 = (GridClientTestPortable)reader.readObject("_portable1");
         portable2 = (GridClientTestPortable)reader.readObject("_portable2");
 
-        GridPortableRawReader raw = reader.rawReader();
+        PortableRawReader raw = reader.rawReader();
 
         bRaw = raw.readByte();
         sRaw = raw.readShort();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/clients/src/test/java/org/gridgain/client/GridClientTestPortableAffinityKeyTask.java
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/java/org/gridgain/client/GridClientTestPortableAffinityKeyTask.java b/modules/clients/src/test/java/org/gridgain/client/GridClientTestPortableAffinityKeyTask.java
index f94481d..883b370 100644
--- a/modules/clients/src/test/java/org/gridgain/client/GridClientTestPortableAffinityKeyTask.java
+++ b/modules/clients/src/test/java/org/gridgain/client/GridClientTestPortableAffinityKeyTask.java
@@ -59,7 +59,7 @@ public class GridClientTestPortableAffinityKeyTask extends ComputeTaskAdapter<Ob
 
         assert args.size() == 3 : args.size();
 
-        GridPortableObject obj = (GridPortableObject)it.next();
+        PortableObject obj = (PortableObject)it.next();
 
         String cacheName = (String)it.next();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/clients/src/test/resources/spring-cache.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-cache.xml b/modules/clients/src/test/resources/spring-cache.xml
index bb4a4cd..fa4c2fa 100644
--- a/modules/clients/src/test/resources/spring-cache.xml
+++ b/modules/clients/src/test/resources/spring-cache.xml
@@ -239,7 +239,7 @@
             <bean class="org.apache.ignite.portables.PortableConfiguration">
                 <property name="typeConfigurations">
                     <list>
-                        <bean class="org.apache.ignite.portables.GridPortableTypeConfiguration">
+                        <bean class="org.apache.ignite.portables.PortableTypeConfiguration">
                             <property name="className" value="org.gridgain.client.GridClientTestPortable"/>
                         </bean>
                     </list>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/clients/src/test/resources/spring-server-node.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-server-node.xml b/modules/clients/src/test/resources/spring-server-node.xml
index d5d8530..de7db25 100644
--- a/modules/clients/src/test/resources/spring-server-node.xml
+++ b/modules/clients/src/test/resources/spring-server-node.xml
@@ -73,16 +73,16 @@
             <bean class="org.apache.ignite.portables.PortableConfiguration">
                 <property name="typeConfigurations">
                     <list>
-                        <bean class="org.apache.ignite.portables.GridPortableTypeConfiguration">
+                        <bean class="org.apache.ignite.portables.PortableTypeConfiguration">
                             <property name="className" value="org.gridgain.client.GridClientTestPortable"/>
                         </bean>
-                        <bean class="org.apache.ignite.portables.GridPortableTypeConfiguration">
+                        <bean class="org.apache.ignite.portables.PortableTypeConfiguration">
                             <property name="className" value="org.gridgain.client.model.GridPortablePerson"/>
                         </bean>
-                        <bean class="org.apache.ignite.portables.GridPortableTypeConfiguration">
+                        <bean class="org.apache.ignite.portables.PortableTypeConfiguration">
                             <property name="className" value="org.gridgain.client.model.GridImplicitPortablePerson"/>
                         </bean>
-                        <bean class="org.apache.ignite.portables.GridPortableTypeConfiguration">
+                        <bean class="org.apache.ignite.portables.PortableTypeConfiguration">
                             <property name="className" value="GridNoDefPortablePerson"/>
                         </bean>
                     </list>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/clients/src/test/resources/spring-server-ssl-node.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-server-ssl-node.xml b/modules/clients/src/test/resources/spring-server-ssl-node.xml
index 0a363d5..3d50ace 100644
--- a/modules/clients/src/test/resources/spring-server-ssl-node.xml
+++ b/modules/clients/src/test/resources/spring-server-ssl-node.xml
@@ -321,7 +321,7 @@
             <bean class="org.apache.ignite.portables.PortableConfiguration">
                 <property name="typeConfigurations">
                     <list>
-                        <bean class="org.apache.ignite.portables.GridPortableTypeConfiguration">
+                        <bean class="org.apache.ignite.portables.PortableTypeConfiguration">
                             <property name="className" value="org.gridgain.client.GridClientTestPortable"/>
                         </bean>
                     </list>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/IgnitePortables.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/IgnitePortables.java b/modules/core/src/main/java/org/apache/ignite/IgnitePortables.java
index 88d0e4d..7f7dbd4 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgnitePortables.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgnitePortables.java
@@ -28,7 +28,7 @@ import java.util.Date;
  * <li>Automatically convert collections and maps between Java, .NET, and C++.</li>
  * <li>
  *      Optionally avoid deserialization of objects on the server side
- *      (objects are stored in {@link org.apache.ignite.portables.GridPortableObject} format).
+ *      (objects are stored in {@link org.apache.ignite.portables.PortableObject} format).
  * </li>
  * <li>Avoid need to have concrete class definitions on the server side.</li>
  * <li>Dynamically change structure of the classes without having to restart the cluster.</li>
@@ -74,7 +74,7 @@ import java.util.Date;
  * GridCacheProjection&lt;Integer.class, GridPortableObject.class&gt; prj = cache.keepPortable();
  * </pre>
  * <h1 class="header">Automatic Portable Types</h1>
- * Note that only portable classes are converted to {@link org.apache.ignite.portables.GridPortableObject} format. Following
+ * Note that only portable classes are converted to {@link org.apache.ignite.portables.PortableObject} format. Following
  * classes are never converted (e.g., {@link #toPortable(Object)} method will return original
  * object, and instances of these classes will be stored in cache without changes):
  * <ul>
@@ -174,7 +174,7 @@ import java.util.Date;
  *
  * gridCfg.setPortableConfiguration(portCfg);
  * </pre>
- * You can also specify class name for a portable object via {@link org.apache.ignite.portables.GridPortableTypeConfiguration}.
+ * You can also specify class name for a portable object via {@link org.apache.ignite.portables.PortableTypeConfiguration}.
  * Do it in case if you need to override other configuration properties on per-type level, like
  * ID-mapper, or serializer.
  * <h1 class="header">Custom Affinity Keys</h1>
@@ -223,8 +223,8 @@ import java.util.Date;
  * }
  * </pre>
  * Alternatively, if you cannot change class definitions, you can provide custom serialization
- * logic in {@link org.apache.ignite.portables.GridPortableSerializer} either globally in {@link org.apache.ignite.portables.PortableConfiguration} or
- * for a specific type via {@link org.apache.ignite.portables.GridPortableTypeConfiguration} instance.
+ * logic in {@link org.apache.ignite.portables.PortableSerializer} either globally in {@link org.apache.ignite.portables.PortableConfiguration} or
+ * for a specific type via {@link org.apache.ignite.portables.PortableTypeConfiguration} instance.
  * <p>
  * Similar to java serialization you can use {@code writeReplace()} and {@code readResolve()} methods.
  * <ul>
@@ -244,7 +244,7 @@ import java.util.Date;
  * you can provide your own {@link org.apache.ignite.portables.PortableIdMapper} implementation.
  * <p>
  * ID-mapper may be provided either globally in {@link org.apache.ignite.portables.PortableConfiguration},
- * or for a specific type via {@link org.apache.ignite.portables.GridPortableTypeConfiguration} instance.
+ * or for a specific type via {@link org.apache.ignite.portables.PortableTypeConfiguration} instance.
  * <h1 class="header">Query Indexing</h1>
  * Portable objects can be indexed for querying by specifying index fields in
  * {@link GridCacheQueryTypeMetadata} inside of specific {@link GridCacheConfiguration} instance,
@@ -287,7 +287,7 @@ public interface IgnitePortables {
     public int typeId(String typeName);
 
     /**
-     * Converts provided object to instance of {@link org.apache.ignite.portables.GridPortableObject}.
+     * Converts provided object to instance of {@link org.apache.ignite.portables.PortableObject}.
      * <p>
      * Note that object's type needs to be configured in {@link org.apache.ignite.portables.PortableConfiguration}.
      *
@@ -319,7 +319,7 @@ public interface IgnitePortables {
      * @param portableObj Portable object to initialize builder.
      * @return Portable builder.
      */
-    public PortableBuilder builder(GridPortableObject portableObj);
+    public PortableBuilder builder(PortableObject portableObj);
 
     /**
      * Gets metadata for provided class.
@@ -328,7 +328,7 @@ public interface IgnitePortables {
      * @return Metadata.
      * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    @Nullable public GridPortableMetadata metadata(Class<?> cls) throws PortableException;
+    @Nullable public PortableMetadata metadata(Class<?> cls) throws PortableException;
 
     /**
      * Gets metadata for provided class name.
@@ -337,7 +337,7 @@ public interface IgnitePortables {
      * @return Metadata.
      * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    @Nullable public GridPortableMetadata metadata(String typeName) throws PortableException;
+    @Nullable public PortableMetadata metadata(String typeName) throws PortableException;
 
     /**
      * Gets metadata for provided type ID.
@@ -346,7 +346,7 @@ public interface IgnitePortables {
      * @return Metadata.
      * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    @Nullable public GridPortableMetadata metadata(int typeId) throws PortableException;
+    @Nullable public PortableMetadata metadata(int typeId) throws PortableException;
 
     /**
      * Gets metadata for all known types.
@@ -354,5 +354,5 @@ public interface IgnitePortables {
      * @return Metadata.
      * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    public Collection<GridPortableMetadata> metadata() throws PortableException;
+    public Collection<PortableMetadata> metadata() throws PortableException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/GridPortableMetadata.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableMetadata.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableMetadata.java
deleted file mode 100644
index 5ec0dea..0000000
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableMetadata.java
+++ /dev/null
@@ -1,53 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.portables;
-
-import org.jetbrains.annotations.*;
-
-import java.util.*;
-
-/**
- * Portable type meta data. Metadata for portable types can be accessed from any of the
- * {@link org.apache.ignite.IgnitePortables#metadata(String) GridPortables.metadata(...)} methods.
- * Having metadata also allows for proper formatting of {@code GridPortableObject.toString()} method,
- * even when portable objects are kept in binary format only, which may be necessary for audit reasons.
- */
-public interface GridPortableMetadata {
-    /**
-     * Gets portable type name.
-     *
-     * @return Portable type name.
-     */
-    public String typeName();
-
-    /**
-     * Gets collection of all field names for this portable type.
-     *
-     * @return Collection of all field names for this portable type.
-     */
-    public Collection<String> fields();
-
-    /**
-     * Gets name of the field type for a given field.
-     *
-     * @param fieldName Field name.
-     * @return Field type name.
-     */
-    @Nullable public String fieldTypeName(String fieldName);
-
-    /**
-     * Portable objects can optionally specify custom key-affinity mapping in the
-     * configuration. This method returns the name of the field which should be
-     * used for the key-affinity mapping.
-     *
-     * @return Affinity key field name.
-     */
-    @Nullable public String affinityKeyFieldName();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/GridPortableObject.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableObject.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableObject.java
deleted file mode 100644
index eb1f593..0000000
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableObject.java
+++ /dev/null
@@ -1,166 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.portables;
-
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-import java.util.*;
-
-/**
- * Wrapper for portable object in portable binary format. Once an object is defined as portable,
- * GridGain will always store it in memory in the portable (i.e. binary) format.
- * User can choose to work either with the portable format or with the deserialized form
- * (assuming that class definitions are present in the classpath).
- * <p>
- * <b>NOTE:</b> user does not need to (and should not) implement this interface directly.
- * <p>
- * To work with the portable format directly, user should create a cache projection
- * over {@code GridPortableObject} class and then retrieve individual fields as needed:
- * <pre name=code class=java>
- * GridCacheProjection&lt;GridPortableObject.class, GridPortableObject.class&gt; prj =
- *     cache.projection(GridPortableObject.class, GridPortableObject.class);
- *
- * // Convert instance of MyKey to portable format.
- * // We could also use GridPortableBuilder to create
- * // the key in portable format directly.
- * GridPortableObject key = grid.portables().toPortable(new MyKey());
- *
- * GridPortableObject val = prj.get(key);
- *
- * String field = val.field("myFieldName");
- * </pre>
- * Alternatively, we could also choose a hybrid approach, where, for example,
- * the keys are concrete deserialized objects and the values are returned in portable
- * format, like so:
- * <pre name=code class=java>
- * GridCacheProjection&lt;MyKey.class, GridPortableObject.class&gt; prj =
- *     cache.projection(MyKey.class, GridPortableObject.class);
- *
- * GridPortableObject val = prj.get(new MyKey());
- *
- * String field = val.field("myFieldName");
- * </pre>
- * We could also have the values as concrete deserialized objects and the keys in portable format,
- * but such use case is a lot less common because cache keys are usually a lot smaller than values, and
- * it may be very cheap to deserialize the keys, but not the values.
- * <p>
- * And finally, if we have class definitions in the classpath, we may choose to work with deserialized
- * typed objects at all times. In this case we do incur the deserialization cost, however,
- * GridGain will only deserialize on the first access and will cache the deserialized object,
- * so it does not have to be deserialized again:
- * <pre name=code class=java>
- * GridCacheProjection&lt;MyKey.class, MyValue.class&gt; prj =
- *     cache.projection(MyKey.class, MyValue.class);
- *
- * MyValue val = prj.get(new MyKey());
- *
- * // Normal java getter.
- * String fieldVal = val.getMyFieldName();
- * </pre>
- * <h1 class="header">Working With Maps and Collections</h1>
- * All maps and collections in the portable objects are serialized automatically. When working
- * with different platforms, e.g. C++ or .NET, GridGain will automatically pick the most
- * adequate collection or map in either language. For example, {@link ArrayList} in Java will become
- * {@code List} in C#, {@link LinkedList} in Java is {@link LinkedList} in C#, {@link HashMap}
- * in Java is {@code Dictionary} in C#, and {@link TreeMap} in Java becomes {@code SortedDictionary}
- * in C#, etc.
- * <h1 class="header">Dynamic Structure Changes</h1>
- * Since objects are always cached in the portable binary format, server does not need to
- * be aware of the class definitions. Moreover, if class definitions are not present or not
- * used on the server, then clients can continuously change the structure of the portable
- * objects without having to restart the cluster. For example, if one client stores a
- * certain class with fields A and B, and another client stores the same class with
- * fields B and C, then the server-side portable object will have the fields A, B, and C.
- * As the structure of a portable object changes, the new fields become available for SQL queries
- * automatically.
- * <h1 class="header">Building Portable Objects</h1>
- * GridGain comes with {@link PortableBuilder} which allows to build portable objects dynamically:
- * <pre name=code class=java>
- * GridPortableBuilder builder = GridGain.grid().portables().builder("org.project.MyObject");
- *
- * builder.setField("fieldA", "A");
- * builder.setField("fieldB", "B");
- *
- * GridPortableObject portableObj = builder.build();
- * </pre>
- * For the cases when class definition is present
- * in the class path, it is also possible to populate a standard POJO and then
- * convert it to portable format, like so:
- * <pre name=code class=java>
- * MyObject obj = new MyObject();
- *
- * obj.setFieldA("A");
- * obj.setFieldB(123);
- *
- * GridPortableObject portableObj = GridGain.grid().portables().toPortable(obj);
- * </pre>
- * <h1 class="header">Portable Metadata</h1>
- * Even though GridGain portable protocol only works with hash codes for type and field names
- * to achieve better performance, GridGain provides metadata for all portable types which
- * can be queried ar runtime via any of the {@link org.apache.ignite.IgnitePortables#metadata(Class) GridPortables.metadata(...)}
- * methods. Having metadata also allows for proper formatting of {@code GridPortableObject.toString()} method,
- * even when portable objects are kept in binary format only, which may be necessary for audit reasons.
- */
-public interface GridPortableObject extends Serializable, Cloneable {
-    /**
-     * Gets portable object type ID.
-     *
-     * @return Type ID.
-     */
-    public int typeId();
-
-    /**
-     * Gets meta data for this portable object.
-     *
-     * @return Meta data.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public GridPortableMetadata metaData() throws PortableException;
-
-    /**
-     * Gets field value.
-     *
-     * @param fieldName Field name.
-     * @return Field value.
-     * @throws PortableException In case of any other error.
-     */
-    @Nullable public <F> F field(String fieldName) throws PortableException;
-
-    /**
-     * Gets fully deserialized instance of portable object.
-     *
-     * @return Fully deserialized instance of portable object.
-     * @throws PortableInvalidClassException If class doesn't exist.
-     * @throws PortableException In case of any other error.
-     */
-    @Nullable public <T> T deserialize() throws PortableException;
-
-    /**
-     * Creates a copy of this portable object and optionally changes field values
-     * if they are provided in map. If map is empty or {@code null}, clean copy
-     * is created.
-     *
-     * @param fields Fields to modify in copy.
-     * @return Copy of this portable object.
-     * @throws PortableException In case of error.
-     * @deprecated Use {@link PortableBuilder} instead.
-     * @see PortableBuilder
-     */
-    @Deprecated
-    public GridPortableObject copy(@Nullable Map<String, Object> fields) throws PortableException;
-
-    /**
-     * Copies this portable object.
-     *
-     * @return Copy of this portable object.
-     */
-    public GridPortableObject clone() throws CloneNotSupportedException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawReader.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawReader.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawReader.java
deleted file mode 100644
index 49f86bd..0000000
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawReader.java
+++ /dev/null
@@ -1,214 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.portables;
-
-import org.jetbrains.annotations.*;
-
-import java.sql.*;
-import java.util.*;
-import java.util.Date;
-
-/**
- * Raw reader for portable objects. Raw reader does not use field name hash codes, therefore,
- * making the format even more compact. However, if the raw reader is used,
- * dynamic structure changes to the portable objects are not supported.
- */
-public interface GridPortableRawReader {
-    /**
-     * @return Byte value.
-     * @throws PortableException In case of error.
-     */
-    public byte readByte() throws PortableException;
-
-    /**
-     * @return Short value.
-     * @throws PortableException In case of error.
-     */
-    public short readShort() throws PortableException;
-
-    /**
-     * @return Integer value.
-     * @throws PortableException In case of error.
-     */
-    public int readInt() throws PortableException;
-
-    /**
-     * @return Long value.
-     * @throws PortableException In case of error.
-     */
-    public long readLong() throws PortableException;
-
-    /**
-     * @return Float value.
-     * @throws PortableException In case of error.
-     */
-    public float readFloat() throws PortableException;
-
-    /**
-     * @return Double value.
-     * @throws PortableException In case of error.
-     */
-    public double readDouble() throws PortableException;
-
-    /**
-     * @return Char value.
-     * @throws PortableException In case of error.
-     */
-    public char readChar() throws PortableException;
-
-    /**
-     * @return Boolean value.
-     * @throws PortableException In case of error.
-     */
-    public boolean readBoolean() throws PortableException;
-
-    /**
-     * @return String value.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public String readString() throws PortableException;
-
-    /**
-     * @return UUID.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public UUID readUuid() throws PortableException;
-
-    /**
-     * @return Date.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public Date readDate() throws PortableException;
-
-    /**
-     * @return Timestamp.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public Timestamp readTimestamp() throws PortableException;
-
-    /**
-     * @return Object.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public Object readObject() throws PortableException;
-
-    /**
-     * @return Byte array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public byte[] readByteArray() throws PortableException;
-
-    /**
-     * @return Short array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public short[] readShortArray() throws PortableException;
-
-    /**
-     * @return Integer array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public int[] readIntArray() throws PortableException;
-
-    /**
-     * @return Long array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public long[] readLongArray() throws PortableException;
-
-    /**
-     * @return Float array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public float[] readFloatArray() throws PortableException;
-
-    /**
-     * @return Byte array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public double[] readDoubleArray() throws PortableException;
-
-    /**
-     * @return Char array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public char[] readCharArray() throws PortableException;
-
-    /**
-     * @return Boolean array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public boolean[] readBooleanArray() throws PortableException;
-
-    /**
-     * @return String array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public String[] readStringArray() throws PortableException;
-
-    /**
-     * @return UUID array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public UUID[] readUuidArray() throws PortableException;
-
-    /**
-     * @return Date array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public Date[] readDateArray() throws PortableException;
-
-    /**
-     * @return Object array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public Object[] readObjectArray() throws PortableException;
-
-    /**
-     * @return Collection.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public <T> Collection<T> readCollection() throws PortableException;
-
-    /**
-     * @param colCls Collection class.
-     * @return Collection.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public <T> Collection<T> readCollection(Class<? extends Collection<T>> colCls)
-        throws PortableException;
-
-    /**
-     * @return Map.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public <K, V> Map<K, V> readMap() throws PortableException;
-
-    /**
-     * @param mapCls Map class.
-     * @return Map.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public <K, V> Map<K, V> readMap(Class<? extends Map<K, V>> mapCls) throws PortableException;
-
-    /**
-     * @param enumCls Enum class.
-     * @return Value.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public <T extends Enum<?>> T readEnum(Class<T> enumCls) throws PortableException;
-
-    /**
-     * @param enumCls Enum class.
-     * @return Value.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public <T extends Enum<?>> T[] readEnumArray(Class<T> enumCls) throws PortableException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawWriter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawWriter.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawWriter.java
deleted file mode 100644
index 6cb0931..0000000
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableRawWriter.java
+++ /dev/null
@@ -1,197 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.portables;
-
-import org.jetbrains.annotations.*;
-
-import java.sql.*;
-import java.util.*;
-import java.util.Date;
-
-/**
- * Raw writer for portable object. Raw writer does not write field name hash codes, therefore,
- * making the format even more compact. However, if the raw writer is used,
- * dynamic structure changes to the portable objects are not supported.
- */
-public interface GridPortableRawWriter {
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeByte(byte val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeShort(short val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeInt(int val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeLong(long val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeFloat(float val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeDouble(double val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeChar(char val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeBoolean(boolean val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeString(@Nullable String val) throws PortableException;
-
-    /**
-     * @param val UUID to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeUuid(@Nullable UUID val) throws PortableException;
-
-    /**
-     * @param val Date to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeDate(@Nullable Date val) throws PortableException;
-
-    /**
-     * @param val Timestamp to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeTimestamp(@Nullable Timestamp val) throws PortableException;
-
-    /**
-     * @param obj Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeObject(@Nullable Object obj) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeByteArray(@Nullable byte[] val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeShortArray(@Nullable short[] val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeIntArray(@Nullable int[] val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeLongArray(@Nullable long[] val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeFloatArray(@Nullable float[] val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeDoubleArray(@Nullable double[] val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeCharArray(@Nullable char[] val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeBooleanArray(@Nullable boolean[] val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeStringArray(@Nullable String[] val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeUuidArray(@Nullable UUID[] val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeDateArray(@Nullable Date[] val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeObjectArray(@Nullable Object[] val) throws PortableException;
-
-    /**
-     * @param col Collection to write.
-     * @throws PortableException In case of error.
-     */
-    public <T> void writeCollection(@Nullable Collection<T> col) throws PortableException;
-
-    /**
-     * @param map Map to write.
-     * @throws PortableException In case of error.
-     */
-    public <K, V> void writeMap(@Nullable Map<K, V> map) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public <T extends Enum<?>> void writeEnum(T val) throws PortableException;
-
-    /**
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public <T extends Enum<?>> void writeEnumArray(T[] val) throws PortableException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/GridPortableReader.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableReader.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableReader.java
deleted file mode 100644
index e244ee7..0000000
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableReader.java
+++ /dev/null
@@ -1,263 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.portables;
-
-import org.jetbrains.annotations.*;
-
-import java.sql.*;
-import java.util.*;
-import java.util.Date;
-
-/**
- * Reader for portable objects used in {@link PortableMarshalAware} implementations.
- * Useful for the cases when user wants a fine-grained control over serialization.
- * <p>
- * Note that GridGain never writes full strings for field or type names. Instead,
- * for performance reasons, GridGain writes integer hash codes for type and field names.
- * It has been tested that hash code conflicts for the type names or the field names
- * within the same type are virtually non-existent and, to gain performance, it is safe
- * to work with hash codes. For the cases when hash codes for different types or fields
- * actually do collide, GridGain provides {@link PortableIdMapper} which
- * allows to override the automatically generated hash code IDs for the type and field names.
- */
-public interface GridPortableReader {
-    /**
-     * @param fieldName Field name.
-     * @return Byte value.
-     * @throws PortableException In case of error.
-     */
-    public byte readByte(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Short value.
-     * @throws PortableException In case of error.
-     */
-    public short readShort(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Integer value.
-     * @throws PortableException In case of error.
-     */
-    public int readInt(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Long value.
-     * @throws PortableException In case of error.
-     */
-    public long readLong(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @throws PortableException In case of error.
-     * @return Float value.
-     */
-    public float readFloat(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Double value.
-     * @throws PortableException In case of error.
-     */
-    public double readDouble(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Char value.
-     * @throws PortableException In case of error.
-     */
-    public char readChar(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Boolean value.
-     * @throws PortableException In case of error.
-     */
-    public boolean readBoolean(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return String value.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public String readString(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return UUID.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public UUID readUuid(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Date.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public Date readDate(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Timestamp.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public Timestamp readTimestamp(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Object.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public <T> T readObject(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Byte array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public byte[] readByteArray(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Short array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public short[] readShortArray(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Integer array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public int[] readIntArray(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Long array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public long[] readLongArray(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Float array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public float[] readFloatArray(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Byte array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public double[] readDoubleArray(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Char array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public char[] readCharArray(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Boolean array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public boolean[] readBooleanArray(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return String array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public String[] readStringArray(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return UUID array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public UUID[] readUuidArray(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Date array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public Date[] readDateArray(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Object array.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public Object[] readObjectArray(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Collection.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public <T> Collection<T> readCollection(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param colCls Collection class.
-     * @return Collection.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public <T> Collection<T> readCollection(String fieldName, Class<? extends Collection<T>> colCls)
-        throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @return Map.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public <K, V> Map<K, V> readMap(String fieldName) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param mapCls Map class.
-     * @return Map.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public <K, V> Map<K, V> readMap(String fieldName, Class<? extends Map<K, V>> mapCls)
-        throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param enumCls Enum class.
-     * @return Value.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public <T extends Enum<?>> T readEnum(String fieldName, Class<T> enumCls) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param enumCls Enum class.
-     * @return Value.
-     * @throws PortableException In case of error.
-     */
-    @Nullable public <T extends Enum<?>> T[] readEnumArray(String fieldName, Class<T> enumCls)
-        throws PortableException;
-
-    /**
-     * Gets raw reader. Raw reader does not use field name hash codes, therefore,
-     * making the format even more compact. However, if the raw reader is used,
-     * dynamic structure changes to the portable objects are not supported.
-     *
-     * @return Raw reader.
-     */
-    public GridPortableRawReader rawReader();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/GridPortableSerializer.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableSerializer.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableSerializer.java
deleted file mode 100644
index 30932f4..0000000
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableSerializer.java
+++ /dev/null
@@ -1,39 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.portables;
-
-/**
- * Interface that allows to implement custom serialization logic for portable objects.
- * Can be used instead of {@link PortableMarshalAware} in case if the class
- * cannot be changed directly.
- * <p>
- * Portable serializer can be configured for all portable objects via
- * {@link PortableConfiguration#getSerializer()} method, or for a specific
- * portable type via {@link GridPortableTypeConfiguration#getSerializer()} method.
- */
-public interface GridPortableSerializer {
-    /**
-     * Writes fields to provided writer.
-     *
-     * @param obj Empty object.
-     * @param writer Portable object writer.
-     * @throws PortableException In case of error.
-     */
-    public void writePortable(Object obj, GridPortableWriter writer) throws PortableException;
-
-    /**
-     * Reads fields from provided reader.
-     *
-     * @param obj Empty object
-     * @param reader Portable object reader.
-     * @throws PortableException In case of error.
-     */
-    public void readPortable(Object obj, GridPortableReader reader) throws PortableException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/GridPortableTypeConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableTypeConfiguration.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableTypeConfiguration.java
deleted file mode 100644
index 8278544..0000000
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableTypeConfiguration.java
+++ /dev/null
@@ -1,187 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.portables;
-
-import org.gridgain.grid.util.typedef.internal.*;
-
-import java.sql.*;
-
-/**
- * Defines configuration properties for a specific portable type. Providing per-type
- * configuration is optional, as it is generally enough to provide global
- * portable configuration in {@link PortableConfiguration} instance. However,
- * this class allows you to change configuration properties for a specific
- * portable type without affecting configuration for other portable types.
- * <p>
- * Per-type portable configuration can be specified in
- * {@link PortableConfiguration#getTypeConfigurations()} method.
- */
-public class GridPortableTypeConfiguration {
-    /** Class name. */
-    private String clsName;
-
-    /** ID mapper. */
-    private PortableIdMapper idMapper;
-
-    /** Serializer. */
-    private GridPortableSerializer serializer;
-
-    /** Use timestamp flag. */
-    private Boolean useTs;
-
-    /** Meta data enabled flag. */
-    private Boolean metaDataEnabled;
-
-    /** Keep deserialized flag. */
-    private Boolean keepDeserialized;
-
-    /** Affinity key field name. */
-    private String affKeyFieldName;
-
-    /**
-     */
-    public GridPortableTypeConfiguration() {
-        // No-op.
-    }
-
-    /**
-     * @param clsName Class name.
-     */
-    public GridPortableTypeConfiguration(String clsName) {
-        this.clsName = clsName;
-    }
-
-    /**
-     * Gets type name.
-     *
-     * @return Type name.
-     */
-    public String getClassName() {
-        return clsName;
-    }
-
-    /**
-     * Sets type name.
-     *
-     * @param clsName Type name.
-     */
-    public void setClassName(String clsName) {
-        this.clsName = clsName;
-    }
-
-    /**
-     * Gets ID mapper.
-     *
-     * @return ID mapper.
-     */
-    public PortableIdMapper getIdMapper() {
-        return idMapper;
-    }
-
-    /**
-     * Sets ID mapper.
-     *
-     * @param idMapper ID mapper.
-     */
-    public void setIdMapper(PortableIdMapper idMapper) {
-        this.idMapper = idMapper;
-    }
-
-    /**
-     * Gets serializer.
-     *
-     * @return Serializer.
-     */
-    public GridPortableSerializer getSerializer() {
-        return serializer;
-    }
-
-    /**
-     * Sets serializer.
-     *
-     * @param serializer Serializer.
-     */
-    public void setSerializer(GridPortableSerializer serializer) {
-        this.serializer = serializer;
-    }
-
-    /**
-     * If {@code true} then date values converted to {@link Timestamp} during unmarshalling.
-     *
-     * @return Flag indicating whether date values converted to {@link Timestamp} during unmarshalling.
-     */
-    public Boolean isUseTimestamp() {
-        return useTs;
-    }
-
-    /**
-     * @param useTs Flag indicating whether date values converted to {@link Timestamp} during unmarshalling.
-     */
-    public void setUseTimestamp(Boolean useTs) {
-        this.useTs = useTs;
-    }
-
-    /**
-     * Defines whether meta data is collected for this type. If provided, this value will override
-     * {@link PortableConfiguration#isMetaDataEnabled()} property.
-     *
-     * @return Whether meta data is collected.
-     */
-    public Boolean isMetaDataEnabled() {
-        return metaDataEnabled;
-    }
-
-    /**
-     * @param metaDataEnabled Whether meta data is collected.
-     */
-    public void setMetaDataEnabled(Boolean metaDataEnabled) {
-        this.metaDataEnabled = metaDataEnabled;
-    }
-
-    /**
-     * Defines whether {@link GridPortableObject} should cache deserialized instance. If provided,
-     * this value will override {@link PortableConfiguration#isKeepDeserialized()} property.
-     *
-     * @return Whether deserialized value is kept.
-     */
-    public Boolean isKeepDeserialized() {
-        return keepDeserialized;
-    }
-
-    /**
-     * @param keepDeserialized Whether deserialized value is kept.
-     */
-    public void setKeepDeserialized(Boolean keepDeserialized) {
-        this.keepDeserialized = keepDeserialized;
-    }
-
-    /**
-     * Gets affinity key field name.
-     *
-     * @return Affinity key field name.
-     */
-    public String getAffinityKeyFieldName() {
-        return affKeyFieldName;
-    }
-
-    /**
-     * Sets affinity key field name.
-     *
-     * @param affKeyFieldName Affinity key field name.
-     */
-    public void setAffinityKeyFieldName(String affKeyFieldName) {
-        this.affKeyFieldName = affKeyFieldName;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridPortableTypeConfiguration.class, this, super.toString());
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/GridPortableWriter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableWriter.java b/modules/core/src/main/java/org/apache/ignite/portables/GridPortableWriter.java
deleted file mode 100644
index 769faa0..0000000
--- a/modules/core/src/main/java/org/apache/ignite/portables/GridPortableWriter.java
+++ /dev/null
@@ -1,242 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.apache.ignite.portables;
-
-import org.jetbrains.annotations.*;
-
-import java.sql.*;
-import java.util.*;
-import java.util.Date;
-
-/**
- * Writer for portable object used in {@link PortableMarshalAware} implementations.
- * Useful for the cases when user wants a fine-grained control over serialization.
- * <p>
- * Note that GridGain never writes full strings for field or type names. Instead,
- * for performance reasons, GridGain writes integer hash codes for type and field names.
- * It has been tested that hash code conflicts for the type names or the field names
- * within the same type are virtually non-existent and, to gain performance, it is safe
- * to work with hash codes. For the cases when hash codes for different types or fields
- * actually do collide, GridGain provides {@link PortableIdMapper} which
- * allows to override the automatically generated hash code IDs for the type and field names.
- */
-public interface GridPortableWriter {
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeByte(String fieldName, byte val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeShort(String fieldName, short val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeInt(String fieldName, int val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeLong(String fieldName, long val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeFloat(String fieldName, float val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeDouble(String fieldName, double val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeChar(String fieldName, char val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeBoolean(String fieldName, boolean val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeString(String fieldName, @Nullable String val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val UUID to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeUuid(String fieldName, @Nullable UUID val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Date to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeDate(String fieldName, @Nullable Date val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Timestamp to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeTimestamp(String fieldName, @Nullable Timestamp val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param obj Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeObject(String fieldName, @Nullable Object obj) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeByteArray(String fieldName, @Nullable byte[] val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeShortArray(String fieldName, @Nullable short[] val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeIntArray(String fieldName, @Nullable int[] val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeLongArray(String fieldName, @Nullable long[] val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeFloatArray(String fieldName, @Nullable float[] val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeDoubleArray(String fieldName, @Nullable double[] val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeCharArray(String fieldName, @Nullable char[] val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeBooleanArray(String fieldName, @Nullable boolean[] val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeStringArray(String fieldName, @Nullable String[] val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeUuidArray(String fieldName, @Nullable UUID[] val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeDateArray(String fieldName, @Nullable Date[] val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public void writeObjectArray(String fieldName, @Nullable Object[] val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param col Collection to write.
-     * @throws PortableException In case of error.
-     */
-    public <T> void writeCollection(String fieldName, @Nullable Collection<T> col) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param map Map to write.
-     * @throws PortableException In case of error.
-     */
-    public <K, V> void writeMap(String fieldName, @Nullable Map<K, V> map) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public <T extends Enum<?>> void writeEnum(String fieldName, T val) throws PortableException;
-
-    /**
-     * @param fieldName Field name.
-     * @param val Value to write.
-     * @throws PortableException In case of error.
-     */
-    public <T extends Enum<?>> void writeEnumArray(String fieldName, T[] val) throws PortableException;
-
-    /**
-     * Gets raw writer. Raw writer does not write field name hash codes, therefore,
-     * making the format even more compact. However, if the raw writer is used,
-     * dynamic structure changes to the portable objects are not supported.
-     *
-     * @return Raw writer.
-     */
-    public GridPortableRawWriter rawWriter();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/PortableBuilder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableBuilder.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableBuilder.java
index e353d7b..969cff7 100644
--- a/modules/core/src/main/java/org/apache/ignite/portables/PortableBuilder.java
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableBuilder.java
@@ -55,7 +55,7 @@ import org.jetbrains.annotations.*;
  *
  * @see org.apache.ignite.IgnitePortables#builder(int)
  * @see org.apache.ignite.IgnitePortables#builder(String)
- * @see org.apache.ignite.IgnitePortables#builder(GridPortableObject)
+ * @see org.apache.ignite.IgnitePortables#builder(PortableObject)
  */
 public interface PortableBuilder {
     /**
@@ -75,7 +75,7 @@ public interface PortableBuilder {
      *
      * @param name Field name.
      * @param val Field value (cannot be {@code null}).
-     * @see GridPortableObject#metaData()
+     * @see PortableObject#metaData()
      */
     public PortableBuilder setField(String name, Object val);
 
@@ -87,7 +87,7 @@ public interface PortableBuilder {
      * @param name Field name.
      * @param val Field value.
      * @param type Field type.
-     * @see GridPortableObject#metaData()
+     * @see PortableObject#metaData()
      */
     public <T> PortableBuilder setField(String name, @Nullable T val, Class<? super T> type);
 
@@ -125,5 +125,5 @@ public interface PortableBuilder {
      * @return Portable object.
      * @throws PortableException In case of error.
      */
-    public GridPortableObject build() throws PortableException;
+    public PortableObject build() throws PortableException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/PortableConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableConfiguration.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableConfiguration.java
index 573836e..986d49c 100644
--- a/modules/core/src/main/java/org/apache/ignite/portables/PortableConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableConfiguration.java
@@ -17,7 +17,7 @@ import java.util.*;
 /**
  * Defines configuration for GridGain portable functionality. All configuration
  * properties defined here can be overridden on per-type level in
- * {@link GridPortableTypeConfiguration}. Type configurations are provided via
+ * {@link PortableTypeConfiguration}. Type configurations are provided via
  * {@link #getTypeConfigurations()} method.
  */
 public class PortableConfiguration {
@@ -28,10 +28,10 @@ public class PortableConfiguration {
     private PortableIdMapper idMapper;
 
     /** Serializer. */
-    private GridPortableSerializer serializer;
+    private PortableSerializer serializer;
 
     /** Types. */
-    private Collection<GridPortableTypeConfiguration> typeCfgs;
+    private Collection<PortableTypeConfiguration> typeCfgs;
 
     /** Use timestamp flag. */
     private boolean useTs = true;
@@ -83,7 +83,7 @@ public class PortableConfiguration {
      *
      * @return Serializer.
      */
-    public GridPortableSerializer getSerializer() {
+    public PortableSerializer getSerializer() {
         return serializer;
     }
 
@@ -92,7 +92,7 @@ public class PortableConfiguration {
      *
      * @param serializer Serializer.
      */
-    public void setSerializer(GridPortableSerializer serializer) {
+    public void setSerializer(PortableSerializer serializer) {
         this.serializer = serializer;
     }
 
@@ -101,7 +101,7 @@ public class PortableConfiguration {
      *
      * @return Types configuration.
      */
-    public Collection<GridPortableTypeConfiguration> getTypeConfigurations() {
+    public Collection<PortableTypeConfiguration> getTypeConfigurations() {
         return typeCfgs;
     }
 
@@ -110,7 +110,7 @@ public class PortableConfiguration {
      *
      * @param typeCfgs Type configurations.
      */
-    public void setTypeConfigurations(Collection<GridPortableTypeConfiguration> typeCfgs) {
+    public void setTypeConfigurations(Collection<PortableTypeConfiguration> typeCfgs) {
         this.typeCfgs = typeCfgs;
     }
 
@@ -134,7 +134,7 @@ public class PortableConfiguration {
 
     /**
      * If {@code true}, meta data will be collected or all types. If you need to override this behaviour for
-     * some specific type, use {@link GridPortableTypeConfiguration#setMetaDataEnabled(Boolean)} method.
+     * some specific type, use {@link PortableTypeConfiguration#setMetaDataEnabled(Boolean)} method.
      * <p>
      * Default value if {@code true}.
      *
@@ -152,11 +152,11 @@ public class PortableConfiguration {
     }
 
     /**
-     * If {@code true}, {@link GridPortableObject} will cache deserialized instance after
-     * {@link GridPortableObject#deserialize()} is called. All consequent calls of this
-     * method on the same instance of {@link GridPortableObject} will return that cached
+     * If {@code true}, {@link PortableObject} will cache deserialized instance after
+     * {@link PortableObject#deserialize()} is called. All consequent calls of this
+     * method on the same instance of {@link PortableObject} will return that cached
      * value without actually deserializing portable object. If you need to override this
-     * behaviour for some specific type, use {@link GridPortableTypeConfiguration#setKeepDeserialized(Boolean)}
+     * behaviour for some specific type, use {@link PortableTypeConfiguration#setKeepDeserialized(Boolean)}
      * method.
      * <p>
      * Default value if {@code true}.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/PortableIdMapper.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableIdMapper.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableIdMapper.java
index dafaca9..b2e69e5 100644
--- a/modules/core/src/main/java/org/apache/ignite/portables/PortableIdMapper.java
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableIdMapper.java
@@ -21,7 +21,7 @@ package org.apache.ignite.portables;
  * <p>
  * Portable ID mapper can be configured for all portable objects via
  * {@link PortableConfiguration#getIdMapper()} method, or for a specific
- * portable type via {@link GridPortableTypeConfiguration#getIdMapper()} method.
+ * portable type via {@link PortableTypeConfiguration#getIdMapper()} method.
  */
 public interface PortableIdMapper {
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/PortableInvalidClassException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableInvalidClassException.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableInvalidClassException.java
index 5322fa9..fc3f040 100644
--- a/modules/core/src/main/java/org/apache/ignite/portables/PortableInvalidClassException.java
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableInvalidClassException.java
@@ -14,7 +14,7 @@ import org.jetbrains.annotations.*;
 /**
  * Exception indicating that class needed for deserialization of portable object does not exist.
  * <p>
- * Thrown from {@link GridPortableObject#deserialize()} method.
+ * Thrown from {@link PortableObject#deserialize()} method.
  */
 public class PortableInvalidClassException extends PortableException {
     /** */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/PortableMarshalAware.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableMarshalAware.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableMarshalAware.java
index d0b5bcb..78dd0e5 100644
--- a/modules/core/src/main/java/org/apache/ignite/portables/PortableMarshalAware.java
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableMarshalAware.java
@@ -28,7 +28,7 @@ public interface PortableMarshalAware {
      * @param writer Portable object writer.
      * @throws PortableException In case of error.
      */
-    public void writePortable(GridPortableWriter writer) throws PortableException;
+    public void writePortable(PortableWriter writer) throws PortableException;
 
     /**
      * Reads fields from provided reader.
@@ -36,5 +36,5 @@ public interface PortableMarshalAware {
      * @param reader Portable object reader.
      * @throws PortableException In case of error.
      */
-    public void readPortable(GridPortableReader reader) throws PortableException;
+    public void readPortable(PortableReader reader) throws PortableException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/PortableMetadata.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableMetadata.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableMetadata.java
new file mode 100644
index 0000000..15f4abd
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableMetadata.java
@@ -0,0 +1,53 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.portables;
+
+import org.jetbrains.annotations.*;
+
+import java.util.*;
+
+/**
+ * Portable type meta data. Metadata for portable types can be accessed from any of the
+ * {@link org.apache.ignite.IgnitePortables#metadata(String) GridPortables.metadata(...)} methods.
+ * Having metadata also allows for proper formatting of {@code GridPortableObject.toString()} method,
+ * even when portable objects are kept in binary format only, which may be necessary for audit reasons.
+ */
+public interface PortableMetadata {
+    /**
+     * Gets portable type name.
+     *
+     * @return Portable type name.
+     */
+    public String typeName();
+
+    /**
+     * Gets collection of all field names for this portable type.
+     *
+     * @return Collection of all field names for this portable type.
+     */
+    public Collection<String> fields();
+
+    /**
+     * Gets name of the field type for a given field.
+     *
+     * @param fieldName Field name.
+     * @return Field type name.
+     */
+    @Nullable public String fieldTypeName(String fieldName);
+
+    /**
+     * Portable objects can optionally specify custom key-affinity mapping in the
+     * configuration. This method returns the name of the field which should be
+     * used for the key-affinity mapping.
+     *
+     * @return Affinity key field name.
+     */
+    @Nullable public String affinityKeyFieldName();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1515c5aa/modules/core/src/main/java/org/apache/ignite/portables/PortableObject.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/portables/PortableObject.java b/modules/core/src/main/java/org/apache/ignite/portables/PortableObject.java
new file mode 100644
index 0000000..59b9141
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/portables/PortableObject.java
@@ -0,0 +1,166 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.portables;
+
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+import java.util.*;
+
+/**
+ * Wrapper for portable object in portable binary format. Once an object is defined as portable,
+ * GridGain will always store it in memory in the portable (i.e. binary) format.
+ * User can choose to work either with the portable format or with the deserialized form
+ * (assuming that class definitions are present in the classpath).
+ * <p>
+ * <b>NOTE:</b> user does not need to (and should not) implement this interface directly.
+ * <p>
+ * To work with the portable format directly, user should create a cache projection
+ * over {@code GridPortableObject} class and then retrieve individual fields as needed:
+ * <pre name=code class=java>
+ * GridCacheProjection&lt;GridPortableObject.class, GridPortableObject.class&gt; prj =
+ *     cache.projection(GridPortableObject.class, GridPortableObject.class);
+ *
+ * // Convert instance of MyKey to portable format.
+ * // We could also use GridPortableBuilder to create
+ * // the key in portable format directly.
+ * GridPortableObject key = grid.portables().toPortable(new MyKey());
+ *
+ * GridPortableObject val = prj.get(key);
+ *
+ * String field = val.field("myFieldName");
+ * </pre>
+ * Alternatively, we could also choose a hybrid approach, where, for example,
+ * the keys are concrete deserialized objects and the values are returned in portable
+ * format, like so:
+ * <pre name=code class=java>
+ * GridCacheProjection&lt;MyKey.class, GridPortableObject.class&gt; prj =
+ *     cache.projection(MyKey.class, GridPortableObject.class);
+ *
+ * GridPortableObject val = prj.get(new MyKey());
+ *
+ * String field = val.field("myFieldName");
+ * </pre>
+ * We could also have the values as concrete deserialized objects and the keys in portable format,
+ * but such use case is a lot less common because cache keys are usually a lot smaller than values, and
+ * it may be very cheap to deserialize the keys, but not the values.
+ * <p>
+ * And finally, if we have class definitions in the classpath, we may choose to work with deserialized
+ * typed objects at all times. In this case we do incur the deserialization cost, however,
+ * GridGain will only deserialize on the first access and will cache the deserialized object,
+ * so it does not have to be deserialized again:
+ * <pre name=code class=java>
+ * GridCacheProjection&lt;MyKey.class, MyValue.class&gt; prj =
+ *     cache.projection(MyKey.class, MyValue.class);
+ *
+ * MyValue val = prj.get(new MyKey());
+ *
+ * // Normal java getter.
+ * String fieldVal = val.getMyFieldName();
+ * </pre>
+ * <h1 class="header">Working With Maps and Collections</h1>
+ * All maps and collections in the portable objects are serialized automatically. When working
+ * with different platforms, e.g. C++ or .NET, GridGain will automatically pick the most
+ * adequate collection or map in either language. For example, {@link ArrayList} in Java will become
+ * {@code List} in C#, {@link LinkedList} in Java is {@link LinkedList} in C#, {@link HashMap}
+ * in Java is {@code Dictionary} in C#, and {@link TreeMap} in Java becomes {@code SortedDictionary}
+ * in C#, etc.
+ * <h1 class="header">Dynamic Structure Changes</h1>
+ * Since objects are always cached in the portable binary format, server does not need to
+ * be aware of the class definitions. Moreover, if class definitions are not present or not
+ * used on the server, then clients can continuously change the structure of the portable
+ * objects without having to restart the cluster. For example, if one client stores a
+ * certain class with fields A and B, and another client stores the same class with
+ * fields B and C, then the server-side portable object will have the fields A, B, and C.
+ * As the structure of a portable object changes, the new fields become available for SQL queries
+ * automatically.
+ * <h1 class="header">Building Portable Objects</h1>
+ * GridGain comes with {@link PortableBuilder} which allows to build portable objects dynamically:
+ * <pre name=code class=java>
+ * GridPortableBuilder builder = GridGain.grid().portables().builder("org.project.MyObject");
+ *
+ * builder.setField("fieldA", "A");
+ * builder.setField("fieldB", "B");
+ *
+ * GridPortableObject portableObj = builder.build();
+ * </pre>
+ * For the cases when class definition is present
+ * in the class path, it is also possible to populate a standard POJO and then
+ * convert it to portable format, like so:
+ * <pre name=code class=java>
+ * MyObject obj = new MyObject();
+ *
+ * obj.setFieldA("A");
+ * obj.setFieldB(123);
+ *
+ * GridPortableObject portableObj = GridGain.grid().portables().toPortable(obj);
+ * </pre>
+ * <h1 class="header">Portable Metadata</h1>
+ * Even though GridGain portable protocol only works with hash codes for type and field names
+ * to achieve better performance, GridGain provides metadata for all portable types which
+ * can be queried ar runtime via any of the {@link org.apache.ignite.IgnitePortables#metadata(Class) GridPortables.metadata(...)}
+ * methods. Having metadata also allows for proper formatting of {@code GridPortableObject.toString()} method,
+ * even when portable objects are kept in binary format only, which may be necessary for audit reasons.
+ */
+public interface PortableObject extends Serializable, Cloneable {
+    /**
+     * Gets portable object type ID.
+     *
+     * @return Type ID.
+     */
+    public int typeId();
+
+    /**
+     * Gets meta data for this portable object.
+     *
+     * @return Meta data.
+     * @throws PortableException In case of error.
+     */
+    @Nullable public PortableMetadata metaData() throws PortableException;
+
+    /**
+     * Gets field value.
+     *
+     * @param fieldName Field name.
+     * @return Field value.
+     * @throws PortableException In case of any other error.
+     */
+    @Nullable public <F> F field(String fieldName) throws PortableException;
+
+    /**
+     * Gets fully deserialized instance of portable object.
+     *
+     * @return Fully deserialized instance of portable object.
+     * @throws PortableInvalidClassException If class doesn't exist.
+     * @throws PortableException In case of any other error.
+     */
+    @Nullable public <T> T deserialize() throws PortableException;
+
+    /**
+     * Creates a copy of this portable object and optionally changes field values
+     * if they are provided in map. If map is empty or {@code null}, clean copy
+     * is created.
+     *
+     * @param fields Fields to modify in copy.
+     * @return Copy of this portable object.
+     * @throws PortableException In case of error.
+     * @deprecated Use {@link PortableBuilder} instead.
+     * @see PortableBuilder
+     */
+    @Deprecated
+    public PortableObject copy(@Nullable Map<String, Object> fields) throws PortableException;
+
+    /**
+     * Copies this portable object.
+     *
+     * @return Copy of this portable object.
+     */
+    public PortableObject clone() throws CloneNotSupportedException;
+}


[19/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
# Renaming


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

Branch: refs/heads/master
Commit: 3ba3dc44103f39273513b1dad885beb9526ac55d
Parents: cd01ed9
Author: sboikov <sb...@gridgain.com>
Authored: Fri Dec 5 11:19:34 2014 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Dec 5 11:19:34 2014 +0300

----------------------------------------------------------------------
 examples/config/filesystem/example-ggfs.xml     |   2 +-
 .../main/java/org/apache/ignite/IgniteFs.java   |  20 +-
 .../ggfs/GridGgfsCorruptedFileException.java    |  42 ----
 .../org/gridgain/grid/ggfs/GridGgfsFile.java    | 112 ---------
 .../ggfs/GridGgfsFileNotFoundException.java     |  36 ---
 .../gridgain/grid/ggfs/GridGgfsFileSystem.java  | 208 ----------------
 .../ggfs/GridGgfsGroupDataBlocksKeyMapper.java  |  93 --------
 .../grid/ggfs/IgniteFsConfiguration.java        |   6 +-
 .../ggfs/IgniteFsCorruptedFileException.java    |  42 ++++
 .../org/gridgain/grid/ggfs/IgniteFsFile.java    | 112 +++++++++
 .../ggfs/IgniteFsFileNotFoundException.java     |  36 +++
 .../gridgain/grid/ggfs/IgniteFsFileSystem.java  | 208 ++++++++++++++++
 .../ggfs/IgniteFsGroupDataBlocksKeyMapper.java  |  93 ++++++++
 .../grid/ggfs/mapreduce/GridGgfsTask.java       |   2 +-
 .../ggfs/common/GridGgfsControlResponse.java    |  18 +-
 .../processors/ggfs/GridGgfsAsyncImpl.java      |   6 +-
 .../processors/ggfs/GridGgfsAttributes.java     |   6 +-
 .../processors/ggfs/GridGgfsDataManager.java    |   4 +-
 .../processors/ggfs/GridGgfsFileImpl.java       | 237 -------------------
 .../kernal/processors/ggfs/GridGgfsImpl.java    |  46 ++--
 .../ggfs/GridGgfsInputStreamImpl.java           |   6 +-
 .../processors/ggfs/GridGgfsMetaManager.java    |  46 ++--
 .../ggfs/GridGgfsOutputStreamImpl.java          |   2 +-
 .../processors/ggfs/GridGgfsProcessor.java      |   8 +-
 .../processors/ggfs/IgniteFsFileImpl.java       | 237 +++++++++++++++++++
 .../visor/node/VisorGgfsConfiguration.java      |   2 +-
 modules/core/src/test/config/ggfs-loopback.xml  |   2 +-
 .../core/src/test/config/ggfs-no-endpoint.xml   |   2 +-
 modules/core/src/test/config/ggfs-shmem.xml     |   2 +-
 .../ggfs/GridGgfsEventsAbstractSelfTest.java    |   2 +-
 .../GridGgfsFragmentizerAbstractSelfTest.java   |   6 +-
 ...heGgfsPerBlockLruEvictionPolicySelfTest.java |   4 +-
 .../ggfs/GridGgfsAbstractSelfTest.java          |  26 +-
 .../processors/ggfs/GridGgfsCacheSelfTest.java  |   2 +-
 .../ggfs/GridGgfsDataManagerSelfTest.java       |   2 +-
 .../ggfs/GridGgfsDualAbstractSelfTest.java      |  10 +-
 ...GgfsGroupDataBlockKeyMapperHashSelfTest.java |   8 +-
 .../ggfs/GridGgfsMetaManagerSelfTest.java       |   2 +-
 .../ggfs/GridGgfsMetricsSelfTest.java           |   4 +-
 .../processors/ggfs/GridGgfsModesSelfTest.java  |   4 +-
 .../ggfs/GridGgfsProcessorSelfTest.java         |  10 +-
 .../GridGgfsProcessorValidationSelfTest.java    |   4 +-
 ...IpcEndpointRegistrationAbstractSelfTest.java |   2 +-
 .../processors/ggfs/GridGgfsSizeSelfTest.java   |   2 +-
 .../ggfs/GridGgfsStreamsSelfTest.java           |   8 +-
 .../processors/ggfs/GridGgfsTaskSelfTest.java   |   2 +-
 .../GridGgfsAbstractRecordResolverSelfTest.java |   2 +-
 .../hadoop/v1/GridGgfsHadoopFileSystem.java     |  10 +-
 .../hadoop/v2/GridGgfsHadoopFileSystem.java     |  10 +-
 .../grid/kernal/ggfs/hadoop/GridGgfsHadoop.java |   6 +-
 .../hadoop/GridGgfsHadoopFileSystemWrapper.java |  26 +-
 .../ggfs/hadoop/GridGgfsHadoopInProc.java       |   6 +-
 .../ggfs/hadoop/GridGgfsHadoopOutProc.java      |  10 +-
 .../kernal/ggfs/hadoop/GridGgfsHadoopUtils.java |   2 +-
 .../ggfs/hadoop/GridGgfsHadoopWrapper.java      |  18 +-
 .../GridHadoopClientProtocolSelfTest.java       |   2 +-
 ...dGgfsHadoop20FileSystemAbstractSelfTest.java |   6 +-
 .../GridGgfsHadoopDualAbstractSelfTest.java     |   6 +-
 ...ridGgfsHadoopFileSystemAbstractSelfTest.java |   6 +-
 .../GridGgfsHadoopFileSystemClientSelfTest.java |   2 +-
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |   2 +-
 ...ridGgfsHadoopFileSystemIpcCacheSelfTest.java |   2 +-
 .../GridGgfsHadoopFileSystemLoggerSelfTest.java |   4 +-
 ...GgfsHadoopFileSystemLoggerStateSelfTest.java |   2 +-
 ...fsHadoopFileSystemSecondaryModeSelfTest.java |   4 +-
 .../ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java |   2 +-
 .../hadoop/GridHadoopAbstractSelfTest.java      |   2 +-
 ...idHadoopDefaultMapReducePlannerSelfTest.java |   6 +-
 68 files changed, 935 insertions(+), 935 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/examples/config/filesystem/example-ggfs.xml
----------------------------------------------------------------------
diff --git a/examples/config/filesystem/example-ggfs.xml b/examples/config/filesystem/example-ggfs.xml
index 9c6ec1c..1387438 100644
--- a/examples/config/filesystem/example-ggfs.xml
+++ b/examples/config/filesystem/example-ggfs.xml
@@ -119,7 +119,7 @@
                     <property name="distributionMode" value="PARTITIONED_ONLY"/>
                     <property name="backups" value="0"/>
                     <property name="affinityMapper">
-                        <bean class="org.gridgain.grid.ggfs.GridGgfsGroupDataBlocksKeyMapper">
+                        <bean class="org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper">
                             <!-- Haw many blocks in row will be stored on the same node. -->
                             <constructor-arg value="512"/>
                         </bean>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
index 21b28fb..b2780fc 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
@@ -48,7 +48,7 @@ import java.util.*;
  * <p>
  * <b>NOTE:</b> integration with Hadoop is available only in {@code In-Memory Accelerator For Hadoop} edition.
  */
-public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
+public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
     /** GGFS scheme name. */
     public static final String GGFS_SCHEME = "ggfs";
 
@@ -75,7 +75,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      *
      * @param path Path to get information for.
      * @return Summary object.
-     * @throws GridGgfsFileNotFoundException If path is not found.
+     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path is not found.
      * @throws GridException If failed.
      */
     public IgniteFsPathSummary summary(IgniteFsPath path) throws GridException;
@@ -86,7 +86,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @param path File path to read.
      * @return File input stream to read data from.
      * @throws GridException In case of error.
-     * @throws GridGgfsFileNotFoundException If path doesn't exist.
+     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist.
      */
     public GridGgfsInputStream open(IgniteFsPath path) throws GridException;
 
@@ -97,7 +97,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @param bufSize Read buffer size (bytes) or {@code zero} to use default value.
      * @return File input stream to read data from.
      * @throws GridException In case of error.
-     * @throws GridGgfsFileNotFoundException If path doesn't exist.
+     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist.
      */
     @Override public GridGgfsInputStream open(IgniteFsPath path, int bufSize) throws GridException;
 
@@ -109,7 +109,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @param seqReadsBeforePrefetch Amount of sequential reads before prefetch is started.
      * @return File input stream to read data from.
      * @throws GridException In case of error.
-     * @throws GridGgfsFileNotFoundException If path doesn't exist.
+     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist.
      */
     public GridGgfsInputStream open(IgniteFsPath path, int bufSize, int seqReadsBeforePrefetch) throws GridException;
 
@@ -163,7 +163,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @param create Create file if it doesn't exist yet.
      * @return File output stream to append data to.
      * @throws GridException In case of error.
-     * @throws GridGgfsFileNotFoundException If path doesn't exist and create flag is {@code false}.
+     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist and create flag is {@code false}.
      */
     public GridGgfsOutputStream append(IgniteFsPath path, boolean create) throws GridException;
 
@@ -176,7 +176,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @param props File properties to set only in case it file was just created.
      * @return File output stream to append data to.
      * @throws GridException In case of error.
-     * @throws GridGgfsFileNotFoundException If path doesn't exist and create flag is {@code false}.
+     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist and create flag is {@code false}.
      */
     @Override public GridGgfsOutputStream append(IgniteFsPath path, int bufSize, boolean create,
         @Nullable Map<String, String> props) throws GridException;
@@ -189,7 +189,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @param accessTime Optional last access time to set. Value {@code -1} does not update access time.
      * @param modificationTime Optional last modification time to set. Value {@code -1} does not update
      *      modification time.
-     * @throws GridGgfsFileNotFoundException If target was not found.
+     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If target was not found.
      * @throws GridException If error occurred.
      */
     public void setTimes(IgniteFsPath path, long accessTime, long modificationTime) throws GridException;
@@ -203,7 +203,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @param len Size of data in the file to resolve affinity for.
      * @return Affinity block locations.
      * @throws GridException In case of error.
-     * @throws GridGgfsFileNotFoundException If path doesn't exist.
+     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist.
      */
     public Collection<IgniteFsBlockLocation> affinity(IgniteFsPath path, long start, long len) throws GridException;
 
@@ -218,7 +218,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @param maxLen Maximum length of a single returned block location length.
      * @return Affinity block locations.
      * @throws GridException In case of error.
-     * @throws GridGgfsFileNotFoundException If path doesn't exist.
+     * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist.
      */
     public Collection<IgniteFsBlockLocation> affinity(IgniteFsPath path, long start, long len, long maxLen)
         throws GridException;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsCorruptedFileException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsCorruptedFileException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsCorruptedFileException.java
deleted file mode 100644
index 4159042..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsCorruptedFileException.java
+++ /dev/null
@@ -1,42 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.jetbrains.annotations.*;
-
-/**
- * Exception thrown when target file's block is not found in data cache.
- */
-public class GridGgfsCorruptedFileException extends IgniteFsException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * @param msg Error message.
-     */
-    public GridGgfsCorruptedFileException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * @param cause Error cause.
-     */
-    public GridGgfsCorruptedFileException(Throwable cause) {
-        super(cause);
-    }
-
-    /**
-     * @param msg Error message.
-     * @param cause Error cause.
-     */
-    public GridGgfsCorruptedFileException(String msg, @Nullable Throwable cause) {
-        super(msg, cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFile.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFile.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFile.java
deleted file mode 100644
index 558a961..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFile.java
+++ /dev/null
@@ -1,112 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.jetbrains.annotations.*;
-
-import java.util.*;
-
-/**
- * {@code GGFS} file or directory descriptor. For example, to get information about
- * a file you would use the following code:
- * <pre name="code" class="java">
- *     GridGgfsPath filePath = new GridGgfsPath("my/working/dir", "file.txt");
- *
- *     // Get metadata about file.
- *     GridGgfsFile file = ggfs.info(filePath);
- * </pre>
- */
-public interface GridGgfsFile {
-    /**
-     * Gets path to file.
-     *
-     * @return Path to file.
-     */
-    public IgniteFsPath path();
-
-    /**
-     * Check this file is a data file.
-     *
-     * @return {@code True} if this is a data file.
-     */
-    public boolean isFile();
-
-    /**
-     * Check this file is a directory.
-     *
-     * @return {@code True} if this is a directory.
-     */
-    public boolean isDirectory();
-
-    /**
-     * Gets file's length.
-     *
-     * @return File's length or {@code zero} for directories.
-     */
-    public long length();
-
-    /**
-     * Gets file's data block size.
-     *
-     * @return File's data block size or {@code zero} for directories.
-     */
-    public int blockSize();
-
-    /**
-     * Gets file group block size (i.e. block size * group size).
-     *
-     * @return File group block size.
-     */
-    public long groupBlockSize();
-
-    /**
-     * Gets file last access time. File last access time is not updated automatically due to
-     * performance considerations and can be updated on demand with
-     * {@link org.apache.ignite.IgniteFs#setTimes(IgniteFsPath, long, long)} method.
-     * <p>
-     * By default last access time equals file creation time.
-     *
-     * @return Last access time.
-     */
-    public long accessTime();
-
-    /**
-     * Gets file last modification time. File modification time is updated automatically on each file write and
-     * append.
-     *
-     * @return Last modification time.
-     */
-    public long modificationTime();
-
-    /**
-     * Get file's property for specified name.
-     *
-     * @param name Name of the property.
-     * @return File's property for specified name.
-     * @throws IllegalArgumentException If requested property was not found.
-     */
-    public String property(String name) throws IllegalArgumentException;
-
-    /**
-     * Get file's property for specified name.
-     *
-     * @param name Name of the property.
-     * @param dfltVal Default value if requested property was not found.
-     * @return File's property for specified name.
-     */
-    @Nullable public String property(String name, @Nullable String dfltVal);
-
-    /**
-     * Get properties of the file.
-     *
-     * @return Properties of the file.
-     */
-    public Map<String, String> properties();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFileNotFoundException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFileNotFoundException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFileNotFoundException.java
deleted file mode 100644
index 7bf969f..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFileNotFoundException.java
+++ /dev/null
@@ -1,36 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-/**
- * {@code GGFS} exception indicating that target resource is not found.
- */
-public class GridGgfsFileNotFoundException extends GridGgfsInvalidPathException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Creates exception with error message specified.
-     *
-     * @param msg Error message.
-     */
-    public GridGgfsFileNotFoundException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * Creates exception with given exception cause.
-     *
-     * @param cause Exception cause.
-     */
-    public GridGgfsFileNotFoundException(Throwable cause) {
-        super(cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFileSystem.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFileSystem.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFileSystem.java
deleted file mode 100644
index 2b57888..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFileSystem.java
+++ /dev/null
@@ -1,208 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.gridgain.grid.*;
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-import java.util.*;
-
-/**
- * Common file system interface. It provides a typical generalized "view" of any file system:
- * <ul>
- *     <li>list directories or get information for a single path</li>
- *     <li>create/move/delete files or directories</li>
- *     <li>write/read data streams into/from files</li>
- * </ul>
- *
- * This is the minimum of functionality that is needed to work as secondary file system in dual modes of GGFS.
- */
-public interface GridGgfsFileSystem {
-    /** File property: user name. */
-    public static final String PROP_USER_NAME = "usrName";
-
-    /** File property: group name. */
-    public static final String PROP_GROUP_NAME = "grpName";
-
-    /** File property: permission. */
-    public static final String PROP_PERMISSION = "permission";
-
-    /**
-     * Checks if the specified path exists in the file system.
-     *
-     * @param path Path to check for existence in the file system.
-     * @return {@code True} if such file exists, otherwise - {@code false}.
-     * @throws GridException In case of error.
-     */
-    public boolean exists(IgniteFsPath path) throws GridException;
-
-    /**
-     * Updates file information for the specified path. Existent properties, not listed in the passed collection,
-     * will not be affected. Other properties will be added or overwritten. Passed properties with {@code null} values
-     * will be removed from the stored properties or ignored if they don't exist in the file info.
-     * <p>
-     * When working in {@code DUAL_SYNC} or {@code DUAL_ASYNC} modes only the following properties will be propagated
-     * to the secondary file system:
-     * <ul>
-     * <li>{@code usrName} - file owner name;</li>
-     * <li>{@code grpName} - file owner group;</li>
-     * <li>{@code permission} - Unix-style string representing file permissions.</li>
-     * </ul>
-     *
-     * @param path File path to set properties for.
-     * @param props Properties to update.
-     * @return File information for specified path or {@code null} if such path does not exist.
-     * @throws GridException In case of error.
-     */
-    @Nullable public GridGgfsFile update(IgniteFsPath path, Map<String, String> props) throws GridException;
-
-    /**
-     * Renames/moves a file.
-     * <p>
-     * You are free to rename/move data files as you wish, but directories can be only renamed.
-     * You cannot move the directory between different parent directories.
-     * <p>
-     * Examples:
-     * <ul>
-     *     <li>"/work/file.txt" => "/home/project/Presentation Scenario.txt"</li>
-     *     <li>"/work" => "/work-2012.bkp"</li>
-     *     <li>"/work" => "<strike>/backups/work</strike>" - such operation is restricted for directories.</li>
-     * </ul>
-     *
-     * @param src Source file path to rename.
-     * @param dest Destination file path. If destination path is a directory, then source file will be placed
-     *     into destination directory with original name.
-     * @throws GridException In case of error.
-     * @throws GridGgfsFileNotFoundException If source file doesn't exist.
-     */
-    public void rename(IgniteFsPath src, IgniteFsPath dest) throws GridException;
-
-    /**
-     * Deletes file.
-     *
-     * @param path File path to delete.
-     * @param recursive Delete non-empty directories recursively.
-     * @return {@code True} in case of success, {@code false} otherwise.
-     * @throws GridException In case of error.
-     */
-    boolean delete(IgniteFsPath path, boolean recursive) throws GridException;
-
-    /**
-     * Creates directories under specified path.
-     *
-     * @param path Path of directories chain to create.
-     * @throws GridException In case of error.
-     */
-    public void mkdirs(IgniteFsPath path) throws GridException;
-
-    /**
-     * Creates directories under specified path with the specified properties.
-     *
-     * @param path Path of directories chain to create.
-     * @param props Metadata properties to set on created directories.
-     * @throws GridException In case of error.
-     */
-    public void mkdirs(IgniteFsPath path, @Nullable Map<String, String> props) throws GridException;
-
-    /**
-     * Lists file paths under the specified path.
-     *
-     * @param path Path to list files under.
-     * @return List of files under the specified path.
-     * @throws GridException In case of error.
-     * @throws GridGgfsFileNotFoundException If path doesn't exist.
-     */
-    public Collection<IgniteFsPath> listPaths(IgniteFsPath path) throws GridException;
-
-    /**
-     * Lists files under the specified path.
-     *
-     * @param path Path to list files under.
-     * @return List of files under the specified path.
-     * @throws GridException In case of error.
-     * @throws GridGgfsFileNotFoundException If path doesn't exist.
-     */
-    public Collection<GridGgfsFile> listFiles(IgniteFsPath path) throws GridException;
-
-    /**
-     * Opens a file for reading.
-     *
-     * @param path File path to read.
-     * @param bufSize Read buffer size (bytes) or {@code zero} to use default value.
-     * @return File input stream to read data from.
-     * @throws GridException In case of error.
-     * @throws GridGgfsFileNotFoundException If path doesn't exist.
-     */
-    public IgniteFsReader open(IgniteFsPath path, int bufSize) throws GridException;
-
-    /**
-     * Creates a file and opens it for writing.
-     *
-     * @param path File path to create.
-     * @param overwrite Overwrite file if it already exists. Note: you cannot overwrite an existent directory.
-     * @return File output stream to write data to.
-     * @throws GridException In case of error.
-     */
-    public OutputStream create(IgniteFsPath path, boolean overwrite) throws GridException;
-
-    /**
-     * Creates a file and opens it for writing.
-     *
-     * @param path File path to create.
-     * @param bufSize Write buffer size (bytes) or {@code zero} to use default value.
-     * @param overwrite Overwrite file if it already exists. Note: you cannot overwrite an existent directory.
-     * @param replication Replication factor.
-     * @param blockSize Block size.
-     * @param props File properties to set.
-     * @return File output stream to write data to.
-     * @throws GridException In case of error.
-     */
-    public OutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication, long blockSize,
-       @Nullable Map<String, String> props) throws GridException;
-
-    /**
-     * Opens an output stream to an existing file for appending data.
-     *
-     * @param path File path to append.
-     * @param bufSize Write buffer size (bytes) or {@code zero} to use default value.
-     * @param create Create file if it doesn't exist yet.
-     * @param props File properties to set only in case it file was just created.
-     * @return File output stream to append data to.
-     * @throws GridException In case of error.
-     * @throws GridGgfsFileNotFoundException If path doesn't exist and create flag is {@code false}.
-     */
-    public OutputStream append(IgniteFsPath path, int bufSize, boolean create, @Nullable Map<String, String> props)
-        throws GridException;
-
-    /**
-     * Gets file information for the specified path.
-     *
-     * @param path Path to get information for.
-     * @return File information for specified path or {@code null} if such path does not exist.
-     * @throws GridException In case of error.
-     */
-    @Nullable public GridGgfsFile info(IgniteFsPath path) throws GridException;
-
-    /**
-     * Gets used space in bytes.
-     *
-     * @return Used space in bytes.
-     * @throws GridException In case of error.
-     */
-    public long usedSpaceSize() throws GridException;
-
-    /**
-     * Gets the implementation specific properties of file system.
-     *
-     * @return Map of properties.
-     */
-    public Map<String,String> properties();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsGroupDataBlocksKeyMapper.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsGroupDataBlocksKeyMapper.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsGroupDataBlocksKeyMapper.java
deleted file mode 100644
index 0fd4509..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsGroupDataBlocksKeyMapper.java
+++ /dev/null
@@ -1,93 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.gridgain.grid.kernal.processors.cache.*;
-import org.gridgain.grid.kernal.processors.ggfs.*;
-import org.gridgain.grid.util.typedef.internal.*;
-
-/**
- * {@code GGFS} class providing ability to group file's data blocks together on one node.
- * All blocks within the same group are guaranteed to be cached together on the same node.
- * Group size parameter controls how many sequential blocks will be cached together on the same node.
- * <p>
- * For example, if block size is {@code 64kb} and group size is {@code 256}, then each group will contain
- * {@code 64kb * 256 = 16Mb}. Larger group sizes would reduce number of splits required to run map-reduce
- * tasks, but will increase inequality of data size being stored on different nodes.
- * <p>
- * Note that {@link #groupSize()} parameter must correlate to Hadoop split size parameter defined
- * in Hadoop via {@code mapred.max.split.size} property. Ideally you want all blocks accessed
- * within one split to be mapped to {@code 1} group, so they can be located on the same grid node.
- * For example, default Hadoop split size is {@code 64mb} and default {@code GGFS} block size
- * is {@code 64kb}. This means that to make sure that each split goes only through blocks on
- * the same node (without hopping between nodes over network), we have to make the {@link #groupSize()}
- * value be equal to {@code 64mb / 64kb = 1024}.
- * <p>
- * It is required for {@code GGFS} data cache to be configured with this mapper. Here is an
- * example of how it can be specified in XML configuration:
- * <pre name="code" class="xml">
- * &lt;bean id="cacheCfgBase" class="org.gridgain.grid.cache.GridCacheConfiguration" abstract="true"&gt;
- *     ...
- *     &lt;property name="affinityMapper"&gt;
- *         &lt;bean class="org.gridgain.grid.ggfs.GridGgfsGroupDataBlocksKeyMapper"&gt;
- *             &lt;!-- How many sequential blocks will be stored on the same node. --&gt;
- *             &lt;constructor-arg value="512"/&gt;
- *         &lt;/bean&gt;
- *     &lt;/property&gt;
- *     ...
- * &lt;/bean&gt;
- * </pre>
- */
-public class GridGgfsGroupDataBlocksKeyMapper extends GridCacheDefaultAffinityKeyMapper {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** Size of the group. */
-    private final int grpSize;
-
-    /***
-     * Constructs affinity mapper to group several data blocks with the same key.
-     *
-     * @param grpSize Size of the group in blocks.
-     */
-    public GridGgfsGroupDataBlocksKeyMapper(int grpSize) {
-        A.ensure(grpSize >= 1, "grpSize >= 1");
-
-        this.grpSize = grpSize;
-    }
-
-    /** {@inheritDoc} */
-    @Override public Object affinityKey(Object key) {
-        if (key != null && GridGgfsBlockKey.class.equals(key.getClass())) {
-            GridGgfsBlockKey blockKey = (GridGgfsBlockKey)key;
-
-            if (blockKey.affinityKey() != null)
-                return blockKey.affinityKey();
-
-            long grpId = blockKey.getBlockId() / grpSize;
-
-            return blockKey.getFileId().hashCode() + (int)(grpId ^ (grpId >>> 32));
-        }
-
-        return super.affinityKey(key);
-    }
-
-    /**
-     * @return Size of the group.
-     */
-    public int groupSize() {
-        return grpSize;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridGgfsGroupDataBlocksKeyMapper.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
index 670a3a2..8b43058 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsConfiguration.java
@@ -115,7 +115,7 @@ public class IgniteFsConfiguration {
     private int mgmtPort = DFLT_MGMT_PORT;
 
     /** Secondary file system */
-    private GridGgfsFileSystem secondaryFs;
+    private IgniteFsFileSystem secondaryFs;
 
     /** GGFS mode. */
     private GridGgfsMode dfltMode = DFLT_MODE;
@@ -511,7 +511,7 @@ public class IgniteFsConfiguration {
      *
      * @return Secondary file system.
      */
-    public GridGgfsFileSystem getSecondaryFileSystem() {
+    public IgniteFsFileSystem getSecondaryFileSystem() {
         return secondaryFs;
     }
 
@@ -521,7 +521,7 @@ public class IgniteFsConfiguration {
      *
      * @param fileSystem
      */
-    public void setSecondaryFileSystem(GridGgfsFileSystem fileSystem) {
+    public void setSecondaryFileSystem(IgniteFsFileSystem fileSystem) {
         secondaryFs = fileSystem;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsCorruptedFileException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsCorruptedFileException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsCorruptedFileException.java
new file mode 100644
index 0000000..b3aeaf6
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsCorruptedFileException.java
@@ -0,0 +1,42 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+import org.jetbrains.annotations.*;
+
+/**
+ * Exception thrown when target file's block is not found in data cache.
+ */
+public class IgniteFsCorruptedFileException extends IgniteFsException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * @param msg Error message.
+     */
+    public IgniteFsCorruptedFileException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * @param cause Error cause.
+     */
+    public IgniteFsCorruptedFileException(Throwable cause) {
+        super(cause);
+    }
+
+    /**
+     * @param msg Error message.
+     * @param cause Error cause.
+     */
+    public IgniteFsCorruptedFileException(String msg, @Nullable Throwable cause) {
+        super(msg, cause);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFile.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFile.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFile.java
new file mode 100644
index 0000000..9e39239
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFile.java
@@ -0,0 +1,112 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+import org.jetbrains.annotations.*;
+
+import java.util.*;
+
+/**
+ * {@code GGFS} file or directory descriptor. For example, to get information about
+ * a file you would use the following code:
+ * <pre name="code" class="java">
+ *     GridGgfsPath filePath = new GridGgfsPath("my/working/dir", "file.txt");
+ *
+ *     // Get metadata about file.
+ *     GridGgfsFile file = ggfs.info(filePath);
+ * </pre>
+ */
+public interface IgniteFsFile {
+    /**
+     * Gets path to file.
+     *
+     * @return Path to file.
+     */
+    public IgniteFsPath path();
+
+    /**
+     * Check this file is a data file.
+     *
+     * @return {@code True} if this is a data file.
+     */
+    public boolean isFile();
+
+    /**
+     * Check this file is a directory.
+     *
+     * @return {@code True} if this is a directory.
+     */
+    public boolean isDirectory();
+
+    /**
+     * Gets file's length.
+     *
+     * @return File's length or {@code zero} for directories.
+     */
+    public long length();
+
+    /**
+     * Gets file's data block size.
+     *
+     * @return File's data block size or {@code zero} for directories.
+     */
+    public int blockSize();
+
+    /**
+     * Gets file group block size (i.e. block size * group size).
+     *
+     * @return File group block size.
+     */
+    public long groupBlockSize();
+
+    /**
+     * Gets file last access time. File last access time is not updated automatically due to
+     * performance considerations and can be updated on demand with
+     * {@link org.apache.ignite.IgniteFs#setTimes(IgniteFsPath, long, long)} method.
+     * <p>
+     * By default last access time equals file creation time.
+     *
+     * @return Last access time.
+     */
+    public long accessTime();
+
+    /**
+     * Gets file last modification time. File modification time is updated automatically on each file write and
+     * append.
+     *
+     * @return Last modification time.
+     */
+    public long modificationTime();
+
+    /**
+     * Get file's property for specified name.
+     *
+     * @param name Name of the property.
+     * @return File's property for specified name.
+     * @throws IllegalArgumentException If requested property was not found.
+     */
+    public String property(String name) throws IllegalArgumentException;
+
+    /**
+     * Get file's property for specified name.
+     *
+     * @param name Name of the property.
+     * @param dfltVal Default value if requested property was not found.
+     * @return File's property for specified name.
+     */
+    @Nullable public String property(String name, @Nullable String dfltVal);
+
+    /**
+     * Get properties of the file.
+     *
+     * @return Properties of the file.
+     */
+    public Map<String, String> properties();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileNotFoundException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileNotFoundException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileNotFoundException.java
new file mode 100644
index 0000000..8106679
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileNotFoundException.java
@@ -0,0 +1,36 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+/**
+ * {@code GGFS} exception indicating that target resource is not found.
+ */
+public class IgniteFsFileNotFoundException extends GridGgfsInvalidPathException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Creates exception with error message specified.
+     *
+     * @param msg Error message.
+     */
+    public IgniteFsFileNotFoundException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * Creates exception with given exception cause.
+     *
+     * @param cause Exception cause.
+     */
+    public IgniteFsFileNotFoundException(Throwable cause) {
+        super(cause);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileSystem.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileSystem.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileSystem.java
new file mode 100644
index 0000000..26c7f1b
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileSystem.java
@@ -0,0 +1,208 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+import org.gridgain.grid.*;
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+import java.util.*;
+
+/**
+ * Common file system interface. It provides a typical generalized "view" of any file system:
+ * <ul>
+ *     <li>list directories or get information for a single path</li>
+ *     <li>create/move/delete files or directories</li>
+ *     <li>write/read data streams into/from files</li>
+ * </ul>
+ *
+ * This is the minimum of functionality that is needed to work as secondary file system in dual modes of GGFS.
+ */
+public interface IgniteFsFileSystem {
+    /** File property: user name. */
+    public static final String PROP_USER_NAME = "usrName";
+
+    /** File property: group name. */
+    public static final String PROP_GROUP_NAME = "grpName";
+
+    /** File property: permission. */
+    public static final String PROP_PERMISSION = "permission";
+
+    /**
+     * Checks if the specified path exists in the file system.
+     *
+     * @param path Path to check for existence in the file system.
+     * @return {@code True} if such file exists, otherwise - {@code false}.
+     * @throws GridException In case of error.
+     */
+    public boolean exists(IgniteFsPath path) throws GridException;
+
+    /**
+     * Updates file information for the specified path. Existent properties, not listed in the passed collection,
+     * will not be affected. Other properties will be added or overwritten. Passed properties with {@code null} values
+     * will be removed from the stored properties or ignored if they don't exist in the file info.
+     * <p>
+     * When working in {@code DUAL_SYNC} or {@code DUAL_ASYNC} modes only the following properties will be propagated
+     * to the secondary file system:
+     * <ul>
+     * <li>{@code usrName} - file owner name;</li>
+     * <li>{@code grpName} - file owner group;</li>
+     * <li>{@code permission} - Unix-style string representing file permissions.</li>
+     * </ul>
+     *
+     * @param path File path to set properties for.
+     * @param props Properties to update.
+     * @return File information for specified path or {@code null} if such path does not exist.
+     * @throws GridException In case of error.
+     */
+    @Nullable public IgniteFsFile update(IgniteFsPath path, Map<String, String> props) throws GridException;
+
+    /**
+     * Renames/moves a file.
+     * <p>
+     * You are free to rename/move data files as you wish, but directories can be only renamed.
+     * You cannot move the directory between different parent directories.
+     * <p>
+     * Examples:
+     * <ul>
+     *     <li>"/work/file.txt" => "/home/project/Presentation Scenario.txt"</li>
+     *     <li>"/work" => "/work-2012.bkp"</li>
+     *     <li>"/work" => "<strike>/backups/work</strike>" - such operation is restricted for directories.</li>
+     * </ul>
+     *
+     * @param src Source file path to rename.
+     * @param dest Destination file path. If destination path is a directory, then source file will be placed
+     *     into destination directory with original name.
+     * @throws GridException In case of error.
+     * @throws IgniteFsFileNotFoundException If source file doesn't exist.
+     */
+    public void rename(IgniteFsPath src, IgniteFsPath dest) throws GridException;
+
+    /**
+     * Deletes file.
+     *
+     * @param path File path to delete.
+     * @param recursive Delete non-empty directories recursively.
+     * @return {@code True} in case of success, {@code false} otherwise.
+     * @throws GridException In case of error.
+     */
+    boolean delete(IgniteFsPath path, boolean recursive) throws GridException;
+
+    /**
+     * Creates directories under specified path.
+     *
+     * @param path Path of directories chain to create.
+     * @throws GridException In case of error.
+     */
+    public void mkdirs(IgniteFsPath path) throws GridException;
+
+    /**
+     * Creates directories under specified path with the specified properties.
+     *
+     * @param path Path of directories chain to create.
+     * @param props Metadata properties to set on created directories.
+     * @throws GridException In case of error.
+     */
+    public void mkdirs(IgniteFsPath path, @Nullable Map<String, String> props) throws GridException;
+
+    /**
+     * Lists file paths under the specified path.
+     *
+     * @param path Path to list files under.
+     * @return List of files under the specified path.
+     * @throws GridException In case of error.
+     * @throws IgniteFsFileNotFoundException If path doesn't exist.
+     */
+    public Collection<IgniteFsPath> listPaths(IgniteFsPath path) throws GridException;
+
+    /**
+     * Lists files under the specified path.
+     *
+     * @param path Path to list files under.
+     * @return List of files under the specified path.
+     * @throws GridException In case of error.
+     * @throws IgniteFsFileNotFoundException If path doesn't exist.
+     */
+    public Collection<IgniteFsFile> listFiles(IgniteFsPath path) throws GridException;
+
+    /**
+     * Opens a file for reading.
+     *
+     * @param path File path to read.
+     * @param bufSize Read buffer size (bytes) or {@code zero} to use default value.
+     * @return File input stream to read data from.
+     * @throws GridException In case of error.
+     * @throws IgniteFsFileNotFoundException If path doesn't exist.
+     */
+    public IgniteFsReader open(IgniteFsPath path, int bufSize) throws GridException;
+
+    /**
+     * Creates a file and opens it for writing.
+     *
+     * @param path File path to create.
+     * @param overwrite Overwrite file if it already exists. Note: you cannot overwrite an existent directory.
+     * @return File output stream to write data to.
+     * @throws GridException In case of error.
+     */
+    public OutputStream create(IgniteFsPath path, boolean overwrite) throws GridException;
+
+    /**
+     * Creates a file and opens it for writing.
+     *
+     * @param path File path to create.
+     * @param bufSize Write buffer size (bytes) or {@code zero} to use default value.
+     * @param overwrite Overwrite file if it already exists. Note: you cannot overwrite an existent directory.
+     * @param replication Replication factor.
+     * @param blockSize Block size.
+     * @param props File properties to set.
+     * @return File output stream to write data to.
+     * @throws GridException In case of error.
+     */
+    public OutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication, long blockSize,
+       @Nullable Map<String, String> props) throws GridException;
+
+    /**
+     * Opens an output stream to an existing file for appending data.
+     *
+     * @param path File path to append.
+     * @param bufSize Write buffer size (bytes) or {@code zero} to use default value.
+     * @param create Create file if it doesn't exist yet.
+     * @param props File properties to set only in case it file was just created.
+     * @return File output stream to append data to.
+     * @throws GridException In case of error.
+     * @throws IgniteFsFileNotFoundException If path doesn't exist and create flag is {@code false}.
+     */
+    public OutputStream append(IgniteFsPath path, int bufSize, boolean create, @Nullable Map<String, String> props)
+        throws GridException;
+
+    /**
+     * Gets file information for the specified path.
+     *
+     * @param path Path to get information for.
+     * @return File information for specified path or {@code null} if such path does not exist.
+     * @throws GridException In case of error.
+     */
+    @Nullable public IgniteFsFile info(IgniteFsPath path) throws GridException;
+
+    /**
+     * Gets used space in bytes.
+     *
+     * @return Used space in bytes.
+     * @throws GridException In case of error.
+     */
+    public long usedSpaceSize() throws GridException;
+
+    /**
+     * Gets the implementation specific properties of file system.
+     *
+     * @return Map of properties.
+     */
+    public Map<String,String> properties();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsGroupDataBlocksKeyMapper.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsGroupDataBlocksKeyMapper.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsGroupDataBlocksKeyMapper.java
new file mode 100644
index 0000000..b8fd433
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsGroupDataBlocksKeyMapper.java
@@ -0,0 +1,93 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+import org.gridgain.grid.kernal.processors.cache.*;
+import org.gridgain.grid.kernal.processors.ggfs.*;
+import org.gridgain.grid.util.typedef.internal.*;
+
+/**
+ * {@code GGFS} class providing ability to group file's data blocks together on one node.
+ * All blocks within the same group are guaranteed to be cached together on the same node.
+ * Group size parameter controls how many sequential blocks will be cached together on the same node.
+ * <p>
+ * For example, if block size is {@code 64kb} and group size is {@code 256}, then each group will contain
+ * {@code 64kb * 256 = 16Mb}. Larger group sizes would reduce number of splits required to run map-reduce
+ * tasks, but will increase inequality of data size being stored on different nodes.
+ * <p>
+ * Note that {@link #groupSize()} parameter must correlate to Hadoop split size parameter defined
+ * in Hadoop via {@code mapred.max.split.size} property. Ideally you want all blocks accessed
+ * within one split to be mapped to {@code 1} group, so they can be located on the same grid node.
+ * For example, default Hadoop split size is {@code 64mb} and default {@code GGFS} block size
+ * is {@code 64kb}. This means that to make sure that each split goes only through blocks on
+ * the same node (without hopping between nodes over network), we have to make the {@link #groupSize()}
+ * value be equal to {@code 64mb / 64kb = 1024}.
+ * <p>
+ * It is required for {@code GGFS} data cache to be configured with this mapper. Here is an
+ * example of how it can be specified in XML configuration:
+ * <pre name="code" class="xml">
+ * &lt;bean id="cacheCfgBase" class="org.gridgain.grid.cache.GridCacheConfiguration" abstract="true"&gt;
+ *     ...
+ *     &lt;property name="affinityMapper"&gt;
+ *         &lt;bean class="org.gridgain.grid.ggfs.GridGgfsGroupDataBlocksKeyMapper"&gt;
+ *             &lt;!-- How many sequential blocks will be stored on the same node. --&gt;
+ *             &lt;constructor-arg value="512"/&gt;
+ *         &lt;/bean&gt;
+ *     &lt;/property&gt;
+ *     ...
+ * &lt;/bean&gt;
+ * </pre>
+ */
+public class IgniteFsGroupDataBlocksKeyMapper extends GridCacheDefaultAffinityKeyMapper {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** Size of the group. */
+    private final int grpSize;
+
+    /***
+     * Constructs affinity mapper to group several data blocks with the same key.
+     *
+     * @param grpSize Size of the group in blocks.
+     */
+    public IgniteFsGroupDataBlocksKeyMapper(int grpSize) {
+        A.ensure(grpSize >= 1, "grpSize >= 1");
+
+        this.grpSize = grpSize;
+    }
+
+    /** {@inheritDoc} */
+    @Override public Object affinityKey(Object key) {
+        if (key != null && GridGgfsBlockKey.class.equals(key.getClass())) {
+            GridGgfsBlockKey blockKey = (GridGgfsBlockKey)key;
+
+            if (blockKey.affinityKey() != null)
+                return blockKey.affinityKey();
+
+            long grpId = blockKey.getBlockId() / grpSize;
+
+            return blockKey.getFileId().hashCode() + (int)(grpId ^ (grpId >>> 32));
+        }
+
+        return super.affinityKey(key);
+    }
+
+    /**
+     * @return Size of the group.
+     */
+    public int groupSize() {
+        return grpSize;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsGroupDataBlocksKeyMapper.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
index ebf758a..055ef09 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
@@ -89,7 +89,7 @@ public abstract class GridGgfsTask<T, R> extends ComputeTaskAdapter<GridGgfsTask
         Map<UUID, ClusterNode> nodes = mapSubgrid(subgrid);
 
         for (IgniteFsPath path : args.paths()) {
-            GridGgfsFile file = ggfs.info(path);
+            IgniteFsFile file = ggfs.info(path);
 
             if (file == null) {
                 if (args.skipNonExistentFiles())

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
index 00919ee..8abd967 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
@@ -160,7 +160,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
     /**
      * @param res Response.
      */
-    public void response(GridGgfsFile res) {
+    public void response(IgniteFsFile res) {
         resType = RES_TYPE_GGFS_FILE;
 
         this.res = res;
@@ -187,7 +187,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
     /**
      * @param res Response.
      */
-    public void files(Collection<GridGgfsFile> res) {
+    public void files(Collection<IgniteFsFile> res) {
         resType = RES_TYPE_COL_GGFS_FILE;
 
         this.res = res;
@@ -253,7 +253,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
         assert errCode != -1;
 
         if (errCode == ERR_FILE_NOT_FOUND)
-            throw new GridGgfsFileNotFoundException(err);
+            throw new IgniteFsFileNotFoundException(err);
         else if (errCode == ERR_PATH_ALREADY_EXISTS)
             throw new IgniteFsPathAlreadyExistsException(err);
         else if (errCode == ERR_DIRECTORY_NOT_EMPTY)
@@ -263,7 +263,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
         else if (errCode == ERR_INVALID_HDFS_VERSION)
             throw new GridGgfsInvalidHdfsVersionException(err);
         else if (errCode == ERR_CORRUPTED_FILE)
-            throw new GridGgfsCorruptedFileException(err);
+            throw new IgniteFsCorruptedFileException(err);
         else if (errCode == ERR_GGFS_GENERIC)
             throw new IgniteFsException(err);
 
@@ -324,7 +324,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
      */
     @SuppressWarnings("unchecked")
     private int errorCode(GridException e, boolean checkIo) {
-        if (X.hasCause(e, GridGgfsFileNotFoundException.class))
+        if (X.hasCause(e, IgniteFsFileNotFoundException.class))
             return ERR_FILE_NOT_FOUND;
         else if (IgniteFsPathAlreadyExistsException.class.isInstance(e))
             return ERR_PATH_ALREADY_EXISTS;
@@ -334,7 +334,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
             return ERR_PARENT_NOT_DIRECTORY;
         else if (GridGgfsInvalidHdfsVersionException.class.isInstance(e))
             return ERR_INVALID_HDFS_VERSION;
-        else if (X.hasCause(e, GridGgfsCorruptedFileException.class))
+        else if (X.hasCause(e, IgniteFsCorruptedFileException.class))
             return ERR_CORRUPTED_FILE;
             // This check should be the last.
         else if (IgniteFsException.class.isInstance(e))
@@ -495,7 +495,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
                 boolean hasVal = in.readBoolean();
 
                 if (hasVal) {
-                    GridGgfsFileImpl file = new GridGgfsFileImpl();
+                    IgniteFsFileImpl file = new IgniteFsFileImpl();
 
                     file.readExternal(in);
 
@@ -548,7 +548,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
             }
 
             case RES_TYPE_COL_GGFS_FILE: {
-                Collection<GridGgfsFile> files = null;
+                Collection<IgniteFsFile> files = null;
 
                 int size = in.readInt();
 
@@ -556,7 +556,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
                     files = new ArrayList<>(size);
 
                     for (int i = 0; i < size; i++) {
-                        GridGgfsFileImpl file = new GridGgfsFileImpl();
+                        IgniteFsFileImpl file = new IgniteFsFileImpl();
 
                         file.readExternal(in);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
index a38de0d..62726bd 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
@@ -239,7 +239,7 @@ public class GridGgfsAsyncImpl extends IgniteAsyncSupportAdapter implements Grid
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public GridGgfsFile update(IgniteFsPath path, Map<String, String> props) throws GridException {
+    @Nullable @Override public IgniteFsFile update(IgniteFsPath path, Map<String, String> props) throws GridException {
         return ggfs.update(path, props);
     }
 
@@ -269,12 +269,12 @@ public class GridGgfsAsyncImpl extends IgniteAsyncSupportAdapter implements Grid
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsFile> listFiles(IgniteFsPath path) throws GridException {
+    @Override public Collection<IgniteFsFile> listFiles(IgniteFsPath path) throws GridException {
         return ggfs.listFiles(path);
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public GridGgfsFile info(IgniteFsPath path) throws GridException {
+    @Nullable @Override public IgniteFsFile info(IgniteFsPath path) throws GridException {
         return ggfs.info(path);
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributes.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributes.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributes.java
index 4336fb1..26b80c5 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributes.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributes.java
@@ -30,7 +30,7 @@ public class GridGgfsAttributes implements Externalizable {
     /** File's data block size (bytes). */
     private int blockSize;
 
-    /** Size of the group figured in {@link GridGgfsGroupDataBlocksKeyMapper}. */
+    /** Size of the group figured in {@link org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper}. */
     private int grpSize;
 
     /** Meta cache name. */
@@ -51,7 +51,7 @@ public class GridGgfsAttributes implements Externalizable {
     /**
      * @param ggfsName GGFS name.
      * @param blockSize File's data block size (bytes).
-     * @param grpSize Size of the group figured in {@link GridGgfsGroupDataBlocksKeyMapper}.
+     * @param grpSize Size of the group figured in {@link org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper}.
      * @param metaCacheName Meta cache name.
      * @param dataCacheName Data cache name.
      * @param dfltMode Default mode.
@@ -91,7 +91,7 @@ public class GridGgfsAttributes implements Externalizable {
     }
 
     /**
-     * @return Size of the group figured in {@link GridGgfsGroupDataBlocksKeyMapper}.
+     * @return Size of the group figured in {@link org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper}.
      */
     public int groupSize() {
         return grpSize;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
index e3254b5..031c15a 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManager.java
@@ -157,8 +157,8 @@ public class GridGgfsDataManager extends GridGgfsManager {
         GridCacheAffinityKeyMapper mapper = ggfsCtx.kernalContext().cache()
             .internalCache(ggfsCtx.configuration().getDataCacheName()).configuration().getAffinityMapper();
 
-        grpSize = mapper instanceof GridGgfsGroupDataBlocksKeyMapper ?
-            ((GridGgfsGroupDataBlocksKeyMapper)mapper).groupSize() : 1;
+        grpSize = mapper instanceof IgniteFsGroupDataBlocksKeyMapper ?
+            ((IgniteFsGroupDataBlocksKeyMapper)mapper).groupSize() : 1;
 
         grpBlockSize = ggfsCtx.configuration().getBlockSize() * grpSize;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileImpl.java
deleted file mode 100644
index 0485761..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsFileImpl.java
+++ /dev/null
@@ -1,237 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.kernal.processors.ggfs;
-
-import org.apache.ignite.lang.*;
-import org.gridgain.grid.ggfs.*;
-import org.gridgain.grid.util.typedef.internal.*;
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-import java.util.*;
-
-/**
- * File or directory information.
- */
-public final class GridGgfsFileImpl implements GridGgfsFile, Externalizable {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** Path to this file. */
-    private IgniteFsPath path;
-
-    /** File id. */
-    private IgniteUuid fileId;
-
-    /** Block size. */
-    private int blockSize;
-
-    /** Group block size. */
-    private long grpBlockSize;
-
-    /** File length. */
-    private long len;
-
-    /** Last access time. */
-    private long accessTime;
-
-    /** Last modification time. */
-    private long modificationTime;
-
-    /** Properties. */
-    private Map<String, String> props;
-
-    /**
-     * Empty constructor required by {@link Externalizable}.
-     */
-    public GridGgfsFileImpl() {
-        // No-op.
-    }
-
-    /**
-     * Constructs directory info.
-     *
-     * @param path Path.
-     */
-    public GridGgfsFileImpl(IgniteFsPath path, GridGgfsFileInfo info, long globalGrpBlockSize) {
-        A.notNull(path, "path");
-        A.notNull(info, "info");
-
-        this.path = path;
-        fileId = info.id();
-
-        if (info.isFile()) {
-            blockSize = info.blockSize();
-            len = info.length();
-
-            grpBlockSize = info.affinityKey() == null ? globalGrpBlockSize :
-                info.length() == 0 ? globalGrpBlockSize : info.length();
-        }
-
-        props = info.properties();
-
-        if (props == null)
-            props = Collections.emptyMap();
-
-        accessTime = info.accessTime();
-        modificationTime = info.modificationTime();
-    }
-
-    /**
-     * Constructs file instance.
-     *
-     * @param path Path.
-     * @param entry Listing entry.
-     */
-    public GridGgfsFileImpl(IgniteFsPath path, GridGgfsListingEntry entry, long globalGrpSize) {
-        A.notNull(path, "path");
-        A.notNull(entry, "entry");
-
-        this.path = path;
-        fileId = entry.fileId();
-
-        blockSize = entry.blockSize();
-
-        grpBlockSize = entry.affinityKey() == null ? globalGrpSize :
-            entry.length() == 0 ? globalGrpSize : entry.length();
-
-        len = entry.length();
-        props = entry.properties();
-
-        accessTime = entry.accessTime();
-        modificationTime = entry.modificationTime();
-    }
-
-    /** {@inheritDoc} */
-    @Override public IgniteFsPath path() {
-        return path;
-    }
-
-    /**
-     * @return File ID.
-     */
-    public IgniteUuid fileId() {
-        return fileId;
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean isFile() {
-        return blockSize > 0;
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean isDirectory() {
-        return blockSize == 0;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long length() {
-        return len;
-    }
-
-    /** {@inheritDoc} */
-    @Override public int blockSize() {
-        return blockSize;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long groupBlockSize() {
-        return grpBlockSize;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long accessTime() {
-        return accessTime;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long modificationTime() {
-        return modificationTime;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String property(String name) throws IllegalArgumentException {
-        String val = props.get(name);
-
-        if (val ==  null)
-            throw new IllegalArgumentException("File property not found [path=" + path + ", name=" + name + ']');
-
-        return val;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String property(String name, @Nullable String dfltVal) {
-        String val = props.get(name);
-
-        return val == null ? dfltVal : val;
-    }
-
-    /** {@inheritDoc} */
-    @Override public Map<String, String> properties() {
-        return props;
-    }
-
-    /**
-     * Writes object to data output.
-     *
-     * @param out Data output.
-     */
-    @Override public void writeExternal(ObjectOutput out) throws IOException {
-        path.writeExternal(out);
-
-        out.writeInt(blockSize);
-        out.writeLong(grpBlockSize);
-        out.writeLong(len);
-        U.writeStringMap(out, props);
-        out.writeLong(accessTime);
-        out.writeLong(modificationTime);
-    }
-
-    /**
-     * Reads object from data input.
-     *
-     * @param in Data input.
-     */
-    @Override public void readExternal(ObjectInput in) throws IOException {
-        path = new IgniteFsPath();
-
-        path.readExternal(in);
-
-        blockSize = in.readInt();
-        grpBlockSize = in.readLong();
-        len = in.readLong();
-        props = U.readStringMap(in);
-        accessTime = in.readLong();
-        modificationTime = in.readLong();
-    }
-
-    /** {@inheritDoc} */
-    @Override public int hashCode() {
-        return path.hashCode();
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean equals(Object o) {
-        if (o == this)
-            return true;
-
-        if (o == null || getClass() != o.getClass())
-            return false;
-
-        GridGgfsFileImpl that = (GridGgfsFileImpl)o;
-
-        return path.equals(that.path);
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridGgfsFileImpl.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
index e1d75c3..9c804a4 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
@@ -81,7 +81,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     private final GridGgfsModeResolver modeRslvr;
 
     /** Connection to the secondary file system. */
-    private GridGgfsFileSystem secondaryFs;
+    private IgniteFsFileSystem secondaryFs;
 
     /** Busy lock. */
     private final GridSpinBusyLock busyLock = new GridSpinBusyLock();
@@ -497,7 +497,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile info(IgniteFsPath path) throws GridException {
+    @Override public IgniteFsFile info(IgniteFsPath path) throws GridException {
         if (enterBusy()) {
             try {
                 A.notNull(path, "path");
@@ -515,7 +515,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 if (info == null)
                     return null;
 
-                return new GridGgfsFileImpl(path, info, data.groupBlockSize());
+                return new IgniteFsFileImpl(path, info, data.groupBlockSize());
             }
             finally {
                 busyLock.leaveBusy();
@@ -537,7 +537,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 IgniteUuid fileId = meta.fileId(path);
 
                 if (fileId == null)
-                    throw new GridGgfsFileNotFoundException("Failed to get path summary (path not found): " + path);
+                    throw new IgniteFsFileNotFoundException("Failed to get path summary (path not found): " + path);
 
                 IgniteFsPathSummary sum = new IgniteFsPathSummary(path);
 
@@ -554,7 +554,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile update(IgniteFsPath path, Map<String, String> props) throws GridException {
+    @Override public IgniteFsFile update(IgniteFsPath path, Map<String, String> props) throws GridException {
         if (enterBusy()) {
             try {
                 A.notNull(path, "path");
@@ -578,7 +578,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                     if (info == null)
                         return null;
 
-                    return new GridGgfsFileImpl(path, info, data.groupBlockSize());
+                    return new IgniteFsFileImpl(path, info, data.groupBlockSize());
                 }
 
                 List<IgniteUuid> fileIds = meta.fileIds(path);
@@ -596,7 +596,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                     if (evts.isRecordable(EVT_GGFS_META_UPDATED))
                         evts.record(new IgniteFsEvent(path, localNode(), EVT_GGFS_META_UPDATED, props));
 
-                    return new GridGgfsFileImpl(path, info, data.groupBlockSize());
+                    return new IgniteFsFileImpl(path, info, data.groupBlockSize());
                 }
                 else
                     return null;
@@ -661,7 +661,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                     if (mode == PRIMARY)
                         checkConflictWithPrimary(src);
 
-                    throw new GridGgfsFileNotFoundException("Failed to rename (source path not found): " + src);
+                    throw new IgniteFsFileNotFoundException("Failed to rename (source path not found): " + src);
                 }
 
                 String srcFileName = src.name();
@@ -681,7 +681,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
 
                     // Destination directory doesn't exist.
                     if (destDesc == null)
-                        throw new GridGgfsFileNotFoundException("Failed to rename (destination directory does not " +
+                        throw new IgniteFsFileNotFoundException("Failed to rename (destination directory does not " +
                             "exist): " + dest);
 
                     destFileName = dest.name();
@@ -940,7 +940,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 else if (mode == PRIMARY) {
                     checkConflictWithPrimary(path);
 
-                    throw new GridGgfsFileNotFoundException("Failed to list files (path not found): " + path);
+                    throw new IgniteFsFileNotFoundException("Failed to list files (path not found): " + path);
                 }
 
                 return F.viewReadOnly(files, new C1<String, IgniteFsPath>() {
@@ -959,7 +959,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsFile> listFiles(final IgniteFsPath path) throws GridException {
+    @Override public Collection<IgniteFsFile> listFiles(final IgniteFsPath path) throws GridException {
         if (enterBusy()) {
             try {
                 A.notNull(path, "path");
@@ -974,18 +974,18 @@ public final class GridGgfsImpl implements GridGgfsEx {
 
                 Set<GridGgfsMode> childrenModes = modeRslvr.resolveChildrenModes(path);
 
-                Collection<GridGgfsFile> files = new HashSet<>();
+                Collection<IgniteFsFile> files = new HashSet<>();
 
                 if (childrenModes.contains(DUAL_SYNC) || childrenModes.contains(DUAL_ASYNC)) {
                     assert secondaryFs != null;
 
-                    Collection<GridGgfsFile> children = secondaryFs.listFiles(path);
+                    Collection<IgniteFsFile> children = secondaryFs.listFiles(path);
 
-                    for (GridGgfsFile child : children) {
+                    for (IgniteFsFile child : children) {
                         GridGgfsFileInfo fsInfo = new GridGgfsFileInfo(cfg.getBlockSize(), child.length(),
                             evictExclude(path, false), child.properties());
 
-                        files.add(new GridGgfsFileImpl(child.path(), fsInfo, data.groupBlockSize()));
+                        files.add(new IgniteFsFileImpl(child.path(), fsInfo, data.groupBlockSize()));
                     }
                 }
 
@@ -998,21 +998,21 @@ public final class GridGgfsImpl implements GridGgfsEx {
                     if (info != null) {
                         if (info.isFile())
                             // If this is a file, return its description.
-                            return Collections.<GridGgfsFile>singleton(new GridGgfsFileImpl(path, info,
+                            return Collections.<IgniteFsFile>singleton(new IgniteFsFileImpl(path, info,
                                 data.groupBlockSize()));
 
                         // Perform the listing.
                         for (Map.Entry<String, GridGgfsListingEntry> e : info.listing().entrySet()) {
                             IgniteFsPath p = new IgniteFsPath(path, e.getKey());
 
-                            files.add(new GridGgfsFileImpl(p, e.getValue(), data.groupBlockSize()));
+                            files.add(new IgniteFsFileImpl(p, e.getValue(), data.groupBlockSize()));
                         }
                     }
                 }
                 else if (mode == PRIMARY) {
                     checkConflictWithPrimary(path);
 
-                    throw new GridGgfsFileNotFoundException("Failed to list files (path not found): " + path);
+                    throw new IgniteFsFileNotFoundException("Failed to list files (path not found): " + path);
                 }
 
                 return files;
@@ -1083,7 +1083,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 if (info == null) {
                     checkConflictWithPrimary(path);
 
-                    throw new GridGgfsFileNotFoundException("File not found: " + path);
+                    throw new IgniteFsFileNotFoundException("File not found: " + path);
                 }
 
                 if (!info.isFile())
@@ -1294,7 +1294,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                     if (!create) {
                         checkConflictWithPrimary(path);
 
-                        throw new GridGgfsFileNotFoundException("File not found: " + path);
+                        throw new IgniteFsFileNotFoundException("File not found: " + path);
                     }
 
                     if (parentId == null)
@@ -1346,7 +1346,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 if (desc == null) {
                     checkConflictWithPrimary(path);
 
-                    throw new GridGgfsFileNotFoundException("Failed to update times (path not found): " + path);
+                    throw new IgniteFsFileNotFoundException("Failed to update times (path not found): " + path);
                 }
 
                 // Cannot update times for root.
@@ -1414,7 +1414,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 }
 
                 if (info == null)
-                    throw new GridGgfsFileNotFoundException("File not found: " + path);
+                    throw new IgniteFsFileNotFoundException("File not found: " + path);
 
                 if (!info.isFile())
                     throw new GridGgfsInvalidPathException("Failed to get affinity info for file (not a file): " +
@@ -1800,7 +1800,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 info = meta.info(meta.fileId(path));
 
                 if (info == null) {
-                    GridGgfsFile status = secondaryFs.info(path);
+                    IgniteFsFile status = secondaryFs.info(path);
 
                     if (status != null)
                         info = status.isDirectory() ? new GridGgfsFileInfo(true, status.properties()) :

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java
index 5fa2366..da60ae4 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java
@@ -377,7 +377,7 @@ public class GridGgfsInputStreamImpl extends GridGgfsInputStreamAdapter {
             try {
                 return block(blockIdx);
             }
-            catch (GridGgfsCorruptedFileException e) {
+            catch (IgniteFsCorruptedFileException e) {
                 if (log.isDebugEnabled())
                     log.debug("Failed to fetch file block [path=" + path + ", fileInfo=" + fileInfo +
                         ", blockIdx=" + blockIdx + ", errMsg=" + e.getMessage() + ']');
@@ -388,7 +388,7 @@ public class GridGgfsInputStreamImpl extends GridGgfsInputStreamAdapter {
 
                     // File was deleted.
                     if (newInfo == null)
-                        throw new GridGgfsFileNotFoundException("Failed to read file block (file was concurrently " +
+                        throw new IgniteFsFileNotFoundException("Failed to read file block (file was concurrently " +
                                 "deleted) [path=" + path + ", blockIdx=" + blockIdx + ']');
 
                     fileInfo = newInfo;
@@ -451,7 +451,7 @@ public class GridGgfsInputStreamImpl extends GridGgfsInputStreamAdapter {
         byte[] bytes = bytesFut.get();
 
         if (bytes == null)
-            throw new GridGgfsCorruptedFileException("Failed to retrieve file's data block (corrupted file?) " +
+            throw new IgniteFsCorruptedFileException("Failed to retrieve file's data block (corrupted file?) " +
                 "[path=" + path + ", blockIdx=" + blockIdx + ']');
 
         int blockSize = fileInfo.blockSize();


[33/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
# Renaming


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

Branch: refs/heads/master
Commit: bf07cfaea33a59d6bfd310ace13b562f4c086097
Parents: 81e0195
Author: sboikov <sb...@gridgain.com>
Authored: Fri Dec 5 11:32:07 2014 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Dec 5 11:32:07 2014 +0300

----------------------------------------------------------------------
 .../examples/ggfs/GgfsMapReduceExample.java     |   4 +-
 .../main/java/org/apache/ignite/IgniteFs.java   |   2 +-
 .../apache/ignite/fs/IgniteFsConfiguration.java |   4 +-
 .../ignite/fs/mapreduce/IgniteFsFileRange.java  |  72 +++++++
 .../IgniteFsInputStreamJobAdapter.java          |  45 +++++
 .../apache/ignite/fs/mapreduce/IgniteFsJob.java |  62 ++++++
 .../ignite/fs/mapreduce/IgniteFsJobAdapter.java |  20 ++
 .../fs/mapreduce/IgniteFsRangeInputStream.java  | 189 +++++++++++++++++++
 .../fs/mapreduce/IgniteFsRecordResolver.java    |  49 +++++
 .../ignite/fs/mapreduce/IgniteFsTask.java       | 165 ++++++++++++++++
 .../ignite/fs/mapreduce/IgniteFsTaskArgs.java   |  74 ++++++++
 .../mapreduce/IgniteFsTaskNoReduceAdapter.java  |  34 ++++
 .../org/apache/ignite/fs/mapreduce/package.html |  15 ++
 .../grid/ggfs/mapreduce/IgniteFsFileRange.java  |  72 -------
 .../IgniteFsInputStreamJobAdapter.java          |  45 -----
 .../grid/ggfs/mapreduce/IgniteFsJob.java        |  62 ------
 .../grid/ggfs/mapreduce/IgniteFsJobAdapter.java |  20 --
 .../mapreduce/IgniteFsRangeInputStream.java     | 189 -------------------
 .../ggfs/mapreduce/IgniteFsRecordResolver.java  |  49 -----
 .../grid/ggfs/mapreduce/IgniteFsTask.java       | 165 ----------------
 .../grid/ggfs/mapreduce/IgniteFsTaskArgs.java   |  74 --------
 .../mapreduce/IgniteFsTaskNoReduceAdapter.java  |  34 ----
 .../gridgain/grid/ggfs/mapreduce/package.html   |  15 --
 .../IgniteFsByteDelimiterRecordResolver.java    |   2 +-
 .../IgniteFsFixedLengthRecordResolver.java      |   2 +-
 .../processors/ggfs/GridGgfsAsyncImpl.java      |   2 +-
 .../kernal/processors/ggfs/GridGgfsImpl.java    |   2 +-
 .../kernal/processors/ggfs/GridGgfsJobImpl.java |   2 +-
 .../processors/ggfs/GridGgfsProcessor.java      |   2 +-
 .../ggfs/GridGgfsProcessorAdapter.java          |   2 +-
 .../processors/ggfs/GridNoopGgfsProcessor.java  |   2 +-
 .../processors/ggfs/IgniteFsTaskArgsImpl.java   |   2 +-
 .../processors/ggfs/GridGgfsTaskSelfTest.java   |   4 +-
 .../GridGgfsAbstractRecordResolverSelfTest.java |   2 +-
 ...GgfsByteDelimiterRecordResolverSelfTest.java |   2 +-
 ...idGgfsFixedLengthRecordResolverSelfTest.java |   2 +-
 ...sNewLineDelimiterRecordResolverSelfTest.java |   2 +-
 ...fsStringDelimiterRecordResolverSelfTest.java |   2 +-
 ...idHadoopDefaultMapReducePlannerSelfTest.java |   2 +-
 39 files changed, 747 insertions(+), 747 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
index ec9c52a..10913b0 100644
--- a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
+++ b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
@@ -12,15 +12,15 @@ package org.gridgain.examples.ggfs;
 import org.apache.ignite.*;
 import org.apache.ignite.compute.*;
 import org.apache.ignite.fs.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.ggfs.mapreduce.records.*;
 
 import java.io.*;
 import java.util.*;
 
 /**
- * Example that shows how to use {@link org.gridgain.grid.ggfs.mapreduce.IgniteFsTask} to find lines matching particular pattern in the file in pretty
+ * Example that shows how to use {@link org.apache.ignite.fs.mapreduce.IgniteFsTask} to find lines matching particular pattern in the file in pretty
  * the same way as {@code grep} command does.
  * <p>
  * Remote nodes should always be started with configuration file which includes

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
index 323a778..11e4732 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
@@ -10,9 +10,9 @@
 package org.apache.ignite;
 
 import org.apache.ignite.fs.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
 import org.jetbrains.annotations.*;
 
 import java.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsConfiguration.java b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsConfiguration.java
index 13e6746..f98b92b 100644
--- a/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/fs/IgniteFsConfiguration.java
@@ -753,13 +753,13 @@ public class IgniteFsConfiguration {
 
     /**
      * Get maximum default range size of a file being split during GGFS task execution. When GGFS task is about to
-     * be executed, it requests file block locations first. Each location is defined as {@link org.gridgain.grid.ggfs.mapreduce.IgniteFsFileRange} which
+     * be executed, it requests file block locations first. Each location is defined as {@link org.apache.ignite.fs.mapreduce.IgniteFsFileRange} which
      * has length. In case this parameter is set to positive value, then GGFS will split single file range into smaller
      * ranges with length not greater that this parameter. The only exception to this case is when maximum task range
      * length is smaller than file block size. In this case maximum task range size will be overridden and set to file
      * block size.
      * <p>
-     * Note that this parameter is applied when task is split into jobs before {@link org.gridgain.grid.ggfs.mapreduce.IgniteFsRecordResolver} is
+     * Note that this parameter is applied when task is split into jobs before {@link org.apache.ignite.fs.mapreduce.IgniteFsRecordResolver} is
      * applied. Therefore, final file ranges being assigned to particular jobs could be greater than value of this
      * parameter depending on file data layout and selected resolver type.
      * <p>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsFileRange.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsFileRange.java b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsFileRange.java
new file mode 100644
index 0000000..9e49cb1
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsFileRange.java
@@ -0,0 +1,72 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs.mapreduce;
+
+import org.apache.ignite.fs.*;
+import org.gridgain.grid.util.typedef.internal.*;
+
+/**
+ * Entity representing part of GGFS file identified by file path, start position, and length.
+ */
+public class IgniteFsFileRange {
+    /** File path. */
+    private IgniteFsPath path;
+
+    /** Start position. */
+    private long start;
+
+    /** Length. */
+    private long len;
+
+    /**
+     * Creates file range.
+     *
+     * @param path File path.
+     * @param start Start position.
+     * @param len Length.
+     */
+    public IgniteFsFileRange(IgniteFsPath path, long start, long len) {
+        this.path = path;
+        this.start = start;
+        this.len = len;
+    }
+
+    /**
+     * Gets file path.
+     *
+     * @return File path.
+     */
+    public IgniteFsPath path() {
+        return path;
+    }
+
+    /**
+     * Gets range start position.
+     *
+     * @return Start position.
+     */
+    public long start() {
+        return start;
+    }
+
+    /**
+     * Gets range length.
+     *
+     * @return Length.
+     */
+    public long length() {
+        return len;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsFileRange.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsInputStreamJobAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsInputStreamJobAdapter.java b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsInputStreamJobAdapter.java
new file mode 100644
index 0000000..23449be
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsInputStreamJobAdapter.java
@@ -0,0 +1,45 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs.mapreduce;
+
+import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
+import org.gridgain.grid.*;
+import org.gridgain.grid.util.*;
+
+import java.io.*;
+
+/**
+ * Convenient {@link IgniteFsJob} adapter. It limits data returned from {@link org.apache.ignite.fs.IgniteFsInputStream} to bytes within
+ * the {@link IgniteFsFileRange} assigned to the job.
+ * <p>
+ * Under the covers it simply puts job's {@code GridGgfsInputStream} position to range start and wraps in into
+ * {@link GridFixedSizeInputStream} limited to range length.
+ */
+public abstract class IgniteFsInputStreamJobAdapter extends IgniteFsJobAdapter {
+    /** {@inheritDoc} */
+    @Override public final Object execute(IgniteFs ggfs, IgniteFsFileRange range, IgniteFsInputStream in)
+        throws GridException, IOException {
+        in.seek(range.start());
+
+        return execute(ggfs, new IgniteFsRangeInputStream(in, range));
+    }
+
+    /**
+     * Executes this job.
+     *
+     * @param ggfs GGFS instance.
+     * @param in Input stream.
+     * @return Execution result.
+     * @throws GridException If execution failed.
+     * @throws IOException If IO exception encountered while working with stream.
+     */
+    public abstract Object execute(IgniteFs ggfs, IgniteFsRangeInputStream in) throws GridException, IOException;
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsJob.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsJob.java b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsJob.java
new file mode 100644
index 0000000..b4921eb
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsJob.java
@@ -0,0 +1,62 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs.mapreduce;
+
+import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
+import org.gridgain.grid.*;
+
+import java.io.*;
+
+/**
+ * Defines executable unit for {@link IgniteFsTask}. Before this job is executed, it is assigned one of the
+ * ranges provided by the {@link IgniteFsRecordResolver} passed to one of the {@code GridGgfs.execute(...)} methods.
+ * <p>
+ * {@link #execute(org.apache.ignite.IgniteFs, IgniteFsFileRange, org.apache.ignite.fs.IgniteFsInputStream)} method is given {@link IgniteFsFileRange} this
+ * job is expected to operate on, and already opened {@link org.apache.ignite.fs.IgniteFsInputStream} for the file this range belongs to.
+ * <p>
+ * Note that provided input stream has position already adjusted to range start. However, it will not
+ * automatically stop on range end. This is done to provide capability in some cases to look beyond
+ * the range end or seek position before the reange start.
+ * <p>
+ * In majority of the cases, when you want to process only provided range, you should explicitly control amount
+ * of returned data and stop at range end. You can also use {@link IgniteFsInputStreamJobAdapter}, which operates
+ * on {@link IgniteFsRangeInputStream} bounded to range start and end, or manually wrap provided input stream with
+ * {@link IgniteFsRangeInputStream}.
+ * <p>
+ * You can inject any resources in concrete implementation, just as with regular {@link org.apache.ignite.compute.ComputeJob} implementations.
+ */
+public interface IgniteFsJob {
+    /**
+     * Executes this job.
+     *
+     * @param ggfs GGFS instance.
+     * @param range File range aligned to record boundaries.
+     * @param in Input stream for split file. This input stream is not aligned to range and points to file start
+     *     by default.
+     * @return Execution result.
+     * @throws GridException If execution failed.
+     * @throws IOException If file system operation resulted in IO exception.
+     */
+    public Object execute(IgniteFs ggfs, IgniteFsFileRange range, IgniteFsInputStream in) throws GridException,
+        IOException;
+
+    /**
+     * This method is called when system detects that completion of this
+     * job can no longer alter the overall outcome (for example, when parent task
+     * has already reduced the results). Job is also cancelled when
+     * {@link org.apache.ignite.compute.ComputeTaskFuture#cancel()} is called.
+     * <p>
+     * Note that job cancellation is only a hint, and just like with
+     * {@link Thread#interrupt()}  method, it is really up to the actual job
+     * instance to gracefully finish execution and exit.
+     */
+    public void cancel();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsJobAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsJobAdapter.java b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsJobAdapter.java
new file mode 100644
index 0000000..af20038
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsJobAdapter.java
@@ -0,0 +1,20 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs.mapreduce;
+
+/**
+ * Adapter for {@link IgniteFsJob} with no-op implementation of {@link #cancel()} method.
+ */
+public abstract class IgniteFsJobAdapter implements IgniteFsJob {
+    /** {@inheritDoc} */
+    @Override public void cancel() {
+        // No-op.
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsRangeInputStream.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsRangeInputStream.java b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsRangeInputStream.java
new file mode 100644
index 0000000..f59a7d3
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsRangeInputStream.java
@@ -0,0 +1,189 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs.mapreduce;
+
+import org.apache.ignite.fs.*;
+import org.gridgain.grid.util.typedef.internal.*;
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+
+/**
+ * Decorator for regular {@link org.apache.ignite.fs.IgniteFsInputStream} which streams only data within the given range.
+ * This stream is used for {@link IgniteFsInputStreamJobAdapter} convenience adapter to create
+ * jobs which will be working only with the assigned range. You can also use it explicitly when
+ * working with {@link IgniteFsJob} directly.
+ */
+public final class IgniteFsRangeInputStream extends IgniteFsInputStream {
+    /** Base input stream. */
+    private final IgniteFsInputStream is;
+
+    /** Start position. */
+    private final long start;
+
+    /** Maximum stream length. */
+    private final long maxLen;
+
+    /** Current position within the stream. */
+    private long pos;
+
+    /**
+     * Constructor.
+     *
+     * @param is Base input stream.
+     * @param start Start position.
+     * @param maxLen Maximum stream length.
+     * @throws IOException In case of exception.
+     */
+    public IgniteFsRangeInputStream(IgniteFsInputStream is, long start, long maxLen) throws IOException {
+        if (is == null)
+            throw new IllegalArgumentException("Input stream cannot be null.");
+
+        if (start < 0)
+            throw new IllegalArgumentException("Start position cannot be negative.");
+
+        if (start >= is.length())
+            throw new IllegalArgumentException("Start position cannot be greater that file length.");
+
+        if (maxLen < 0)
+            throw new IllegalArgumentException("Length cannot be negative.");
+
+        if (start + maxLen > is.length())
+            throw new IllegalArgumentException("Sum of start position and length cannot be greater than file length.");
+
+        this.is = is;
+        this.start = start;
+        this.maxLen = maxLen;
+
+        is.seek(start);
+    }
+
+    /** {@inheritDoc} */
+    @Override public long length() {
+        return is.length();
+    }
+
+    /**
+     * Constructor.
+     *
+     * @param is Base input stream.
+     * @param range File range.
+     * @throws IOException In case of exception.
+     */
+    public IgniteFsRangeInputStream(IgniteFsInputStream is, IgniteFsFileRange range) throws IOException {
+        this(is, range.start(), range.length());
+    }
+
+    /** {@inheritDoc} */
+    @Override public int read() throws IOException {
+        if (pos < maxLen) {
+            int res = is.read();
+
+            if (res != -1)
+                pos++;
+
+            return res;
+        }
+        else
+            return -1;
+    }
+
+    /** {@inheritDoc} */
+    @Override public int read(@NotNull byte[] b, int off, int len) throws IOException {
+        if (pos < maxLen) {
+            len = (int)Math.min(len, maxLen - pos);
+
+            int res = is.read(b, off, len);
+
+            if (res != -1)
+                pos += res;
+
+            return res;
+        }
+        else
+            return -1;
+    }
+
+    /** {@inheritDoc} */
+    @Override public int read(long pos, byte[] buf, int off, int len) throws IOException {
+        seek(pos);
+
+        return read(buf, off, len);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readFully(long pos, byte[] buf) throws IOException {
+        readFully(pos, buf, 0, buf.length);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readFully(long pos, byte[] buf, int off, int len) throws IOException {
+        seek(pos);
+
+        for (int readBytes = 0; readBytes < len;) {
+            int read = read(buf, off + readBytes, len - readBytes);
+
+            if (read == -1)
+                throw new EOFException("Failed to read stream fully (stream ends unexpectedly) [pos=" + pos +
+                    ", buf.length=" + buf.length + ", off=" + off + ", len=" + len + ']');
+
+            readBytes += read;
+        }
+    }
+
+    /** {@inheritDoc} */
+    @Override public void seek(long pos) throws IOException {
+        if (pos < 0)
+            throw new IOException("Seek position cannot be negative: " + pos);
+
+        is.seek(start + pos);
+
+        this.pos = pos;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long position() {
+        return pos;
+    }
+
+    /**
+     * Since range input stream represents a part of larger file stream, there is an offset at which this
+     * range input stream starts in original input stream. This method returns start offset of this input
+     * stream relative to original input stream.
+     *
+     * @return Start offset in original input stream.
+     */
+    public long startOffset() {
+        return start;
+    }
+
+    /** {@inheritDoc} */
+    @Override public int available() {
+        long l = maxLen - pos;
+
+        if (l < 0)
+            return 0;
+
+        if (l > Integer.MAX_VALUE)
+            return Integer.MAX_VALUE;
+
+        return (int)l;
+    }
+
+    /** {@inheritDoc} */
+    @Override public void close() throws IOException {
+        is.close();
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsRangeInputStream.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsRecordResolver.java b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsRecordResolver.java
new file mode 100644
index 0000000..3e347b7
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsRecordResolver.java
@@ -0,0 +1,49 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs.mapreduce;
+
+import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
+import org.gridgain.grid.*;
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+
+/**
+ * GGFS record resolver. When {@link IgniteFsTask} is split into {@link IgniteFsJob}s each produced job will obtain
+ * {@link IgniteFsFileRange} based on file data location. Record resolver is invoked in each job before actual
+ * execution in order to adjust record boundaries in a way consistent with user data.
+ * <p>
+ * E.g., you may want to split your task into jobs so that each job process zero, one or several lines from that file.
+ * But file is split into ranges based on block locations, not new line boundaries. Using convenient record resolver
+ * you can adjust job range so that it covers the whole line(s).
+ * <p>
+ * The following record resolvers are available out of the box:
+ * <ul>
+ *     <li>{@link org.gridgain.grid.ggfs.mapreduce.records.IgniteFsFixedLengthRecordResolver}</li>
+ *     <li>{@link org.gridgain.grid.ggfs.mapreduce.records.IgniteFsByteDelimiterRecordResolver}</li>
+ *     <li>{@link org.gridgain.grid.ggfs.mapreduce.records.IgniteFsStringDelimiterRecordResolver}</li>
+ *     <li>{@link org.gridgain.grid.ggfs.mapreduce.records.IgniteFsNewLineRecordResolver}</li>
+ * </ul>
+ */
+public interface IgniteFsRecordResolver extends Serializable {
+    /**
+     * Adjusts record start offset and length.
+     *
+     * @param ggfs GGFS instance to use.
+     * @param stream Input stream for split file.
+     * @param suggestedRecord Suggested file system record.
+     * @return New adjusted record. If this method returns {@code null}, original record is ignored.
+     * @throws GridException If resolve failed.
+     * @throws IOException If resolve failed.
+     */
+    @Nullable public IgniteFsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
+        IgniteFsFileRange suggestedRecord) throws GridException, IOException;
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsTask.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsTask.java b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsTask.java
new file mode 100644
index 0000000..c1383bf
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsTask.java
@@ -0,0 +1,165 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs.mapreduce;
+
+import org.apache.ignite.*;
+import org.apache.ignite.cluster.*;
+import org.apache.ignite.compute.*;
+import org.apache.ignite.fs.*;
+import org.apache.ignite.resources.*;
+import org.gridgain.grid.*;
+import org.gridgain.grid.kernal.*;
+import org.gridgain.grid.kernal.processors.ggfs.*;
+import org.gridgain.grid.util.typedef.internal.*;
+import org.jetbrains.annotations.*;
+
+import java.util.*;
+
+/**
+ * GGFS task which can be executed on the grid using one of {@code GridGgfs.execute()} methods. Essentially GGFS task
+ * is regular {@link org.apache.ignite.compute.ComputeTask} with different map logic. Instead of implementing
+ * {@link org.apache.ignite.compute.ComputeTask#map(List, Object)} method to split task into jobs, you must implement
+ * {@link IgniteFsTask#createJob(org.apache.ignite.fs.IgniteFsPath, IgniteFsFileRange, IgniteFsTaskArgs)} method.
+ * <p>
+ * Each file participating in GGFS task is split into {@link IgniteFsFileRange}s first. Normally range is a number of
+ * consequent bytes located on a single node (see {@code GridGgfsGroupDataBlocksKeyMapper}). In case maximum range size
+ * is provided (either through {@link org.apache.ignite.fs.IgniteFsConfiguration#getMaximumTaskRangeLength()} or {@code GridGgfs.execute()}
+ * argument), then ranges could be further divided into smaller chunks.
+ * <p>
+ * Once file is split into ranges, each range is passed to {@code GridGgfsTask.createJob()} method in order to create a
+ * {@link IgniteFsJob}.
+ * <p>
+ * Finally all generated jobs are sent to Grid nodes for execution.
+ * <p>
+ * As with regular {@code GridComputeTask} you can define your own logic for results handling and reduce step.
+ * <p>
+ * Here is an example of such a task:
+ * <pre name="code" class="java">
+ * public class WordCountTask extends GridGgfsTask&lt;String, Integer&gt; {
+ *     &#64;Override
+ *     public GridGgfsJob createJob(GridGgfsPath path, GridGgfsFileRange range, GridGgfsTaskArgs&lt;T&gt; args) throws GridException {
+ *         // New job will be created for each range within each file.
+ *         // We pass user-provided argument (which is essentially a word to look for) to that job.
+ *         return new WordCountJob(args.userArgument());
+ *     }
+ *
+ *     // Aggregate results into one compound result.
+ *     public Integer reduce(List&lt;GridComputeJobResult&gt; results) throws GridException {
+ *         Integer total = 0;
+ *
+ *         for (GridComputeJobResult res : results) {
+ *             Integer cnt = res.getData();
+ *
+ *             // Null can be returned for non-existent file in case we decide to ignore such situations.
+ *             if (cnt != null)
+ *                 total += cnt;
+ *         }
+ *
+ *         return total;
+ *     }
+ * }
+ * </pre>
+ */
+public abstract class IgniteFsTask<T, R> extends ComputeTaskAdapter<IgniteFsTaskArgs<T>, R> {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** Injected grid. */
+    @IgniteInstanceResource
+    private Ignite ignite;
+
+    /** {@inheritDoc} */
+    @Nullable @Override public final Map<? extends ComputeJob, ClusterNode> map(List<ClusterNode> subgrid,
+        @Nullable IgniteFsTaskArgs<T> args) throws GridException {
+        assert ignite != null;
+        assert args != null;
+
+        IgniteFs ggfs = ignite.fileSystem(args.ggfsName());
+        GridGgfsProcessorAdapter ggfsProc = ((GridKernal) ignite).context().ggfs();
+
+        Map<ComputeJob, ClusterNode> splitMap = new HashMap<>();
+
+        Map<UUID, ClusterNode> nodes = mapSubgrid(subgrid);
+
+        for (IgniteFsPath path : args.paths()) {
+            IgniteFsFile file = ggfs.info(path);
+
+            if (file == null) {
+                if (args.skipNonExistentFiles())
+                    continue;
+                else
+                    throw new GridException("Failed to process GGFS file because it doesn't exist: " + path);
+            }
+
+            Collection<IgniteFsBlockLocation> aff = ggfs.affinity(path, 0, file.length(), args.maxRangeLength());
+
+            long totalLen = 0;
+
+            for (IgniteFsBlockLocation loc : aff) {
+                ClusterNode node = null;
+
+                for (UUID nodeId : loc.nodeIds()) {
+                    node = nodes.get(nodeId);
+
+                    if (node != null)
+                        break;
+                }
+
+                if (node == null)
+                    throw new GridException("Failed to find any of block affinity nodes in subgrid [loc=" + loc +
+                        ", subgrid=" + subgrid + ']');
+
+                IgniteFsJob job = createJob(path, new IgniteFsFileRange(file.path(), loc.start(), loc.length()), args);
+
+                if (job != null) {
+                    ComputeJob jobImpl = ggfsProc.createJob(job, ggfs.name(), file.path(), loc.start(),
+                        loc.length(), args.recordResolver());
+
+                    splitMap.put(jobImpl, node);
+                }
+
+                totalLen += loc.length();
+            }
+
+            assert totalLen == file.length();
+        }
+
+        return splitMap;
+    }
+
+    /**
+     * Callback invoked during task map procedure to create job that will process specified split
+     * for GGFS file.
+     *
+     * @param path Path.
+     * @param range File range based on consecutive blocks. This range will be further
+     *      realigned to record boundaries on destination node.
+     * @param args Task argument.
+     * @return GGFS job. If {@code null} is returned, the passed in file range will be skipped.
+     * @throws GridException If job creation failed.
+     */
+    @Nullable public abstract IgniteFsJob createJob(IgniteFsPath path, IgniteFsFileRange range,
+        IgniteFsTaskArgs<T> args) throws GridException;
+
+    /**
+     * Maps list by node ID.
+     *
+     * @param subgrid Subgrid.
+     * @return Map.
+     */
+    private Map<UUID, ClusterNode> mapSubgrid(Collection<ClusterNode> subgrid) {
+        Map<UUID, ClusterNode> res = U.newHashMap(subgrid.size());
+
+        for (ClusterNode node : subgrid)
+            res.put(node.id(), node);
+
+        return res;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsTaskArgs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsTaskArgs.java b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsTaskArgs.java
new file mode 100644
index 0000000..3880fd3
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsTaskArgs.java
@@ -0,0 +1,74 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs.mapreduce;
+
+import org.apache.ignite.fs.*;
+
+import java.util.*;
+
+/**
+ * GGFS task arguments. When you initiate new GGFS task execution using one of {@code GridGgfs.execute(...)} methods,
+ * all passed parameters are encapsulated in a single {@code GridGgfsTaskArgs} object. Later on this object is
+ * passed to {@link IgniteFsTask#createJob(org.apache.ignite.fs.IgniteFsPath, IgniteFsFileRange, IgniteFsTaskArgs)} method.
+ * <p>
+ * Task arguments encapsulates the following data:
+ * <ul>
+ *     <li>GGFS name</li>
+ *     <li>File paths passed to {@code GridGgfs.execute()} method</li>
+ *     <li>{@link IgniteFsRecordResolver} for that task</li>
+ *     <li>Flag indicating whether to skip non-existent file paths or throw an exception</li>
+ *     <li>User-defined task argument</li>
+ *     <li>Maximum file range length for that task (see {@link org.apache.ignite.fs.IgniteFsConfiguration#getMaximumTaskRangeLength()})</li>
+ * </ul>
+ */
+public interface IgniteFsTaskArgs<T> {
+    /**
+     * Gets GGFS name.
+     *
+     * @return GGFS name.
+     */
+    public String ggfsName();
+
+    /**
+     * Gets file paths to process.
+     *
+     * @return File paths to process.
+     */
+    public Collection<IgniteFsPath> paths();
+
+    /**
+     * Gets record resolver for the task.
+     *
+     * @return Record resolver.
+     */
+    public IgniteFsRecordResolver recordResolver();
+
+    /**
+     * Flag indicating whether to fail or simply skip non-existent files.
+     *
+     * @return {@code True} if non-existent files should be skipped.
+     */
+    public boolean skipNonExistentFiles();
+
+    /**
+     * User argument provided for task execution.
+     *
+     * @return User argument.
+     */
+    public T userArgument();
+
+    /**
+     * Optional maximum allowed range length, {@code 0} by default. If not specified, full range including
+     * all consecutive blocks will be used without any limitations.
+     *
+     * @return Maximum range length.
+     */
+    public long maxRangeLength();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsTaskNoReduceAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsTaskNoReduceAdapter.java b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsTaskNoReduceAdapter.java
new file mode 100644
index 0000000..45c6e89
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsTaskNoReduceAdapter.java
@@ -0,0 +1,34 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs.mapreduce;
+
+import org.apache.ignite.compute.*;
+
+import java.util.*;
+
+/**
+ * Convenient {@link IgniteFsTask} adapter with empty reduce step. Use this adapter in case you are not interested in
+ * results returned by jobs.
+ */
+public abstract class IgniteFsTaskNoReduceAdapter<T, R> extends IgniteFsTask<T, R> {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Default implementation which will ignore all results sent from execution nodes.
+     *
+     * @param results Received results of broadcasted remote executions. Note that if task class has
+     *      {@link org.apache.ignite.compute.ComputeTaskNoResultCache} annotation, then this list will be empty.
+     * @return Will always return {@code null}.
+     */
+    @Override public R reduce(List<ComputeJobResult> results) {
+        return null;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/package.html
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/package.html b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/package.html
new file mode 100644
index 0000000..cde37cf
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/package.html
@@ -0,0 +1,15 @@
+<!DOCTYPE html PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+    @html.file.header
+    _________        _____ __________________        _____
+    __  ____/___________(_)______  /__  ____/______ ____(_)_______
+    _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+    / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+    \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+-->
+<html>
+<body>
+    <!-- Package description. -->
+    Contains APIs for In-Memory MapReduce over GGFS.
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsFileRange.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsFileRange.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsFileRange.java
deleted file mode 100644
index 57ca491..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsFileRange.java
+++ /dev/null
@@ -1,72 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-import org.apache.ignite.fs.*;
-import org.gridgain.grid.util.typedef.internal.*;
-
-/**
- * Entity representing part of GGFS file identified by file path, start position, and length.
- */
-public class IgniteFsFileRange {
-    /** File path. */
-    private IgniteFsPath path;
-
-    /** Start position. */
-    private long start;
-
-    /** Length. */
-    private long len;
-
-    /**
-     * Creates file range.
-     *
-     * @param path File path.
-     * @param start Start position.
-     * @param len Length.
-     */
-    public IgniteFsFileRange(IgniteFsPath path, long start, long len) {
-        this.path = path;
-        this.start = start;
-        this.len = len;
-    }
-
-    /**
-     * Gets file path.
-     *
-     * @return File path.
-     */
-    public IgniteFsPath path() {
-        return path;
-    }
-
-    /**
-     * Gets range start position.
-     *
-     * @return Start position.
-     */
-    public long start() {
-        return start;
-    }
-
-    /**
-     * Gets range length.
-     *
-     * @return Length.
-     */
-    public long length() {
-        return len;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(IgniteFsFileRange.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java
deleted file mode 100644
index 0432046..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsInputStreamJobAdapter.java
+++ /dev/null
@@ -1,45 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-import org.apache.ignite.*;
-import org.apache.ignite.fs.*;
-import org.gridgain.grid.*;
-import org.gridgain.grid.util.*;
-
-import java.io.*;
-
-/**
- * Convenient {@link IgniteFsJob} adapter. It limits data returned from {@link org.apache.ignite.fs.IgniteFsInputStream} to bytes within
- * the {@link IgniteFsFileRange} assigned to the job.
- * <p>
- * Under the covers it simply puts job's {@code GridGgfsInputStream} position to range start and wraps in into
- * {@link GridFixedSizeInputStream} limited to range length.
- */
-public abstract class IgniteFsInputStreamJobAdapter extends IgniteFsJobAdapter {
-    /** {@inheritDoc} */
-    @Override public final Object execute(IgniteFs ggfs, IgniteFsFileRange range, IgniteFsInputStream in)
-        throws GridException, IOException {
-        in.seek(range.start());
-
-        return execute(ggfs, new IgniteFsRangeInputStream(in, range));
-    }
-
-    /**
-     * Executes this job.
-     *
-     * @param ggfs GGFS instance.
-     * @param in Input stream.
-     * @return Execution result.
-     * @throws GridException If execution failed.
-     * @throws IOException If IO exception encountered while working with stream.
-     */
-    public abstract Object execute(IgniteFs ggfs, IgniteFsRangeInputStream in) throws GridException, IOException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java
deleted file mode 100644
index 5bcf6b3..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJob.java
+++ /dev/null
@@ -1,62 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-import org.apache.ignite.*;
-import org.apache.ignite.fs.*;
-import org.gridgain.grid.*;
-
-import java.io.*;
-
-/**
- * Defines executable unit for {@link IgniteFsTask}. Before this job is executed, it is assigned one of the
- * ranges provided by the {@link IgniteFsRecordResolver} passed to one of the {@code GridGgfs.execute(...)} methods.
- * <p>
- * {@link #execute(org.apache.ignite.IgniteFs, IgniteFsFileRange, org.apache.ignite.fs.IgniteFsInputStream)} method is given {@link IgniteFsFileRange} this
- * job is expected to operate on, and already opened {@link org.apache.ignite.fs.IgniteFsInputStream} for the file this range belongs to.
- * <p>
- * Note that provided input stream has position already adjusted to range start. However, it will not
- * automatically stop on range end. This is done to provide capability in some cases to look beyond
- * the range end or seek position before the reange start.
- * <p>
- * In majority of the cases, when you want to process only provided range, you should explicitly control amount
- * of returned data and stop at range end. You can also use {@link IgniteFsInputStreamJobAdapter}, which operates
- * on {@link IgniteFsRangeInputStream} bounded to range start and end, or manually wrap provided input stream with
- * {@link IgniteFsRangeInputStream}.
- * <p>
- * You can inject any resources in concrete implementation, just as with regular {@link org.apache.ignite.compute.ComputeJob} implementations.
- */
-public interface IgniteFsJob {
-    /**
-     * Executes this job.
-     *
-     * @param ggfs GGFS instance.
-     * @param range File range aligned to record boundaries.
-     * @param in Input stream for split file. This input stream is not aligned to range and points to file start
-     *     by default.
-     * @return Execution result.
-     * @throws GridException If execution failed.
-     * @throws IOException If file system operation resulted in IO exception.
-     */
-    public Object execute(IgniteFs ggfs, IgniteFsFileRange range, IgniteFsInputStream in) throws GridException,
-        IOException;
-
-    /**
-     * This method is called when system detects that completion of this
-     * job can no longer alter the overall outcome (for example, when parent task
-     * has already reduced the results). Job is also cancelled when
-     * {@link org.apache.ignite.compute.ComputeTaskFuture#cancel()} is called.
-     * <p>
-     * Note that job cancellation is only a hint, and just like with
-     * {@link Thread#interrupt()}  method, it is really up to the actual job
-     * instance to gracefully finish execution and exit.
-     */
-    public void cancel();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJobAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJobAdapter.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJobAdapter.java
deleted file mode 100644
index e8aa1ea..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsJobAdapter.java
+++ /dev/null
@@ -1,20 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-/**
- * Adapter for {@link IgniteFsJob} with no-op implementation of {@link #cancel()} method.
- */
-public abstract class IgniteFsJobAdapter implements IgniteFsJob {
-    /** {@inheritDoc} */
-    @Override public void cancel() {
-        // No-op.
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRangeInputStream.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRangeInputStream.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRangeInputStream.java
deleted file mode 100644
index 6c123eb..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRangeInputStream.java
+++ /dev/null
@@ -1,189 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-import org.apache.ignite.fs.*;
-import org.gridgain.grid.util.typedef.internal.*;
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-
-/**
- * Decorator for regular {@link org.apache.ignite.fs.IgniteFsInputStream} which streams only data within the given range.
- * This stream is used for {@link IgniteFsInputStreamJobAdapter} convenience adapter to create
- * jobs which will be working only with the assigned range. You can also use it explicitly when
- * working with {@link IgniteFsJob} directly.
- */
-public final class IgniteFsRangeInputStream extends IgniteFsInputStream {
-    /** Base input stream. */
-    private final IgniteFsInputStream is;
-
-    /** Start position. */
-    private final long start;
-
-    /** Maximum stream length. */
-    private final long maxLen;
-
-    /** Current position within the stream. */
-    private long pos;
-
-    /**
-     * Constructor.
-     *
-     * @param is Base input stream.
-     * @param start Start position.
-     * @param maxLen Maximum stream length.
-     * @throws IOException In case of exception.
-     */
-    public IgniteFsRangeInputStream(IgniteFsInputStream is, long start, long maxLen) throws IOException {
-        if (is == null)
-            throw new IllegalArgumentException("Input stream cannot be null.");
-
-        if (start < 0)
-            throw new IllegalArgumentException("Start position cannot be negative.");
-
-        if (start >= is.length())
-            throw new IllegalArgumentException("Start position cannot be greater that file length.");
-
-        if (maxLen < 0)
-            throw new IllegalArgumentException("Length cannot be negative.");
-
-        if (start + maxLen > is.length())
-            throw new IllegalArgumentException("Sum of start position and length cannot be greater than file length.");
-
-        this.is = is;
-        this.start = start;
-        this.maxLen = maxLen;
-
-        is.seek(start);
-    }
-
-    /** {@inheritDoc} */
-    @Override public long length() {
-        return is.length();
-    }
-
-    /**
-     * Constructor.
-     *
-     * @param is Base input stream.
-     * @param range File range.
-     * @throws IOException In case of exception.
-     */
-    public IgniteFsRangeInputStream(IgniteFsInputStream is, IgniteFsFileRange range) throws IOException {
-        this(is, range.start(), range.length());
-    }
-
-    /** {@inheritDoc} */
-    @Override public int read() throws IOException {
-        if (pos < maxLen) {
-            int res = is.read();
-
-            if (res != -1)
-                pos++;
-
-            return res;
-        }
-        else
-            return -1;
-    }
-
-    /** {@inheritDoc} */
-    @Override public int read(@NotNull byte[] b, int off, int len) throws IOException {
-        if (pos < maxLen) {
-            len = (int)Math.min(len, maxLen - pos);
-
-            int res = is.read(b, off, len);
-
-            if (res != -1)
-                pos += res;
-
-            return res;
-        }
-        else
-            return -1;
-    }
-
-    /** {@inheritDoc} */
-    @Override public int read(long pos, byte[] buf, int off, int len) throws IOException {
-        seek(pos);
-
-        return read(buf, off, len);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void readFully(long pos, byte[] buf) throws IOException {
-        readFully(pos, buf, 0, buf.length);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void readFully(long pos, byte[] buf, int off, int len) throws IOException {
-        seek(pos);
-
-        for (int readBytes = 0; readBytes < len;) {
-            int read = read(buf, off + readBytes, len - readBytes);
-
-            if (read == -1)
-                throw new EOFException("Failed to read stream fully (stream ends unexpectedly) [pos=" + pos +
-                    ", buf.length=" + buf.length + ", off=" + off + ", len=" + len + ']');
-
-            readBytes += read;
-        }
-    }
-
-    /** {@inheritDoc} */
-    @Override public void seek(long pos) throws IOException {
-        if (pos < 0)
-            throw new IOException("Seek position cannot be negative: " + pos);
-
-        is.seek(start + pos);
-
-        this.pos = pos;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long position() {
-        return pos;
-    }
-
-    /**
-     * Since range input stream represents a part of larger file stream, there is an offset at which this
-     * range input stream starts in original input stream. This method returns start offset of this input
-     * stream relative to original input stream.
-     *
-     * @return Start offset in original input stream.
-     */
-    public long startOffset() {
-        return start;
-    }
-
-    /** {@inheritDoc} */
-    @Override public int available() {
-        long l = maxLen - pos;
-
-        if (l < 0)
-            return 0;
-
-        if (l > Integer.MAX_VALUE)
-            return Integer.MAX_VALUE;
-
-        return (int)l;
-    }
-
-    /** {@inheritDoc} */
-    @Override public void close() throws IOException {
-        is.close();
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(IgniteFsRangeInputStream.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java
deleted file mode 100644
index 697f575..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsRecordResolver.java
+++ /dev/null
@@ -1,49 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-import org.apache.ignite.*;
-import org.apache.ignite.fs.*;
-import org.gridgain.grid.*;
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-
-/**
- * GGFS record resolver. When {@link IgniteFsTask} is split into {@link IgniteFsJob}s each produced job will obtain
- * {@link IgniteFsFileRange} based on file data location. Record resolver is invoked in each job before actual
- * execution in order to adjust record boundaries in a way consistent with user data.
- * <p>
- * E.g., you may want to split your task into jobs so that each job process zero, one or several lines from that file.
- * But file is split into ranges based on block locations, not new line boundaries. Using convenient record resolver
- * you can adjust job range so that it covers the whole line(s).
- * <p>
- * The following record resolvers are available out of the box:
- * <ul>
- *     <li>{@link org.gridgain.grid.ggfs.mapreduce.records.IgniteFsFixedLengthRecordResolver}</li>
- *     <li>{@link org.gridgain.grid.ggfs.mapreduce.records.IgniteFsByteDelimiterRecordResolver}</li>
- *     <li>{@link org.gridgain.grid.ggfs.mapreduce.records.IgniteFsStringDelimiterRecordResolver}</li>
- *     <li>{@link org.gridgain.grid.ggfs.mapreduce.records.IgniteFsNewLineRecordResolver}</li>
- * </ul>
- */
-public interface IgniteFsRecordResolver extends Serializable {
-    /**
-     * Adjusts record start offset and length.
-     *
-     * @param ggfs GGFS instance to use.
-     * @param stream Input stream for split file.
-     * @param suggestedRecord Suggested file system record.
-     * @return New adjusted record. If this method returns {@code null}, original record is ignored.
-     * @throws GridException If resolve failed.
-     * @throws IOException If resolve failed.
-     */
-    @Nullable public IgniteFsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
-        IgniteFsFileRange suggestedRecord) throws GridException, IOException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java
deleted file mode 100644
index bfde75c..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTask.java
+++ /dev/null
@@ -1,165 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-import org.apache.ignite.*;
-import org.apache.ignite.cluster.*;
-import org.apache.ignite.compute.*;
-import org.apache.ignite.fs.*;
-import org.apache.ignite.resources.*;
-import org.gridgain.grid.*;
-import org.gridgain.grid.kernal.*;
-import org.gridgain.grid.kernal.processors.ggfs.*;
-import org.gridgain.grid.util.typedef.internal.*;
-import org.jetbrains.annotations.*;
-
-import java.util.*;
-
-/**
- * GGFS task which can be executed on the grid using one of {@code GridGgfs.execute()} methods. Essentially GGFS task
- * is regular {@link org.apache.ignite.compute.ComputeTask} with different map logic. Instead of implementing
- * {@link org.apache.ignite.compute.ComputeTask#map(List, Object)} method to split task into jobs, you must implement
- * {@link IgniteFsTask#createJob(org.apache.ignite.fs.IgniteFsPath, IgniteFsFileRange, IgniteFsTaskArgs)} method.
- * <p>
- * Each file participating in GGFS task is split into {@link IgniteFsFileRange}s first. Normally range is a number of
- * consequent bytes located on a single node (see {@code GridGgfsGroupDataBlocksKeyMapper}). In case maximum range size
- * is provided (either through {@link org.apache.ignite.fs.IgniteFsConfiguration#getMaximumTaskRangeLength()} or {@code GridGgfs.execute()}
- * argument), then ranges could be further divided into smaller chunks.
- * <p>
- * Once file is split into ranges, each range is passed to {@code GridGgfsTask.createJob()} method in order to create a
- * {@link IgniteFsJob}.
- * <p>
- * Finally all generated jobs are sent to Grid nodes for execution.
- * <p>
- * As with regular {@code GridComputeTask} you can define your own logic for results handling and reduce step.
- * <p>
- * Here is an example of such a task:
- * <pre name="code" class="java">
- * public class WordCountTask extends GridGgfsTask&lt;String, Integer&gt; {
- *     &#64;Override
- *     public GridGgfsJob createJob(GridGgfsPath path, GridGgfsFileRange range, GridGgfsTaskArgs&lt;T&gt; args) throws GridException {
- *         // New job will be created for each range within each file.
- *         // We pass user-provided argument (which is essentially a word to look for) to that job.
- *         return new WordCountJob(args.userArgument());
- *     }
- *
- *     // Aggregate results into one compound result.
- *     public Integer reduce(List&lt;GridComputeJobResult&gt; results) throws GridException {
- *         Integer total = 0;
- *
- *         for (GridComputeJobResult res : results) {
- *             Integer cnt = res.getData();
- *
- *             // Null can be returned for non-existent file in case we decide to ignore such situations.
- *             if (cnt != null)
- *                 total += cnt;
- *         }
- *
- *         return total;
- *     }
- * }
- * </pre>
- */
-public abstract class IgniteFsTask<T, R> extends ComputeTaskAdapter<IgniteFsTaskArgs<T>, R> {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** Injected grid. */
-    @IgniteInstanceResource
-    private Ignite ignite;
-
-    /** {@inheritDoc} */
-    @Nullable @Override public final Map<? extends ComputeJob, ClusterNode> map(List<ClusterNode> subgrid,
-        @Nullable IgniteFsTaskArgs<T> args) throws GridException {
-        assert ignite != null;
-        assert args != null;
-
-        IgniteFs ggfs = ignite.fileSystem(args.ggfsName());
-        GridGgfsProcessorAdapter ggfsProc = ((GridKernal) ignite).context().ggfs();
-
-        Map<ComputeJob, ClusterNode> splitMap = new HashMap<>();
-
-        Map<UUID, ClusterNode> nodes = mapSubgrid(subgrid);
-
-        for (IgniteFsPath path : args.paths()) {
-            IgniteFsFile file = ggfs.info(path);
-
-            if (file == null) {
-                if (args.skipNonExistentFiles())
-                    continue;
-                else
-                    throw new GridException("Failed to process GGFS file because it doesn't exist: " + path);
-            }
-
-            Collection<IgniteFsBlockLocation> aff = ggfs.affinity(path, 0, file.length(), args.maxRangeLength());
-
-            long totalLen = 0;
-
-            for (IgniteFsBlockLocation loc : aff) {
-                ClusterNode node = null;
-
-                for (UUID nodeId : loc.nodeIds()) {
-                    node = nodes.get(nodeId);
-
-                    if (node != null)
-                        break;
-                }
-
-                if (node == null)
-                    throw new GridException("Failed to find any of block affinity nodes in subgrid [loc=" + loc +
-                        ", subgrid=" + subgrid + ']');
-
-                IgniteFsJob job = createJob(path, new IgniteFsFileRange(file.path(), loc.start(), loc.length()), args);
-
-                if (job != null) {
-                    ComputeJob jobImpl = ggfsProc.createJob(job, ggfs.name(), file.path(), loc.start(),
-                        loc.length(), args.recordResolver());
-
-                    splitMap.put(jobImpl, node);
-                }
-
-                totalLen += loc.length();
-            }
-
-            assert totalLen == file.length();
-        }
-
-        return splitMap;
-    }
-
-    /**
-     * Callback invoked during task map procedure to create job that will process specified split
-     * for GGFS file.
-     *
-     * @param path Path.
-     * @param range File range based on consecutive blocks. This range will be further
-     *      realigned to record boundaries on destination node.
-     * @param args Task argument.
-     * @return GGFS job. If {@code null} is returned, the passed in file range will be skipped.
-     * @throws GridException If job creation failed.
-     */
-    @Nullable public abstract IgniteFsJob createJob(IgniteFsPath path, IgniteFsFileRange range,
-        IgniteFsTaskArgs<T> args) throws GridException;
-
-    /**
-     * Maps list by node ID.
-     *
-     * @param subgrid Subgrid.
-     * @return Map.
-     */
-    private Map<UUID, ClusterNode> mapSubgrid(Collection<ClusterNode> subgrid) {
-        Map<UUID, ClusterNode> res = U.newHashMap(subgrid.size());
-
-        for (ClusterNode node : subgrid)
-            res.put(node.id(), node);
-
-        return res;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskArgs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskArgs.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskArgs.java
deleted file mode 100644
index d6622ef..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskArgs.java
+++ /dev/null
@@ -1,74 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-import org.apache.ignite.fs.*;
-
-import java.util.*;
-
-/**
- * GGFS task arguments. When you initiate new GGFS task execution using one of {@code GridGgfs.execute(...)} methods,
- * all passed parameters are encapsulated in a single {@code GridGgfsTaskArgs} object. Later on this object is
- * passed to {@link IgniteFsTask#createJob(org.apache.ignite.fs.IgniteFsPath, IgniteFsFileRange, IgniteFsTaskArgs)} method.
- * <p>
- * Task arguments encapsulates the following data:
- * <ul>
- *     <li>GGFS name</li>
- *     <li>File paths passed to {@code GridGgfs.execute()} method</li>
- *     <li>{@link IgniteFsRecordResolver} for that task</li>
- *     <li>Flag indicating whether to skip non-existent file paths or throw an exception</li>
- *     <li>User-defined task argument</li>
- *     <li>Maximum file range length for that task (see {@link org.apache.ignite.fs.IgniteFsConfiguration#getMaximumTaskRangeLength()})</li>
- * </ul>
- */
-public interface IgniteFsTaskArgs<T> {
-    /**
-     * Gets GGFS name.
-     *
-     * @return GGFS name.
-     */
-    public String ggfsName();
-
-    /**
-     * Gets file paths to process.
-     *
-     * @return File paths to process.
-     */
-    public Collection<IgniteFsPath> paths();
-
-    /**
-     * Gets record resolver for the task.
-     *
-     * @return Record resolver.
-     */
-    public IgniteFsRecordResolver recordResolver();
-
-    /**
-     * Flag indicating whether to fail or simply skip non-existent files.
-     *
-     * @return {@code True} if non-existent files should be skipped.
-     */
-    public boolean skipNonExistentFiles();
-
-    /**
-     * User argument provided for task execution.
-     *
-     * @return User argument.
-     */
-    public T userArgument();
-
-    /**
-     * Optional maximum allowed range length, {@code 0} by default. If not specified, full range including
-     * all consecutive blocks will be used without any limitations.
-     *
-     * @return Maximum range length.
-     */
-    public long maxRangeLength();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskNoReduceAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskNoReduceAdapter.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskNoReduceAdapter.java
deleted file mode 100644
index 180d7a4..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/IgniteFsTaskNoReduceAdapter.java
+++ /dev/null
@@ -1,34 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce;
-
-import org.apache.ignite.compute.*;
-
-import java.util.*;
-
-/**
- * Convenient {@link IgniteFsTask} adapter with empty reduce step. Use this adapter in case you are not interested in
- * results returned by jobs.
- */
-public abstract class IgniteFsTaskNoReduceAdapter<T, R> extends IgniteFsTask<T, R> {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Default implementation which will ignore all results sent from execution nodes.
-     *
-     * @param results Received results of broadcasted remote executions. Note that if task class has
-     *      {@link org.apache.ignite.compute.ComputeTaskNoResultCache} annotation, then this list will be empty.
-     * @return Will always return {@code null}.
-     */
-    @Override public R reduce(List<ComputeJobResult> results) {
-        return null;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/package.html
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/package.html b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/package.html
deleted file mode 100644
index cde37cf..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/package.html
+++ /dev/null
@@ -1,15 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
-<!--
-    @html.file.header
-    _________        _____ __________________        _____
-    __  ____/___________(_)______  /__  ____/______ ____(_)_______
-    _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
-    / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
-    \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
--->
-<html>
-<body>
-    <!-- Package description. -->
-    Contains APIs for In-Memory MapReduce over GGFS.
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java
index 9ca7b54..480e574 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java
@@ -11,9 +11,9 @@ package org.gridgain.grid.ggfs.mapreduce.records;
 
 import org.apache.ignite.*;
 import org.apache.ignite.fs.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.util.typedef.*;
 import org.gridgain.grid.util.typedef.internal.*;
 import org.gridgain.grid.util.tostring.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java
index ddfd402..b360483 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java
@@ -11,8 +11,8 @@ package org.gridgain.grid.ggfs.mapreduce.records;
 
 import org.apache.ignite.*;
 import org.apache.ignite.fs.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.util.typedef.internal.*;
 
 import java.io.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
index 0351392..24f0a5c 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
@@ -11,9 +11,9 @@ package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.*;
 import org.apache.ignite.fs.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
 import org.jetbrains.annotations.*;
 
 import java.net.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
index a54515c..2f00e69 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
@@ -14,13 +14,13 @@ import org.apache.ignite.cluster.*;
 import org.apache.ignite.compute.*;
 import org.apache.ignite.events.*;
 import org.apache.ignite.fs.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.resources.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.cache.eviction.*;
 import org.gridgain.grid.cache.eviction.ggfs.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.managers.communication.*;
 import org.gridgain.grid.kernal.managers.eventstorage.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
index bdd8e66..93aff1a 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
@@ -12,9 +12,9 @@ package org.gridgain.grid.kernal.processors.ggfs;
 import org.apache.ignite.*;
 import org.apache.ignite.compute.*;
 import org.apache.ignite.fs.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.apache.ignite.resources.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.kernal.*;
 
 import java.io.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
index 5ba2e40..335b05c 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
@@ -14,11 +14,11 @@ import org.apache.ignite.cluster.*;
 import org.apache.ignite.compute.*;
 import org.apache.ignite.configuration.*;
 import org.apache.ignite.fs.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
 import org.gridgain.grid.cache.affinity.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.processors.cache.*;
 import org.gridgain.grid.kernal.processors.license.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
index a3bc423..ab4c8af 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
@@ -12,7 +12,7 @@ package org.gridgain.grid.kernal.processors.ggfs;
 import org.apache.ignite.*;
 import org.apache.ignite.compute.*;
 import org.apache.ignite.fs.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.processors.*;
 import org.gridgain.grid.util.ipc.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
index d1f9d6e..1f2875b 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
@@ -12,7 +12,7 @@ package org.gridgain.grid.kernal.processors.ggfs;
 import org.apache.ignite.*;
 import org.apache.ignite.compute.*;
 import org.apache.ignite.fs.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.util.ipc.*;
 import org.gridgain.grid.util.typedef.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsTaskArgsImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsTaskArgsImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsTaskArgsImpl.java
index 78ecc7d..fe73fe4 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsTaskArgsImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsTaskArgsImpl.java
@@ -10,7 +10,7 @@
 package org.gridgain.grid.kernal.processors.ggfs;
 
 import org.apache.ignite.fs.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.gridgain.grid.util.typedef.internal.*;
 
 import java.io.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
index 02aa9ef..c6d6f24 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
@@ -13,11 +13,11 @@ import org.apache.ignite.*;
 import org.apache.ignite.compute.*;
 import org.apache.ignite.configuration.*;
 import org.apache.ignite.fs.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.resources.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.ggfs.mapreduce.records.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.*;
@@ -35,7 +35,7 @@ import static org.gridgain.grid.cache.GridCacheWriteSynchronizationMode.*;
 import static org.apache.ignite.fs.IgniteFsMode.*;
 
 /**
- * Tests for {@link org.gridgain.grid.ggfs.mapreduce.IgniteFsTask}.
+ * Tests for {@link org.apache.ignite.fs.mapreduce.IgniteFsTask}.
  */
 public class GridGgfsTaskSelfTest extends GridGgfsCommonAbstractTest {
     /** Predefined words dictionary. */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
index 7347f0f..905410c 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
@@ -12,8 +12,8 @@ package org.gridgain.grid.kernal.processors.ggfs.split;
 import org.apache.ignite.*;
 import org.apache.ignite.configuration.*;
 import org.apache.ignite.fs.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.vm.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
index b9f6b8d..bd9712a 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
@@ -10,7 +10,7 @@
 package org.gridgain.grid.kernal.processors.ggfs.split;
 
 import org.apache.ignite.fs.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.gridgain.grid.ggfs.mapreduce.records.*;
 import org.gridgain.grid.util.typedef.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
index e9d3357..7bebc96 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
@@ -10,7 +10,7 @@
 package org.gridgain.grid.kernal.processors.ggfs.split;
 
 import org.apache.ignite.fs.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.gridgain.grid.ggfs.mapreduce.records.*;
 import org.gridgain.grid.util.typedef.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
index b1efc24..93d7286 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
@@ -10,7 +10,7 @@
 package org.gridgain.grid.kernal.processors.ggfs.split;
 
 import org.apache.ignite.fs.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.gridgain.grid.ggfs.mapreduce.records.*;
 import org.gridgain.grid.util.typedef.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
index bea2eff..efa044a 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
@@ -10,7 +10,7 @@
 package org.gridgain.grid.kernal.processors.ggfs.split;
 
 import org.apache.ignite.fs.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.gridgain.grid.ggfs.mapreduce.records.*;
 import org.gridgain.grid.util.typedef.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bf07cfae/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
index 51424f4..e0b444d 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
@@ -12,10 +12,10 @@ package org.gridgain.grid.kernal.processors.hadoop;
 import org.apache.ignite.*;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.fs.*;
+import org.apache.ignite.fs.mapreduce.*;
 import org.apache.ignite.lang.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.mapreduce.*;
 import org.gridgain.grid.hadoop.*;
 import org.gridgain.grid.kernal.*;
 import org.gridgain.grid.kernal.processors.cache.*;


[23/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java
deleted file mode 100644
index 8e58787..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java
+++ /dev/null
@@ -1,497 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.kernal.processors.ggfs;
-
-import org.apache.ignite.*;
-import org.apache.ignite.lang.*;
-import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.*;
-import org.gridgain.grid.kernal.processors.task.*;
-import org.gridgain.grid.util.typedef.internal.*;
-import org.gridgain.grid.util.future.*;
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-import java.nio.*;
-import java.util.concurrent.atomic.*;
-
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
-
-/**
- * Output stream to store data into grid cache with separate blocks.
- */
-class GridGgfsOutputStreamImpl extends GridGgfsOutputStreamAdapter {
-    /** Maximum number of blocks in buffer. */
-    private static final int MAX_BLOCKS_CNT = 16;
-
-    /** GGFS context. */
-    private GridGgfsContext ggfsCtx;
-
-    /** Meta info manager. */
-    private final GridGgfsMetaManager meta;
-
-    /** Data manager. */
-    private final GridGgfsDataManager data;
-
-    /** File descriptor. */
-    @SuppressWarnings("FieldAccessedSynchronizedAndUnsynchronized")
-    private GridGgfsFileInfo fileInfo;
-
-    /** Parent ID. */
-    private final IgniteUuid parentId;
-
-    /** File name. */
-    private final String fileName;
-
-    /** Space in file to write data. */
-    @SuppressWarnings("FieldAccessedSynchronizedAndUnsynchronized")
-    private long space;
-
-    /** Intermediate remainder to keep data. */
-    private byte[] remainder;
-
-    /** Data length in remainder. */
-    private int remainderDataLen;
-
-    /** Write completion future. */
-    private final IgniteFuture<Boolean> writeCompletionFut;
-
-    /** GGFS mode. */
-    private final GridGgfsMode mode;
-
-    /** File worker batch. */
-    private final GridGgfsFileWorkerBatch batch;
-
-    /** Ensures that onClose)_ routine is called no more than once. */
-    private final AtomicBoolean onCloseGuard = new AtomicBoolean();
-
-    /** Local GGFS metrics. */
-    private final GridGgfsLocalMetrics metrics;
-
-    /** Affinity written by this output stream. */
-    private GridGgfsFileAffinityRange streamRange;
-
-    /**
-     * Constructs file output stream.
-     *
-     * @param ggfsCtx GGFS context.
-     * @param path Path to stored file.
-     * @param fileInfo File info to write binary data to.
-     * @param bufSize The size of the buffer to be used.
-     * @param mode Grid GGFS mode.
-     * @param batch Optional secondary file system batch.
-     * @param metrics Local GGFs metrics.
-     * @throws GridException If stream creation failed.
-     */
-    GridGgfsOutputStreamImpl(GridGgfsContext ggfsCtx, IgniteFsPath path, GridGgfsFileInfo fileInfo, IgniteUuid parentId,
-        int bufSize, GridGgfsMode mode, @Nullable GridGgfsFileWorkerBatch batch, GridGgfsLocalMetrics metrics)
-        throws GridException {
-        super(path, optimizeBufferSize(bufSize, fileInfo));
-
-        assert fileInfo != null;
-        assert fileInfo.isFile() : "Unexpected file info: " + fileInfo;
-        assert mode != null && mode != PROXY;
-        assert mode == PRIMARY && batch == null || batch != null;
-        assert metrics != null;
-
-        // File hasn't been locked.
-        if (fileInfo.lockId() == null)
-            throw new IgniteFsException("Failed to acquire file lock (concurrently modified?): " + path);
-
-        this.ggfsCtx = ggfsCtx;
-        meta = ggfsCtx.meta();
-        data = ggfsCtx.data();
-
-        this.fileInfo = fileInfo;
-        this.mode = mode;
-        this.batch = batch;
-        this.parentId = parentId;
-        this.metrics = metrics;
-
-        streamRange = initialStreamRange(fileInfo);
-
-        fileName = path.name();
-
-        writeCompletionFut = data.writeStart(fileInfo);
-    }
-
-    /**
-     * Optimize buffer size.
-     *
-     * @param bufSize Requested buffer size.
-     * @param fileInfo File info.
-     * @return Optimized buffer size.
-     */
-    @SuppressWarnings("IfMayBeConditional")
-    private static int optimizeBufferSize(int bufSize, GridGgfsFileInfo fileInfo) {
-        assert bufSize > 0;
-
-        if (fileInfo == null)
-            return bufSize;
-
-        int blockSize = fileInfo.blockSize();
-
-        if (blockSize <= 0)
-            return bufSize;
-
-        if (bufSize <= blockSize)
-            // Optimize minimum buffer size to be equal file's block size.
-            return blockSize;
-
-        int maxBufSize = blockSize * MAX_BLOCKS_CNT;
-
-        if (bufSize > maxBufSize)
-            // There is no profit or optimization from larger buffers.
-            return maxBufSize;
-
-        if (fileInfo.length() == 0)
-            // Make buffer size multiple of block size (optimized for new files).
-            return bufSize / blockSize * blockSize;
-
-        return bufSize;
-    }
-
-    /** {@inheritDoc} */
-    @Override protected synchronized void storeDataBlock(ByteBuffer block) throws GridException, IOException {
-        int writeLen = block.remaining();
-
-        preStoreDataBlocks(null, writeLen);
-
-        int blockSize = fileInfo.blockSize();
-
-        // If data length is not enough to fill full block, fill the remainder and return.
-        if (remainderDataLen + writeLen < blockSize) {
-            if (remainder == null)
-                remainder = new byte[blockSize];
-            else if (remainder.length != blockSize) {
-                assert remainderDataLen == remainder.length;
-
-                byte[] allocated = new byte[blockSize];
-
-                U.arrayCopy(remainder, 0, allocated, 0, remainder.length);
-
-                remainder = allocated;
-            }
-
-            block.get(remainder, remainderDataLen, writeLen);
-
-            remainderDataLen += writeLen;
-        }
-        else {
-            remainder = data.storeDataBlocks(fileInfo, fileInfo.length() + space, remainder, remainderDataLen, block,
-                false, streamRange, batch);
-
-            remainderDataLen = remainder == null ? 0 : remainder.length;
-        }
-    }
-
-    /** {@inheritDoc} */
-    @Override protected synchronized void storeDataBlocks(DataInput in, int len) throws GridException, IOException {
-        preStoreDataBlocks(in, len);
-
-        int blockSize = fileInfo.blockSize();
-
-        // If data length is not enough to fill full block, fill the remainder and return.
-        if (remainderDataLen + len < blockSize) {
-            if (remainder == null)
-                remainder = new byte[blockSize];
-            else if (remainder.length != blockSize) {
-                assert remainderDataLen == remainder.length;
-
-                byte[] allocated = new byte[blockSize];
-
-                U.arrayCopy(remainder, 0, allocated, 0, remainder.length);
-
-                remainder = allocated;
-            }
-
-            in.readFully(remainder, remainderDataLen, len);
-
-            remainderDataLen += len;
-        }
-        else {
-            remainder = data.storeDataBlocks(fileInfo, fileInfo.length() + space, remainder, remainderDataLen, in, len,
-                false, streamRange, batch);
-
-            remainderDataLen = remainder == null ? 0 : remainder.length;
-        }
-    }
-
-    /**
-     * Initializes data loader if it was not initialized yet and updates written space.
-     *
-     * @param len Data length to be written.
-     */
-    private void preStoreDataBlocks(@Nullable DataInput in, int len) throws GridException, IOException {
-        // Check if any exception happened while writing data.
-        if (writeCompletionFut.isDone()) {
-            assert ((GridFutureAdapter)writeCompletionFut).isFailed();
-
-            if (in != null)
-                in.skipBytes(len);
-
-            writeCompletionFut.get();
-        }
-
-        bytes += len;
-        space += len;
-    }
-
-    /**
-     * Flushes this output stream and forces any buffered output bytes to be written out.
-     *
-     * @exception IOException  if an I/O error occurs.
-     */
-    @Override public synchronized void flush() throws IOException {
-        boolean exists;
-
-        try {
-            exists = meta.exists(fileInfo.id());
-        }
-        catch (GridException e) {
-            throw new IOError(e); // Something unrecoverable.
-        }
-
-        if (!exists) {
-            onClose(true);
-
-            throw new IOException("File was concurrently deleted: " + path);
-        }
-
-        super.flush();
-
-        try {
-            if (remainder != null) {
-                data.storeDataBlocks(fileInfo, fileInfo.length() + space, null, 0,
-                    ByteBuffer.wrap(remainder, 0, remainderDataLen), true, streamRange, batch);
-
-                remainder = null;
-                remainderDataLen = 0;
-            }
-
-            if (space > 0) {
-                GridGgfsFileInfo fileInfo0 = meta.updateInfo(fileInfo.id(),
-                    new ReserveSpaceClosure(space, streamRange));
-
-                if (fileInfo0 == null)
-                    throw new IOException("File was concurrently deleted: " + path);
-                else
-                    fileInfo = fileInfo0;
-
-                streamRange = initialStreamRange(fileInfo);
-
-                space = 0;
-            }
-        }
-        catch (GridException e) {
-            throw new IOException("Failed to flush data [path=" + path + ", space=" + space + ']', e);
-        }
-    }
-
-    /** {@inheritDoc} */
-    @Override protected void onClose() throws IOException {
-        onClose(false);
-    }
-
-    /**
-     * Close callback. It will be called only once in synchronized section.
-     *
-     * @param deleted Whether we already know that the file was deleted.
-     * @throws IOException If failed.
-     */
-    private void onClose(boolean deleted) throws IOException {
-        assert Thread.holdsLock(this);
-
-        if (onCloseGuard.compareAndSet(false, true)) {
-            // Notify backing secondary file system batch to finish.
-            if (mode != PRIMARY) {
-                assert batch != null;
-
-                batch.finish();
-            }
-
-            // Ensure file existence.
-            boolean exists;
-
-            try {
-                exists = !deleted && meta.exists(fileInfo.id());
-            }
-            catch (GridException e) {
-                throw new IOError(e); // Something unrecoverable.
-            }
-
-            if (exists) {
-                IOException err = null;
-
-                try {
-                    data.writeClose(fileInfo);
-
-                    writeCompletionFut.get();
-                }
-                catch (GridException e) {
-                    err = new IOException("Failed to close stream [path=" + path + ", fileInfo=" + fileInfo + ']', e);
-                }
-
-                metrics.addWrittenBytesTime(bytes, time);
-
-                // Await secondary file system processing to finish.
-                if (mode == DUAL_SYNC) {
-                    try {
-                        batch.await();
-                    }
-                    catch (GridException e) {
-                        if (err == null)
-                            err = new IOException("Failed to close secondary file system stream [path=" + path +
-                                ", fileInfo=" + fileInfo + ']', e);
-                    }
-                }
-
-                long modificationTime = System.currentTimeMillis();
-
-                try {
-                    meta.unlock(fileInfo, modificationTime);
-                }
-                catch (IgniteFsFileNotFoundException ignore) {
-                    data.delete(fileInfo); // Safety to ensure that all data blocks are deleted.
-
-                    throw new IOException("File was concurrently deleted: " + path);
-                }
-                catch (GridException e) {
-                    throw new IOError(e); // Something unrecoverable.
-                }
-
-                meta.updateParentListingAsync(parentId, fileInfo.id(), fileName, bytes, modificationTime);
-
-                if (err != null)
-                    throw err;
-            }
-            else {
-                try {
-                    if (mode == DUAL_SYNC)
-                        batch.await();
-                }
-                catch (GridException e) {
-                    throw new IOException("Failed to close secondary file system stream [path=" + path +
-                        ", fileInfo=" + fileInfo + ']', e);
-                }
-                finally {
-                    data.delete(fileInfo);
-                }
-            }
-        }
-    }
-
-    /**
-     * Gets initial affinity range. This range will have 0 length and will start from first
-     * non-occupied file block.
-     *
-     * @param fileInfo File info to build initial range for.
-     * @return Affinity range.
-     */
-    private GridGgfsFileAffinityRange initialStreamRange(GridGgfsFileInfo fileInfo) {
-        if (!ggfsCtx.configuration().isFragmentizerEnabled())
-            return null;
-
-        if (!Boolean.parseBoolean(fileInfo.properties().get(IgniteFs.PROP_PREFER_LOCAL_WRITES)))
-            return null;
-
-        int blockSize = fileInfo.blockSize();
-
-        // Find first non-occupied block offset.
-        long off = ((fileInfo.length() + blockSize - 1) / blockSize) * blockSize;
-
-        // Need to get last affinity key and reuse it if we are on the same node.
-        long lastBlockOff = off - fileInfo.blockSize();
-
-        if (lastBlockOff < 0)
-            lastBlockOff = 0;
-
-        GridGgfsFileMap map = fileInfo.fileMap();
-
-        IgniteUuid prevAffKey = map == null ? null : map.affinityKey(lastBlockOff, false);
-
-        IgniteUuid affKey = data.nextAffinityKey(prevAffKey);
-
-        return affKey == null ? null : new GridGgfsFileAffinityRange(off, off, affKey);
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridGgfsOutputStreamImpl.class, this);
-    }
-
-    /**
-     * Helper closure to reserve specified space and update file's length
-     */
-    @GridInternal
-    private static final class ReserveSpaceClosure implements IgniteClosure<GridGgfsFileInfo, GridGgfsFileInfo>,
-        Externalizable {
-        /** */
-        private static final long serialVersionUID = 0L;
-
-        /** Space amount (bytes number) to increase file's length. */
-        private long space;
-
-        /** Affinity range for this particular update. */
-        private GridGgfsFileAffinityRange range;
-
-        /**
-         * Empty constructor required for {@link Externalizable}.
-         *
-         */
-        public ReserveSpaceClosure() {
-            // No-op.
-        }
-
-        /**
-         * Constructs the closure to reserve specified space and update file's length.
-         *
-         * @param space Space amount (bytes number) to increase file's length.
-         * @param range Affinity range specifying which part of file was colocated.
-         */
-        private ReserveSpaceClosure(long space, GridGgfsFileAffinityRange range) {
-            this.space = space;
-            this.range = range;
-        }
-
-        /** {@inheritDoc} */
-        @Override public GridGgfsFileInfo apply(GridGgfsFileInfo oldInfo) {
-            GridGgfsFileMap oldMap = oldInfo.fileMap();
-
-            GridGgfsFileMap newMap = new GridGgfsFileMap(oldMap);
-
-            newMap.addRange(range);
-
-            // Update file length.
-            GridGgfsFileInfo updated = new GridGgfsFileInfo(oldInfo, oldInfo.length() + space);
-
-            updated.fileMap(newMap);
-
-            return updated;
-        }
-
-        /** {@inheritDoc} */
-        @Override public void writeExternal(ObjectOutput out) throws IOException {
-            out.writeLong(space);
-            out.writeObject(range);
-        }
-
-        /** {@inheritDoc} */
-        @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
-            space = in.readLong();
-            range = (GridGgfsFileAffinityRange)in.readObject();
-        }
-
-        /** {@inheritDoc} */
-        @Override public String toString() {
-            return S.toString(ReserveSpaceClosure.class, this);
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPaths.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPaths.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPaths.java
index 12b401c..5dbb004 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPaths.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPaths.java
@@ -28,10 +28,10 @@ public class GridGgfsPaths implements Externalizable {
     private Map<String, String> props;
 
     /** Default GGFS mode. */
-    private GridGgfsMode dfltMode;
+    private IgniteFsMode dfltMode;
 
     /** Path modes. */
-    private List<T2<IgniteFsPath, GridGgfsMode>> pathModes;
+    private List<T2<IgniteFsPath, IgniteFsMode>> pathModes;
 
     /**
      * Empty constructor required by {@link Externalizable}.
@@ -47,8 +47,8 @@ public class GridGgfsPaths implements Externalizable {
      * @param dfltMode Default GGFS mode.
      * @param pathModes Path modes.
      */
-    public GridGgfsPaths(Map<String, String> props, GridGgfsMode dfltMode, @Nullable List<T2<IgniteFsPath,
-        GridGgfsMode>> pathModes) {
+    public GridGgfsPaths(Map<String, String> props, IgniteFsMode dfltMode, @Nullable List<T2<IgniteFsPath,
+        IgniteFsMode>> pathModes) {
         this.props = props;
         this.dfltMode = dfltMode;
         this.pathModes = pathModes;
@@ -64,14 +64,14 @@ public class GridGgfsPaths implements Externalizable {
     /**
      * @return Default GGFS mode.
      */
-    public GridGgfsMode defaultMode() {
+    public IgniteFsMode defaultMode() {
         return dfltMode;
     }
 
     /**
      * @return Path modes.
      */
-    @Nullable public List<T2<IgniteFsPath, GridGgfsMode>> pathModes() {
+    @Nullable public List<T2<IgniteFsPath, IgniteFsMode>> pathModes() {
         return pathModes;
     }
 
@@ -84,7 +84,7 @@ public class GridGgfsPaths implements Externalizable {
             out.writeBoolean(true);
             out.writeInt(pathModes.size());
 
-            for (T2<IgniteFsPath, GridGgfsMode> pathMode : pathModes) {
+            for (T2<IgniteFsPath, IgniteFsMode> pathMode : pathModes) {
                 pathMode.getKey().writeExternal(out);
                 U.writeEnum0(out, pathMode.getValue());
             }
@@ -96,7 +96,7 @@ public class GridGgfsPaths implements Externalizable {
     /** {@inheritDoc} */
     @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
         props = U.readStringMap(in);
-        dfltMode = GridGgfsMode.fromOrdinal(U.readEnumOrdinal0(in));
+        dfltMode = IgniteFsMode.fromOrdinal(U.readEnumOrdinal0(in));
 
         if (in.readBoolean()) {
             int size = in.readInt();
@@ -107,7 +107,7 @@ public class GridGgfsPaths implements Externalizable {
                 IgniteFsPath path = new IgniteFsPath();
                 path.readExternal(in);
 
-                T2<IgniteFsPath, GridGgfsMode> entry = new T2<>(path, GridGgfsMode.fromOrdinal(U.readEnumOrdinal0(in)));
+                T2<IgniteFsPath, IgniteFsMode> entry = new T2<>(path, IgniteFsMode.fromOrdinal(U.readEnumOrdinal0(in)));
 
                 pathModes.add(entry);
             }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
index 0b37e55..3d26dcd 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
@@ -35,7 +35,7 @@ import java.util.concurrent.*;
 import static org.gridgain.grid.GridSystemProperties.*;
 import static org.gridgain.grid.cache.GridCacheMemoryMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 import static org.gridgain.grid.kernal.GridNodeAttributes.*;
 import static org.gridgain.grid.kernal.processors.license.GridLicenseSubsystem.*;
 
@@ -360,7 +360,7 @@ public class GridGgfsProcessor extends GridGgfsProcessorAdapter {
             boolean secondary = cfg.getDefaultMode() == PROXY;
 
             if (cfg.getPathModes() != null) {
-                for (Map.Entry<String, GridGgfsMode> mode : cfg.getPathModes().entrySet()) {
+                for (Map.Entry<String, IgniteFsMode> mode : cfg.getPathModes().entrySet()) {
                     if (mode.getValue() == PROXY)
                         secondary = true;
                 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamAdapter.java
new file mode 100644
index 0000000..b1cdf1b
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamAdapter.java
@@ -0,0 +1,255 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.kernal.processors.ggfs;
+
+import org.gridgain.grid.*;
+import org.gridgain.grid.ggfs.*;
+import org.gridgain.grid.util.typedef.internal.*;
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+import java.nio.*;
+
+/**
+ * Output stream to store data into grid cache with separate blocks.
+ */
+@SuppressWarnings("NonPrivateFieldAccessedInSynchronizedContext")
+abstract class IgniteFsOutputStreamAdapter extends IgniteFsOutputStream {
+    /** Path to file. */
+    protected final IgniteFsPath path;
+
+    /** Buffer size. */
+    private final int bufSize;
+
+    /** Flag for this stream open/closed state. */
+    private boolean closed;
+
+    /** Local buffer to store stream data as consistent block. */
+    private ByteBuffer buf;
+
+    /** Bytes written. */
+    @SuppressWarnings("FieldAccessedSynchronizedAndUnsynchronized")
+    protected long bytes;
+
+    /** Time consumed by write operations. */
+    protected long time;
+
+    /**
+     * Constructs file output stream.
+     *
+     * @param path Path to stored file.
+     * @param bufSize The size of the buffer to be used.
+     */
+    IgniteFsOutputStreamAdapter(IgniteFsPath path, int bufSize) {
+        assert path != null;
+        assert bufSize > 0;
+
+        this.path = path;
+        this.bufSize = bufSize;
+    }
+
+    /**
+     * Gets number of written bytes.
+     *
+     * @return Written bytes.
+     */
+    public long bytes() {
+        return bytes;
+    }
+
+    /** {@inheritDoc} */
+    @Override public synchronized void write(int b) throws IOException {
+        checkClosed(null, 0);
+
+        long startTime = System.nanoTime();
+
+        b &= 0xFF;
+
+        if (buf == null)
+            buf = ByteBuffer.allocate(bufSize);
+
+        buf.put((byte)b);
+
+        if (buf.position() >= bufSize)
+            sendData(true); // Send data to server.
+
+        time += System.nanoTime() - startTime;
+    }
+
+    /** {@inheritDoc} */
+    @Override public synchronized void write(byte[] b, int off, int len) throws IOException {
+        A.notNull(b, "b");
+
+        if ((off < 0) || (off > b.length) || (len < 0) || ((off + len) > b.length) || ((off + len) < 0)) {
+            throw new IndexOutOfBoundsException("Invalid bounds [data.length=" + b.length + ", offset=" + off +
+                ", length=" + len + ']');
+        }
+
+        checkClosed(null, 0);
+
+        if (len == 0)
+            return; // Done.
+
+        long startTime = System.nanoTime();
+
+        if (buf == null) {
+            // Do not allocate and copy byte buffer if will send data immediately.
+            if (len >= bufSize) {
+                buf = ByteBuffer.wrap(b, off, len);
+
+                sendData(false);
+
+                return;
+            }
+
+            buf = ByteBuffer.allocate(Math.max(bufSize, len));
+        }
+
+        if (buf.remaining() < len)
+            // Expand buffer capacity, if remaining size is less then data size.
+            buf = ByteBuffer.allocate(buf.position() + len).put((ByteBuffer)buf.flip());
+
+        assert len <= buf.remaining() : "Expects write data size less or equal then remaining buffer capacity " +
+            "[len=" + len + ", buf.remaining=" + buf.remaining() + ']';
+
+        buf.put(b, off, len);
+
+        if (buf.position() >= bufSize)
+            sendData(true); // Send data to server.
+
+        time += System.nanoTime() - startTime;
+    }
+
+    /** {@inheritDoc} */
+    @Override public synchronized void transferFrom(DataInput in, int len) throws IOException {
+        checkClosed(in, len);
+
+        long startTime = System.nanoTime();
+
+        // Send all IPC data from the local buffer before streaming.
+        if (buf != null && buf.position() > 0)
+            sendData(true);
+
+        try {
+            storeDataBlocks(in, len);
+        }
+        catch (GridException e) {
+            throw new IOException(e.getMessage(), e);
+        }
+
+        time += System.nanoTime() - startTime;
+    }
+
+    /**
+     * Flushes this output stream and forces any buffered output bytes to be written out.
+     *
+     * @exception IOException  if an I/O error occurs.
+     */
+    @Override public synchronized void flush() throws IOException {
+        checkClosed(null, 0);
+
+        // Send all IPC data from the local buffer.
+        if (buf != null && buf.position() > 0)
+            sendData(true);
+    }
+
+    /** {@inheritDoc} */
+    @Override public final synchronized void close() throws IOException {
+        // Do nothing if stream is already closed.
+        if (closed)
+            return;
+
+        try {
+            // Send all IPC data from the local buffer.
+            try {
+                flush();
+            }
+            finally {
+                onClose(); // "onClose()" routine must be invoked anyway!
+            }
+        }
+        finally {
+            // Mark this stream closed AFTER flush.
+            closed = true;
+        }
+    }
+
+    /**
+     * Store data blocks in file.<br/>
+     * Note! If file concurrently deleted we'll get lost blocks.
+     *
+     * @param data Data to store.
+     * @throws GridException If failed.
+     */
+    protected abstract void storeDataBlock(ByteBuffer data) throws GridException, IOException;
+
+    /**
+     * Store data blocks in file reading appropriate number of bytes from given data input.
+     *
+     * @param in Data input to read from.
+     * @param len Data length to store.
+     * @throws GridException If failed.
+     */
+    protected abstract void storeDataBlocks(DataInput in, int len) throws GridException, IOException;
+
+    /**
+     * Close callback. It will be called only once in synchronized section.
+     *
+     * @throws IOException If failed.
+     */
+    protected void onClose() throws IOException {
+        // No-op.
+    }
+
+    /**
+     * Validate this stream is open.
+     *
+     * @throws IOException If this stream is closed.
+     */
+    private void checkClosed(@Nullable DataInput in, int len) throws IOException {
+        assert Thread.holdsLock(this);
+
+        if (closed) {
+            // Must read data from stream before throwing exception.
+            if (in != null)
+                in.skipBytes(len);
+
+            throw new IOException("Stream has been closed: " + this);
+        }
+    }
+
+    /**
+     * Send all local-buffered data to server.
+     *
+     * @param flip Whether to flip buffer on sending data. We do not want to flip it if sending wrapped
+     *      byte array.
+     * @throws IOException In case of IO exception.
+     */
+    private void sendData(boolean flip) throws IOException {
+        assert Thread.holdsLock(this);
+
+        try {
+            if (flip)
+                buf.flip();
+
+            storeDataBlock(buf);
+        }
+        catch (GridException e) {
+            throw new IOException("Failed to store data into file: " + path, e);
+        }
+
+        buf = null;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsOutputStreamAdapter.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamImpl.java
new file mode 100644
index 0000000..1ea8d91
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsOutputStreamImpl.java
@@ -0,0 +1,497 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.kernal.processors.ggfs;
+
+import org.apache.ignite.*;
+import org.apache.ignite.lang.*;
+import org.gridgain.grid.*;
+import org.gridgain.grid.ggfs.*;
+import org.gridgain.grid.kernal.processors.task.*;
+import org.gridgain.grid.util.typedef.internal.*;
+import org.gridgain.grid.util.future.*;
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+import java.nio.*;
+import java.util.concurrent.atomic.*;
+
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
+
+/**
+ * Output stream to store data into grid cache with separate blocks.
+ */
+class IgniteFsOutputStreamImpl extends IgniteFsOutputStreamAdapter {
+    /** Maximum number of blocks in buffer. */
+    private static final int MAX_BLOCKS_CNT = 16;
+
+    /** GGFS context. */
+    private GridGgfsContext ggfsCtx;
+
+    /** Meta info manager. */
+    private final GridGgfsMetaManager meta;
+
+    /** Data manager. */
+    private final GridGgfsDataManager data;
+
+    /** File descriptor. */
+    @SuppressWarnings("FieldAccessedSynchronizedAndUnsynchronized")
+    private GridGgfsFileInfo fileInfo;
+
+    /** Parent ID. */
+    private final IgniteUuid parentId;
+
+    /** File name. */
+    private final String fileName;
+
+    /** Space in file to write data. */
+    @SuppressWarnings("FieldAccessedSynchronizedAndUnsynchronized")
+    private long space;
+
+    /** Intermediate remainder to keep data. */
+    private byte[] remainder;
+
+    /** Data length in remainder. */
+    private int remainderDataLen;
+
+    /** Write completion future. */
+    private final IgniteFuture<Boolean> writeCompletionFut;
+
+    /** GGFS mode. */
+    private final IgniteFsMode mode;
+
+    /** File worker batch. */
+    private final GridGgfsFileWorkerBatch batch;
+
+    /** Ensures that onClose)_ routine is called no more than once. */
+    private final AtomicBoolean onCloseGuard = new AtomicBoolean();
+
+    /** Local GGFS metrics. */
+    private final GridGgfsLocalMetrics metrics;
+
+    /** Affinity written by this output stream. */
+    private GridGgfsFileAffinityRange streamRange;
+
+    /**
+     * Constructs file output stream.
+     *
+     * @param ggfsCtx GGFS context.
+     * @param path Path to stored file.
+     * @param fileInfo File info to write binary data to.
+     * @param bufSize The size of the buffer to be used.
+     * @param mode Grid GGFS mode.
+     * @param batch Optional secondary file system batch.
+     * @param metrics Local GGFs metrics.
+     * @throws GridException If stream creation failed.
+     */
+    IgniteFsOutputStreamImpl(GridGgfsContext ggfsCtx, IgniteFsPath path, GridGgfsFileInfo fileInfo, IgniteUuid parentId,
+                             int bufSize, IgniteFsMode mode, @Nullable GridGgfsFileWorkerBatch batch, GridGgfsLocalMetrics metrics)
+        throws GridException {
+        super(path, optimizeBufferSize(bufSize, fileInfo));
+
+        assert fileInfo != null;
+        assert fileInfo.isFile() : "Unexpected file info: " + fileInfo;
+        assert mode != null && mode != PROXY;
+        assert mode == PRIMARY && batch == null || batch != null;
+        assert metrics != null;
+
+        // File hasn't been locked.
+        if (fileInfo.lockId() == null)
+            throw new IgniteFsException("Failed to acquire file lock (concurrently modified?): " + path);
+
+        this.ggfsCtx = ggfsCtx;
+        meta = ggfsCtx.meta();
+        data = ggfsCtx.data();
+
+        this.fileInfo = fileInfo;
+        this.mode = mode;
+        this.batch = batch;
+        this.parentId = parentId;
+        this.metrics = metrics;
+
+        streamRange = initialStreamRange(fileInfo);
+
+        fileName = path.name();
+
+        writeCompletionFut = data.writeStart(fileInfo);
+    }
+
+    /**
+     * Optimize buffer size.
+     *
+     * @param bufSize Requested buffer size.
+     * @param fileInfo File info.
+     * @return Optimized buffer size.
+     */
+    @SuppressWarnings("IfMayBeConditional")
+    private static int optimizeBufferSize(int bufSize, GridGgfsFileInfo fileInfo) {
+        assert bufSize > 0;
+
+        if (fileInfo == null)
+            return bufSize;
+
+        int blockSize = fileInfo.blockSize();
+
+        if (blockSize <= 0)
+            return bufSize;
+
+        if (bufSize <= blockSize)
+            // Optimize minimum buffer size to be equal file's block size.
+            return blockSize;
+
+        int maxBufSize = blockSize * MAX_BLOCKS_CNT;
+
+        if (bufSize > maxBufSize)
+            // There is no profit or optimization from larger buffers.
+            return maxBufSize;
+
+        if (fileInfo.length() == 0)
+            // Make buffer size multiple of block size (optimized for new files).
+            return bufSize / blockSize * blockSize;
+
+        return bufSize;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected synchronized void storeDataBlock(ByteBuffer block) throws GridException, IOException {
+        int writeLen = block.remaining();
+
+        preStoreDataBlocks(null, writeLen);
+
+        int blockSize = fileInfo.blockSize();
+
+        // If data length is not enough to fill full block, fill the remainder and return.
+        if (remainderDataLen + writeLen < blockSize) {
+            if (remainder == null)
+                remainder = new byte[blockSize];
+            else if (remainder.length != blockSize) {
+                assert remainderDataLen == remainder.length;
+
+                byte[] allocated = new byte[blockSize];
+
+                U.arrayCopy(remainder, 0, allocated, 0, remainder.length);
+
+                remainder = allocated;
+            }
+
+            block.get(remainder, remainderDataLen, writeLen);
+
+            remainderDataLen += writeLen;
+        }
+        else {
+            remainder = data.storeDataBlocks(fileInfo, fileInfo.length() + space, remainder, remainderDataLen, block,
+                false, streamRange, batch);
+
+            remainderDataLen = remainder == null ? 0 : remainder.length;
+        }
+    }
+
+    /** {@inheritDoc} */
+    @Override protected synchronized void storeDataBlocks(DataInput in, int len) throws GridException, IOException {
+        preStoreDataBlocks(in, len);
+
+        int blockSize = fileInfo.blockSize();
+
+        // If data length is not enough to fill full block, fill the remainder and return.
+        if (remainderDataLen + len < blockSize) {
+            if (remainder == null)
+                remainder = new byte[blockSize];
+            else if (remainder.length != blockSize) {
+                assert remainderDataLen == remainder.length;
+
+                byte[] allocated = new byte[blockSize];
+
+                U.arrayCopy(remainder, 0, allocated, 0, remainder.length);
+
+                remainder = allocated;
+            }
+
+            in.readFully(remainder, remainderDataLen, len);
+
+            remainderDataLen += len;
+        }
+        else {
+            remainder = data.storeDataBlocks(fileInfo, fileInfo.length() + space, remainder, remainderDataLen, in, len,
+                false, streamRange, batch);
+
+            remainderDataLen = remainder == null ? 0 : remainder.length;
+        }
+    }
+
+    /**
+     * Initializes data loader if it was not initialized yet and updates written space.
+     *
+     * @param len Data length to be written.
+     */
+    private void preStoreDataBlocks(@Nullable DataInput in, int len) throws GridException, IOException {
+        // Check if any exception happened while writing data.
+        if (writeCompletionFut.isDone()) {
+            assert ((GridFutureAdapter)writeCompletionFut).isFailed();
+
+            if (in != null)
+                in.skipBytes(len);
+
+            writeCompletionFut.get();
+        }
+
+        bytes += len;
+        space += len;
+    }
+
+    /**
+     * Flushes this output stream and forces any buffered output bytes to be written out.
+     *
+     * @exception IOException  if an I/O error occurs.
+     */
+    @Override public synchronized void flush() throws IOException {
+        boolean exists;
+
+        try {
+            exists = meta.exists(fileInfo.id());
+        }
+        catch (GridException e) {
+            throw new IOError(e); // Something unrecoverable.
+        }
+
+        if (!exists) {
+            onClose(true);
+
+            throw new IOException("File was concurrently deleted: " + path);
+        }
+
+        super.flush();
+
+        try {
+            if (remainder != null) {
+                data.storeDataBlocks(fileInfo, fileInfo.length() + space, null, 0,
+                    ByteBuffer.wrap(remainder, 0, remainderDataLen), true, streamRange, batch);
+
+                remainder = null;
+                remainderDataLen = 0;
+            }
+
+            if (space > 0) {
+                GridGgfsFileInfo fileInfo0 = meta.updateInfo(fileInfo.id(),
+                    new ReserveSpaceClosure(space, streamRange));
+
+                if (fileInfo0 == null)
+                    throw new IOException("File was concurrently deleted: " + path);
+                else
+                    fileInfo = fileInfo0;
+
+                streamRange = initialStreamRange(fileInfo);
+
+                space = 0;
+            }
+        }
+        catch (GridException e) {
+            throw new IOException("Failed to flush data [path=" + path + ", space=" + space + ']', e);
+        }
+    }
+
+    /** {@inheritDoc} */
+    @Override protected void onClose() throws IOException {
+        onClose(false);
+    }
+
+    /**
+     * Close callback. It will be called only once in synchronized section.
+     *
+     * @param deleted Whether we already know that the file was deleted.
+     * @throws IOException If failed.
+     */
+    private void onClose(boolean deleted) throws IOException {
+        assert Thread.holdsLock(this);
+
+        if (onCloseGuard.compareAndSet(false, true)) {
+            // Notify backing secondary file system batch to finish.
+            if (mode != PRIMARY) {
+                assert batch != null;
+
+                batch.finish();
+            }
+
+            // Ensure file existence.
+            boolean exists;
+
+            try {
+                exists = !deleted && meta.exists(fileInfo.id());
+            }
+            catch (GridException e) {
+                throw new IOError(e); // Something unrecoverable.
+            }
+
+            if (exists) {
+                IOException err = null;
+
+                try {
+                    data.writeClose(fileInfo);
+
+                    writeCompletionFut.get();
+                }
+                catch (GridException e) {
+                    err = new IOException("Failed to close stream [path=" + path + ", fileInfo=" + fileInfo + ']', e);
+                }
+
+                metrics.addWrittenBytesTime(bytes, time);
+
+                // Await secondary file system processing to finish.
+                if (mode == DUAL_SYNC) {
+                    try {
+                        batch.await();
+                    }
+                    catch (GridException e) {
+                        if (err == null)
+                            err = new IOException("Failed to close secondary file system stream [path=" + path +
+                                ", fileInfo=" + fileInfo + ']', e);
+                    }
+                }
+
+                long modificationTime = System.currentTimeMillis();
+
+                try {
+                    meta.unlock(fileInfo, modificationTime);
+                }
+                catch (IgniteFsFileNotFoundException ignore) {
+                    data.delete(fileInfo); // Safety to ensure that all data blocks are deleted.
+
+                    throw new IOException("File was concurrently deleted: " + path);
+                }
+                catch (GridException e) {
+                    throw new IOError(e); // Something unrecoverable.
+                }
+
+                meta.updateParentListingAsync(parentId, fileInfo.id(), fileName, bytes, modificationTime);
+
+                if (err != null)
+                    throw err;
+            }
+            else {
+                try {
+                    if (mode == DUAL_SYNC)
+                        batch.await();
+                }
+                catch (GridException e) {
+                    throw new IOException("Failed to close secondary file system stream [path=" + path +
+                        ", fileInfo=" + fileInfo + ']', e);
+                }
+                finally {
+                    data.delete(fileInfo);
+                }
+            }
+        }
+    }
+
+    /**
+     * Gets initial affinity range. This range will have 0 length and will start from first
+     * non-occupied file block.
+     *
+     * @param fileInfo File info to build initial range for.
+     * @return Affinity range.
+     */
+    private GridGgfsFileAffinityRange initialStreamRange(GridGgfsFileInfo fileInfo) {
+        if (!ggfsCtx.configuration().isFragmentizerEnabled())
+            return null;
+
+        if (!Boolean.parseBoolean(fileInfo.properties().get(IgniteFs.PROP_PREFER_LOCAL_WRITES)))
+            return null;
+
+        int blockSize = fileInfo.blockSize();
+
+        // Find first non-occupied block offset.
+        long off = ((fileInfo.length() + blockSize - 1) / blockSize) * blockSize;
+
+        // Need to get last affinity key and reuse it if we are on the same node.
+        long lastBlockOff = off - fileInfo.blockSize();
+
+        if (lastBlockOff < 0)
+            lastBlockOff = 0;
+
+        GridGgfsFileMap map = fileInfo.fileMap();
+
+        IgniteUuid prevAffKey = map == null ? null : map.affinityKey(lastBlockOff, false);
+
+        IgniteUuid affKey = data.nextAffinityKey(prevAffKey);
+
+        return affKey == null ? null : new GridGgfsFileAffinityRange(off, off, affKey);
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsOutputStreamImpl.class, this);
+    }
+
+    /**
+     * Helper closure to reserve specified space and update file's length
+     */
+    @GridInternal
+    private static final class ReserveSpaceClosure implements IgniteClosure<GridGgfsFileInfo, GridGgfsFileInfo>,
+        Externalizable {
+        /** */
+        private static final long serialVersionUID = 0L;
+
+        /** Space amount (bytes number) to increase file's length. */
+        private long space;
+
+        /** Affinity range for this particular update. */
+        private GridGgfsFileAffinityRange range;
+
+        /**
+         * Empty constructor required for {@link Externalizable}.
+         *
+         */
+        public ReserveSpaceClosure() {
+            // No-op.
+        }
+
+        /**
+         * Constructs the closure to reserve specified space and update file's length.
+         *
+         * @param space Space amount (bytes number) to increase file's length.
+         * @param range Affinity range specifying which part of file was colocated.
+         */
+        private ReserveSpaceClosure(long space, GridGgfsFileAffinityRange range) {
+            this.space = space;
+            this.range = range;
+        }
+
+        /** {@inheritDoc} */
+        @Override public GridGgfsFileInfo apply(GridGgfsFileInfo oldInfo) {
+            GridGgfsFileMap oldMap = oldInfo.fileMap();
+
+            GridGgfsFileMap newMap = new GridGgfsFileMap(oldMap);
+
+            newMap.addRange(range);
+
+            // Update file length.
+            GridGgfsFileInfo updated = new GridGgfsFileInfo(oldInfo, oldInfo.length() + space);
+
+            updated.fileMap(newMap);
+
+            return updated;
+        }
+
+        /** {@inheritDoc} */
+        @Override public void writeExternal(ObjectOutput out) throws IOException {
+            out.writeLong(space);
+            out.writeObject(range);
+        }
+
+        /** {@inheritDoc} */
+        @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
+            space = in.readLong();
+            range = (GridGgfsFileAffinityRange)in.readObject();
+        }
+
+        /** {@inheritDoc} */
+        @Override public String toString() {
+            return S.toString(ReserveSpaceClosure.class, this);
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/processors/job/GridJobWorker.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/job/GridJobWorker.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/job/GridJobWorker.java
index c90e959..6a932f4 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/job/GridJobWorker.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/job/GridJobWorker.java
@@ -488,7 +488,7 @@ public class GridJobWorker extends GridWorker implements GridTimeoutObject {
                 assert ex != null;
             }
             else {
-                if (X.hasCause(e, GridInternalException.class) || X.hasCause(e, GridGgfsOutOfSpaceException.class)) {
+                if (X.hasCause(e, GridInternalException.class) || X.hasCause(e, IgniteFsOutOfSpaceException.class)) {
                     // Print exception for internal errors only if debug is enabled.
                     if (log.isDebugEnabled())
                         U.error(log, "Failed to execute job [jobId=" + ses.getJobId() + ", ses=" + ses + ']', e);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/processors/task/GridTaskWorker.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/task/GridTaskWorker.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/task/GridTaskWorker.java
index 4d18c4b..9bf93e0 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/task/GridTaskWorker.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/task/GridTaskWorker.java
@@ -826,7 +826,7 @@ class GridTaskWorker<T, R> extends GridWorker implements GridTimeoutObject {
                 }
                 catch (GridException e) {
                     if (X.hasCause(e, GridInternalException.class) ||
-                        X.hasCause(e, GridGgfsOutOfSpaceException.class)) {
+                        X.hasCause(e, IgniteFsOutOfSpaceException.class)) {
                         // Print internal exceptions only if debug is enabled.
                         if (log.isDebugEnabled())
                             U.error(log, "Failed to obtain remote job result policy for result from " +
@@ -851,7 +851,7 @@ class GridTaskWorker<T, R> extends GridWorker implements GridTimeoutObject {
                 }
                 catch (GridRuntimeException e) {
                     if (X.hasCause(e, GridInternalException.class) ||
-                        X.hasCause(e, GridGgfsOutOfSpaceException.class)) {
+                        X.hasCause(e, IgniteFsOutOfSpaceException.class)) {
                         // Print internal exceptions only if debug is enabled.
                         if (log.isDebugEnabled())
                             U.error(log, "Failed to obtain remote job result policy for result from " +

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfs.java b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfs.java
index 8f0d716..9d537de 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfs.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfs.java
@@ -27,7 +27,7 @@ public class VisorGgfs implements Serializable {
     private final String name;
 
     /** GGFS instance working mode. */
-    private final GridGgfsMode mode;
+    private final IgniteFsMode mode;
 
     /** GGFS metrics. */
     private final VisorGgfsMetrics metrics;
@@ -45,7 +45,7 @@ public class VisorGgfs implements Serializable {
      */
     public VisorGgfs(
         String name,
-        GridGgfsMode mode,
+        IgniteFsMode mode,
         VisorGgfsMetrics metrics,
         boolean secondaryFsConfigured
     ) {
@@ -81,7 +81,7 @@ public class VisorGgfs implements Serializable {
     /**
      * @return GGFS instance working mode.
      */
-    public GridGgfsMode mode() {
+    public IgniteFsMode mode() {
         return mode;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfiler.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfiler.java b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfiler.java
index 5020bec..e1c8c14 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfiler.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfiler.java
@@ -48,7 +48,7 @@ public class VisorGgfsProfiler {
             long bytesWritten = 0;
             long writeTime = 0;
             long userWriteTime = 0;
-            GridGgfsMode mode = null;
+            IgniteFsMode mode = null;
             VisorGgfsProfilerUniformityCounters counters = new VisorGgfsProfilerUniformityCounters();
 
             for (VisorGgfsProfilerEntry entry : entries) {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerEntry.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerEntry.java b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerEntry.java
index 773cc9c..b027627 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerEntry.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerEntry.java
@@ -37,7 +37,7 @@ public class VisorGgfsProfilerEntry implements Serializable {
     private final long timestamp;
 
     /** GGFS mode. */
-    private final GridGgfsMode mode;
+    private final IgniteFsMode mode;
 
     /** File size. */
     private final long size;
@@ -76,7 +76,7 @@ public class VisorGgfsProfilerEntry implements Serializable {
     public VisorGgfsProfilerEntry(
         String path,
         long timestamp,
-        GridGgfsMode mode,
+        IgniteFsMode mode,
         long size,
         long bytesRead,
         long readTime,
@@ -139,7 +139,7 @@ public class VisorGgfsProfilerEntry implements Serializable {
     /**
      * @return GGFS mode.
      */
-    public GridGgfsMode mode() {
+    public IgniteFsMode mode() {
         return mode;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerTask.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerTask.java b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerTask.java
index 5ae5348..c82ebd9 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerTask.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsProfilerTask.java
@@ -46,7 +46,7 @@ public class VisorGgfsProfilerTask extends VisorOneNodeTask<String, Collection<V
         private final String path;
 
         /** File GGFS mode. */
-        private final GridGgfsMode mode;
+        private final IgniteFsMode mode;
 
         /** Stream ID. */
         private final long streamId;
@@ -76,7 +76,7 @@ public class VisorGgfsProfilerTask extends VisorOneNodeTask<String, Collection<V
             long ts,
             int entryType,
             String path,
-            GridGgfsMode mode,
+            IgniteFsMode mode,
             long streamId,
             long dataLen,
             boolean overwrite,
@@ -234,13 +234,13 @@ public class VisorGgfsProfilerTask extends VisorOneNodeTask<String, Collection<V
          * @param ix Index of array item to parse.
          * @return Parsed GGFS mode or {@code null} if string is empty.
          */
-        private GridGgfsMode parseGgfsMode(String[] ss, int ix) {
+        private IgniteFsMode parseGgfsMode(String[] ss, int ix) {
             if (ss.length <= ix)
                 return null;
             else {
                 String s = ss[ix];
 
-                return s.isEmpty() ? null : GridGgfsMode.valueOf(s);
+                return s.isEmpty() ? null : IgniteFsMode.valueOf(s);
             }
         }
 
@@ -295,7 +295,7 @@ public class VisorGgfsProfilerTask extends VisorOneNodeTask<String, Collection<V
             long bytesWritten = 0;
             long writeTime = 0;
             long userWriteTime = 0;
-            GridGgfsMode mode = null;
+            IgniteFsMode mode = null;
 
             for (VisorGgfsProfilerParsedLine line : lines) {
                 if (!line.path.isEmpty())

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java
index 0ac5d5d..2c75301 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java
@@ -62,10 +62,10 @@ public class VisorGgfsConfiguration implements Serializable {
     private String secondaryHadoopFileSystemConfigPath;
 
     /** GGFS instance mode. */
-    private GridGgfsMode defaultMode;
+    private IgniteFsMode defaultMode;
 
     /** Map of paths to GGFS modes. */
-    private Map<String, GridGgfsMode> pathModes;
+    private Map<String, IgniteFsMode> pathModes;
 
     /** Dual mode PUT operations executor service. */
     private String dualModePutExecutorService;
@@ -322,28 +322,28 @@ public class VisorGgfsConfiguration implements Serializable {
     /**
      * @return GGFS instance mode.
      */
-    public GridGgfsMode defaultMode() {
+    public IgniteFsMode defaultMode() {
         return defaultMode;
     }
 
     /**
      * @param dfltMode New gGFS instance mode.
      */
-    public void defaultMode(GridGgfsMode dfltMode) {
+    public void defaultMode(IgniteFsMode dfltMode) {
         defaultMode = dfltMode;
     }
 
     /**
      * @return Map of paths to GGFS modes.
      */
-    @Nullable public Map<String, GridGgfsMode> pathModes() {
+    @Nullable public Map<String, IgniteFsMode> pathModes() {
         return pathModes;
     }
 
     /**
      * @param pathModes New map of paths to GGFS modes.
      */
-    public void pathModes(@Nullable Map<String, GridGgfsMode> pathModes) {
+    public void pathModes(@Nullable Map<String, IgniteFsMode> pathModes) {
         this.pathModes = pathModes;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
index bf46e18..44df918 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
@@ -776,7 +776,7 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
         byte[] buf = new byte[dataSize];
 
         // Will generate GGFS_FILE_CREATED, GGFS_FILE_OPENED_WRITE, GGFS_FILE_CLOSED_WRITE.
-        try (GridGgfsOutputStream os = ggfs.create(file, false)) {
+        try (IgniteFsOutputStream os = ggfs.create(file, false)) {
             os.write(buf); // Will generate no events.
         }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java
index 08e88b8..dfb99d6 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java
@@ -32,7 +32,7 @@ public class GridGgfsFragmentizerSelfTest extends GridGgfsFragmentizerAbstractSe
 
         IgniteFsPath path = new IgniteFsPath("/someFile");
 
-        try (GridGgfsOutputStream out = ggfs.create(path, true)) {
+        try (IgniteFsOutputStream out = ggfs.create(path, true)) {
             // Write 10 groups.
             for (int i = 0; i < 10 * GGFS_GROUP_SIZE; i++) {
                 byte[] data = new byte[GGFS_BLOCK_SIZE];
@@ -102,7 +102,7 @@ public class GridGgfsFragmentizerSelfTest extends GridGgfsFragmentizerAbstractSe
         while (written < fileSize) {
             IgniteFs ggfs = grid(ggfsIdx).fileSystem("ggfs");
 
-            try (GridGgfsOutputStream out = ggfs.append(path, true)) {
+            try (IgniteFsOutputStream out = ggfs.append(path, true)) {
                 byte[] data = new byte[chunkSize];
 
                 Arrays.fill(data, (byte)i);
@@ -177,7 +177,7 @@ public class GridGgfsFragmentizerSelfTest extends GridGgfsFragmentizerAbstractSe
         byte[] chunk = new byte[chunkSize];
 
         while (written < fileSize) {
-            try (GridGgfsOutputStream out = ggfs.append(path, true)) {
+            try (IgniteFsOutputStream out = ggfs.append(path, true)) {
                 for (int i = 0; i < 8; i++) {
                     Arrays.fill(chunk, (byte)cnt);
 
@@ -220,7 +220,7 @@ public class GridGgfsFragmentizerSelfTest extends GridGgfsFragmentizerAbstractSe
         for (int i = 0; i < 30; i++) {
             IgniteFsPath path = new IgniteFsPath("/someFile" + i);
 
-            try (GridGgfsOutputStream out = ggfs.create(path, true)) {
+            try (IgniteFsOutputStream out = ggfs.create(path, true)) {
                 for (int j = 0; j < 5 * GGFS_GROUP_SIZE; j++)
                     out.write(new byte[GGFS_BLOCK_SIZE]);
             }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerTopologySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerTopologySelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerTopologySelfTest.java
index f8b2b01..4d99ac8 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerTopologySelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerTopologySelfTest.java
@@ -27,7 +27,7 @@ public class GridGgfsFragmentizerTopologySelfTest extends GridGgfsFragmentizerAb
 
             IgniteFs ggfs = grid(1).fileSystem("ggfs");
 
-            try (GridGgfsOutputStream out = ggfs.create(path, true)) {
+            try (IgniteFsOutputStream out = ggfs.create(path, true)) {
                 for (int i = 0; i < 10 * GGFS_GROUP_SIZE; i++)
                     out.write(new byte[GGFS_BLOCK_SIZE]);
             }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
index 01d6586..f0f4965 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
@@ -28,7 +28,7 @@ import java.util.concurrent.*;
 
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * Tests for GGFS per-block LR eviction policy.
@@ -85,7 +85,7 @@ public class GridCacheGgfsPerBlockLruEvictionPolicySelfTest extends GridGgfsComm
         ggfsCfg.setSequentialReadsBeforePrefetch(Integer.MAX_VALUE);
         ggfsCfg.setSecondaryFileSystem(secondaryFs);
 
-        Map<String, GridGgfsMode> pathModes = new HashMap<>();
+        Map<String, IgniteFsMode> pathModes = new HashMap<>();
 
         pathModes.put(FILE_RMT.toString(), DUAL_SYNC);
 
@@ -437,7 +437,7 @@ public class GridCacheGgfsPerBlockLruEvictionPolicySelfTest extends GridGgfsComm
      * @throws Exception If failed.
      */
     private void append(IgniteFsPath path, int len) throws Exception {
-        GridGgfsOutputStream os = ggfsPrimary.append(path, false);
+        IgniteFsOutputStream os = ggfsPrimary.append(path, false);
 
         os.write(new byte[len]);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
index f722fdd..e64b9b3 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
@@ -34,7 +34,7 @@ import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMemoryMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
 import static org.apache.ignite.IgniteFs.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * Test fo regular GGFs operations.
@@ -104,7 +104,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
     protected static GridGgfsImpl ggfsSecondary;
 
     /** GGFS mode. */
-    protected final GridGgfsMode mode;
+    protected final IgniteFsMode mode;
 
     /** Dual mode flag. */
     protected final boolean dual;
@@ -117,11 +117,11 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      *
      * @param mode GGFS mode.
      */
-    protected GridGgfsAbstractSelfTest(GridGgfsMode mode) {
+    protected GridGgfsAbstractSelfTest(IgniteFsMode mode) {
         this(mode, ONHEAP_TIERED);
     }
 
-    protected GridGgfsAbstractSelfTest(GridGgfsMode mode, GridCacheMemoryMode memoryMode) {
+    protected GridGgfsAbstractSelfTest(IgniteFsMode mode, GridCacheMemoryMode memoryMode) {
         assert mode != null && mode != PROXY;
 
         this.mode = mode;
@@ -167,7 +167,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @return Started grid instance.
      * @throws Exception If failed.
      */
-    protected Ignite startGridWithGgfs(String gridName, String ggfsName, GridGgfsMode mode,
+    protected Ignite startGridWithGgfs(String gridName, String ggfsName, IgniteFsMode mode,
         @Nullable IgniteFsFileSystem secondaryFs, @Nullable String restCfg) throws Exception {
         IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
@@ -766,7 +766,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
         create(ggfs, paths(DIR, SUBDIR), paths(FILE));
 
-        try (GridGgfsOutputStream os = ggfs.append(FILE, false)) {
+        try (IgniteFsOutputStream os = ggfs.append(FILE, false)) {
             os.write(new byte[10 * 1024 * 1024]);
         }
 
@@ -903,8 +903,8 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
         GridTestUtils.assertThrows(log(), new Callable<Object>() {
             @Override public Object call() throws Exception {
-                GridGgfsOutputStream os1 = null;
-                GridGgfsOutputStream os2 = null;
+                IgniteFsOutputStream os1 = null;
+                IgniteFsOutputStream os2 = null;
 
                 try {
                     os1 = ggfs.create(FILE, true);
@@ -928,7 +928,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
     public void testCreateRenameNoClose() throws Exception {
         create(ggfs, paths(DIR, SUBDIR), null);
 
-        GridGgfsOutputStream os = null;
+        IgniteFsOutputStream os = null;
 
         try {
             os = ggfs.create(FILE, true);
@@ -950,7 +950,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
     public void testCreateRenameParentNoClose() throws Exception {
         create(ggfs, paths(DIR, SUBDIR), null);
 
-        GridGgfsOutputStream os = null;
+        IgniteFsOutputStream os = null;
 
         try {
             os = ggfs.create(FILE, true);
@@ -974,7 +974,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
         GridTestUtils.assertThrows(log, new Callable<Object>() {
             @Override public Object call() throws Exception {
-                GridGgfsOutputStream os = null;
+                IgniteFsOutputStream os = null;
 
                 try {
                     os = ggfs.create(FILE, true);
@@ -1004,7 +1004,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
         GridTestUtils.assertThrows(log, new Callable<Object>() {
             @Override public Object call() throws Exception {
-                GridGgfsOutputStream os = null;
+                IgniteFsOutputStream os = null;
 
                 try {
                     os = ggfs.create(FILE, true);
@@ -1037,7 +1037,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
         create(ggfs, paths(DIR, SUBDIR), null);
 
-        GridGgfsOutputStream os = null;
+        IgniteFsOutputStream os = null;
 
         try {
             os = ggfs.create(FILE, true);
@@ -1070,7 +1070,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
                 try {
                     for (int i = 0; i < REPEAT_CNT; i++) {
-                        GridGgfsOutputStream os = ggfs.create(path, 128, true, null, 0, 256, null);
+                        IgniteFsOutputStream os = ggfs.create(path, 128, true, null, 0, 256, null);
 
                         os.write(chunk);
 
@@ -1111,7 +1111,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
         IgniteFuture<?> fut = multithreadedAsync(new Runnable() {
             @Override public void run() {
                 while (!stop.get()) {
-                    GridGgfsOutputStream os = null;
+                    IgniteFsOutputStream os = null;
 
                     try {
                         os = ggfs.create(FILE, true);
@@ -1203,8 +1203,8 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
         GridTestUtils.assertThrowsInherited(log(), new Callable<Object>() {
             @Override public Object call() throws Exception {
-                GridGgfsOutputStream os1 = null;
-                GridGgfsOutputStream os2 = null;
+                IgniteFsOutputStream os1 = null;
+                IgniteFsOutputStream os2 = null;
 
                 try {
                     os1 = ggfs.append(FILE, false);
@@ -1230,7 +1230,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
         createFile(ggfs, FILE, false);
 
-        GridGgfsOutputStream os = null;
+        IgniteFsOutputStream os = null;
 
         try {
             os = ggfs.append(FILE, false);
@@ -1254,7 +1254,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
         createFile(ggfs, FILE, false);
 
-        GridGgfsOutputStream os = null;
+        IgniteFsOutputStream os = null;
 
         try {
             os = ggfs.append(FILE, false);
@@ -1280,7 +1280,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
         GridTestUtils.assertThrows(log, new Callable<Object>() {
             @Override public Object call() throws Exception {
-                GridGgfsOutputStream os = null;
+                IgniteFsOutputStream os = null;
 
                 try {
                     os = ggfs.append(FILE, false);
@@ -1312,7 +1312,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
         GridTestUtils.assertThrows(log, new Callable<Object>() {
             @Override public Object call() throws Exception {
-                GridGgfsOutputStream os = null;
+                IgniteFsOutputStream os = null;
 
                 try {
                     IgniteUuid id = ggfs.context().meta().fileId(FILE);
@@ -1349,7 +1349,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
         createFile(ggfs, FILE, false);
 
-        GridGgfsOutputStream os = null;
+        IgniteFsOutputStream os = null;
 
         try {
             os = ggfs.append(FILE, false);
@@ -1389,7 +1389,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
                     for (int i = 0; i < REPEAT_CNT; i++) {
                         chunks[i] = chunk;
 
-                        GridGgfsOutputStream os = ggfs.append(path, false);
+                        IgniteFsOutputStream os = ggfs.append(path, false);
 
                         os.write(chunk);
 
@@ -1430,7 +1430,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
         IgniteFuture<?> fut = multithreadedAsync(new Runnable() {
             @Override public void run() {
                 while (!stop.get()) {
-                    GridGgfsOutputStream os = null;
+                    IgniteFsOutputStream os = null;
 
                     try {
                         os = ggfs.append(FILE, false);
@@ -1490,7 +1490,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
     public void testStop() throws Exception {
         create(ggfs, paths(DIR, SUBDIR), null);
 
-        GridGgfsOutputStream os = ggfs.create(FILE, true);
+        IgniteFsOutputStream os = ggfs.create(FILE, true);
 
         os.write(chunk);
 
@@ -2077,7 +2077,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
                         U.awaitQuiet(barrier);
 
-                        GridGgfsOutputStream os = null;
+                        IgniteFsOutputStream os = null;
 
                         try {
                             os = ggfs.create(path, true);
@@ -2178,7 +2178,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      */
     protected void createFile(IgniteFs ggfs, IgniteFsPath file, boolean overwrite, long blockSize,
         @Nullable byte[]... chunks) throws Exception {
-        GridGgfsOutputStream os = null;
+        IgniteFsOutputStream os = null;
 
         try {
             os = ggfs.create(file, 256, overwrite, null, 0, blockSize, null);
@@ -2202,7 +2202,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      */
     protected void appendFile(IgniteFs ggfs, IgniteFsPath file, @Nullable byte[]... chunks)
         throws Exception {
-        GridGgfsOutputStream os = null;
+        IgniteFsOutputStream os = null;
 
         try {
             os = ggfs.append(file, false);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributesSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributesSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributesSelfTest.java
index 140331c..35cabd4 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributesSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAttributesSelfTest.java
@@ -15,7 +15,7 @@ import java.io.*;
 import java.lang.reflect.*;
 import java.util.*;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * {@link GridGgfsAttributes} test case.
@@ -25,7 +25,7 @@ public class GridGgfsAttributesSelfTest extends GridGgfsCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testSerialization() throws Exception {
-        Map<String, GridGgfsMode> pathModes = new HashMap<>();
+        Map<String, IgniteFsMode> pathModes = new HashMap<>();
 
         pathModes.put("path1", PRIMARY);
         pathModes.put("path2", PROXY);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
index 9df3b88..99feec6 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
@@ -21,7 +21,7 @@ import java.util.*;
 import java.util.concurrent.*;
 
 import static org.apache.ignite.IgniteFs.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * Tests for GGFS working in mode when remote file system exists: DUAL_SYNC, DUAL_ASYNC.
@@ -32,7 +32,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      *
      * @param mode GGFS mode.
      */
-    protected GridGgfsDualAbstractSelfTest(GridGgfsMode mode) {
+    protected GridGgfsDualAbstractSelfTest(IgniteFsMode mode) {
         super(mode);
 
         assert mode == DUAL_SYNC || mode == DUAL_ASYNC;
@@ -1128,7 +1128,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         // Write enough data to the secondary file system.
         final int blockSize = GGFS_BLOCK_SIZE;
 
-        GridGgfsOutputStream out = ggfsSecondary.append(FILE, false);
+        IgniteFsOutputStream out = ggfsSecondary.append(FILE, false);
 
         int totalWritten = 0;
 
@@ -1207,7 +1207,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         // Write enough data to the secondary file system.
         final int blockSize = ggfs.info(FILE).blockSize();
 
-        GridGgfsOutputStream out = ggfsSecondary.append(FILE, false);
+        IgniteFsOutputStream out = ggfsSecondary.append(FILE, false);
 
         int totalWritten = 0;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAsyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAsyncSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAsyncSelfTest.java
index 2aa2f30..01bc9f2 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAsyncSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAsyncSelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * Tests for DUAL_ASYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualSyncSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualSyncSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualSyncSelfTest.java
index 83d5a14..c9d5e64 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualSyncSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualSyncSelfTest.java
@@ -9,7 +9,7 @@
 
 package org.gridgain.grid.kernal.processors.ggfs;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * Tests for DUAL_SYNC mode.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
index efd5418..42d4cb8 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
@@ -24,7 +24,7 @@ import java.util.*;
 
 import static org.gridgain.grid.cache.GridCacheAtomicityMode.*;
 import static org.gridgain.grid.cache.GridCacheMode.*;
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  * Test for GGFS metrics.
@@ -100,7 +100,7 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
         ggfsCfg.setDefaultMode(PRIMARY);
         ggfsCfg.setSecondaryFileSystem(ggfsSecondary);
 
-        Map<String, GridGgfsMode> pathModes = new HashMap<>();
+        Map<String, IgniteFsMode> pathModes = new HashMap<>();
 
         pathModes.put("/fileRemote", DUAL_SYNC);
 
@@ -232,9 +232,9 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
         assertEquals(0, m.filesOpenedForRead());
         assertEquals(0, m.filesOpenedForWrite());
 
-        GridGgfsOutputStream out1 = fs.create(new IgniteFsPath("/dir1/file1"), false);
-        GridGgfsOutputStream out2 = fs.create(new IgniteFsPath("/dir1/file2"), false);
-        GridGgfsOutputStream out3 = fs.create(new IgniteFsPath("/dir1/dir2/file"), false);
+        IgniteFsOutputStream out1 = fs.create(new IgniteFsPath("/dir1/file1"), false);
+        IgniteFsOutputStream out2 = fs.create(new IgniteFsPath("/dir1/file2"), false);
+        IgniteFsOutputStream out3 = fs.create(new IgniteFsPath("/dir1/dir2/file"), false);
 
         m = fs.metrics();
 
@@ -269,7 +269,7 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
         assertEquals(0, m.filesOpenedForRead());
         assertEquals(0, m.filesOpenedForWrite());
 
-        GridGgfsOutputStream out = fs.append(new IgniteFsPath("/dir1/file1"), false);
+        IgniteFsOutputStream out = fs.append(new IgniteFsPath("/dir1/file1"), false);
 
         out.write(new byte[20]);
 
@@ -341,7 +341,7 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
     public void testMultipleClose() throws Exception {
         IgniteFs fs = ggfsPrimary[0];
 
-        GridGgfsOutputStream out = fs.create(new IgniteFsPath("/file"), false);
+        IgniteFsOutputStream out = fs.create(new IgniteFsPath("/file"), false);
 
         out.close();
         out.close();
@@ -370,7 +370,7 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
         IgniteFsPath file2 = new IgniteFsPath("/file2");
 
         // Create remote file and write some data to it.
-        GridGgfsOutputStream out = ggfsSecondary.create(fileRemote, 256, true, null, 1, 256, null);
+        IgniteFsOutputStream out = ggfsSecondary.create(fileRemote, 256, true, null, 1, 256, null);
 
         int rmtBlockSize = ggfsSecondary.info(fileRemote).blockSize();
 
@@ -388,7 +388,7 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
         checkBlockMetrics(initMetrics, ggfs.metrics(), 0, 0, 0, 0, 0, 0);
 
         // Write two blocks to the file.
-        GridGgfsOutputStream os = ggfs.append(file1, false);
+        IgniteFsOutputStream os = ggfs.append(file1, false);
         os.write(new byte[blockSize * 2]);
         os.close();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5e4cd4d8/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolverSelfTest.java
index 3c397de..1bc63d3 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolverSelfTest.java
@@ -15,7 +15,7 @@ import org.gridgain.grid.util.typedef.*;
 
 import java.util.*;
 
-import static org.gridgain.grid.ggfs.GridGgfsMode.*;
+import static org.gridgain.grid.ggfs.IgniteFsMode.*;
 
 /**
  *
@@ -49,21 +49,21 @@ public class GridGgfsModeResolverSelfTest extends TestCase {
      * @throws Exception If failed.
      */
     public void testResolveChildren() throws Exception {
-        assertEquals(new HashSet<GridGgfsMode>(){{add(DUAL_SYNC); add(PRIMARY); add(PROXY);}},
+        assertEquals(new HashSet<IgniteFsMode>(){{add(DUAL_SYNC); add(PRIMARY); add(PROXY);}},
             resolver.resolveChildrenModes(new IgniteFsPath("/")));
-        assertEquals(new HashSet<GridGgfsMode>(){{add(DUAL_SYNC); add(PRIMARY); add(PROXY);}},
+        assertEquals(new HashSet<IgniteFsMode>(){{add(DUAL_SYNC); add(PRIMARY); add(PROXY);}},
             resolver.resolveChildrenModes(new IgniteFsPath("/a")));
-        assertEquals(new HashSet<GridGgfsMode>(){{add(DUAL_SYNC);}},
+        assertEquals(new HashSet<IgniteFsMode>(){{add(DUAL_SYNC);}},
             resolver.resolveChildrenModes(new IgniteFsPath("/a/1")));
-        assertEquals(new HashSet<GridGgfsMode>(){{add(PRIMARY); add(PROXY);}},
+        assertEquals(new HashSet<IgniteFsMode>(){{add(PRIMARY); add(PROXY);}},
             resolver.resolveChildrenModes(new IgniteFsPath("/a/b")));
-        assertEquals(new HashSet<GridGgfsMode>(){{add(PRIMARY); add(PROXY);}},
+        assertEquals(new HashSet<IgniteFsMode>(){{add(PRIMARY); add(PROXY);}},
             resolver.resolveChildrenModes(new IgniteFsPath("/a/b/c")));
-        assertEquals(new HashSet<GridGgfsMode>(){{add(PRIMARY);}},
+        assertEquals(new HashSet<IgniteFsMode>(){{add(PRIMARY);}},
             resolver.resolveChildrenModes(new IgniteFsPath("/a/b/c/2")));
-        assertEquals(new HashSet<GridGgfsMode>(){{add(PROXY);}},
+        assertEquals(new HashSet<IgniteFsMode>(){{add(PROXY);}},
             resolver.resolveChildrenModes(new IgniteFsPath("/a/b/c/d")));
-        assertEquals(new HashSet<GridGgfsMode>(){{add(PROXY);}},
+        assertEquals(new HashSet<IgniteFsMode>(){{add(PROXY);}},
             resolver.resolveChildrenModes(new IgniteFsPath("/a/b/c/d/e")));
     }
 }


[11/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPaths.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPaths.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPaths.java
index e922089..12b401c 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPaths.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsPaths.java
@@ -31,7 +31,7 @@ public class GridGgfsPaths implements Externalizable {
     private GridGgfsMode dfltMode;
 
     /** Path modes. */
-    private List<T2<GridGgfsPath, GridGgfsMode>> pathModes;
+    private List<T2<IgniteFsPath, GridGgfsMode>> pathModes;
 
     /**
      * Empty constructor required by {@link Externalizable}.
@@ -47,7 +47,7 @@ public class GridGgfsPaths implements Externalizable {
      * @param dfltMode Default GGFS mode.
      * @param pathModes Path modes.
      */
-    public GridGgfsPaths(Map<String, String> props, GridGgfsMode dfltMode, @Nullable List<T2<GridGgfsPath,
+    public GridGgfsPaths(Map<String, String> props, GridGgfsMode dfltMode, @Nullable List<T2<IgniteFsPath,
         GridGgfsMode>> pathModes) {
         this.props = props;
         this.dfltMode = dfltMode;
@@ -71,7 +71,7 @@ public class GridGgfsPaths implements Externalizable {
     /**
      * @return Path modes.
      */
-    @Nullable public List<T2<GridGgfsPath, GridGgfsMode>> pathModes() {
+    @Nullable public List<T2<IgniteFsPath, GridGgfsMode>> pathModes() {
         return pathModes;
     }
 
@@ -84,7 +84,7 @@ public class GridGgfsPaths implements Externalizable {
             out.writeBoolean(true);
             out.writeInt(pathModes.size());
 
-            for (T2<GridGgfsPath, GridGgfsMode> pathMode : pathModes) {
+            for (T2<IgniteFsPath, GridGgfsMode> pathMode : pathModes) {
                 pathMode.getKey().writeExternal(out);
                 U.writeEnum0(out, pathMode.getValue());
             }
@@ -104,10 +104,10 @@ public class GridGgfsPaths implements Externalizable {
             pathModes = new ArrayList<>(size);
 
             for (int i = 0; i < size; i++) {
-                GridGgfsPath path = new GridGgfsPath();
+                IgniteFsPath path = new IgniteFsPath();
                 path.readExternal(in);
 
-                T2<GridGgfsPath, GridGgfsMode> entry = new T2<>(path, GridGgfsMode.fromOrdinal(U.readEnumOrdinal0(in)));
+                T2<IgniteFsPath, GridGgfsMode> entry = new T2<>(path, GridGgfsMode.fromOrdinal(U.readEnumOrdinal0(in)));
 
                 pathModes.add(entry);
             }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
index 8bb4edc..f1cfeba 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
@@ -222,7 +222,7 @@ public class GridGgfsProcessor extends GridGgfsProcessorAdapter {
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public ComputeJob createJob(GridGgfsJob job, @Nullable String ggfsName, GridGgfsPath path,
+    @Nullable @Override public ComputeJob createJob(GridGgfsJob job, @Nullable String ggfsName, IgniteFsPath path,
         long start, long length, GridGgfsRecordResolver recRslv) {
         return new GridGgfsJobImpl(job, ggfsName, path, start, length, recRslv);
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
index c0509b0..f2dd046 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorAdapter.java
@@ -67,6 +67,6 @@ public abstract class GridGgfsProcessorAdapter extends GridProcessorAdapter {
      * @param recRslv Record resolver.
      * @return Compute job.
      */
-    @Nullable public abstract ComputeJob createJob(GridGgfsJob job, @Nullable String ggfsName, GridGgfsPath path,
+    @Nullable public abstract ComputeJob createJob(GridGgfsJob job, @Nullable String ggfsName, IgniteFsPath path,
         long start, long length, GridGgfsRecordResolver recRslv);
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSecondaryInputStreamDescriptor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSecondaryInputStreamDescriptor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSecondaryInputStreamDescriptor.java
index d7d33cd..3a17d38 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSecondaryInputStreamDescriptor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSecondaryInputStreamDescriptor.java
@@ -19,7 +19,7 @@ public class GridGgfsSecondaryInputStreamDescriptor {
     private final GridGgfsFileInfo info;
 
     /** Secondary file system input stream wrapper. */
-    private final GridGgfsReader secReader;
+    private final IgniteFsReader secReader;
 
     /**
      * Constructor.
@@ -27,7 +27,7 @@ public class GridGgfsSecondaryInputStreamDescriptor {
      * @param info File info in the primary file system.
      * @param secReader Secondary file system reader.
      */
-    GridGgfsSecondaryInputStreamDescriptor(GridGgfsFileInfo info, GridGgfsReader secReader) {
+    GridGgfsSecondaryInputStreamDescriptor(GridGgfsFileInfo info, IgniteFsReader secReader) {
         assert info != null;
         assert secReader != null;
 
@@ -45,7 +45,7 @@ public class GridGgfsSecondaryInputStreamDescriptor {
     /**
      * @return Secondary file system reader.
      */
-    GridGgfsReader reader() {
+    IgniteFsReader reader() {
         return secReader;
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskArgsImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskArgsImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskArgsImpl.java
index cc5be2e..516e5a4 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskArgsImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskArgsImpl.java
@@ -27,7 +27,7 @@ public class GridGgfsTaskArgsImpl<T> implements GridGgfsTaskArgs<T>,  Externaliz
     private String ggfsName;
 
     /** Paths. */
-    private Collection<GridGgfsPath> paths;
+    private Collection<IgniteFsPath> paths;
 
     /** Record resolver. */
     private GridGgfsRecordResolver recRslvr;
@@ -58,7 +58,7 @@ public class GridGgfsTaskArgsImpl<T> implements GridGgfsTaskArgs<T>,  Externaliz
      * @param maxRangeLen Maximum range length.
      * @param usrArg User argument.
      */
-    public GridGgfsTaskArgsImpl(String ggfsName, Collection<GridGgfsPath> paths, GridGgfsRecordResolver recRslvr,
+    public GridGgfsTaskArgsImpl(String ggfsName, Collection<IgniteFsPath> paths, GridGgfsRecordResolver recRslvr,
         boolean skipNonExistentFiles, long maxRangeLen, T usrArg) {
         this.ggfsName = ggfsName;
         this.paths = paths;
@@ -74,7 +74,7 @@ public class GridGgfsTaskArgsImpl<T> implements GridGgfsTaskArgs<T>,  Externaliz
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsPath> paths() {
+    @Override public Collection<IgniteFsPath> paths() {
         return paths;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
index 3836723..0c3887b 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridNoopGgfsProcessor.java
@@ -56,7 +56,7 @@ public class GridNoopGgfsProcessor extends GridGgfsProcessorAdapter {
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public ComputeJob createJob(GridGgfsJob job, @Nullable String ggfsName, GridGgfsPath path,
+    @Nullable @Override public ComputeJob createJob(GridGgfsJob job, @Nullable String ggfsName, IgniteFsPath path,
         long start, long length, GridGgfsRecordResolver recRslv) {
         return null;
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
index 00d1e80..b6b6cb6 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
@@ -196,15 +196,15 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
             }
         }, EVTS_GGFS);
 
-        GridGgfsPath dir = new GridGgfsPath("/dir1/dir2/dir3");
+        IgniteFsPath dir = new IgniteFsPath("/dir1/dir2/dir3");
 
-        GridGgfsPath file = new GridGgfsPath(dir, "file1");
+        IgniteFsPath file = new IgniteFsPath(dir, "file1");
 
         // Will generate 3 EVT_GGFS_DIR_CREATED + EVT_GGFS_FILE_CREATED + EVT_GGFS_FILE_OPENED_WRITE +
         // EVT_GGFS_FILE_CLOSED and a number of EVT_GGFS_META_UPDATED.
         ggfs.create(file, true).close();
 
-        GridGgfsPath mvFile = new GridGgfsPath(dir, "mvFile1");
+        IgniteFsPath mvFile = new IgniteFsPath(dir, "mvFile1");
 
         ggfs.rename(file, mvFile); // Will generate EVT_GGFS_FILE_RENAMED.
 
@@ -217,39 +217,39 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
 
         IgniteFsEvent evt = (IgniteFsEvent)evtList.get(0);
         assertEquals(EVT_GGFS_DIR_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1"), evt.path());
         assertTrue(evt.isDirectory());
 
         evt = (IgniteFsEvent)evtList.get(1);
         assertEquals(EVT_GGFS_DIR_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/dir2"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/dir2"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(2);
         assertEquals(EVT_GGFS_DIR_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/dir2/dir3"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/dir2/dir3"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(3);
         assertEquals(EVT_GGFS_FILE_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/dir2/dir3/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/dir2/dir3/file1"), evt.path());
         assertFalse(evt.isDirectory());
 
         evt = (IgniteFsEvent)evtList.get(4);
         assertEquals(EVT_GGFS_FILE_OPENED_WRITE, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/dir2/dir3/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/dir2/dir3/file1"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(5);
         assertEquals(EVT_GGFS_FILE_CLOSED_WRITE, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/dir2/dir3/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/dir2/dir3/file1"), evt.path());
         assertEquals(0, evt.dataSize());
 
         evt = (IgniteFsEvent)evtList.get(6);
         assertEquals(EVT_GGFS_FILE_RENAMED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/dir2/dir3/file1"), evt.path());
-        assertEquals(new GridGgfsPath("/dir1/dir2/dir3/mvFile1"), evt.newPath());
+        assertEquals(new IgniteFsPath("/dir1/dir2/dir3/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/dir2/dir3/mvFile1"), evt.newPath());
 
         evt = (IgniteFsEvent)evtList.get(7);
         assertEquals(EVT_GGFS_DIR_DELETED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/dir2"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/dir2"), evt.path());
     }
 
     /**
@@ -277,10 +277,10 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
             }
         }, EVTS_GGFS);
 
-        GridGgfsPath dir = new GridGgfsPath("/dir1");
+        IgniteFsPath dir = new IgniteFsPath("/dir1");
 
-        GridGgfsPath file1 = new GridGgfsPath(dir, "file1");
-        GridGgfsPath file2 = new GridGgfsPath(dir, "file2");
+        IgniteFsPath file1 = new IgniteFsPath(dir, "file1");
+        IgniteFsPath file2 = new IgniteFsPath(dir, "file2");
 
         // Will generate EVT_GGFS_DIR_CREATED + EVT_GGFS_FILE_CREATED + EVT_GGFS_FILE_OPENED_WRITE +
         // EVT_GGFS_FILE_CLOSED_WRITE.
@@ -299,38 +299,38 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
 
         IgniteFsEvent evt = (IgniteFsEvent)evtList.get(0);
         assertEquals(EVT_GGFS_DIR_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1"), evt.path());
         assertTrue(evt.isDirectory());
 
         evt = (IgniteFsEvent)evtList.get(1);
         assertEquals(EVT_GGFS_FILE_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/file1"), evt.path());
         assertFalse(evt.isDirectory());
 
         evt = (IgniteFsEvent)evtList.get(2);
         assertEquals(EVT_GGFS_FILE_OPENED_WRITE, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/file1"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(3);
         assertEquals(EVT_GGFS_FILE_CLOSED_WRITE, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/file1"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(4);
         assertEquals(EVT_GGFS_FILE_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/file2"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/file2"), evt.path());
         assertFalse(evt.isDirectory());
 
         evt = (IgniteFsEvent)evtList.get(5);
         assertEquals(EVT_GGFS_FILE_OPENED_WRITE, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/file2"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/file2"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(6);
         assertEquals(EVT_GGFS_FILE_CLOSED_WRITE, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/file2"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/file2"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(7);
         assertEquals(EVT_GGFS_DIR_DELETED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1"), evt.path());
     }
 
     /**
@@ -358,11 +358,11 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
             }
         }, EVTS_GGFS);
 
-        GridGgfsPath dir = new GridGgfsPath("/dir1");
+        IgniteFsPath dir = new IgniteFsPath("/dir1");
 
         ggfs.mkdirs(dir); // Will generate EVT_GGFS_DIR_CREATED.
 
-        GridGgfsPath mvDir = new GridGgfsPath("/mvDir1");
+        IgniteFsPath mvDir = new IgniteFsPath("/mvDir1");
 
         ggfs.rename(dir, mvDir); // Will generate EVT_GGFS_DIR_RENAMED.
 
@@ -376,18 +376,18 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
 
         IgniteFsEvent evt = (IgniteFsEvent)evtList.get(0);
         assertEquals(EVT_GGFS_DIR_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1"), evt.path());
         assertTrue(evt.isDirectory());
 
         evt = (IgniteFsEvent)evtList.get(1);
         assertEquals(EVT_GGFS_DIR_RENAMED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1"), evt.path());
-        assertEquals(new GridGgfsPath("/mvDir1"), evt.newPath());
+        assertEquals(new IgniteFsPath("/dir1"), evt.path());
+        assertEquals(new IgniteFsPath("/mvDir1"), evt.newPath());
         assertTrue(evt.isDirectory());
 
         evt = (IgniteFsEvent)evtList.get(2);
         assertEquals(EVT_GGFS_DIR_DELETED, evt.type());
-        assertEquals(new GridGgfsPath("/mvDir1"), evt.path());
+        assertEquals(new IgniteFsPath("/mvDir1"), evt.path());
         assertTrue(evt.isDirectory());
     }
 
@@ -415,14 +415,14 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
             }
         }, EVTS_GGFS);
 
-        GridGgfsPath dir = new GridGgfsPath("/dir1");
+        IgniteFsPath dir = new IgniteFsPath("/dir1");
 
-        GridGgfsPath file1 = new GridGgfsPath(dir, "file1");
+        IgniteFsPath file1 = new IgniteFsPath(dir, "file1");
 
         // Will generate EVT_GGFS_FILE_CREATED event + EVT_GGFS_DIR_CREATED event + OPEN + CLOSE.
         ggfs.create(file1, true).close();
 
-        GridGgfsPath file2 = new GridGgfsPath(dir, "file2");
+        IgniteFsPath file2 = new IgniteFsPath(dir, "file2");
 
         ggfs.create(file2, true).close(); // Will generate 1 EVT_GGFS_FILE_CREATED event + OPEN + CLOSE.
 
@@ -439,41 +439,41 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
 
         IgniteFsEvent evt = (IgniteFsEvent)evtList.get(0);
         assertEquals(EVT_GGFS_DIR_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1"), evt.path());
         assertTrue(evt.isDirectory());
 
         evt = (IgniteFsEvent)evtList.get(1);
         assertEquals(EVT_GGFS_FILE_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/file1"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(2);
         assertEquals(EVT_GGFS_FILE_OPENED_WRITE, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/file1"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(3);
         assertEquals(EVT_GGFS_FILE_CLOSED_WRITE, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/file1"), evt.path());
         assertEquals(0, evt.dataSize());
 
         evt = (IgniteFsEvent)evtList.get(4);
         assertEquals(EVT_GGFS_FILE_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/file2"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/file2"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(5);
         assertEquals(EVT_GGFS_FILE_OPENED_WRITE, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/file2"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/file2"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(6);
         assertEquals(EVT_GGFS_FILE_CLOSED_WRITE, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/file2"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/file2"), evt.path());
         assertEquals(0, evt.dataSize());
 
         assertOneToOne(
             evtList.subList(7, 11),
-            new EventPredicate(EVT_GGFS_FILE_DELETED, new GridGgfsPath("/dir1/file1")),
-            new EventPredicate(EVT_GGFS_FILE_PURGED, new GridGgfsPath("/dir1/file1")),
-            new EventPredicate(EVT_GGFS_FILE_DELETED, new GridGgfsPath("/dir1/file2")),
-            new EventPredicate(EVT_GGFS_FILE_PURGED, new GridGgfsPath("/dir1/file2"))
+            new EventPredicate(EVT_GGFS_FILE_DELETED, new IgniteFsPath("/dir1/file1")),
+            new EventPredicate(EVT_GGFS_FILE_PURGED, new IgniteFsPath("/dir1/file1")),
+            new EventPredicate(EVT_GGFS_FILE_DELETED, new IgniteFsPath("/dir1/file2")),
+            new EventPredicate(EVT_GGFS_FILE_PURGED, new IgniteFsPath("/dir1/file2"))
         );
     }
 
@@ -502,7 +502,7 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
             }
         }, EVTS_GGFS);
 
-        GridGgfsPath dir = new GridGgfsPath("/dir1/dir2");
+        IgniteFsPath dir = new IgniteFsPath("/dir1/dir2");
 
         ggfs.mkdirs(dir); // Will generate 2 EVT_GGFS_DIR_CREATED events.
 
@@ -521,15 +521,15 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
 
         IgniteFsEvent evt = (IgniteFsEvent)evtList.get(0);
         assertEquals(EVT_GGFS_DIR_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(1);
         assertEquals(EVT_GGFS_DIR_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/dir2"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/dir2"), evt.path());
 
         IgniteFsEvent evt3 = (IgniteFsEvent)evtList.get(2);
         assertEquals(EVT_GGFS_DIR_DELETED, evt3.type());
-        assertEquals(new GridGgfsPath("/dir1/dir2"), evt3.path());
+        assertEquals(new IgniteFsPath("/dir1/dir2"), evt3.path());
     }
 
     /**
@@ -556,16 +556,16 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
             }
         }, EVTS_GGFS);
 
-        GridGgfsPath dir = new GridGgfsPath("/dir1/dir2");
+        IgniteFsPath dir = new IgniteFsPath("/dir1/dir2");
 
-        GridGgfsPath file = new GridGgfsPath(dir, "file1");
+        IgniteFsPath file = new IgniteFsPath(dir, "file1");
 
         // Will generate 2 EVT_GGFS_DIR_CREATED events + EVT_GGFS_FILE_CREATED_EVENT + OPEN + CLOSE.
         ggfs.create(file, true).close();
 
         ggfs.rename(file, dir.parent()); // Will generate 1 EVT_GGFS_FILE_RENAMED.
 
-        assertTrue(ggfs.exists(new GridGgfsPath(dir.parent(), file.name())));
+        assertTrue(ggfs.exists(new IgniteFsPath(dir.parent(), file.name())));
 
         assertTrue(latch.await(10, TimeUnit.SECONDS));
 
@@ -573,29 +573,29 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
 
         IgniteFsEvent evt = (IgniteFsEvent)evtList.get(0);
         assertEquals(EVT_GGFS_DIR_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(1);
         assertEquals(EVT_GGFS_DIR_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/dir2"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/dir2"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(2);
         assertEquals(EVT_GGFS_FILE_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/dir2/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/dir2/file1"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(3);
         assertEquals(EVT_GGFS_FILE_OPENED_WRITE, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/dir2/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/dir2/file1"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(4);
         assertEquals(EVT_GGFS_FILE_CLOSED_WRITE, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/dir2/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/dir2/file1"), evt.path());
         assertEquals(0, evt.dataSize());
 
         IgniteFsEvent evt4 = (IgniteFsEvent)evtList.get(5);
         assertEquals(EVT_GGFS_FILE_RENAMED, evt4.type());
-        assertEquals(new GridGgfsPath("/dir1/dir2/file1"), evt4.path());
-        assertEquals(new GridGgfsPath("/dir1/file1"), evt4.newPath());
+        assertEquals(new IgniteFsPath("/dir1/dir2/file1"), evt4.path());
+        assertEquals(new IgniteFsPath("/dir1/file1"), evt4.newPath());
     }
 
     /**
@@ -623,7 +623,7 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
             }
         }, EVTS_GGFS);
 
-        GridGgfsPath dir = new GridGgfsPath("/dir1/dir2");
+        IgniteFsPath dir = new IgniteFsPath("/dir1/dir2");
 
         assertFalse(ggfs.exists(dir.parent()));
 
@@ -637,15 +637,15 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
 
         IgniteFsEvent evt = (IgniteFsEvent)evtList.get(0);
         assertEquals(EVT_GGFS_DIR_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(1);
         assertEquals(EVT_GGFS_DIR_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1/dir2"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1/dir2"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(2);
         assertEquals(EVT_GGFS_DIR_DELETED, evt.type());
-        assertEquals(new GridGgfsPath("/dir1"), evt.path());
+        assertEquals(new IgniteFsPath("/dir1"), evt.path());
     }
 
     /**
@@ -673,7 +673,7 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
             }
         }, EVTS_GGFS);
 
-        final GridGgfsPath file = new GridGgfsPath("/file1");
+        final IgniteFsPath file = new IgniteFsPath("/file1");
 
         ggfs.create(file, false).close(); // Will generate create, open and close events.
 
@@ -690,7 +690,7 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
 
         assertEquals(evtsCnt, evtList.size());
 
-        final GridGgfsPath file1 = new GridGgfsPath("/file1");
+        final IgniteFsPath file1 = new IgniteFsPath("/file1");
 
         IgniteFsEvent evt = (IgniteFsEvent)evtList.get(0);
         assertEquals(EVT_GGFS_FILE_CREATED, evt.type());
@@ -769,7 +769,7 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
             }
         }, EVTS_GGFS);
 
-        final GridGgfsPath file = new GridGgfsPath("/file1");
+        final IgniteFsPath file = new IgniteFsPath("/file1");
 
         final int dataSize = 1024;
 
@@ -791,24 +791,24 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
 
         IgniteFsEvent evt = (IgniteFsEvent)evtList.get(0);
         assertEquals(EVT_GGFS_FILE_CREATED, evt.type());
-        assertEquals(new GridGgfsPath("/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/file1"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(1);
         assertEquals(EVT_GGFS_FILE_OPENED_WRITE, evt.type());
-        assertEquals(new GridGgfsPath("/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/file1"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(2);
         assertEquals(EVT_GGFS_FILE_CLOSED_WRITE, evt.type());
-        assertEquals(new GridGgfsPath("/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/file1"), evt.path());
         assertEquals((long)dataSize, evt.dataSize());
 
         evt = (IgniteFsEvent)evtList.get(3);
         assertEquals(EVT_GGFS_FILE_OPENED_READ, evt.type());
-        assertEquals(new GridGgfsPath("/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/file1"), evt.path());
 
         evt = (IgniteFsEvent)evtList.get(4);
         assertEquals(EVT_GGFS_FILE_CLOSED_READ, evt.type());
-        assertEquals(new GridGgfsPath("/file1"), evt.path());
+        assertEquals(new IgniteFsPath("/file1"), evt.path());
         assertEquals((long)dataSize, evt.dataSize());
     }
 
@@ -820,13 +820,13 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
         private final int evt;
 
         /** */
-        private final GridGgfsPath path;
+        private final IgniteFsPath path;
 
         /**
          * @param evt Event type.
          * @param path GGFS path.
          */
-        EventPredicate(int evt, GridGgfsPath path) {
+        EventPredicate(int evt, IgniteFsPath path) {
 
             this.evt = evt;
             this.path = path;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java
index 6239731..fc5a434 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java
@@ -117,7 +117,7 @@ public class GridGgfsFragmentizerAbstractSelfTest extends GridGgfsCommonAbstract
      * @param path Path to await.
      * @throws Exception If failed.
      */
-    protected void awaitFileFragmenting(int gridIdx, GridGgfsPath path) throws Exception {
+    protected void awaitFileFragmenting(int gridIdx, IgniteFsPath path) throws Exception {
         GridGgfsEx ggfs = (GridGgfsEx)grid(gridIdx).fileSystem("ggfs");
 
         GridGgfsMetaManager meta = ggfs.context().meta();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java
index 2f01d30..67169eb 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java
@@ -30,7 +30,7 @@ public class GridGgfsFragmentizerSelfTest extends GridGgfsFragmentizerAbstractSe
     public void testReadFragmentizing() throws Exception {
         IgniteFs ggfs = grid(0).fileSystem("ggfs");
 
-        GridGgfsPath path = new GridGgfsPath("/someFile");
+        IgniteFsPath path = new IgniteFsPath("/someFile");
 
         try (GridGgfsOutputStream out = ggfs.create(path, true)) {
             // Write 10 groups.
@@ -90,7 +90,7 @@ public class GridGgfsFragmentizerSelfTest extends GridGgfsFragmentizerAbstractSe
     * @throws Exception If failed.
     */
     private void checkAppendFragmentizing(int chunkSize, boolean rotate) throws Exception {
-        GridGgfsPath path = new GridGgfsPath("/someFile");
+        IgniteFsPath path = new IgniteFsPath("/someFile");
 
         long written = 0;
 
@@ -165,7 +165,7 @@ public class GridGgfsFragmentizerSelfTest extends GridGgfsFragmentizerAbstractSe
      * @throws Exception If failed.
      */
     private void checkFlushFragmentizing(int chunkSize) throws Exception {
-        GridGgfsPath path = new GridGgfsPath("/someFile");
+        IgniteFsPath path = new IgniteFsPath("/someFile");
 
         long written = 0;
         int cnt = 0;
@@ -218,7 +218,7 @@ public class GridGgfsFragmentizerSelfTest extends GridGgfsFragmentizerAbstractSe
         GridGgfsImpl ggfs = (GridGgfsImpl)grid(0).fileSystem("ggfs");
 
         for (int i = 0; i < 30; i++) {
-            GridGgfsPath path = new GridGgfsPath("/someFile" + i);
+            IgniteFsPath path = new IgniteFsPath("/someFile" + i);
 
             try (GridGgfsOutputStream out = ggfs.create(path, true)) {
                 for (int j = 0; j < 5 * GGFS_GROUP_SIZE; j++)
@@ -228,7 +228,7 @@ public class GridGgfsFragmentizerSelfTest extends GridGgfsFragmentizerAbstractSe
             U.sleep(200);
         }
 
-        ggfs.delete(new GridGgfsPath("/"), true);
+        ggfs.delete(new IgniteFsPath("/"), true);
 
         ggfs.awaitDeletesAsync().get();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerTopologySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerTopologySelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerTopologySelfTest.java
index 74d27c5..f8b2b01 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerTopologySelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerTopologySelfTest.java
@@ -23,7 +23,7 @@ public class GridGgfsFragmentizerTopologySelfTest extends GridGgfsFragmentizerAb
 
         // Now node 1 should be coordinator.
         try {
-            GridGgfsPath path = new GridGgfsPath("/someFile");
+            IgniteFsPath path = new IgniteFsPath("/someFile");
 
             IgniteFs ggfs = grid(1).fileSystem("ggfs");
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsPathSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsPathSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsPathSelfTest.java
index b7e97c6..94168d6 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsPathSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsPathSelfTest.java
@@ -23,7 +23,7 @@ import java.util.*;
 import java.util.concurrent.*;
 
 /**
- * {@link GridGgfsPath} self test.
+ * {@link IgniteFsPath} self test.
  */
 public class GridGgfsPathSelfTest extends GridCommonAbstractTest {
     /** Marshaller to test {@link Externalizable} interface. */
@@ -35,7 +35,7 @@ public class GridGgfsPathSelfTest extends GridCommonAbstractTest {
      * @throws Exception In case of any exception.
      */
     public void testMethods() throws Exception {
-        GridGgfsPath path = new GridGgfsPath("/a/s/d/f");
+        IgniteFsPath path = new IgniteFsPath("/a/s/d/f");
 
         validateParent("/a/s/d/f", "/a/s/d");
         validateParent("/a/s/d", "/a/s");
@@ -43,7 +43,7 @@ public class GridGgfsPathSelfTest extends GridCommonAbstractTest {
         validateParent("/a", "/");
         validateParent("/", null);
 
-        assertEquals(new GridGgfsPath("/a/s/d/f-2"), path.suffix("-2"));
+        assertEquals(new IgniteFsPath("/a/s/d/f-2"), path.suffix("-2"));
         assertEquals(Arrays.asList("a", "s", "d", "f"), path.components());
         assertEquals(4, path.depth());
         assertEquals(3, path.parent().depth());
@@ -51,10 +51,10 @@ public class GridGgfsPathSelfTest extends GridCommonAbstractTest {
 
         assertEquals(path, mu(path));
 
-        GridGgfsPath parent = path.parent();
+        IgniteFsPath parent = path.parent();
 
-        assertTrue(path.compareTo(new GridGgfsPath(parent, "e")) > 0);
-        assertTrue(path.compareTo(new GridGgfsPath(parent, "g")) < 0);
+        assertTrue(path.compareTo(new IgniteFsPath(parent, "e")) > 0);
+        assertTrue(path.compareTo(new IgniteFsPath(parent, "g")) < 0);
     }
 
     /**
@@ -64,7 +64,7 @@ public class GridGgfsPathSelfTest extends GridCommonAbstractTest {
      * @param parent Expected parent path.
      */
     private void validateParent(String child, @Nullable String parent) {
-        assertEquals(parent == null ? null : new GridGgfsPath(parent), new GridGgfsPath(child).parent());
+        assertEquals(parent == null ? null : new IgniteFsPath(parent), new IgniteFsPath(child).parent());
     }
 
     /**
@@ -87,17 +87,17 @@ public class GridGgfsPathSelfTest extends GridCommonAbstractTest {
     public void testConstructors() throws Exception {
         String pathStr = "///";
         URI uri = URI.create(pathStr);
-        GridGgfsPath path = new GridGgfsPath(uri);
+        IgniteFsPath path = new IgniteFsPath(uri);
 
-        assertNotNull(new GridGgfsPath(uri));
-        assertNotNull(new GridGgfsPath(pathStr));
-        assertNotNull(new GridGgfsPath("/"));
-        assertNotNull(new GridGgfsPath(path, pathStr));
-        assertNotNull(new GridGgfsPath());
+        assertNotNull(new IgniteFsPath(uri));
+        assertNotNull(new IgniteFsPath(pathStr));
+        assertNotNull(new IgniteFsPath("/"));
+        assertNotNull(new IgniteFsPath(path, pathStr));
+        assertNotNull(new IgniteFsPath());
 
         Class nullUri = URI.class;
         Class nullStr = String.class;
-        Class nullPath = GridGgfsPath.class;
+        Class nullPath = IgniteFsPath.class;
 
         expectConstructorThrows(NullPointerException.class, nullUri);
         expectConstructorThrows(IllegalArgumentException.class, nullStr);
@@ -107,7 +107,7 @@ public class GridGgfsPathSelfTest extends GridCommonAbstractTest {
 
         String name = "with space in path.txt";
 
-        assertEquals(name, new GridGgfsPath(path, name).name());
+        assertEquals(name, new IgniteFsPath(path, name).name());
     }
 
     /**
@@ -133,7 +133,7 @@ public class GridGgfsPathSelfTest extends GridCommonAbstractTest {
         GridTestUtils.assertThrows(log, new Callable<Object>() {
             @Override public Object call() throws Exception {
                 try {
-                    Constructor<GridGgfsPath> constructor = GridGgfsPath.class.getConstructor(paramTypes);
+                    Constructor<IgniteFsPath> constructor = IgniteFsPath.class.getConstructor(paramTypes);
 
                     constructor.newInstance(args);
                 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
index bf4fcc9..68e7c6d 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
@@ -51,10 +51,10 @@ public class GridCacheGgfsPerBlockLruEvictionPolicySelfTest extends GridGgfsComm
     private static final String SECONDARY_REST_CFG = "{type:'tcp', port:11500}";
 
     /** File working in PRIMARY mode. */
-    public static final GridGgfsPath FILE = new GridGgfsPath("/file");
+    public static final IgniteFsPath FILE = new IgniteFsPath("/file");
 
     /** File working in DUAL mode. */
-    public static final GridGgfsPath FILE_RMT = new GridGgfsPath("/fileRemote");
+    public static final IgniteFsPath FILE_RMT = new IgniteFsPath("/fileRemote");
 
     /** Primary GGFS instances. */
     private static GridGgfsImpl ggfsPrimary;
@@ -421,7 +421,7 @@ public class GridCacheGgfsPerBlockLruEvictionPolicySelfTest extends GridGgfsComm
      * @param len Length.
      * @throws Exception If failed.
      */
-    private void read(GridGgfsPath path, int off, int len) throws Exception {
+    private void read(IgniteFsPath path, int off, int len) throws Exception {
         GridGgfsInputStream is = ggfsPrimary.open(path);
 
         is.readFully(off, new byte[len]);
@@ -436,7 +436,7 @@ public class GridCacheGgfsPerBlockLruEvictionPolicySelfTest extends GridGgfsComm
      * @param len Data length.
      * @throws Exception If failed.
      */
-    private void append(GridGgfsPath path, int len) throws Exception {
+    private void append(IgniteFsPath path, int len) throws Exception {
         GridGgfsOutputStream os = ggfsPrimary.append(path, false);
 
         os.write(new byte[len]);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
index bb5f64c..1178dc0 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
@@ -65,34 +65,34 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
     protected static final String SECONDARY_REST_CFG = "{type:'tcp', port:11500}";
 
     /** Directory. */
-    protected static final GridGgfsPath DIR = new GridGgfsPath("/dir");
+    protected static final IgniteFsPath DIR = new IgniteFsPath("/dir");
 
     /** Sub-directory. */
-    protected static final GridGgfsPath SUBDIR = new GridGgfsPath(DIR, "subdir");
+    protected static final IgniteFsPath SUBDIR = new IgniteFsPath(DIR, "subdir");
 
     /** Another sub-directory in the same directory. */
-    protected static final GridGgfsPath SUBDIR2 = new GridGgfsPath(DIR, "subdir2");
+    protected static final IgniteFsPath SUBDIR2 = new IgniteFsPath(DIR, "subdir2");
 
     /** Sub-directory of the sub-directory. */
-    protected static final GridGgfsPath SUBSUBDIR = new GridGgfsPath(SUBDIR, "subsubdir");
+    protected static final IgniteFsPath SUBSUBDIR = new IgniteFsPath(SUBDIR, "subsubdir");
 
     /** File. */
-    protected static final GridGgfsPath FILE = new GridGgfsPath(SUBDIR, "file");
+    protected static final IgniteFsPath FILE = new IgniteFsPath(SUBDIR, "file");
 
     /** Another file in the same directory. */
-    protected static final GridGgfsPath FILE2 = new GridGgfsPath(SUBDIR, "file2");
+    protected static final IgniteFsPath FILE2 = new IgniteFsPath(SUBDIR, "file2");
 
     /** Other directory. */
-    protected static final GridGgfsPath DIR_NEW = new GridGgfsPath("/dirNew");
+    protected static final IgniteFsPath DIR_NEW = new IgniteFsPath("/dirNew");
 
     /** Other subdirectory. */
-    protected static final GridGgfsPath SUBDIR_NEW = new GridGgfsPath(DIR_NEW, "subdirNew");
+    protected static final IgniteFsPath SUBDIR_NEW = new IgniteFsPath(DIR_NEW, "subdirNew");
 
     /** Other sub-directory of the sub-directory. */
-    protected static final GridGgfsPath SUBSUBDIR_NEW = new GridGgfsPath(SUBDIR_NEW, "subsubdirNew");
+    protected static final IgniteFsPath SUBSUBDIR_NEW = new IgniteFsPath(SUBDIR_NEW, "subsubdirNew");
 
     /** Other file. */
-    protected static final GridGgfsPath FILE_NEW = new GridGgfsPath(SUBDIR_NEW, "fileNew");
+    protected static final IgniteFsPath FILE_NEW = new IgniteFsPath(SUBDIR_NEW, "fileNew");
 
     /** Default data chunk (128 bytes). */
     protected static byte[] chunk;
@@ -357,8 +357,8 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @throws Exception If failed.
      */
     public void testRenameFileParentRoot() throws Exception {
-        GridGgfsPath file1 = new GridGgfsPath("/file1");
-        GridGgfsPath file2 = new GridGgfsPath("/file2");
+        IgniteFsPath file1 = new IgniteFsPath("/file1");
+        IgniteFsPath file2 = new IgniteFsPath("/file2");
 
         create(ggfs, null, paths(file1));
 
@@ -389,8 +389,8 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @throws Exception If failed.
      */
     public void testRenameDirectoryParentRoot() throws Exception {
-        GridGgfsPath dir1 = new GridGgfsPath("/dir1");
-        GridGgfsPath dir2 = new GridGgfsPath("/dir2");
+        IgniteFsPath dir1 = new IgniteFsPath("/dir1");
+        IgniteFsPath dir2 = new IgniteFsPath("/dir2");
 
         create(ggfs, paths(dir1), null);
 
@@ -411,7 +411,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
         ggfs.rename(FILE, SUBDIR_NEW);
 
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, FILE.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, FILE.name()));
         checkNotExist(ggfs, ggfsSecondary, FILE);
     }
 
@@ -423,9 +423,9 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
     public void testMoveFileDestinationRoot() throws Exception {
         create(ggfs, paths(DIR, SUBDIR), paths(FILE));
 
-        ggfs.rename(FILE, new GridGgfsPath());
+        ggfs.rename(FILE, new IgniteFsPath());
 
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath("/" + FILE.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath("/" + FILE.name()));
         checkNotExist(ggfs, ggfsSecondary, FILE);
     }
 
@@ -435,13 +435,13 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @throws Exception If failed.
      */
     public void testMoveFileSourceParentRoot() throws Exception {
-        GridGgfsPath file = new GridGgfsPath("/" + FILE.name());
+        IgniteFsPath file = new IgniteFsPath("/" + FILE.name());
 
         create(ggfs, paths(DIR_NEW, SUBDIR_NEW), paths(file));
 
         ggfs.rename(file, SUBDIR_NEW);
 
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, FILE.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, FILE.name()));
         checkNotExist(ggfs, ggfsSecondary, file);
     }
 
@@ -466,7 +466,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @throws Exception If failed.
      */
     public void testMoveRenameFileDestinationRoot() throws Exception {
-        GridGgfsPath file = new GridGgfsPath("/" + FILE.name());
+        IgniteFsPath file = new IgniteFsPath("/" + FILE.name());
 
         create(ggfs, paths(DIR, SUBDIR), paths(FILE));
 
@@ -482,7 +482,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @throws Exception If failed.
      */
     public void testMoveRenameFileSourceParentRoot() throws Exception {
-        GridGgfsPath file = new GridGgfsPath("/" + FILE_NEW.name());
+        IgniteFsPath file = new IgniteFsPath("/" + FILE_NEW.name());
 
         create(ggfs, paths(DIR_NEW, SUBDIR_NEW), paths(file));
 
@@ -503,7 +503,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
         ggfs.rename(SUBSUBDIR, SUBDIR_NEW);
 
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, SUBSUBDIR.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, SUBSUBDIR.name()));
         checkNotExist(ggfs, ggfsSecondary, SUBSUBDIR);
     }
 
@@ -515,9 +515,9 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
     public void testMoveDirectoryDestinationRoot() throws Exception {
         create(ggfs, paths(DIR, SUBDIR, SUBSUBDIR), null);
 
-        ggfs.rename(SUBSUBDIR, new GridGgfsPath());
+        ggfs.rename(SUBSUBDIR, new IgniteFsPath());
 
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath("/" + SUBSUBDIR.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath("/" + SUBSUBDIR.name()));
         checkNotExist(ggfs, ggfsSecondary, SUBSUBDIR);
     }
 
@@ -527,13 +527,13 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @throws Exception If failed.
      */
     public void testMoveDirectorySourceParentRoot() throws Exception {
-        GridGgfsPath dir = new GridGgfsPath("/" + SUBSUBDIR.name());
+        IgniteFsPath dir = new IgniteFsPath("/" + SUBSUBDIR.name());
 
         create(ggfs, paths(DIR_NEW, SUBDIR_NEW, dir), null);
 
         ggfs.rename(dir, SUBDIR_NEW);
 
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, SUBSUBDIR.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, SUBSUBDIR.name()));
         checkNotExist(ggfs, ggfsSecondary, dir);
     }
 
@@ -558,7 +558,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @throws Exception If failed.
      */
     public void testMoveRenameDirectoryDestinationRoot() throws Exception {
-        GridGgfsPath dir = new GridGgfsPath("/" + SUBSUBDIR.name());
+        IgniteFsPath dir = new IgniteFsPath("/" + SUBSUBDIR.name());
 
         create(ggfs, paths(DIR, SUBDIR, SUBSUBDIR), null);
 
@@ -574,7 +574,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @throws Exception If failed.
      */
     public void testMoveRenameDirectorySourceParentRoot() throws Exception {
-        GridGgfsPath dir = new GridGgfsPath("/" + SUBSUBDIR_NEW.name());
+        IgniteFsPath dir = new IgniteFsPath("/" + SUBSUBDIR_NEW.name());
 
         create(ggfs, paths(DIR_NEW, SUBDIR_NEW, dir), null);
 
@@ -886,7 +886,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @throws Exception If failed.
      */
     public void testCreateParentRoot() throws Exception {
-        GridGgfsPath file = new GridGgfsPath("/" + FILE.name());
+        IgniteFsPath file = new IgniteFsPath("/" + FILE.name());
 
         createFile(ggfs, file, true, chunk);
 
@@ -1066,7 +1066,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
             @Override public void run() {
                 int idx = ctr.incrementAndGet();
 
-                GridGgfsPath path = new GridGgfsPath("/file" + idx);
+                IgniteFsPath path = new IgniteFsPath("/file" + idx);
 
                 try {
                     for (int i = 0; i < REPEAT_CNT; i++) {
@@ -1182,7 +1182,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @throws Exception If failed.
      */
     public void testAppendParentRoot() throws Exception {
-        GridGgfsPath file = new GridGgfsPath("/" + FILE.name());
+        IgniteFsPath file = new IgniteFsPath("/" + FILE.name());
 
         createFile(ggfs, file, true, BLOCK_SIZE, chunk);
 
@@ -1375,13 +1375,13 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
         int threadCnt = 10;
 
         for (int i = 0; i < threadCnt; i++)
-            createFile(ggfs, new GridGgfsPath("/file" + i), false);
+            createFile(ggfs, new IgniteFsPath("/file" + i), false);
 
         multithreaded(new Runnable() {
             @Override public void run() {
                 int idx = ctr.getAndIncrement();
 
-                GridGgfsPath path = new GridGgfsPath("/file" + idx);
+                IgniteFsPath path = new IgniteFsPath("/file" + idx);
 
                 try {
                     byte[][] chunks = new byte[REPEAT_CNT][];
@@ -1903,15 +1903,15 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
         assert childrenDirPerLvl > 0;
 
         // First define file system structure.
-        final Map<Integer, List<GridGgfsPath>> dirPaths = new HashMap<>();
-        final Map<Integer, List<GridGgfsPath>> filePaths = new HashMap<>();
+        final Map<Integer, List<IgniteFsPath>> dirPaths = new HashMap<>();
+        final Map<Integer, List<IgniteFsPath>> filePaths = new HashMap<>();
 
-        Queue<IgniteBiTuple<Integer, GridGgfsPath>> queue = new ArrayDeque<>();
+        Queue<IgniteBiTuple<Integer, IgniteFsPath>> queue = new ArrayDeque<>();
 
-        queue.add(F.t(0, new GridGgfsPath())); // Add root directory.
+        queue.add(F.t(0, new IgniteFsPath())); // Add root directory.
 
         while (!queue.isEmpty()) {
-            IgniteBiTuple<Integer, GridGgfsPath> entry = queue.poll();
+            IgniteBiTuple<Integer, IgniteFsPath> entry = queue.poll();
 
             int lvl = entry.getKey();
 
@@ -1919,21 +1919,21 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
                 int newLvl = lvl + 1;
 
                 for (int i = 0; i < childrenDirPerLvl; i++) {
-                    GridGgfsPath path = new GridGgfsPath(entry.getValue(), "dir-" + newLvl + "-" + i);
+                    IgniteFsPath path = new IgniteFsPath(entry.getValue(), "dir-" + newLvl + "-" + i);
 
                     queue.add(F.t(newLvl, path));
 
                     if (!dirPaths.containsKey(newLvl))
-                        dirPaths.put(newLvl, new ArrayList<GridGgfsPath>());
+                        dirPaths.put(newLvl, new ArrayList<IgniteFsPath>());
 
                     dirPaths.get(newLvl).add(path);
                 }
 
                 for (int i = 0; i < childrenFilePerLvl; i++) {
-                    GridGgfsPath path = new GridGgfsPath(entry.getValue(), "file-" + newLvl + "-" + i);
+                    IgniteFsPath path = new IgniteFsPath(entry.getValue(), "file-" + newLvl + "-" + i);
 
                     if (!filePaths.containsKey(newLvl))
-                        filePaths.put(newLvl, new ArrayList<GridGgfsPath>());
+                        filePaths.put(newLvl, new ArrayList<IgniteFsPath>());
 
                     filePaths.get(newLvl).add(path);
                 }
@@ -1957,8 +1957,8 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
                         int fromLvl = rand.nextInt(lvlCnt) + 1;
                         int toLvl = rand.nextInt(lvlCnt) + 1;
 
-                        List<GridGgfsPath> fromPaths;
-                        List<GridGgfsPath> toPaths;
+                        List<IgniteFsPath> fromPaths;
+                        List<IgniteFsPath> toPaths;
 
                         if (rand.nextInt(childrenDirPerLvl + childrenFilePerLvl) < childrenDirPerLvl) {
                             // Rename directories.
@@ -1971,8 +1971,8 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
                             toPaths = filePaths.get(toLvl);
                         }
 
-                        GridGgfsPath fromPath = fromPaths.get(rand.nextInt(fromPaths.size()));
-                        GridGgfsPath toPath = toPaths.get(rand.nextInt(toPaths.size()));
+                        IgniteFsPath fromPath = fromPaths.get(rand.nextInt(fromPaths.size()));
+                        IgniteFsPath toPath = toPaths.get(rand.nextInt(toPaths.size()));
 
                         U.awaitQuiet(barrier);
 
@@ -1994,7 +1994,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
                     try {
                         int lvl = rand.nextInt(lvlCnt) + 1;
 
-                        GridGgfsPath path = rand.nextInt(childrenDirPerLvl + childrenFilePerLvl) < childrenDirPerLvl ?
+                        IgniteFsPath path = rand.nextInt(childrenDirPerLvl + childrenFilePerLvl) < childrenDirPerLvl ?
                             dirPaths.get(lvl).get(rand.nextInt(dirPaths.get(lvl).size())) :
                             filePaths.get(lvl).get(rand.nextInt(filePaths.get(lvl).size()));
 
@@ -2018,7 +2018,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
                     try {
                         int lvl = rand.nextInt(lvlCnt) + 1;
 
-                        GridGgfsPath path = rand.nextInt(childrenDirPerLvl + childrenFilePerLvl) < childrenDirPerLvl ?
+                        IgniteFsPath path = rand.nextInt(childrenDirPerLvl + childrenFilePerLvl) < childrenDirPerLvl ?
                             dirPaths.get(lvl).get(rand.nextInt(dirPaths.get(lvl).size())) :
                             filePaths.get(lvl).get(rand.nextInt(filePaths.get(lvl).size()));
 
@@ -2044,9 +2044,9 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
                     try {
                         int lvl = rand.nextInt(lvlCnt) + 1;
 
-                        GridGgfsPath parentPath = dirPaths.get(lvl).get(rand.nextInt(dirPaths.get(lvl).size()));
+                        IgniteFsPath parentPath = dirPaths.get(lvl).get(rand.nextInt(dirPaths.get(lvl).size()));
 
-                        GridGgfsPath path = new GridGgfsPath(parentPath, "newDir-" + dirCtr.incrementAndGet());
+                        IgniteFsPath path = new IgniteFsPath(parentPath, "newDir-" + dirCtr.incrementAndGet());
 
                         U.awaitQuiet(barrier);
 
@@ -2071,9 +2071,9 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
                     try {
                         int lvl = rand.nextInt(lvlCnt) + 1;
 
-                        GridGgfsPath parentPath = dirPaths.get(lvl).get(rand.nextInt(dirPaths.get(lvl).size()));
+                        IgniteFsPath parentPath = dirPaths.get(lvl).get(rand.nextInt(dirPaths.get(lvl).size()));
 
-                        GridGgfsPath path = new GridGgfsPath(parentPath, "newFile-" + fileCtr.incrementAndGet());
+                        IgniteFsPath path = new IgniteFsPath(parentPath, "newFile-" + fileCtr.incrementAndGet());
 
                         U.awaitQuiet(barrier);
 
@@ -2103,8 +2103,8 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
             GridGgfsImpl targetGgfs = dual ? lvl <= primaryLvlCnt ? ggfs : ggfsSecondary : ggfs;
 
-            GridGgfsPath[] dirs = dirPaths.get(lvl).toArray(new GridGgfsPath[dirPaths.get(lvl).size()]);
-            GridGgfsPath[] files = filePaths.get(lvl).toArray(new GridGgfsPath[filePaths.get(lvl).size()]);
+            IgniteFsPath[] dirs = dirPaths.get(lvl).toArray(new IgniteFsPath[dirPaths.get(lvl).size()]);
+            IgniteFsPath[] files = filePaths.get(lvl).toArray(new IgniteFsPath[filePaths.get(lvl).size()]);
 
             create(targetGgfs, dirs, files);
         }
@@ -2124,15 +2124,15 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @param files Files.
      * @throws Exception If failed.
      */
-    public static void create(GridGgfsFileSystem ggfs, @Nullable GridGgfsPath[] dirs, @Nullable GridGgfsPath[] files)
+    public static void create(GridGgfsFileSystem ggfs, @Nullable IgniteFsPath[] dirs, @Nullable IgniteFsPath[] files)
         throws Exception {
         if (dirs != null) {
-            for (GridGgfsPath dir : dirs)
+            for (IgniteFsPath dir : dirs)
                 ggfs.mkdirs(dir);
         }
 
         if (files != null) {
-            for (GridGgfsPath file : files) {
+            for (IgniteFsPath file : files) {
                 OutputStream os = ggfs.create(file, true);
 
                 os.close();
@@ -2150,7 +2150,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @throws IOException In case of IO exception.
      * @throws GridException In case of Grid exception.
      */
-    protected static void createFile(GridGgfsFileSystem ggfs, GridGgfsPath file, boolean overwrite,
+    protected static void createFile(GridGgfsFileSystem ggfs, IgniteFsPath file, boolean overwrite,
         @Nullable byte[]... chunks) throws IOException, GridException {
         OutputStream os = null;
 
@@ -2176,7 +2176,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @param chunks Data chunks.
      * @throws Exception If failed.
      */
-    protected void createFile(IgniteFs ggfs, GridGgfsPath file, boolean overwrite, long blockSize,
+    protected void createFile(IgniteFs ggfs, IgniteFsPath file, boolean overwrite, long blockSize,
         @Nullable byte[]... chunks) throws Exception {
         GridGgfsOutputStream os = null;
 
@@ -2200,7 +2200,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @param chunks Data chunks.
      * @throws Exception If failed.
      */
-    protected void appendFile(IgniteFs ggfs, GridGgfsPath file, @Nullable byte[]... chunks)
+    protected void appendFile(IgniteFs ggfs, IgniteFsPath file, @Nullable byte[]... chunks)
         throws Exception {
         GridGgfsOutputStream os = null;
 
@@ -2236,7 +2236,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @param ggfs GGFS.
      * @param file File.
      */
-    public static void awaitFileClose(GridGgfsFileSystem ggfs, GridGgfsPath file) {
+    public static void awaitFileClose(GridGgfsFileSystem ggfs, IgniteFsPath file) {
         try {
             ggfs.update(file, Collections.singletonMap("prop", "val"));
         }
@@ -2253,7 +2253,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @param paths Paths.
      * @throws Exception If failed.
      */
-    protected void checkExist(GridGgfsImpl ggfs, GridGgfsImpl ggfsSecondary, GridGgfsPath... paths) throws Exception {
+    protected void checkExist(GridGgfsImpl ggfs, GridGgfsImpl ggfsSecondary, IgniteFsPath... paths) throws Exception {
         checkExist(ggfs, paths);
 
         if (dual)
@@ -2267,8 +2267,8 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @param paths Paths.
      * @throws GridException If failed.
      */
-    protected void checkExist(GridGgfsImpl ggfs, GridGgfsPath... paths) throws GridException {
-        for (GridGgfsPath path : paths) {
+    protected void checkExist(GridGgfsImpl ggfs, IgniteFsPath... paths) throws GridException {
+        for (IgniteFsPath path : paths) {
             assert ggfs.context().meta().fileId(path) != null : "Path doesn't exist [ggfs=" + ggfs.name() +
                 ", path=" + path + ']';
             assert ggfs.exists(path) : "Path doesn't exist [ggfs=" + ggfs.name() + ", path=" + path + ']';
@@ -2283,7 +2283,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @param paths Paths.
      * @throws Exception If failed.
      */
-    protected void checkNotExist(GridGgfsImpl ggfs, GridGgfsImpl ggfsSecondary, GridGgfsPath... paths)
+    protected void checkNotExist(GridGgfsImpl ggfs, GridGgfsImpl ggfsSecondary, IgniteFsPath... paths)
         throws Exception {
         checkNotExist(ggfs, paths);
 
@@ -2298,8 +2298,8 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @param paths Paths.
      * @throws Exception If failed.
      */
-    protected void checkNotExist(GridGgfsImpl ggfs, GridGgfsPath... paths) throws Exception {
-        for (GridGgfsPath path : paths) {
+    protected void checkNotExist(GridGgfsImpl ggfs, IgniteFsPath... paths) throws Exception {
+        for (IgniteFsPath path : paths) {
             assert ggfs.context().meta().fileId(path) == null : "Path exists [ggfs=" + ggfs.name() + ", path=" +
                 path + ']';
             assert !ggfs.exists(path) : "Path exists [ggfs=" + ggfs.name() + ", path=" + path + ']';
@@ -2316,7 +2316,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @param chunks Expected data.
      * @throws Exception If failed.
      */
-    protected void checkFile(GridGgfsImpl ggfs, GridGgfsImpl ggfsSecondary, GridGgfsPath file,
+    protected void checkFile(GridGgfsImpl ggfs, GridGgfsImpl ggfsSecondary, IgniteFsPath file,
         @Nullable byte[]... chunks) throws Exception {
         checkExist(ggfs, file);
         checkFileContent(ggfs, file, chunks);
@@ -2336,7 +2336,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @throws IOException In case of IO exception.
      * @throws GridException In case of Grid exception.
      */
-    protected void checkFileContent(GridGgfsImpl ggfs, GridGgfsPath file, @Nullable byte[]... chunks)
+    protected void checkFileContent(GridGgfsImpl ggfs, IgniteFsPath file, @Nullable byte[]... chunks)
         throws IOException, GridException {
         if (chunks != null && chunks.length > 0) {
             GridGgfsInputStream is = null;
@@ -2395,7 +2395,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @param paths Paths to group.
      * @return Paths as array.
      */
-    protected GridGgfsPath[] paths(GridGgfsPath... paths) {
+    protected IgniteFsPath[] paths(IgniteFsPath... paths) {
         return paths;
     }
 
@@ -2425,10 +2425,10 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
         workerMapFld.setAccessible(true);
 
         // Wait for all workers to finish.
-        Map<GridGgfsPath, GridGgfsFileWorker> workerMap =
-            (Map<GridGgfsPath, GridGgfsFileWorker>)workerMapFld.get(ggfs);
+        Map<IgniteFsPath, GridGgfsFileWorker> workerMap =
+            (Map<IgniteFsPath, GridGgfsFileWorker>)workerMapFld.get(ggfs);
 
-        for (Map.Entry<GridGgfsPath, GridGgfsFileWorker> entry : workerMap.entrySet()) {
+        for (Map.Entry<IgniteFsPath, GridGgfsFileWorker> entry : workerMap.entrySet()) {
             entry.getValue().cancel();
 
             U.join(entry.getValue());

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java
index c3dc4fc..7d5d494 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java
@@ -148,7 +148,7 @@ public class GridGgfsDataManagerSelfTest extends GridGgfsCommonAbstractTest {
     @SuppressWarnings("ConstantConditions")
     public void testDataStoring() throws Exception {
         for (int i = 0; i < 10; i++) {
-            GridGgfsPath path = new GridGgfsPath();
+            IgniteFsPath path = new IgniteFsPath();
             GridGgfsFileInfo info = new GridGgfsFileInfo(200, null, false, null);
 
             assertNull(mgr.dataBlock(info, path, 0, null).get());
@@ -229,7 +229,7 @@ public class GridGgfsDataManagerSelfTest extends GridGgfsCommonAbstractTest {
         final int blockSize = GGFS_BLOCK_SIZE;
 
         for (int i = 0; i < 10; i++) {
-            GridGgfsPath path = new GridGgfsPath();
+            IgniteFsPath path = new IgniteFsPath();
             GridGgfsFileInfo info = new GridGgfsFileInfo(blockSize, null, false, null);
 
             assertNull(mgr.dataBlock(info, path, 0, null).get());
@@ -316,7 +316,7 @@ public class GridGgfsDataManagerSelfTest extends GridGgfsCommonAbstractTest {
         final int writesCnt = 64;
 
         for (int i = 0; i < 10; i++) {
-            GridGgfsPath path = new GridGgfsPath();
+            IgniteFsPath path = new IgniteFsPath();
             GridGgfsFileInfo info = new GridGgfsFileInfo(blockSize, null, false, null);
 
             GridGgfsFileAffinityRange range = new GridGgfsFileAffinityRange();
@@ -388,17 +388,17 @@ public class GridGgfsDataManagerSelfTest extends GridGgfsCommonAbstractTest {
         GridGgfsFileInfo info = new GridGgfsFileInfo(blockSize, 1024 * 1024, null, null, false, null);
 
         for (int pos = 0; pos < 5 * grpSize; pos++) {
-            assertEquals("Expects no affinity for zero length.", Collections.<GridGgfsBlockLocation>emptyList(),
+            assertEquals("Expects no affinity for zero length.", Collections.<IgniteFsBlockLocation>emptyList(),
                 mgr.affinity(info, pos, 0));
 
             // Expects grouped data blocks are interpreted as a single block location.
             // And no guaranties for blocks out of the group.
             for (int len = 1, maxLen = grpSize - pos % grpSize; len < maxLen; len++) {
-                Collection<GridGgfsBlockLocation> aff = mgr.affinity(info, pos, len);
+                Collection<IgniteFsBlockLocation> aff = mgr.affinity(info, pos, len);
 
                 assertEquals("Unexpected affinity: " + aff, 1, aff.size());
 
-                GridGgfsBlockLocation loc = F.first(aff);
+                IgniteFsBlockLocation loc = F.first(aff);
 
                 assertEquals("Unexpected block location: " + loc, pos, loc.start());
                 assertEquals("Unexpected block location: " + loc, len, loc.length());
@@ -406,11 +406,11 @@ public class GridGgfsDataManagerSelfTest extends GridGgfsCommonAbstractTest {
 
             // Validate ranges.
             for (int len = grpSize * 4 + 1, maxLen = 5 * grpSize - pos % grpSize; len < maxLen; len++) {
-                Collection<GridGgfsBlockLocation> aff = mgr.affinity(info, pos, len);
+                Collection<IgniteFsBlockLocation> aff = mgr.affinity(info, pos, len);
 
                 assertTrue("Unexpected affinity [aff=" + aff + ", pos=" + pos + ", len=" + len + ']', aff.size() <= 5);
 
-                GridGgfsBlockLocation first = F.first(aff);
+                IgniteFsBlockLocation first = F.first(aff);
 
                 assertEquals("Unexpected the first block location [aff=" + aff + ", pos=" + pos + ", len=" + len + ']',
                     pos, first.start());
@@ -418,7 +418,7 @@ public class GridGgfsDataManagerSelfTest extends GridGgfsCommonAbstractTest {
                 assertTrue("Unexpected the first block location [aff=" + aff + ", pos=" + pos + ", len=" + len + ']',
                     first.length() >= grpSize - pos % grpSize);
 
-                GridGgfsBlockLocation last = F.last(aff);
+                IgniteFsBlockLocation last = F.last(aff);
 
                 assertTrue("Unexpected the last block location [aff=" + aff + ", pos=" + pos + ", len=" + len + ']',
                     last.start() <= (pos / grpSize + 4) * grpSize);
@@ -435,9 +435,9 @@ public class GridGgfsDataManagerSelfTest extends GridGgfsCommonAbstractTest {
 
         GridGgfsFileInfo info = new GridGgfsFileInfo(blockSize, 1024 * 1024, null, null, false, null);
 
-        Collection<GridGgfsBlockLocation> affinity = mgr.affinity(info, 0, info.length());
+        Collection<IgniteFsBlockLocation> affinity = mgr.affinity(info, 0, info.length());
 
-        for (GridGgfsBlockLocation loc : affinity) {
+        for (IgniteFsBlockLocation loc : affinity) {
             info("Going to check GGFS block location: " + loc);
 
             int block = (int)(loc.start() / blockSize);
@@ -475,7 +475,7 @@ public class GridGgfsDataManagerSelfTest extends GridGgfsCommonAbstractTest {
 
         info.fileMap(map);
 
-        Collection<GridGgfsBlockLocation> affinity = mgr.affinity(info, 0, info.length());
+        Collection<IgniteFsBlockLocation> affinity = mgr.affinity(info, 0, info.length());
 
         checkAffinity(blockSize, info, affinity);
 
@@ -507,10 +507,10 @@ public class GridGgfsDataManagerSelfTest extends GridGgfsCommonAbstractTest {
      * @param info File info.
      * @param affinity Affinity block locations to check.
      */
-    private void checkAffinity(int blockSize, GridGgfsFileInfo info, Iterable<GridGgfsBlockLocation> affinity) {
+    private void checkAffinity(int blockSize, GridGgfsFileInfo info, Iterable<IgniteFsBlockLocation> affinity) {
         GridCache<Object, Object> dataCache = grid(0).cachex(DATA_CACHE_NAME);
 
-        for (GridGgfsBlockLocation loc : affinity) {
+        for (IgniteFsBlockLocation loc : affinity) {
             info("Going to check GGFS block location: " + loc);
 
             int block = (int)(loc.start() / blockSize);


[17/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
index efb8b1c..516fd23 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopDualAbstractSelfTest.java
@@ -107,7 +107,7 @@ public abstract class GridGgfsHadoopDualAbstractSelfTest extends GridGgfsCommonA
      * @throws Exception If failed.
      */
     protected Ignite startGridWithGgfs(String gridName, String ggfsName, GridGgfsMode mode,
-        @Nullable GridGgfsFileSystem secondaryFs, @Nullable String restCfg) throws Exception {
+        @Nullable IgniteFsFileSystem secondaryFs, @Nullable String restCfg) throws Exception {
         IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("dataCache");
@@ -126,7 +126,7 @@ public abstract class GridGgfsHadoopDualAbstractSelfTest extends GridGgfsCommonA
         dataCacheCfg.setCacheMode(PARTITIONED);
         dataCacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
         dataCacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
-        dataCacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(2));
+        dataCacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(2));
         dataCacheCfg.setBackups(0);
         dataCacheCfg.setQueryIndexEnabled(false);
         dataCacheCfg.setAtomicityMode(TRANSACTIONAL);
@@ -167,7 +167,7 @@ public abstract class GridGgfsHadoopDualAbstractSelfTest extends GridGgfsCommonA
 
         Ignite igniteSecondary = startGridWithGgfs("grid-secondary", "ggfs-secondary", PRIMARY, null, SECONDARY_REST_CFG);
 
-        GridGgfsFileSystem hadoopFs = new GridGgfsHadoopFileSystemWrapper(SECONDARY_URI, SECONDARY_CFG);
+        IgniteFsFileSystem hadoopFs = new GridGgfsHadoopFileSystemWrapper(SECONDARY_URI, SECONDARY_CFG);
 
         Ignite ignite = startGridWithGgfs("grid", "ggfs", mode, hadoopFs, PRIMARY_REST_CFG);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
index 3136908..17e0960 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemAbstractSelfTest.java
@@ -177,7 +177,7 @@ public abstract class GridGgfsHadoopFileSystemAbstractSelfTest extends GridGgfsC
             cacheCfg.setCacheMode(PARTITIONED);
             cacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
             cacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
-            cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(GRP_SIZE));
+            cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(GRP_SIZE));
             cacheCfg.setBackups(0);
             cacheCfg.setQueryIndexEnabled(false);
             cacheCfg.setAtomicityMode(TRANSACTIONAL);
@@ -286,7 +286,7 @@ public abstract class GridGgfsHadoopFileSystemAbstractSelfTest extends GridGgfsC
         cacheCfg.setCacheMode(PARTITIONED);
         cacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
         cacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
-        cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(GRP_SIZE));
+        cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(GRP_SIZE));
         cacheCfg.setBackups(0);
         cacheCfg.setQueryIndexEnabled(false);
         cacheCfg.setAtomicityMode(TRANSACTIONAL);
@@ -1534,7 +1534,7 @@ public abstract class GridGgfsHadoopFileSystemAbstractSelfTest extends GridGgfsC
 
             IgniteFsPath filePath = new IgniteFsPath("/someFile");
 
-            GridGgfsFile fileInfo = igniteFs.info(filePath);
+            IgniteFsFile fileInfo = igniteFs.info(filePath);
 
             Collection<IgniteFsBlockLocation> locations = igniteFs.affinity(filePath, 0, fileInfo.length());
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java
index e1aba0b..bfb0310 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemClientSelfTest.java
@@ -87,7 +87,7 @@ public class GridGgfsHadoopFileSystemClientSelfTest extends GridGgfsCommonAbstra
         cacheCfg.setDistributionMode(PARTITIONED_ONLY);
         cacheCfg.setWriteSynchronizationMode(FULL_SYNC);
         cacheCfg.setEvictionPolicy(null);
-        cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+        cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         cacheCfg.setBackups(0);
         cacheCfg.setQueryIndexEnabled(false);
         cacheCfg.setAtomicityMode(TRANSACTIONAL);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
index 9f3284f..1c8c59f 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemHandshakeSelfTest.java
@@ -211,7 +211,7 @@ public class GridGgfsHadoopFileSystemHandshakeSelfTest extends GridGgfsCommonAbs
         dataCacheCfg.setCacheMode(PARTITIONED);
         dataCacheCfg.setDistributionMode(PARTITIONED_ONLY);
         dataCacheCfg.setWriteSynchronizationMode(FULL_SYNC);
-        dataCacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+        dataCacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         dataCacheCfg.setBackups(0);
         dataCacheCfg.setQueryIndexEnabled(false);
         dataCacheCfg.setAtomicityMode(TRANSACTIONAL);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemIpcCacheSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemIpcCacheSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemIpcCacheSelfTest.java
index 40cdaf0..a1a0606 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemIpcCacheSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemIpcCacheSelfTest.java
@@ -99,7 +99,7 @@ public class GridGgfsHadoopFileSystemIpcCacheSelfTest extends GridGgfsCommonAbst
         cacheCfg.setCacheMode(PARTITIONED);
         cacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
         cacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
-        cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(GRP_SIZE));
+        cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(GRP_SIZE));
         cacheCfg.setBackups(0);
         cacheCfg.setQueryIndexEnabled(false);
         cacheCfg.setAtomicityMode(TRANSACTIONAL);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java
index 8edb6d6..ad016b9 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerSelfTest.java
@@ -219,8 +219,8 @@ public class GridGgfsHadoopFileSystemLoggerSelfTest extends GridGgfsCommonAbstra
      * @param path File path.
      * @return GGFS file instance.
      */
-    private GridGgfsFile file(String path) {
-        return new GridGgfsFileImpl(new IgniteFsPath(path), new GridGgfsFileInfo(), 64 * 1024 * 1024);
+    private IgniteFsFile file(String path) {
+        return new IgniteFsFileImpl(new IgniteFsPath(path), new GridGgfsFileInfo(), 64 * 1024 * 1024);
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java
index afb5081..03d55e3 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemLoggerStateSelfTest.java
@@ -82,7 +82,7 @@ public class GridGgfsHadoopFileSystemLoggerStateSelfTest extends GridGgfsCommonA
         cacheCfg.setCacheMode(PARTITIONED);
         cacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
         cacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
-        cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+        cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         cacheCfg.setBackups(0);
         cacheCfg.setQueryIndexEnabled(false);
         cacheCfg.setAtomicityMode(TRANSACTIONAL);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java
index 0f156761..09bf434 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoopFileSystemSecondaryModeSelfTest.java
@@ -96,7 +96,7 @@ public class GridGgfsHadoopFileSystemSecondaryModeSelfTest extends GridGgfsCommo
         cacheCfg.setCacheMode(PARTITIONED);
         cacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
         cacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
-        cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+        cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         cacheCfg.setBackups(0);
         cacheCfg.setQueryIndexEnabled(false);
         cacheCfg.setAtomicityMode(TRANSACTIONAL);
@@ -155,7 +155,7 @@ public class GridGgfsHadoopFileSystemSecondaryModeSelfTest extends GridGgfsCommo
         cacheCfg.setCacheMode(PARTITIONED);
         cacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
         cacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
-        cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+        cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         cacheCfg.setBackups(0);
         cacheCfg.setQueryIndexEnabled(false);
         cacheCfg.setAtomicityMode(TRANSACTIONAL);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java
index 727716f..33a2863 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java
@@ -108,7 +108,7 @@ public class GridGgfsNearOnlyMultiNodeSelfTest extends GridCommonAbstractTest {
         cacheCfg.setCacheMode(PARTITIONED);
         cacheCfg.setDistributionMode(cnt == 0 ? NEAR_ONLY : PARTITIONED_ONLY);
         cacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
-        cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(GRP_SIZE));
+        cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(GRP_SIZE));
         cacheCfg.setBackups(0);
         cacheCfg.setQueryIndexEnabled(false);
         cacheCfg.setAtomicityMode(TRANSACTIONAL);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractSelfTest.java
index 43238c0..5aa8c15 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopAbstractSelfTest.java
@@ -154,7 +154,7 @@ public abstract class GridHadoopAbstractSelfTest extends GridCommonAbstractTest
         cfg.setName(ggfsDataCacheName);
         cfg.setCacheMode(PARTITIONED);
         cfg.setAtomicityMode(TRANSACTIONAL);
-        cfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(ggfsBlockGroupSize));
+        cfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(ggfsBlockGroupSize));
         cfg.setWriteSynchronizationMode(FULL_SYNC);
 
         return cfg;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
index 66797cd..0c75e80 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/kernal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
@@ -762,7 +762,7 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
         }
 
         /** {@inheritDoc} */
-        @Nullable @Override public GridGgfsFile info(IgniteFsPath path) throws GridException {
+        @Nullable @Override public IgniteFsFile info(IgniteFsPath path) throws GridException {
             return null;
         }
 
@@ -772,7 +772,7 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
         }
 
         /** {@inheritDoc} */
-        @Nullable @Override public GridGgfsFile update(IgniteFsPath path, Map<String, String> props)
+        @Nullable @Override public IgniteFsFile update(IgniteFsPath path, Map<String, String> props)
             throws GridException {
             return null;
         }
@@ -803,7 +803,7 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
         }
 
         /** {@inheritDoc} */
-        @Override public Collection<GridGgfsFile> listFiles(IgniteFsPath path) throws GridException {
+        @Override public Collection<IgniteFsFile> listFiles(IgniteFsPath path) throws GridException {
             return null;
         }
 


[34/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
# Renaming


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

Branch: refs/heads/master
Commit: f1061709b115413c83beadc68ed491e08b19a74a
Parents: bf07cfa
Author: sboikov <sb...@gridgain.com>
Authored: Fri Dec 5 11:33:09 2014 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Dec 5 11:33:09 2014 +0300

----------------------------------------------------------------------
 .../examples/ggfs/GgfsMapReduceExample.java     |   2 +-
 .../fs/mapreduce/IgniteFsRecordResolver.java    |   8 +-
 .../IgniteFsByteDelimiterRecordResolver.java    | 340 +++++++++++++++++++
 .../IgniteFsFixedLengthRecordResolver.java      |  79 +++++
 .../records/IgniteFsNewLineRecordResolver.java  |  58 ++++
 .../IgniteFsStringDelimiterRecordResolver.java  |  76 +++++
 .../ignite/fs/mapreduce/records/package.html    |  15 +
 .../IgniteFsByteDelimiterRecordResolver.java    | 340 -------------------
 .../IgniteFsFixedLengthRecordResolver.java      |  79 -----
 .../records/IgniteFsNewLineRecordResolver.java  |  58 ----
 .../IgniteFsStringDelimiterRecordResolver.java  |  76 -----
 .../grid/ggfs/mapreduce/records/package.html    |  15 -
 .../processors/ggfs/GridGgfsTaskSelfTest.java   |   2 +-
 ...GgfsByteDelimiterRecordResolverSelfTest.java |   2 +-
 ...idGgfsFixedLengthRecordResolverSelfTest.java |   2 +-
 ...sNewLineDelimiterRecordResolverSelfTest.java |   4 +-
 ...fsStringDelimiterRecordResolverSelfTest.java |   2 +-
 17 files changed, 579 insertions(+), 579 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f1061709/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
index 10913b0..2de576a 100644
--- a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
+++ b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
@@ -13,8 +13,8 @@ import org.apache.ignite.*;
 import org.apache.ignite.compute.*;
 import org.apache.ignite.fs.*;
 import org.apache.ignite.fs.mapreduce.*;
+import org.apache.ignite.fs.mapreduce.records.*;
 import org.gridgain.grid.*;
-import org.gridgain.grid.ggfs.mapreduce.records.*;
 
 import java.io.*;
 import java.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f1061709/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsRecordResolver.java b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsRecordResolver.java
index 3e347b7..3e96dcf 100644
--- a/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsRecordResolver.java
+++ b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/IgniteFsRecordResolver.java
@@ -27,10 +27,10 @@ import java.io.*;
  * <p>
  * The following record resolvers are available out of the box:
  * <ul>
- *     <li>{@link org.gridgain.grid.ggfs.mapreduce.records.IgniteFsFixedLengthRecordResolver}</li>
- *     <li>{@link org.gridgain.grid.ggfs.mapreduce.records.IgniteFsByteDelimiterRecordResolver}</li>
- *     <li>{@link org.gridgain.grid.ggfs.mapreduce.records.IgniteFsStringDelimiterRecordResolver}</li>
- *     <li>{@link org.gridgain.grid.ggfs.mapreduce.records.IgniteFsNewLineRecordResolver}</li>
+ *     <li>{@link org.apache.ignite.fs.mapreduce.records.IgniteFsFixedLengthRecordResolver}</li>
+ *     <li>{@link org.apache.ignite.fs.mapreduce.records.IgniteFsByteDelimiterRecordResolver}</li>
+ *     <li>{@link org.apache.ignite.fs.mapreduce.records.IgniteFsStringDelimiterRecordResolver}</li>
+ *     <li>{@link org.apache.ignite.fs.mapreduce.records.IgniteFsNewLineRecordResolver}</li>
  * </ul>
  */
 public interface IgniteFsRecordResolver extends Serializable {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f1061709/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java
new file mode 100644
index 0000000..0d35621
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java
@@ -0,0 +1,340 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs.mapreduce.records;
+
+import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
+import org.apache.ignite.fs.mapreduce.*;
+import org.apache.ignite.lang.*;
+import org.gridgain.grid.*;
+import org.gridgain.grid.util.typedef.*;
+import org.gridgain.grid.util.typedef.internal.*;
+import org.gridgain.grid.util.tostring.*;
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+import java.util.*;
+
+/**
+ * Record resolver which adjusts records based on provided delimiters. Both start position and length are
+ * shifted to the right, based on delimiter positions.
+ * <p>
+ * Note that you can use {@link IgniteFsStringDelimiterRecordResolver} if your delimiter is a plain string.
+ */
+public class IgniteFsByteDelimiterRecordResolver implements IgniteFsRecordResolver, Externalizable {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** Delimiters. */
+    private byte[][] delims;
+
+    /** Maximum delimiter length. */
+    @GridToStringExclude
+    private int maxDelimLen;
+
+    /**
+     * Empty constructor required for {@link Externalizable} support.
+     */
+    public IgniteFsByteDelimiterRecordResolver() {
+        // No-op.
+    }
+
+    /**
+     * Creates delimiter-based record resolver.
+     *
+     * @param delims Delimiters.
+     */
+    public IgniteFsByteDelimiterRecordResolver(byte[]... delims) {
+        if (delims == null || delims.length == 0)
+            throw new IllegalArgumentException("Delimiters cannot be null or empty.");
+
+        this.delims = delims;
+
+        int maxDelimLen = 0;
+
+        for (byte[] delim : delims) {
+            if (delim == null)
+                throw new IllegalArgumentException("Delimiter cannot be null.");
+            else if (maxDelimLen < delim.length)
+                maxDelimLen = delim.length;
+        }
+
+        this.maxDelimLen = maxDelimLen;
+    }
+
+    /** {@inheritDoc} */
+    @Override public IgniteFsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
+        IgniteFsFileRange suggestedRecord) throws GridException, IOException {
+        long suggestedStart = suggestedRecord.start();
+        long suggestedEnd = suggestedStart + suggestedRecord.length();
+
+        IgniteBiTuple<State, Delimiter> firstDelim = findFirstDelimiter(stream, suggestedStart);
+
+        State state = firstDelim != null ? firstDelim.getKey() : new State();
+
+        Delimiter curDelim = firstDelim.getValue();
+
+        while (curDelim != null && curDelim.end < suggestedStart)
+            curDelim = nextDelimiter(stream, state);
+
+        if (curDelim != null && (curDelim.end >= suggestedStart && curDelim.end < suggestedEnd) ||
+            suggestedStart == 0 ) {
+            // We found start delimiter.
+            long start = suggestedStart == 0 ? 0 : curDelim.end;
+
+            if (curDelim == null || curDelim.end < suggestedEnd) {
+                IgniteBiTuple<State, Delimiter> lastDelim = findFirstDelimiter(stream, suggestedEnd);
+
+                state = lastDelim != null ? firstDelim.getKey() : new State();
+
+                curDelim = lastDelim.getValue();
+
+                while (curDelim != null && curDelim.end < suggestedEnd)
+                    curDelim = nextDelimiter(stream, state);
+            }
+
+            long end = curDelim != null ? curDelim.end : stream.position();
+
+            return new IgniteFsFileRange(suggestedRecord.path(), start, end - start);
+        }
+        else
+            // We failed to find any delimiters up to the EOS.
+            return null;
+    }
+
+    /**
+     * Calculate maximum delimiters length.
+     *
+     * @param delims Delimiters.
+     * @return Maximum delimiter length.
+     */
+    private int maxDelimiterLength(byte[][] delims) {
+        int maxDelimLen = 0;
+
+        for (byte[] delim : delims) {
+            if (delim == null)
+                throw new IllegalArgumentException("Delimiter cannot be null.");
+            else if (maxDelimLen < delim.length)
+                maxDelimLen = delim.length;
+        }
+
+        return maxDelimLen;
+    }
+
+    /**
+     * Find first delimiter. In order to achieve this we have to rewind the stream until we find the delimiter
+     * which stands at least [maxDelimLen] from the start search position or until we faced stream start.
+     * Otherwise we cannot be sure that delimiter position is determined correctly.
+     *
+     * @param stream GGFS input stream.
+     * @param startPos Start search position.
+     * @return The first found delimiter.
+     * @throws IOException In case of IO exception.
+     */
+    @Nullable private IgniteBiTuple<State, Delimiter> findFirstDelimiter(IgniteFsInputStream stream, long startPos)
+        throws IOException {
+        State state;
+        Delimiter delim;
+
+        long curPos = Math.max(0, startPos - maxDelimLen);
+
+        while (true) {
+            stream.seek(curPos);
+
+            state = new State();
+
+            delim = nextDelimiter(stream, state);
+
+            if (curPos == 0 || delim == null || delim.start - curPos > maxDelimLen - 1)
+                break;
+            else
+                curPos = Math.max(0, curPos - maxDelimLen);
+        }
+
+        return F.t(state, delim);
+    }
+
+    /**
+     * Resolve next delimiter.
+     *
+     * @param is GGFS input stream.
+     * @param state Current state.
+     * @return Next delimiter and updated map.
+     * @throws IOException In case of exception.
+     */
+    private Delimiter nextDelimiter(IgniteFsInputStream is, State state) throws IOException {
+        assert is != null;
+        assert state != null;
+
+        Map<Integer, Integer> parts = state.parts;
+        LinkedList<Delimiter> delimQueue = state.delims;
+
+        int nextByte = is.read();
+
+        while (nextByte != -1) {
+            // Process read byte.
+            for (int idx = 0; idx < delims.length; idx++) {
+                byte[] delim = delims[idx];
+
+                int val = parts.containsKey(idx) ? parts.get(idx) : 0;
+
+                if (delim[val] == nextByte) {
+                    if (val == delim.length - 1) {
+                        // Full delimiter is found.
+                        parts.remove(idx);
+
+                        Delimiter newDelim = new Delimiter(is.position() - delim.length, is.position());
+
+                        // Read queue from the end looking for the "inner" delimiters.
+                        boolean ignore = false;
+
+                        int replaceIdx = -1;
+
+                        for (int i = delimQueue.size() - 1; i >= 0; i--) {
+                            Delimiter prevDelim = delimQueue.get(i);
+
+                            if (prevDelim.start < newDelim.start) {
+                                if (prevDelim.end > newDelim.start) {
+                                    // Ignore this delimiter.
+                                    ignore = true;
+
+                                    break;
+                                }
+                            }
+                            else if (prevDelim.start == newDelim.start) {
+                                // Ok, we found matching delimiter.
+                                replaceIdx = i;
+
+                                break;
+                            }
+                        }
+
+                        if (!ignore) {
+                            if (replaceIdx >= 0)
+                                delimQueue.removeAll(delimQueue.subList(replaceIdx, delimQueue.size()));
+
+                            delimQueue.add(newDelim);
+                        }
+                    }
+                    else
+                        parts.put(idx, ++val);
+                }
+                else if (val != 0) {
+                    if (delim[0] == nextByte) {
+                        boolean shift = true;
+
+                        for (int k = 1; k < val; k++) {
+                            if (delim[k] != nextByte) {
+                                shift = false;
+
+                                break;
+                            }
+                        }
+
+                        if (!shift)
+                            parts.put(idx, 1);
+                    }
+                    else
+                        // Delimiter sequence is totally broken.
+                        parts.remove(idx);
+                }
+            }
+
+            // Check whether we can be sure that the first delimiter will not change.
+            if (!delimQueue.isEmpty()) {
+                Delimiter delim = delimQueue.get(0);
+
+                if (is.position() - delim.end >= maxDelimLen)
+                    return delimQueue.poll();
+            }
+
+            nextByte = is.read();
+        }
+
+        return delimQueue.poll();
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsByteDelimiterRecordResolver.class, this);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void writeExternal(ObjectOutput out) throws IOException {
+        if (delims != null) {
+            out.writeBoolean(true);
+
+            out.writeInt(delims.length);
+
+            for (byte[] delim : delims)
+                U.writeByteArray(out, delim);
+        }
+        else
+            out.writeBoolean(false);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
+        if (in.readBoolean()) {
+            int len = in.readInt();
+
+            delims = new byte[len][];
+
+            for (int i = 0; i < len; i++)
+                delims[i] = U.readByteArray(in);
+
+            maxDelimLen = maxDelimiterLength(delims);
+        }
+    }
+
+    /**
+     * Delimiter descriptor.
+     */
+    private static class Delimiter {
+        /** Delimiter start position. */
+        private final long start;
+
+        /** Delimiter end position. */
+        private final long end;
+
+        /**
+         * Constructor.
+         *
+         * @param start Delimiter start position.
+         * @param end Delimiter end position.
+         */
+        private Delimiter(long start, long end) {
+            assert start >= 0 && end >= 0 && start <= end;
+
+            this.start = start;
+            this.end = end;
+        }
+    }
+
+    /**
+     * Current resolution state.
+     */
+    private static class State {
+        /** Partially resolved delimiters. */
+        private final Map<Integer, Integer> parts;
+
+        /** Resolved delimiters which could potentially be merged. */
+        private final LinkedList<Delimiter> delims;
+
+        /**
+         * Constructor.
+         */
+        private State() {
+            parts = new HashMap<>();
+
+            delims = new LinkedList<>();
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f1061709/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java
new file mode 100644
index 0000000..70091cf
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java
@@ -0,0 +1,79 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs.mapreduce.records;
+
+import org.apache.ignite.*;
+import org.apache.ignite.fs.*;
+import org.apache.ignite.fs.mapreduce.*;
+import org.gridgain.grid.*;
+import org.gridgain.grid.util.typedef.internal.*;
+
+import java.io.*;
+
+/**
+ * Record resolver which adjusts records to fixed length. That is, start offset of the record is shifted to the
+ * nearest position so that {@code newStart % length == 0}.
+ */
+public class IgniteFsFixedLengthRecordResolver implements IgniteFsRecordResolver, Externalizable {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** Record length. */
+    private long recLen;
+
+    /**
+     * Empty constructor required for {@link Externalizable} support.
+     */
+    public IgniteFsFixedLengthRecordResolver() {
+        // No-op.
+    }
+
+    /**
+     * Creates fixed-length record resolver.
+     *
+     * @param recLen Record length.
+     */
+    public IgniteFsFixedLengthRecordResolver(long recLen) {
+        this.recLen = recLen;
+    }
+
+    /** {@inheritDoc} */
+    @Override public IgniteFsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
+        IgniteFsFileRange suggestedRecord)
+        throws GridException, IOException {
+        long suggestedEnd = suggestedRecord.start() + suggestedRecord.length();
+
+        long startRem = suggestedRecord.start() % recLen;
+        long endRem = suggestedEnd % recLen;
+
+        long start = Math.min(suggestedRecord.start() + (startRem != 0 ? (recLen - startRem) : 0),
+            stream.length());
+        long end = Math.min(suggestedEnd + (endRem != 0 ? (recLen - endRem) : 0), stream.length());
+
+        assert end >= start;
+
+        return start != end ? new IgniteFsFileRange(suggestedRecord.path(), start, end - start) : null;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsFixedLengthRecordResolver.class, this);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void writeExternal(ObjectOutput out) throws IOException {
+        out.writeLong(recLen);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
+        recLen = in.readLong();
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f1061709/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/IgniteFsNewLineRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/IgniteFsNewLineRecordResolver.java b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/IgniteFsNewLineRecordResolver.java
new file mode 100644
index 0000000..14fbedd
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/IgniteFsNewLineRecordResolver.java
@@ -0,0 +1,58 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs.mapreduce.records;
+
+import org.gridgain.grid.util.typedef.internal.*;
+
+import java.io.*;
+
+/**
+ * Record resolver based on new line detection. This resolver can detect new lines based on '\n' or '\r\n' sequences.
+ * <p>
+ * Note that this resolver cannot be created and has one constant implementations: {@link #NEW_LINE}.
+ */
+public class IgniteFsNewLineRecordResolver extends IgniteFsByteDelimiterRecordResolver {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Singleton new line resolver. This resolver will resolve records based on new lines
+     * regardless if they have '\n' or '\r\n' patterns.
+     */
+    public static final IgniteFsNewLineRecordResolver NEW_LINE = new IgniteFsNewLineRecordResolver(true);
+
+    /** CR symbol. */
+    public static final byte SYM_CR = 0x0D;
+
+    /** LF symbol. */
+    public static final byte SYM_LF = 0x0A;
+
+    /**
+     * Empty constructor required for {@link Externalizable} support.
+     */
+    public IgniteFsNewLineRecordResolver() {
+        // No-op.
+    }
+
+    /**
+     * Creates new-line record resolver.
+     *
+     * @param b Artificial flag to differentiate from empty constructor.
+     */
+    @SuppressWarnings("UnusedParameters")
+    private IgniteFsNewLineRecordResolver(boolean b) {
+        super(new byte[] { SYM_CR, SYM_LF }, new byte[] { SYM_LF });
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsNewLineRecordResolver.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f1061709/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/IgniteFsStringDelimiterRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/IgniteFsStringDelimiterRecordResolver.java b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/IgniteFsStringDelimiterRecordResolver.java
new file mode 100644
index 0000000..c617529
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/IgniteFsStringDelimiterRecordResolver.java
@@ -0,0 +1,76 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.apache.ignite.fs.mapreduce.records;
+
+import org.gridgain.grid.util.typedef.internal.*;
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+import java.nio.charset.*;
+
+/**
+ * Record resolver based on delimiters represented as strings. Works in the same way as
+ * {@link IgniteFsByteDelimiterRecordResolver}, but uses strings as delimiters instead of byte arrays.
+ */
+public class IgniteFsStringDelimiterRecordResolver extends IgniteFsByteDelimiterRecordResolver {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Converts string delimiters to byte delimiters.
+     *
+     * @param charset Charset.
+     * @param delims String delimiters.
+     * @return Byte delimiters.
+     */
+    @Nullable private static byte[][] toBytes(Charset charset, @Nullable String... delims) {
+        byte[][] res = null;
+
+        if (delims != null) {
+            res = new byte[delims.length][];
+
+            for (int i = 0; i < delims.length; i++)
+                res[i] = delims[i].getBytes(charset);
+        }
+
+        return res;
+    }
+
+    /**
+     * Empty constructor required for {@link Externalizable} support.
+     */
+    public IgniteFsStringDelimiterRecordResolver() {
+        // No-op.
+    }
+
+    /**
+     * Creates record resolver from given string and given charset.
+     *
+     * @param delims Delimiters.
+     * @param charset Charset.
+     */
+    public IgniteFsStringDelimiterRecordResolver(Charset charset, String... delims) {
+        super(toBytes(charset, delims));
+    }
+
+    /**
+     * Creates record resolver based on given string with default charset.
+     *
+     * @param delims Delimiters.
+     */
+    public IgniteFsStringDelimiterRecordResolver(String... delims) {
+        super(toBytes(Charset.defaultCharset(), delims));
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsStringDelimiterRecordResolver.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f1061709/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/package.html
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/package.html b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/package.html
new file mode 100644
index 0000000..815ecd0
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/fs/mapreduce/records/package.html
@@ -0,0 +1,15 @@
+<!DOCTYPE html PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+    @html.file.header
+    _________        _____ __________________        _____
+    __  ____/___________(_)______  /__  ____/______ ____(_)_______
+    _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+    / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+    \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+-->
+<html>
+<body>
+    <!-- Package description. -->
+    Contains record resolvers for In-Memory MapReduce over GGFS.
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f1061709/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java
deleted file mode 100644
index 480e574..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsByteDelimiterRecordResolver.java
+++ /dev/null
@@ -1,340 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce.records;
-
-import org.apache.ignite.*;
-import org.apache.ignite.fs.*;
-import org.apache.ignite.fs.mapreduce.*;
-import org.apache.ignite.lang.*;
-import org.gridgain.grid.*;
-import org.gridgain.grid.util.typedef.*;
-import org.gridgain.grid.util.typedef.internal.*;
-import org.gridgain.grid.util.tostring.*;
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-import java.util.*;
-
-/**
- * Record resolver which adjusts records based on provided delimiters. Both start position and length are
- * shifted to the right, based on delimiter positions.
- * <p>
- * Note that you can use {@link IgniteFsStringDelimiterRecordResolver} if your delimiter is a plain string.
- */
-public class IgniteFsByteDelimiterRecordResolver implements IgniteFsRecordResolver, Externalizable {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** Delimiters. */
-    private byte[][] delims;
-
-    /** Maximum delimiter length. */
-    @GridToStringExclude
-    private int maxDelimLen;
-
-    /**
-     * Empty constructor required for {@link Externalizable} support.
-     */
-    public IgniteFsByteDelimiterRecordResolver() {
-        // No-op.
-    }
-
-    /**
-     * Creates delimiter-based record resolver.
-     *
-     * @param delims Delimiters.
-     */
-    public IgniteFsByteDelimiterRecordResolver(byte[]... delims) {
-        if (delims == null || delims.length == 0)
-            throw new IllegalArgumentException("Delimiters cannot be null or empty.");
-
-        this.delims = delims;
-
-        int maxDelimLen = 0;
-
-        for (byte[] delim : delims) {
-            if (delim == null)
-                throw new IllegalArgumentException("Delimiter cannot be null.");
-            else if (maxDelimLen < delim.length)
-                maxDelimLen = delim.length;
-        }
-
-        this.maxDelimLen = maxDelimLen;
-    }
-
-    /** {@inheritDoc} */
-    @Override public IgniteFsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
-        IgniteFsFileRange suggestedRecord) throws GridException, IOException {
-        long suggestedStart = suggestedRecord.start();
-        long suggestedEnd = suggestedStart + suggestedRecord.length();
-
-        IgniteBiTuple<State, Delimiter> firstDelim = findFirstDelimiter(stream, suggestedStart);
-
-        State state = firstDelim != null ? firstDelim.getKey() : new State();
-
-        Delimiter curDelim = firstDelim.getValue();
-
-        while (curDelim != null && curDelim.end < suggestedStart)
-            curDelim = nextDelimiter(stream, state);
-
-        if (curDelim != null && (curDelim.end >= suggestedStart && curDelim.end < suggestedEnd) ||
-            suggestedStart == 0 ) {
-            // We found start delimiter.
-            long start = suggestedStart == 0 ? 0 : curDelim.end;
-
-            if (curDelim == null || curDelim.end < suggestedEnd) {
-                IgniteBiTuple<State, Delimiter> lastDelim = findFirstDelimiter(stream, suggestedEnd);
-
-                state = lastDelim != null ? firstDelim.getKey() : new State();
-
-                curDelim = lastDelim.getValue();
-
-                while (curDelim != null && curDelim.end < suggestedEnd)
-                    curDelim = nextDelimiter(stream, state);
-            }
-
-            long end = curDelim != null ? curDelim.end : stream.position();
-
-            return new IgniteFsFileRange(suggestedRecord.path(), start, end - start);
-        }
-        else
-            // We failed to find any delimiters up to the EOS.
-            return null;
-    }
-
-    /**
-     * Calculate maximum delimiters length.
-     *
-     * @param delims Delimiters.
-     * @return Maximum delimiter length.
-     */
-    private int maxDelimiterLength(byte[][] delims) {
-        int maxDelimLen = 0;
-
-        for (byte[] delim : delims) {
-            if (delim == null)
-                throw new IllegalArgumentException("Delimiter cannot be null.");
-            else if (maxDelimLen < delim.length)
-                maxDelimLen = delim.length;
-        }
-
-        return maxDelimLen;
-    }
-
-    /**
-     * Find first delimiter. In order to achieve this we have to rewind the stream until we find the delimiter
-     * which stands at least [maxDelimLen] from the start search position or until we faced stream start.
-     * Otherwise we cannot be sure that delimiter position is determined correctly.
-     *
-     * @param stream GGFS input stream.
-     * @param startPos Start search position.
-     * @return The first found delimiter.
-     * @throws IOException In case of IO exception.
-     */
-    @Nullable private IgniteBiTuple<State, Delimiter> findFirstDelimiter(IgniteFsInputStream stream, long startPos)
-        throws IOException {
-        State state;
-        Delimiter delim;
-
-        long curPos = Math.max(0, startPos - maxDelimLen);
-
-        while (true) {
-            stream.seek(curPos);
-
-            state = new State();
-
-            delim = nextDelimiter(stream, state);
-
-            if (curPos == 0 || delim == null || delim.start - curPos > maxDelimLen - 1)
-                break;
-            else
-                curPos = Math.max(0, curPos - maxDelimLen);
-        }
-
-        return F.t(state, delim);
-    }
-
-    /**
-     * Resolve next delimiter.
-     *
-     * @param is GGFS input stream.
-     * @param state Current state.
-     * @return Next delimiter and updated map.
-     * @throws IOException In case of exception.
-     */
-    private Delimiter nextDelimiter(IgniteFsInputStream is, State state) throws IOException {
-        assert is != null;
-        assert state != null;
-
-        Map<Integer, Integer> parts = state.parts;
-        LinkedList<Delimiter> delimQueue = state.delims;
-
-        int nextByte = is.read();
-
-        while (nextByte != -1) {
-            // Process read byte.
-            for (int idx = 0; idx < delims.length; idx++) {
-                byte[] delim = delims[idx];
-
-                int val = parts.containsKey(idx) ? parts.get(idx) : 0;
-
-                if (delim[val] == nextByte) {
-                    if (val == delim.length - 1) {
-                        // Full delimiter is found.
-                        parts.remove(idx);
-
-                        Delimiter newDelim = new Delimiter(is.position() - delim.length, is.position());
-
-                        // Read queue from the end looking for the "inner" delimiters.
-                        boolean ignore = false;
-
-                        int replaceIdx = -1;
-
-                        for (int i = delimQueue.size() - 1; i >= 0; i--) {
-                            Delimiter prevDelim = delimQueue.get(i);
-
-                            if (prevDelim.start < newDelim.start) {
-                                if (prevDelim.end > newDelim.start) {
-                                    // Ignore this delimiter.
-                                    ignore = true;
-
-                                    break;
-                                }
-                            }
-                            else if (prevDelim.start == newDelim.start) {
-                                // Ok, we found matching delimiter.
-                                replaceIdx = i;
-
-                                break;
-                            }
-                        }
-
-                        if (!ignore) {
-                            if (replaceIdx >= 0)
-                                delimQueue.removeAll(delimQueue.subList(replaceIdx, delimQueue.size()));
-
-                            delimQueue.add(newDelim);
-                        }
-                    }
-                    else
-                        parts.put(idx, ++val);
-                }
-                else if (val != 0) {
-                    if (delim[0] == nextByte) {
-                        boolean shift = true;
-
-                        for (int k = 1; k < val; k++) {
-                            if (delim[k] != nextByte) {
-                                shift = false;
-
-                                break;
-                            }
-                        }
-
-                        if (!shift)
-                            parts.put(idx, 1);
-                    }
-                    else
-                        // Delimiter sequence is totally broken.
-                        parts.remove(idx);
-                }
-            }
-
-            // Check whether we can be sure that the first delimiter will not change.
-            if (!delimQueue.isEmpty()) {
-                Delimiter delim = delimQueue.get(0);
-
-                if (is.position() - delim.end >= maxDelimLen)
-                    return delimQueue.poll();
-            }
-
-            nextByte = is.read();
-        }
-
-        return delimQueue.poll();
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(IgniteFsByteDelimiterRecordResolver.class, this);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void writeExternal(ObjectOutput out) throws IOException {
-        if (delims != null) {
-            out.writeBoolean(true);
-
-            out.writeInt(delims.length);
-
-            for (byte[] delim : delims)
-                U.writeByteArray(out, delim);
-        }
-        else
-            out.writeBoolean(false);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
-        if (in.readBoolean()) {
-            int len = in.readInt();
-
-            delims = new byte[len][];
-
-            for (int i = 0; i < len; i++)
-                delims[i] = U.readByteArray(in);
-
-            maxDelimLen = maxDelimiterLength(delims);
-        }
-    }
-
-    /**
-     * Delimiter descriptor.
-     */
-    private static class Delimiter {
-        /** Delimiter start position. */
-        private final long start;
-
-        /** Delimiter end position. */
-        private final long end;
-
-        /**
-         * Constructor.
-         *
-         * @param start Delimiter start position.
-         * @param end Delimiter end position.
-         */
-        private Delimiter(long start, long end) {
-            assert start >= 0 && end >= 0 && start <= end;
-
-            this.start = start;
-            this.end = end;
-        }
-    }
-
-    /**
-     * Current resolution state.
-     */
-    private static class State {
-        /** Partially resolved delimiters. */
-        private final Map<Integer, Integer> parts;
-
-        /** Resolved delimiters which could potentially be merged. */
-        private final LinkedList<Delimiter> delims;
-
-        /**
-         * Constructor.
-         */
-        private State() {
-            parts = new HashMap<>();
-
-            delims = new LinkedList<>();
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f1061709/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java
deleted file mode 100644
index b360483..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsFixedLengthRecordResolver.java
+++ /dev/null
@@ -1,79 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce.records;
-
-import org.apache.ignite.*;
-import org.apache.ignite.fs.*;
-import org.apache.ignite.fs.mapreduce.*;
-import org.gridgain.grid.*;
-import org.gridgain.grid.util.typedef.internal.*;
-
-import java.io.*;
-
-/**
- * Record resolver which adjusts records to fixed length. That is, start offset of the record is shifted to the
- * nearest position so that {@code newStart % length == 0}.
- */
-public class IgniteFsFixedLengthRecordResolver implements IgniteFsRecordResolver, Externalizable {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** Record length. */
-    private long recLen;
-
-    /**
-     * Empty constructor required for {@link Externalizable} support.
-     */
-    public IgniteFsFixedLengthRecordResolver() {
-        // No-op.
-    }
-
-    /**
-     * Creates fixed-length record resolver.
-     *
-     * @param recLen Record length.
-     */
-    public IgniteFsFixedLengthRecordResolver(long recLen) {
-        this.recLen = recLen;
-    }
-
-    /** {@inheritDoc} */
-    @Override public IgniteFsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
-        IgniteFsFileRange suggestedRecord)
-        throws GridException, IOException {
-        long suggestedEnd = suggestedRecord.start() + suggestedRecord.length();
-
-        long startRem = suggestedRecord.start() % recLen;
-        long endRem = suggestedEnd % recLen;
-
-        long start = Math.min(suggestedRecord.start() + (startRem != 0 ? (recLen - startRem) : 0),
-            stream.length());
-        long end = Math.min(suggestedEnd + (endRem != 0 ? (recLen - endRem) : 0), stream.length());
-
-        assert end >= start;
-
-        return start != end ? new IgniteFsFileRange(suggestedRecord.path(), start, end - start) : null;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(IgniteFsFixedLengthRecordResolver.class, this);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void writeExternal(ObjectOutput out) throws IOException {
-        out.writeLong(recLen);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
-        recLen = in.readLong();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f1061709/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsNewLineRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsNewLineRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsNewLineRecordResolver.java
deleted file mode 100644
index 81f359e..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsNewLineRecordResolver.java
+++ /dev/null
@@ -1,58 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce.records;
-
-import org.gridgain.grid.util.typedef.internal.*;
-
-import java.io.*;
-
-/**
- * Record resolver based on new line detection. This resolver can detect new lines based on '\n' or '\r\n' sequences.
- * <p>
- * Note that this resolver cannot be created and has one constant implementations: {@link #NEW_LINE}.
- */
-public class IgniteFsNewLineRecordResolver extends IgniteFsByteDelimiterRecordResolver {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Singleton new line resolver. This resolver will resolve records based on new lines
-     * regardless if they have '\n' or '\r\n' patterns.
-     */
-    public static final IgniteFsNewLineRecordResolver NEW_LINE = new IgniteFsNewLineRecordResolver(true);
-
-    /** CR symbol. */
-    public static final byte SYM_CR = 0x0D;
-
-    /** LF symbol. */
-    public static final byte SYM_LF = 0x0A;
-
-    /**
-     * Empty constructor required for {@link Externalizable} support.
-     */
-    public IgniteFsNewLineRecordResolver() {
-        // No-op.
-    }
-
-    /**
-     * Creates new-line record resolver.
-     *
-     * @param b Artificial flag to differentiate from empty constructor.
-     */
-    @SuppressWarnings("UnusedParameters")
-    private IgniteFsNewLineRecordResolver(boolean b) {
-        super(new byte[] { SYM_CR, SYM_LF }, new byte[] { SYM_LF });
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(IgniteFsNewLineRecordResolver.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f1061709/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsStringDelimiterRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsStringDelimiterRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsStringDelimiterRecordResolver.java
deleted file mode 100644
index 3a42333..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/IgniteFsStringDelimiterRecordResolver.java
+++ /dev/null
@@ -1,76 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs.mapreduce.records;
-
-import org.gridgain.grid.util.typedef.internal.*;
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-import java.nio.charset.*;
-
-/**
- * Record resolver based on delimiters represented as strings. Works in the same way as
- * {@link IgniteFsByteDelimiterRecordResolver}, but uses strings as delimiters instead of byte arrays.
- */
-public class IgniteFsStringDelimiterRecordResolver extends IgniteFsByteDelimiterRecordResolver {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Converts string delimiters to byte delimiters.
-     *
-     * @param charset Charset.
-     * @param delims String delimiters.
-     * @return Byte delimiters.
-     */
-    @Nullable private static byte[][] toBytes(Charset charset, @Nullable String... delims) {
-        byte[][] res = null;
-
-        if (delims != null) {
-            res = new byte[delims.length][];
-
-            for (int i = 0; i < delims.length; i++)
-                res[i] = delims[i].getBytes(charset);
-        }
-
-        return res;
-    }
-
-    /**
-     * Empty constructor required for {@link Externalizable} support.
-     */
-    public IgniteFsStringDelimiterRecordResolver() {
-        // No-op.
-    }
-
-    /**
-     * Creates record resolver from given string and given charset.
-     *
-     * @param delims Delimiters.
-     * @param charset Charset.
-     */
-    public IgniteFsStringDelimiterRecordResolver(Charset charset, String... delims) {
-        super(toBytes(charset, delims));
-    }
-
-    /**
-     * Creates record resolver based on given string with default charset.
-     *
-     * @param delims Delimiters.
-     */
-    public IgniteFsStringDelimiterRecordResolver(String... delims) {
-        super(toBytes(Charset.defaultCharset(), delims));
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(IgniteFsStringDelimiterRecordResolver.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f1061709/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/package.html
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/package.html b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/package.html
deleted file mode 100644
index 815ecd0..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/package.html
+++ /dev/null
@@ -1,15 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
-<!--
-    @html.file.header
-    _________        _____ __________________        _____
-    __  ____/___________(_)______  /__  ____/______ ____(_)_______
-    _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
-    / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
-    \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
--->
-<html>
-<body>
-    <!-- Package description. -->
-    Contains record resolvers for In-Memory MapReduce over GGFS.
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f1061709/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
index c6d6f24..89e814c 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
@@ -14,11 +14,11 @@ import org.apache.ignite.compute.*;
 import org.apache.ignite.configuration.*;
 import org.apache.ignite.fs.*;
 import org.apache.ignite.fs.mapreduce.*;
+import org.apache.ignite.fs.mapreduce.records.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.resources.*;
 import org.gridgain.grid.*;
 import org.gridgain.grid.cache.*;
-import org.gridgain.grid.ggfs.mapreduce.records.*;
 import org.gridgain.grid.spi.discovery.tcp.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.*;
 import org.gridgain.grid.spi.discovery.tcp.ipfinder.vm.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f1061709/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
index bd9712a..193d61b 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsByteDelimiterRecordResolverSelfTest.java
@@ -11,7 +11,7 @@ package org.gridgain.grid.kernal.processors.ggfs.split;
 
 import org.apache.ignite.fs.*;
 import org.apache.ignite.fs.mapreduce.*;
-import org.gridgain.grid.ggfs.mapreduce.records.*;
+import org.apache.ignite.fs.mapreduce.records.*;
 import org.gridgain.grid.util.typedef.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f1061709/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
index 7bebc96..cdc89e1 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsFixedLengthRecordResolverSelfTest.java
@@ -11,7 +11,7 @@ package org.gridgain.grid.kernal.processors.ggfs.split;
 
 import org.apache.ignite.fs.*;
 import org.apache.ignite.fs.mapreduce.*;
-import org.gridgain.grid.ggfs.mapreduce.records.*;
+import org.apache.ignite.fs.mapreduce.records.*;
 import org.gridgain.grid.util.typedef.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f1061709/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
index 93d7286..c7b8544 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsNewLineDelimiterRecordResolverSelfTest.java
@@ -11,10 +11,10 @@ package org.gridgain.grid.kernal.processors.ggfs.split;
 
 import org.apache.ignite.fs.*;
 import org.apache.ignite.fs.mapreduce.*;
-import org.gridgain.grid.ggfs.mapreduce.records.*;
+import org.apache.ignite.fs.mapreduce.records.*;
 import org.gridgain.grid.util.typedef.*;
 
-import static org.gridgain.grid.ggfs.mapreduce.records.IgniteFsNewLineRecordResolver.*;
+import static org.apache.ignite.fs.mapreduce.records.IgniteFsNewLineRecordResolver.*;
 
 /**
  * New line split resolver self test.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f1061709/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
index efa044a..c9e1fd9 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsStringDelimiterRecordResolverSelfTest.java
@@ -11,7 +11,7 @@ package org.gridgain.grid.kernal.processors.ggfs.split;
 
 import org.apache.ignite.fs.*;
 import org.apache.ignite.fs.mapreduce.*;
-import org.gridgain.grid.ggfs.mapreduce.records.*;
+import org.apache.ignite.fs.mapreduce.records.*;
 import org.gridgain.grid.util.typedef.*;
 
 import java.nio.charset.*;


[13/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
# Renaming


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

Branch: refs/heads/master
Commit: f3d9376217eb3817cbd0d57c94517da9b6ce5594
Parents: 1515c5a
Author: sboikov <sb...@gridgain.com>
Authored: Fri Dec 5 11:13:21 2014 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Dec 5 11:13:23 2014 +0300

----------------------------------------------------------------------
 .../org/gridgain/examples/ggfs/GgfsExample.java |  24 +-
 .../examples/ggfs/GgfsMapReduceExample.java     |   8 +-
 .../main/java/org/apache/ignite/IgniteFs.java   |  34 +--
 .../org/apache/ignite/events/IgniteFsEvent.java |  16 +-
 .../GridCacheGgfsPerBlockLruEvictionPolicy.java |   2 +-
 .../grid/ggfs/GridGgfsBlockLocation.java        |  55 ----
 ...GridGgfsConcurrentModificationException.java |   2 +-
 .../org/gridgain/grid/ggfs/GridGgfsFile.java    |   4 +-
 .../gridgain/grid/ggfs/GridGgfsFileSystem.java  |  26 +-
 .../gridgain/grid/ggfs/GridGgfsInputStream.java |   2 +-
 .../org/gridgain/grid/ggfs/GridGgfsPath.java    | 254 -------------------
 .../GridGgfsPathAlreadyExistsException.java     |  42 ---
 .../gridgain/grid/ggfs/GridGgfsPathSummary.java | 130 ----------
 .../org/gridgain/grid/ggfs/GridGgfsReader.java  |  30 ---
 .../grid/ggfs/IgniteFsBlockLocation.java        |  55 ++++
 .../org/gridgain/grid/ggfs/IgniteFsPath.java    | 254 +++++++++++++++++++
 .../IgniteFsPathAlreadyExistsException.java     |  42 +++
 .../gridgain/grid/ggfs/IgniteFsPathSummary.java | 130 ++++++++++
 .../org/gridgain/grid/ggfs/IgniteFsReader.java  |  30 +++
 .../grid/ggfs/mapreduce/GridGgfsFileRange.java  |   6 +-
 .../grid/ggfs/mapreduce/GridGgfsTask.java       |  10 +-
 .../grid/ggfs/mapreduce/GridGgfsTaskArgs.java   |   4 +-
 .../ggfs/common/GridGgfsControlResponse.java    |  22 +-
 .../grid/kernal/ggfs/common/GridGgfsLogger.java |  14 +-
 .../kernal/ggfs/common/GridGgfsMarshaller.java  |   8 +-
 .../ggfs/common/GridGgfsPathControlRequest.java |  12 +-
 .../processors/ggfs/GridGgfsAsyncImpl.java      |  54 ++--
 .../ggfs/GridGgfsBlockLocationImpl.java         |   4 +-
 .../processors/ggfs/GridGgfsDataManager.java    |  20 +-
 .../grid/kernal/processors/ggfs/GridGgfsEx.java |   8 +-
 .../processors/ggfs/GridGgfsFileImpl.java       |  10 +-
 .../processors/ggfs/GridGgfsFileInfo.java       |   8 +-
 .../ggfs/GridGgfsFileWorkerBatch.java           |   6 +-
 .../kernal/processors/ggfs/GridGgfsImpl.java    | 134 +++++-----
 .../ggfs/GridGgfsInputStreamImpl.java           |   8 +-
 .../kernal/processors/ggfs/GridGgfsJobImpl.java |   4 +-
 .../processors/ggfs/GridGgfsMetaManager.java    | 116 ++++-----
 .../processors/ggfs/GridGgfsModeResolver.java   |  28 +-
 .../ggfs/GridGgfsOutputStreamAdapter.java       |   4 +-
 .../ggfs/GridGgfsOutputStreamImpl.java          |   2 +-
 .../kernal/processors/ggfs/GridGgfsPaths.java   |  12 +-
 .../processors/ggfs/GridGgfsProcessor.java      |   2 +-
 .../ggfs/GridGgfsProcessorAdapter.java          |   2 +-
 .../GridGgfsSecondaryInputStreamDescriptor.java |   6 +-
 .../processors/ggfs/GridGgfsTaskArgsImpl.java   |   6 +-
 .../processors/ggfs/GridNoopGgfsProcessor.java  |   2 +-
 .../ggfs/GridGgfsEventsAbstractSelfTest.java    | 142 +++++------
 .../GridGgfsFragmentizerAbstractSelfTest.java   |   2 +-
 .../grid/ggfs/GridGgfsFragmentizerSelfTest.java |  10 +-
 .../GridGgfsFragmentizerTopologySelfTest.java   |   2 +-
 .../grid/ggfs/GridGgfsPathSelfTest.java         |  32 +--
 ...heGgfsPerBlockLruEvictionPolicySelfTest.java |   8 +-
 .../ggfs/GridGgfsAbstractSelfTest.java          | 146 +++++------
 .../ggfs/GridGgfsDataManagerSelfTest.java       |  28 +-
 .../ggfs/GridGgfsDualAbstractSelfTest.java      | 100 ++++----
 .../ggfs/GridGgfsMetaManagerSelfTest.java       |  66 ++---
 .../ggfs/GridGgfsMetricsSelfTest.java           |  34 +--
 .../ggfs/GridGgfsModeResolverSelfTest.java      |  36 +--
 .../processors/ggfs/GridGgfsModesSelfTest.java  |   6 +-
 .../ggfs/GridGgfsProcessorSelfTest.java         |  48 ++--
 .../processors/ggfs/GridGgfsSizeSelfTest.java   |  16 +-
 .../ggfs/GridGgfsStreamsSelfTest.java           |  22 +-
 .../processors/ggfs/GridGgfsTaskSelfTest.java   |   4 +-
 .../GridGgfsAbstractRecordResolverSelfTest.java |   2 +-
 .../hadoop/v1/GridGgfsHadoopFileSystem.java     |  38 +--
 .../hadoop/v2/GridGgfsHadoopFileSystem.java     |  34 +--
 .../grid/kernal/ggfs/hadoop/GridGgfsHadoop.java |  28 +-
 .../hadoop/GridGgfsHadoopFileSystemWrapper.java |  38 +--
 .../ggfs/hadoop/GridGgfsHadoopInProc.java       |  28 +-
 .../ggfs/hadoop/GridGgfsHadoopOutProc.java      |  34 +--
 .../ggfs/hadoop/GridGgfsHadoopReader.java       |   2 +-
 .../kernal/ggfs/hadoop/GridGgfsHadoopUtils.java |   2 +-
 .../ggfs/hadoop/GridGgfsHadoopWrapper.java      |  42 +--
 .../GridHadoopDefaultMapReducePlanner.java      |   4 +-
 .../GridHadoopClientProtocolSelfTest.java       |  14 +-
 ...dGgfsHadoop20FileSystemAbstractSelfTest.java |   6 +-
 .../GridGgfsHadoopDualAbstractSelfTest.java     |   8 +-
 ...ridGgfsHadoopFileSystemAbstractSelfTest.java |   6 +-
 .../GridGgfsHadoopFileSystemClientSelfTest.java |   2 +-
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |   2 +-
 .../GridGgfsHadoopFileSystemLoggerSelfTest.java |   6 +-
 .../hadoop/GridHadoopAbstractWordCountTest.java |   4 +-
 .../hadoop/GridHadoopCommandLineTest.java       |  14 +-
 ...idHadoopDefaultMapReducePlannerSelfTest.java |  68 ++---
 .../GridHadoopMapReduceEmbeddedSelfTest.java    |   6 +-
 .../hadoop/GridHadoopMapReduceTest.java         |   8 +-
 .../hadoop/GridHadoopTaskExecutionSelfTest.java |   2 +-
 .../hadoop/GridHadoopTasksAllVersionsTest.java  |   8 +-
 ...GridHadoopExternalTaskExecutionSelfTest.java |   2 +-
 89 files changed, 1381 insertions(+), 1381 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java
index 21e30e2..307d582 100644
--- a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java
+++ b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java
@@ -46,7 +46,7 @@ public final class GgfsExample {
             IgniteFs fs = g.fileSystem("ggfs");
 
             // Working directory path.
-            GridGgfsPath workDir = new GridGgfsPath("/examples/ggfs");
+            IgniteFsPath workDir = new IgniteFsPath("/examples/ggfs");
 
             // Cleanup working directory.
             delete(fs, workDir);
@@ -58,7 +58,7 @@ public final class GgfsExample {
             printInfo(fs, workDir);
 
             // File path.
-            GridGgfsPath filePath = new GridGgfsPath(workDir, "file.txt");
+            IgniteFsPath filePath = new IgniteFsPath(workDir, "file.txt");
 
             // Create file.
             create(fs, filePath, new byte[] {1, 2, 3});
@@ -83,7 +83,7 @@ public final class GgfsExample {
 
             // Create several files.
             for (int i = 0; i < 5; i++)
-                create(fs, new GridGgfsPath(workDir, "file-" + i + ".txt"), null);
+                create(fs, new IgniteFsPath(workDir, "file-" + i + ".txt"), null);
 
             list(fs, workDir);
         }
@@ -100,7 +100,7 @@ public final class GgfsExample {
      * @param path File or directory path.
      * @throws GridException In case of error.
      */
-    private static void delete(IgniteFs fs, GridGgfsPath path) throws GridException {
+    private static void delete(IgniteFs fs, IgniteFsPath path) throws GridException {
         assert fs != null;
         assert path != null;
 
@@ -132,7 +132,7 @@ public final class GgfsExample {
      * @param path Directory path.
      * @throws GridException In case of error.
      */
-    private static void mkdirs(IgniteFs fs, GridGgfsPath path) throws GridException {
+    private static void mkdirs(IgniteFs fs, IgniteFsPath path) throws GridException {
         assert fs != null;
         assert path != null;
 
@@ -159,7 +159,7 @@ public final class GgfsExample {
      * @throws GridException If file can't be created.
      * @throws IOException If data can't be written.
      */
-    private static void create(IgniteFs fs, GridGgfsPath path, @Nullable byte[] data)
+    private static void create(IgniteFs fs, IgniteFsPath path, @Nullable byte[] data)
         throws GridException, IOException {
         assert fs != null;
         assert path != null;
@@ -188,7 +188,7 @@ public final class GgfsExample {
      * @throws GridException If file can't be created.
      * @throws IOException If data can't be written.
      */
-    private static void append(IgniteFs fs, GridGgfsPath path, byte[] data) throws GridException, IOException {
+    private static void append(IgniteFs fs, IgniteFsPath path, byte[] data) throws GridException, IOException {
         assert fs != null;
         assert path != null;
         assert data != null;
@@ -213,7 +213,7 @@ public final class GgfsExample {
      * @throws GridException If file can't be opened.
      * @throws IOException If data can't be read.
      */
-    private static void read(IgniteFs fs, GridGgfsPath path) throws GridException, IOException {
+    private static void read(IgniteFs fs, IgniteFsPath path) throws GridException, IOException {
         assert fs != null;
         assert path != null;
         assert fs.info(path).isFile();
@@ -235,12 +235,12 @@ public final class GgfsExample {
      * @param path Directory path.
      * @throws GridException In case of error.
      */
-    private static void list(IgniteFs fs, GridGgfsPath path) throws GridException {
+    private static void list(IgniteFs fs, IgniteFsPath path) throws GridException {
         assert fs != null;
         assert path != null;
         assert fs.info(path).isDirectory();
 
-        Collection<GridGgfsPath> files = fs.listPaths(path);
+        Collection<IgniteFsPath> files = fs.listPaths(path);
 
         if (files.isEmpty()) {
             System.out.println();
@@ -250,7 +250,7 @@ public final class GgfsExample {
             System.out.println();
             System.out.println(">>> List of files in directory: " + path);
 
-            for (GridGgfsPath f : files)
+            for (IgniteFsPath f : files)
                 System.out.println(">>>     " + f.name());
         }
 
@@ -264,7 +264,7 @@ public final class GgfsExample {
      * @param path File or directory path.
      * @throws GridException In case of error.
      */
-    private static void printInfo(IgniteFs fs, GridGgfsPath path) throws GridException {
+    private static void printInfo(IgniteFs fs, IgniteFsPath path) throws GridException {
         System.out.println();
         System.out.println("Information for " + path + ": " + fs.info(path));
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
index cddd30b..89dbbe8 100644
--- a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
+++ b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsMapReduceExample.java
@@ -57,10 +57,10 @@ public class GgfsMapReduceExample {
                 IgniteFs fs = g.fileSystem("ggfs");
 
                 // Working directory path.
-                GridGgfsPath workDir = new GridGgfsPath("/examples/ggfs");
+                IgniteFsPath workDir = new IgniteFsPath("/examples/ggfs");
 
                 // Write file to GGFS.
-                GridGgfsPath fsPath = new GridGgfsPath(workDir, file.getName());
+                IgniteFsPath fsPath = new IgniteFsPath(workDir, file.getName());
 
                 writeFile(fs, fsPath, file);
 
@@ -87,7 +87,7 @@ public class GgfsMapReduceExample {
      * @param file File to write.
      * @throws Exception In case of exception.
      */
-    private static void writeFile(IgniteFs fs, GridGgfsPath fsPath, File file) throws Exception {
+    private static void writeFile(IgniteFs fs, IgniteFsPath fsPath, File file) throws Exception {
         System.out.println();
         System.out.println("Copying file to GGFS: " + file);
 
@@ -121,7 +121,7 @@ public class GgfsMapReduceExample {
      */
     private static class GrepTask extends GridGgfsTask<String, Collection<Line>> {
         /** {@inheritDoc} */
-        @Override public GridGgfsJob createJob(GridGgfsPath path, GridGgfsFileRange range,
+        @Override public GridGgfsJob createJob(IgniteFsPath path, GridGgfsFileRange range,
             GridGgfsTaskArgs<String> args) throws GridException {
             return new GrepJob(args.userArgument());
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
index 8a36d49..d50afd2 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
@@ -78,7 +78,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @throws GridGgfsFileNotFoundException If path is not found.
      * @throws GridException If failed.
      */
-    public GridGgfsPathSummary summary(GridGgfsPath path) throws GridException;
+    public IgniteFsPathSummary summary(IgniteFsPath path) throws GridException;
 
     /**
      * Opens a file for reading.
@@ -88,7 +88,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @throws GridException In case of error.
      * @throws GridGgfsFileNotFoundException If path doesn't exist.
      */
-    public GridGgfsInputStream open(GridGgfsPath path) throws GridException;
+    public GridGgfsInputStream open(IgniteFsPath path) throws GridException;
 
     /**
      * Opens a file for reading.
@@ -99,7 +99,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @throws GridException In case of error.
      * @throws GridGgfsFileNotFoundException If path doesn't exist.
      */
-    @Override public GridGgfsInputStream open(GridGgfsPath path, int bufSize) throws GridException;
+    @Override public GridGgfsInputStream open(IgniteFsPath path, int bufSize) throws GridException;
 
     /**
      * Opens a file for reading.
@@ -111,7 +111,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @throws GridException In case of error.
      * @throws GridGgfsFileNotFoundException If path doesn't exist.
      */
-    public GridGgfsInputStream open(GridGgfsPath path, int bufSize, int seqReadsBeforePrefetch) throws GridException;
+    public GridGgfsInputStream open(IgniteFsPath path, int bufSize, int seqReadsBeforePrefetch) throws GridException;
 
     /**
      * Creates a file and opens it for writing.
@@ -121,7 +121,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @return File output stream to write data to.
      * @throws GridException In case of error.
      */
-    @Override public GridGgfsOutputStream create(GridGgfsPath path, boolean overwrite) throws GridException;
+    @Override public GridGgfsOutputStream create(IgniteFsPath path, boolean overwrite) throws GridException;
 
     /**
      * Creates a file and opens it for writing.
@@ -135,7 +135,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @return File output stream to write data to.
      * @throws GridException In case of error.
      */
-    @Override public GridGgfsOutputStream create(GridGgfsPath path, int bufSize, boolean overwrite, int replication,
+    @Override public GridGgfsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication,
         long blockSize, @Nullable Map<String, String> props) throws GridException;
 
     /**
@@ -152,7 +152,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @return File output stream to write data to.
      * @throws GridException In case of error.
      */
-    public GridGgfsOutputStream create(GridGgfsPath path, int bufSize, boolean overwrite,
+    public GridGgfsOutputStream create(IgniteFsPath path, int bufSize, boolean overwrite,
         @Nullable IgniteUuid affKey, int replication, long blockSize, @Nullable Map<String, String> props)
         throws GridException;
 
@@ -165,7 +165,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @throws GridException In case of error.
      * @throws GridGgfsFileNotFoundException If path doesn't exist and create flag is {@code false}.
      */
-    public GridGgfsOutputStream append(GridGgfsPath path, boolean create) throws GridException;
+    public GridGgfsOutputStream append(IgniteFsPath path, boolean create) throws GridException;
 
     /**
      * Opens an output stream to an existing file for appending data.
@@ -178,7 +178,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @throws GridException In case of error.
      * @throws GridGgfsFileNotFoundException If path doesn't exist and create flag is {@code false}.
      */
-    @Override public GridGgfsOutputStream append(GridGgfsPath path, int bufSize, boolean create,
+    @Override public GridGgfsOutputStream append(IgniteFsPath path, int bufSize, boolean create,
         @Nullable Map<String, String> props) throws GridException;
 
     /**
@@ -192,7 +192,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @throws GridGgfsFileNotFoundException If target was not found.
      * @throws GridException If error occurred.
      */
-    public void setTimes(GridGgfsPath path, long accessTime, long modificationTime) throws GridException;
+    public void setTimes(IgniteFsPath path, long accessTime, long modificationTime) throws GridException;
 
     /**
      * Gets affinity block locations for data blocks of the file, i.e. the nodes, on which the blocks
@@ -205,7 +205,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @throws GridException In case of error.
      * @throws GridGgfsFileNotFoundException If path doesn't exist.
      */
-    public Collection<GridGgfsBlockLocation> affinity(GridGgfsPath path, long start, long len) throws GridException;
+    public Collection<IgniteFsBlockLocation> affinity(IgniteFsPath path, long start, long len) throws GridException;
 
     /**
      * Get affinity block locations for data blocks of the file. In case {@code maxLen} parameter is set and
@@ -220,7 +220,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @throws GridException In case of error.
      * @throws GridGgfsFileNotFoundException If path doesn't exist.
      */
-    public Collection<GridGgfsBlockLocation> affinity(GridGgfsPath path, long start, long len, long maxLen)
+    public Collection<IgniteFsBlockLocation> affinity(IgniteFsPath path, long start, long len, long maxLen)
         throws GridException;
 
     /**
@@ -246,7 +246,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @return Total size.
      * @throws GridException In case of error.
      */
-    public long size(GridGgfsPath path) throws GridException;
+    public long size(IgniteFsPath path) throws GridException;
 
     /**
      * Formats the file system removing all existing entries from it.
@@ -270,7 +270,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @throws GridException If execution failed.
      */
     public <T, R> R execute(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
-        Collection<GridGgfsPath> paths, @Nullable T arg) throws GridException;
+        Collection<IgniteFsPath> paths, @Nullable T arg) throws GridException;
 
     /**
      * Executes GGFS task with overridden maximum range length (see
@@ -290,7 +290,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @throws GridException If execution failed.
      */
     public <T, R> R execute(GridGgfsTask<T, R> task, @Nullable GridGgfsRecordResolver rslvr,
-        Collection<GridGgfsPath> paths, boolean skipNonExistentFiles, long maxRangeLen, @Nullable T arg)
+        Collection<IgniteFsPath> paths, boolean skipNonExistentFiles, long maxRangeLen, @Nullable T arg)
         throws GridException;
 
     /**
@@ -306,7 +306,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @throws GridException If execution failed.
      */
     public <T, R> R execute(Class<? extends GridGgfsTask<T, R>> taskCls,
-        @Nullable GridGgfsRecordResolver rslvr, Collection<GridGgfsPath> paths, @Nullable T arg) throws GridException;
+        @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, @Nullable T arg) throws GridException;
 
     /**
      * Executes GGFS task with overridden maximum range length (see
@@ -325,7 +325,7 @@ public interface IgniteFs extends GridGgfsFileSystem, IgniteAsyncSupport {
      * @throws GridException If execution failed.
      */
     public <T, R> R execute(Class<? extends GridGgfsTask<T, R>> taskCls,
-        @Nullable GridGgfsRecordResolver rslvr, Collection<GridGgfsPath> paths, boolean skipNonExistentFiles,
+        @Nullable GridGgfsRecordResolver rslvr, Collection<IgniteFsPath> paths, boolean skipNonExistentFiles,
         long maxRangeLen, @Nullable T arg) throws GridException;
 
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/apache/ignite/events/IgniteFsEvent.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/events/IgniteFsEvent.java b/modules/core/src/main/java/org/apache/ignite/events/IgniteFsEvent.java
index 41180fc..21e6a20 100644
--- a/modules/core/src/main/java/org/apache/ignite/events/IgniteFsEvent.java
+++ b/modules/core/src/main/java/org/apache/ignite/events/IgniteFsEvent.java
@@ -60,10 +60,10 @@ public class IgniteFsEvent extends IgniteEventAdapter {
     private static final long serialVersionUID = 0L;
 
     /** File path. */
-    private final GridGgfsPath path;
+    private final IgniteFsPath path;
 
     /** New file path (for RENAME event). */
-    private GridGgfsPath newPath;
+    private IgniteFsPath newPath;
 
     /** Data size (for data transfer events). */
     private long dataSize;
@@ -79,7 +79,7 @@ public class IgniteFsEvent extends IgniteEventAdapter {
      * @param node Node.
      * @param type Event type.
      */
-    public IgniteFsEvent(GridGgfsPath path, ClusterNode node, int type) {
+    public IgniteFsEvent(IgniteFsPath path, ClusterNode node, int type) {
         super(node, "GGFS event.", type);
 
         this.path = path;
@@ -95,7 +95,7 @@ public class IgniteFsEvent extends IgniteEventAdapter {
      * @param node Node.
      * @param type Event type.
      */
-    public IgniteFsEvent(GridGgfsPath path, GridGgfsPath newPath, ClusterNode node, int type) {
+    public IgniteFsEvent(IgniteFsPath path, IgniteFsPath newPath, ClusterNode node, int type) {
         this(path, node, type);
 
         this.newPath = newPath;
@@ -111,7 +111,7 @@ public class IgniteFsEvent extends IgniteEventAdapter {
      * @param type Event type.
      * @param dataSize Transferred data size in bytes.
      */
-    public IgniteFsEvent(GridGgfsPath path, ClusterNode node, int type, long dataSize) {
+    public IgniteFsEvent(IgniteFsPath path, ClusterNode node, int type, long dataSize) {
         this(path, node, type);
 
         this.dataSize = dataSize;
@@ -126,7 +126,7 @@ public class IgniteFsEvent extends IgniteEventAdapter {
      * @param type Event type.
      * @param meta Modified properties.
      */
-    public IgniteFsEvent(GridGgfsPath path, ClusterNode node, int type, Map<String, String> meta) {
+    public IgniteFsEvent(IgniteFsPath path, ClusterNode node, int type, Map<String, String> meta) {
         this(path, node, type);
 
         this.meta = meta;
@@ -137,7 +137,7 @@ public class IgniteFsEvent extends IgniteEventAdapter {
      *
      * @return File path.
      */
-    public GridGgfsPath path() {
+    public IgniteFsPath path() {
         return path;
     }
 
@@ -148,7 +148,7 @@ public class IgniteFsEvent extends IgniteEventAdapter {
      * @return New file or directory path or {@code null},
      *         if not relevant for this event.
      */
-    @Nullable public GridGgfsPath newPath() {
+    @Nullable public IgniteFsPath newPath() {
         return newPath;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/cache/eviction/ggfs/GridCacheGgfsPerBlockLruEvictionPolicy.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/cache/eviction/ggfs/GridCacheGgfsPerBlockLruEvictionPolicy.java b/modules/core/src/main/java/org/gridgain/grid/cache/eviction/ggfs/GridCacheGgfsPerBlockLruEvictionPolicy.java
index 6d1822c..266b45c 100644
--- a/modules/core/src/main/java/org/gridgain/grid/cache/eviction/ggfs/GridCacheGgfsPerBlockLruEvictionPolicy.java
+++ b/modules/core/src/main/java/org/gridgain/grid/cache/eviction/ggfs/GridCacheGgfsPerBlockLruEvictionPolicy.java
@@ -263,7 +263,7 @@ public class GridCacheGgfsPerBlockLruEvictionPolicy implements GridCacheEviction
      * @return {@code True} in case non block of related file must be excluded.
      * @throws GridException In case of faulty patterns.
      */
-    public boolean exclude(GridGgfsPath path) throws GridException {
+    public boolean exclude(IgniteFsPath path) throws GridException {
         assert path != null;
 
         Collection<Pattern> excludePatterns0;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsBlockLocation.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsBlockLocation.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsBlockLocation.java
deleted file mode 100644
index 743fdbf..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsBlockLocation.java
+++ /dev/null
@@ -1,55 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import java.util.*;
-
-/**
- * {@code GGFS} file's data block location in the grid. It is used to determine
- * node affinity of a certain file block within the Grid by calling
- * {@link org.apache.ignite.IgniteFs#affinity(GridGgfsPath, long, long)} method.
- */
-public interface GridGgfsBlockLocation {
-    /**
-     * Start position in the file this block relates to.
-     *
-     * @return Start position in the file this block relates to.
-     */
-    public long start();
-
-    /**
-     * Length of the data block in the file.
-     *
-     * @return Length of the data block in the file.
-     */
-    public long length();
-
-    /**
-     * Nodes this block belongs to. First node id in collection is
-     * primary node id.
-     *
-     * @return Nodes this block belongs to.
-     */
-    public Collection<UUID> nodeIds();
-
-    /**
-     * Compliant with Hadoop interface.
-     *
-     * @return Collection of host:port addresses.
-     */
-    public Collection<String> names();
-
-    /**
-     * Compliant with Hadoop interface.
-     *
-     * @return Collection of host names.
-     */
-    public Collection<String> hosts();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsConcurrentModificationException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsConcurrentModificationException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsConcurrentModificationException.java
index db0ad24..fa7c38d 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsConcurrentModificationException.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsConcurrentModificationException.java
@@ -22,7 +22,7 @@ public class GridGgfsConcurrentModificationException extends GridGgfsException {
      *
      * @param path Affected path.
      */
-    public GridGgfsConcurrentModificationException(GridGgfsPath path) {
+    public GridGgfsConcurrentModificationException(IgniteFsPath path) {
         super("File system entry has been modified concurrently: " + path, null);
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFile.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFile.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFile.java
index 180c4a8..558a961 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFile.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFile.java
@@ -29,7 +29,7 @@ public interface GridGgfsFile {
      *
      * @return Path to file.
      */
-    public GridGgfsPath path();
+    public IgniteFsPath path();
 
     /**
      * Check this file is a data file.
@@ -69,7 +69,7 @@ public interface GridGgfsFile {
     /**
      * Gets file last access time. File last access time is not updated automatically due to
      * performance considerations and can be updated on demand with
-     * {@link org.apache.ignite.IgniteFs#setTimes(GridGgfsPath, long, long)} method.
+     * {@link org.apache.ignite.IgniteFs#setTimes(IgniteFsPath, long, long)} method.
      * <p>
      * By default last access time equals file creation time.
      *

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFileSystem.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFileSystem.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFileSystem.java
index 6e59f16..2b57888 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFileSystem.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsFileSystem.java
@@ -42,7 +42,7 @@ public interface GridGgfsFileSystem {
      * @return {@code True} if such file exists, otherwise - {@code false}.
      * @throws GridException In case of error.
      */
-    public boolean exists(GridGgfsPath path) throws GridException;
+    public boolean exists(IgniteFsPath path) throws GridException;
 
     /**
      * Updates file information for the specified path. Existent properties, not listed in the passed collection,
@@ -62,7 +62,7 @@ public interface GridGgfsFileSystem {
      * @return File information for specified path or {@code null} if such path does not exist.
      * @throws GridException In case of error.
      */
-    @Nullable public GridGgfsFile update(GridGgfsPath path, Map<String, String> props) throws GridException;
+    @Nullable public GridGgfsFile update(IgniteFsPath path, Map<String, String> props) throws GridException;
 
     /**
      * Renames/moves a file.
@@ -83,7 +83,7 @@ public interface GridGgfsFileSystem {
      * @throws GridException In case of error.
      * @throws GridGgfsFileNotFoundException If source file doesn't exist.
      */
-    public void rename(GridGgfsPath src, GridGgfsPath dest) throws GridException;
+    public void rename(IgniteFsPath src, IgniteFsPath dest) throws GridException;
 
     /**
      * Deletes file.
@@ -93,7 +93,7 @@ public interface GridGgfsFileSystem {
      * @return {@code True} in case of success, {@code false} otherwise.
      * @throws GridException In case of error.
      */
-    boolean delete(GridGgfsPath path, boolean recursive) throws GridException;
+    boolean delete(IgniteFsPath path, boolean recursive) throws GridException;
 
     /**
      * Creates directories under specified path.
@@ -101,7 +101,7 @@ public interface GridGgfsFileSystem {
      * @param path Path of directories chain to create.
      * @throws GridException In case of error.
      */
-    public void mkdirs(GridGgfsPath path) throws GridException;
+    public void mkdirs(IgniteFsPath path) throws GridException;
 
     /**
      * Creates directories under specified path with the specified properties.
@@ -110,7 +110,7 @@ public interface GridGgfsFileSystem {
      * @param props Metadata properties to set on created directories.
      * @throws GridException In case of error.
      */
-    public void mkdirs(GridGgfsPath path, @Nullable Map<String, String> props) throws GridException;
+    public void mkdirs(IgniteFsPath path, @Nullable Map<String, String> props) throws GridException;
 
     /**
      * Lists file paths under the specified path.
@@ -120,7 +120,7 @@ public interface GridGgfsFileSystem {
      * @throws GridException In case of error.
      * @throws GridGgfsFileNotFoundException If path doesn't exist.
      */
-    public Collection<GridGgfsPath> listPaths(GridGgfsPath path) throws GridException;
+    public Collection<IgniteFsPath> listPaths(IgniteFsPath path) throws GridException;
 
     /**
      * Lists files under the specified path.
@@ -130,7 +130,7 @@ public interface GridGgfsFileSystem {
      * @throws GridException In case of error.
      * @throws GridGgfsFileNotFoundException If path doesn't exist.
      */
-    public Collection<GridGgfsFile> listFiles(GridGgfsPath path) throws GridException;
+    public Collection<GridGgfsFile> listFiles(IgniteFsPath path) throws GridException;
 
     /**
      * Opens a file for reading.
@@ -141,7 +141,7 @@ public interface GridGgfsFileSystem {
      * @throws GridException In case of error.
      * @throws GridGgfsFileNotFoundException If path doesn't exist.
      */
-    public GridGgfsReader open(GridGgfsPath path, int bufSize) throws GridException;
+    public IgniteFsReader open(IgniteFsPath path, int bufSize) throws GridException;
 
     /**
      * Creates a file and opens it for writing.
@@ -151,7 +151,7 @@ public interface GridGgfsFileSystem {
      * @return File output stream to write data to.
      * @throws GridException In case of error.
      */
-    public OutputStream create(GridGgfsPath path, boolean overwrite) throws GridException;
+    public OutputStream create(IgniteFsPath path, boolean overwrite) throws GridException;
 
     /**
      * Creates a file and opens it for writing.
@@ -165,7 +165,7 @@ public interface GridGgfsFileSystem {
      * @return File output stream to write data to.
      * @throws GridException In case of error.
      */
-    public OutputStream create(GridGgfsPath path, int bufSize, boolean overwrite, int replication, long blockSize,
+    public OutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication, long blockSize,
        @Nullable Map<String, String> props) throws GridException;
 
     /**
@@ -179,7 +179,7 @@ public interface GridGgfsFileSystem {
      * @throws GridException In case of error.
      * @throws GridGgfsFileNotFoundException If path doesn't exist and create flag is {@code false}.
      */
-    public OutputStream append(GridGgfsPath path, int bufSize, boolean create, @Nullable Map<String, String> props)
+    public OutputStream append(IgniteFsPath path, int bufSize, boolean create, @Nullable Map<String, String> props)
         throws GridException;
 
     /**
@@ -189,7 +189,7 @@ public interface GridGgfsFileSystem {
      * @return File information for specified path or {@code null} if such path does not exist.
      * @throws GridException In case of error.
      */
-    @Nullable public GridGgfsFile info(GridGgfsPath path) throws GridException;
+    @Nullable public GridGgfsFile info(IgniteFsPath path) throws GridException;
 
     /**
      * Gets used space in bytes.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInputStream.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInputStream.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInputStream.java
index e178f45..e3f8c0b 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInputStream.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInputStream.java
@@ -15,7 +15,7 @@ import java.io.*;
  * {@code GGFS} input stream to read data from the file system.
  * It provides several additional methods for asynchronous access.
  */
-public abstract class GridGgfsInputStream extends InputStream implements GridGgfsReader {
+public abstract class GridGgfsInputStream extends InputStream implements IgniteFsReader {
     /**
      * Gets file length during file open.
      *

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsPath.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsPath.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsPath.java
deleted file mode 100644
index 6beed3d..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsPath.java
+++ /dev/null
@@ -1,254 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.gridgain.grid.util.io.*;
-import org.gridgain.grid.util.typedef.*;
-import org.gridgain.grid.util.typedef.internal.*;
-import org.jetbrains.annotations.*;
-
-import java.io.*;
-import java.net.*;
-import java.util.*;
-
-/**
- * {@code GGFS} path to file in the file system. For example, to get information about
- * a file you would use the following code:
- * <pre name="code" class="java">
- *     GridGgfsPath dirPath = new GridGgfsPath("/my/working/dir");
- *     GridGgfsPath filePath = new GridGgfsPath(dirPath, "file.txt");
- *
- *     // Get metadata about file.
- *     GridGgfsFile file = ggfs.info(filePath);
- * </pre>
- */
-public final class GridGgfsPath implements Comparable<GridGgfsPath>, Externalizable {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** The directory separator character. */
-    private static final char SLASH_CHAR = '/';
-
-    /** The directory separator. */
-    private static final String SLASH = "/";
-
-    /** URI representing this path. Should never change after object creation or de-serialization. */
-    private String path;
-
-    /**
-     * Constructs default root path.
-     */
-    public GridGgfsPath() {
-        path = SLASH;
-    }
-
-    /**
-     * Constructs a path from an URI
-     *
-     * @param uri URI to create path from.
-     */
-    public GridGgfsPath(URI uri) {
-        A.notNull(uri, "uri");
-
-        path = normalizePath(uri.getPath());
-    }
-
-    /**
-     * Constructs a path from the URI string.
-     *
-     * @param path URI string.
-     */
-    public GridGgfsPath(String path) {
-        A.ensure(!F.isEmpty(path), "'path' is null or empty");
-
-        this.path = normalizePath(path);
-    }
-
-    /**
-     * Resolve a child path against a parent path.
-     *
-     * @param parentPath Parent path.
-     * @param childPath Child path.
-     */
-    public GridGgfsPath(GridGgfsPath parentPath, String childPath) {
-        A.notNull(parentPath, "parentPath");
-
-        String path = GridFilenameUtils.concat(parentPath.path, childPath);
-
-        if (F.isEmpty(path))
-            throw new IllegalArgumentException("Failed to parse path" +
-                " [parent=" + parentPath + ", childPath=" + childPath + ']');
-
-        this.path = normalizePath(path);
-    }
-
-    /**
-     * Initialize path with (1) not-null, (2) normalized, (3) absolute and (4) unix-format path component.
-     *
-     * @param path Path.
-     * @return Normalized path.
-     */
-    private static String normalizePath(String path) {
-        assert path != null;
-
-        String normalizedPath = GridFilenameUtils.normalizeNoEndSeparator(path, true);
-
-        if (F.isEmpty(normalizedPath))
-            throw new IllegalArgumentException("Failed to normalize path: " + path);
-
-        if (!SLASH.equals(GridFilenameUtils.getPrefix(normalizedPath)))
-            throw new IllegalArgumentException("Path should be absolute: " + path);
-
-        assert !normalizedPath.isEmpty() : "Expects normalized path is not empty.";
-        assert normalizedPath.length() == 1 || !normalizedPath.endsWith(SLASH) :
-            "Expects normalized path is root or don't ends with '/' symbol.";
-
-        return normalizedPath;
-    }
-
-    /**
-     * Returns the final component of this path.
-     *
-     * @return The final component of this path.
-     */
-    public String name() {
-        return GridFilenameUtils.getName(path);
-    }
-
-    /**
-     * Returns a root for this path.
-     *
-     * @return Root for this path.
-     */
-    public GridGgfsPath root() {
-        return new GridGgfsPath();
-    }
-
-    /**
-     * Split full path on components.
-     *
-     * @return Path components.
-     */
-    public List<String> components() {
-        String path = this.path;
-
-        assert path.length() >= 1 : "Path expected to be absolute: " + path;
-
-        // Path is short-living object, so we don't need to cache component's resolution result.
-        return path.length() == 1 ? Collections.<String>emptyList() : Arrays.asList(path.substring(1).split(SLASH));
-    }
-
-    /**
-     * Returns the parent of a path or {@code null} if at root.
-     *
-     * @return The parent of a path or {@code null} if at root.
-     */
-    @Nullable public GridGgfsPath parent() {
-        String path = this.path;
-
-        if (path.length() == 1)
-            return null; // Current path is root.
-
-        path = GridFilenameUtils.getFullPathNoEndSeparator(path);
-
-        return new GridGgfsPath(path);
-    }
-
-    /**
-     * Adds a suffix to the final name in the path.
-     *
-     * @param suffix Suffix.
-     * @return Path with suffix.
-     */
-    public GridGgfsPath suffix(String suffix) {
-        A.ensure(!F.isEmpty(suffix), "'suffix' is null or empty.");
-        A.ensure(!suffix.contains(SLASH), "'suffix' contains file's separator '" + SLASH + "'");
-
-        return new GridGgfsPath(path + suffix);
-    }
-
-    /**
-     * Return the number of elements in this path.
-     *
-     * @return The number of elements in this path, zero depth means root directory.
-     */
-    public int depth() {
-        final String path = this.path;
-        final int size = path.length();
-
-        assert size >= 1 && path.charAt(0) == SLASH_CHAR : "Expects absolute path: " + path;
-
-        if (size == 1)
-            return 0;
-
-        int depth = 1;
-
-        // Ignore the first character.
-        for (int i = 1; i < size; i++)
-            if (path.charAt(i) == SLASH_CHAR)
-                depth++;
-
-        return depth;
-    }
-
-    /**
-     * Checks whether this path is a sub-directory of argument.
-     *
-     * @param path Path to check.
-     * @return {@code True} if argument is same or a sub-directory of this object.
-     */
-    public boolean isSubDirectoryOf(GridGgfsPath path) {
-        A.notNull(path, "path");
-
-        return this.path.startsWith(path.path.endsWith(SLASH) ? path.path : path.path + SLASH);
-    }
-
-    /**
-     * Checks if paths are identical.
-     *
-     * @param path Path to check.
-     * @return {@code True} if paths are identical.
-     */
-    public boolean isSame(GridGgfsPath path) {
-        A.notNull(path, "path");
-
-        return this == path || this.path.equals(path.path);
-    }
-
-    /** {@inheritDoc} */
-    @Override public int compareTo(GridGgfsPath o) {
-        return path.compareTo(o.path);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void writeExternal(ObjectOutput out) throws IOException {
-        U.writeString(out, path);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void readExternal(ObjectInput in) throws IOException {
-        path = U.readString(in);
-    }
-
-    /** {@inheritDoc} */
-    @Override public int hashCode() {
-        return path.hashCode();
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean equals(Object o) {
-        return o == this || o != null && getClass() == o.getClass() && path.equals(((GridGgfsPath)o).path);
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return path;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsPathAlreadyExistsException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsPathAlreadyExistsException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsPathAlreadyExistsException.java
deleted file mode 100644
index fdeedb3..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsPathAlreadyExistsException.java
+++ /dev/null
@@ -1,42 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.jetbrains.annotations.*;
-
-/**
- * Exception thrown when target path supposed to be created already exists.
- */
-public class GridGgfsPathAlreadyExistsException extends GridGgfsInvalidPathException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * @param msg Error message.
-     */
-    public GridGgfsPathAlreadyExistsException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * @param cause Exception cause.
-     */
-    public GridGgfsPathAlreadyExistsException(Throwable cause) {
-        super(cause);
-    }
-
-    /**
-     * @param msg Error message.
-     * @param cause Exception cause.
-     */
-    public GridGgfsPathAlreadyExistsException(String msg, @Nullable Throwable cause) {
-        super(msg, cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsPathSummary.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsPathSummary.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsPathSummary.java
deleted file mode 100644
index 1ad9bfe..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsPathSummary.java
+++ /dev/null
@@ -1,130 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.gridgain.grid.util.typedef.internal.*;
-
-import java.io.*;
-
-/**
- * Path summary: total files count, total directories count, total length.
- */
-public class GridGgfsPathSummary implements Externalizable {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** Path. */
-    private GridGgfsPath path;
-
-    /** File count. */
-    private int filesCnt;
-
-    /** Directories count. */
-    private int dirCnt;
-
-    /** Length consumed. */
-    private long totalLen;
-
-    /**
-     * Empty constructor required by {@link Externalizable}.
-     */
-    public GridGgfsPathSummary() {
-        // No-op.
-    }
-
-    /**
-     * Construct empty path summary.
-     *
-     * @param path Path.
-     */
-    public GridGgfsPathSummary(GridGgfsPath path) {
-        this.path = path;
-    }
-
-    /**
-     * @return Files count.
-     */
-    public int filesCount() {
-        return filesCnt;
-    }
-
-    /**
-     * @param filesCnt Files count.
-     */
-    public void filesCount(int filesCnt) {
-        this.filesCnt = filesCnt;
-    }
-
-    /**
-     * @return Directories count.
-     */
-    public int directoriesCount() {
-        return dirCnt;
-    }
-
-    /**
-     * @param dirCnt Directories count.
-     */
-    public void directoriesCount(int dirCnt) {
-        this.dirCnt = dirCnt;
-    }
-
-    /**
-     * @return Total length.
-     */
-    public long totalLength() {
-        return totalLen;
-    }
-
-    /**
-     * @param totalLen Total length.
-     */
-    public void totalLength(long totalLen) {
-        this.totalLen = totalLen;
-    }
-
-    /**
-     * @return Path for which summary is obtained.
-     */
-    public GridGgfsPath path() {
-        return path;
-    }
-
-    /**
-     * @param path Path for which summary is obtained.
-     */
-    public void path(GridGgfsPath path) {
-        this.path = path;
-    }
-
-    /** {@inheritDoc} */
-    @Override public void writeExternal(ObjectOutput out) throws IOException {
-        out.writeInt(filesCnt);
-        out.writeInt(dirCnt);
-        out.writeLong(totalLen);
-
-        path.writeExternal(out);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
-        filesCnt = in.readInt();
-        dirCnt = in.readInt();
-        totalLen = in.readLong();
-
-        path = new GridGgfsPath();
-        path.readExternal(in);
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridGgfsPathSummary.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsReader.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsReader.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsReader.java
deleted file mode 100644
index 0e1883b..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsReader.java
+++ /dev/null
@@ -1,30 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import java.io.*;
-
-/**
- * The simplest data input interface to read from secondary file system in dual modes.
- */
-public interface GridGgfsReader extends Closeable {
-    /**
-     * Read up to the specified number of bytes, from a given position within a file, and return the number of bytes
-     * read.
-     *
-     * @param pos Position in the input stream to seek.
-     * @param buf Buffer into which data is read.
-     * @param off Offset in the buffer from which stream data should be written.
-     * @param len The number of bytes to read.
-     * @return Total number of bytes read into the buffer, or -1 if there is no more data (EOF).
-     * @throws IOException In case of any exception.
-     */
-    public int read(long pos, byte[] buf, int off, int len) throws IOException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsBlockLocation.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsBlockLocation.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsBlockLocation.java
new file mode 100644
index 0000000..403ee3c
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsBlockLocation.java
@@ -0,0 +1,55 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+import java.util.*;
+
+/**
+ * {@code GGFS} file's data block location in the grid. It is used to determine
+ * node affinity of a certain file block within the Grid by calling
+ * {@link org.apache.ignite.IgniteFs#affinity(IgniteFsPath, long, long)} method.
+ */
+public interface IgniteFsBlockLocation {
+    /**
+     * Start position in the file this block relates to.
+     *
+     * @return Start position in the file this block relates to.
+     */
+    public long start();
+
+    /**
+     * Length of the data block in the file.
+     *
+     * @return Length of the data block in the file.
+     */
+    public long length();
+
+    /**
+     * Nodes this block belongs to. First node id in collection is
+     * primary node id.
+     *
+     * @return Nodes this block belongs to.
+     */
+    public Collection<UUID> nodeIds();
+
+    /**
+     * Compliant with Hadoop interface.
+     *
+     * @return Collection of host:port addresses.
+     */
+    public Collection<String> names();
+
+    /**
+     * Compliant with Hadoop interface.
+     *
+     * @return Collection of host names.
+     */
+    public Collection<String> hosts();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPath.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPath.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPath.java
new file mode 100644
index 0000000..aa321b3
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPath.java
@@ -0,0 +1,254 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+import org.gridgain.grid.util.io.*;
+import org.gridgain.grid.util.typedef.*;
+import org.gridgain.grid.util.typedef.internal.*;
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+import java.net.*;
+import java.util.*;
+
+/**
+ * {@code GGFS} path to file in the file system. For example, to get information about
+ * a file you would use the following code:
+ * <pre name="code" class="java">
+ *     GridGgfsPath dirPath = new GridGgfsPath("/my/working/dir");
+ *     GridGgfsPath filePath = new GridGgfsPath(dirPath, "file.txt");
+ *
+ *     // Get metadata about file.
+ *     GridGgfsFile file = ggfs.info(filePath);
+ * </pre>
+ */
+public final class IgniteFsPath implements Comparable<IgniteFsPath>, Externalizable {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** The directory separator character. */
+    private static final char SLASH_CHAR = '/';
+
+    /** The directory separator. */
+    private static final String SLASH = "/";
+
+    /** URI representing this path. Should never change after object creation or de-serialization. */
+    private String path;
+
+    /**
+     * Constructs default root path.
+     */
+    public IgniteFsPath() {
+        path = SLASH;
+    }
+
+    /**
+     * Constructs a path from an URI
+     *
+     * @param uri URI to create path from.
+     */
+    public IgniteFsPath(URI uri) {
+        A.notNull(uri, "uri");
+
+        path = normalizePath(uri.getPath());
+    }
+
+    /**
+     * Constructs a path from the URI string.
+     *
+     * @param path URI string.
+     */
+    public IgniteFsPath(String path) {
+        A.ensure(!F.isEmpty(path), "'path' is null or empty");
+
+        this.path = normalizePath(path);
+    }
+
+    /**
+     * Resolve a child path against a parent path.
+     *
+     * @param parentPath Parent path.
+     * @param childPath Child path.
+     */
+    public IgniteFsPath(IgniteFsPath parentPath, String childPath) {
+        A.notNull(parentPath, "parentPath");
+
+        String path = GridFilenameUtils.concat(parentPath.path, childPath);
+
+        if (F.isEmpty(path))
+            throw new IllegalArgumentException("Failed to parse path" +
+                " [parent=" + parentPath + ", childPath=" + childPath + ']');
+
+        this.path = normalizePath(path);
+    }
+
+    /**
+     * Initialize path with (1) not-null, (2) normalized, (3) absolute and (4) unix-format path component.
+     *
+     * @param path Path.
+     * @return Normalized path.
+     */
+    private static String normalizePath(String path) {
+        assert path != null;
+
+        String normalizedPath = GridFilenameUtils.normalizeNoEndSeparator(path, true);
+
+        if (F.isEmpty(normalizedPath))
+            throw new IllegalArgumentException("Failed to normalize path: " + path);
+
+        if (!SLASH.equals(GridFilenameUtils.getPrefix(normalizedPath)))
+            throw new IllegalArgumentException("Path should be absolute: " + path);
+
+        assert !normalizedPath.isEmpty() : "Expects normalized path is not empty.";
+        assert normalizedPath.length() == 1 || !normalizedPath.endsWith(SLASH) :
+            "Expects normalized path is root or don't ends with '/' symbol.";
+
+        return normalizedPath;
+    }
+
+    /**
+     * Returns the final component of this path.
+     *
+     * @return The final component of this path.
+     */
+    public String name() {
+        return GridFilenameUtils.getName(path);
+    }
+
+    /**
+     * Returns a root for this path.
+     *
+     * @return Root for this path.
+     */
+    public IgniteFsPath root() {
+        return new IgniteFsPath();
+    }
+
+    /**
+     * Split full path on components.
+     *
+     * @return Path components.
+     */
+    public List<String> components() {
+        String path = this.path;
+
+        assert path.length() >= 1 : "Path expected to be absolute: " + path;
+
+        // Path is short-living object, so we don't need to cache component's resolution result.
+        return path.length() == 1 ? Collections.<String>emptyList() : Arrays.asList(path.substring(1).split(SLASH));
+    }
+
+    /**
+     * Returns the parent of a path or {@code null} if at root.
+     *
+     * @return The parent of a path or {@code null} if at root.
+     */
+    @Nullable public IgniteFsPath parent() {
+        String path = this.path;
+
+        if (path.length() == 1)
+            return null; // Current path is root.
+
+        path = GridFilenameUtils.getFullPathNoEndSeparator(path);
+
+        return new IgniteFsPath(path);
+    }
+
+    /**
+     * Adds a suffix to the final name in the path.
+     *
+     * @param suffix Suffix.
+     * @return Path with suffix.
+     */
+    public IgniteFsPath suffix(String suffix) {
+        A.ensure(!F.isEmpty(suffix), "'suffix' is null or empty.");
+        A.ensure(!suffix.contains(SLASH), "'suffix' contains file's separator '" + SLASH + "'");
+
+        return new IgniteFsPath(path + suffix);
+    }
+
+    /**
+     * Return the number of elements in this path.
+     *
+     * @return The number of elements in this path, zero depth means root directory.
+     */
+    public int depth() {
+        final String path = this.path;
+        final int size = path.length();
+
+        assert size >= 1 && path.charAt(0) == SLASH_CHAR : "Expects absolute path: " + path;
+
+        if (size == 1)
+            return 0;
+
+        int depth = 1;
+
+        // Ignore the first character.
+        for (int i = 1; i < size; i++)
+            if (path.charAt(i) == SLASH_CHAR)
+                depth++;
+
+        return depth;
+    }
+
+    /**
+     * Checks whether this path is a sub-directory of argument.
+     *
+     * @param path Path to check.
+     * @return {@code True} if argument is same or a sub-directory of this object.
+     */
+    public boolean isSubDirectoryOf(IgniteFsPath path) {
+        A.notNull(path, "path");
+
+        return this.path.startsWith(path.path.endsWith(SLASH) ? path.path : path.path + SLASH);
+    }
+
+    /**
+     * Checks if paths are identical.
+     *
+     * @param path Path to check.
+     * @return {@code True} if paths are identical.
+     */
+    public boolean isSame(IgniteFsPath path) {
+        A.notNull(path, "path");
+
+        return this == path || this.path.equals(path.path);
+    }
+
+    /** {@inheritDoc} */
+    @Override public int compareTo(IgniteFsPath o) {
+        return path.compareTo(o.path);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void writeExternal(ObjectOutput out) throws IOException {
+        U.writeString(out, path);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readExternal(ObjectInput in) throws IOException {
+        path = U.readString(in);
+    }
+
+    /** {@inheritDoc} */
+    @Override public int hashCode() {
+        return path.hashCode();
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean equals(Object o) {
+        return o == this || o != null && getClass() == o.getClass() && path.equals(((IgniteFsPath)o).path);
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return path;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathAlreadyExistsException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathAlreadyExistsException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathAlreadyExistsException.java
new file mode 100644
index 0000000..7ca2581
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathAlreadyExistsException.java
@@ -0,0 +1,42 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+import org.jetbrains.annotations.*;
+
+/**
+ * Exception thrown when target path supposed to be created already exists.
+ */
+public class IgniteFsPathAlreadyExistsException extends GridGgfsInvalidPathException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * @param msg Error message.
+     */
+    public IgniteFsPathAlreadyExistsException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * @param cause Exception cause.
+     */
+    public IgniteFsPathAlreadyExistsException(Throwable cause) {
+        super(cause);
+    }
+
+    /**
+     * @param msg Error message.
+     * @param cause Exception cause.
+     */
+    public IgniteFsPathAlreadyExistsException(String msg, @Nullable Throwable cause) {
+        super(msg, cause);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathSummary.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathSummary.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathSummary.java
new file mode 100644
index 0000000..706a3cb
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathSummary.java
@@ -0,0 +1,130 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+import org.gridgain.grid.util.typedef.internal.*;
+
+import java.io.*;
+
+/**
+ * Path summary: total files count, total directories count, total length.
+ */
+public class IgniteFsPathSummary implements Externalizable {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** Path. */
+    private IgniteFsPath path;
+
+    /** File count. */
+    private int filesCnt;
+
+    /** Directories count. */
+    private int dirCnt;
+
+    /** Length consumed. */
+    private long totalLen;
+
+    /**
+     * Empty constructor required by {@link Externalizable}.
+     */
+    public IgniteFsPathSummary() {
+        // No-op.
+    }
+
+    /**
+     * Construct empty path summary.
+     *
+     * @param path Path.
+     */
+    public IgniteFsPathSummary(IgniteFsPath path) {
+        this.path = path;
+    }
+
+    /**
+     * @return Files count.
+     */
+    public int filesCount() {
+        return filesCnt;
+    }
+
+    /**
+     * @param filesCnt Files count.
+     */
+    public void filesCount(int filesCnt) {
+        this.filesCnt = filesCnt;
+    }
+
+    /**
+     * @return Directories count.
+     */
+    public int directoriesCount() {
+        return dirCnt;
+    }
+
+    /**
+     * @param dirCnt Directories count.
+     */
+    public void directoriesCount(int dirCnt) {
+        this.dirCnt = dirCnt;
+    }
+
+    /**
+     * @return Total length.
+     */
+    public long totalLength() {
+        return totalLen;
+    }
+
+    /**
+     * @param totalLen Total length.
+     */
+    public void totalLength(long totalLen) {
+        this.totalLen = totalLen;
+    }
+
+    /**
+     * @return Path for which summary is obtained.
+     */
+    public IgniteFsPath path() {
+        return path;
+    }
+
+    /**
+     * @param path Path for which summary is obtained.
+     */
+    public void path(IgniteFsPath path) {
+        this.path = path;
+    }
+
+    /** {@inheritDoc} */
+    @Override public void writeExternal(ObjectOutput out) throws IOException {
+        out.writeInt(filesCnt);
+        out.writeInt(dirCnt);
+        out.writeLong(totalLen);
+
+        path.writeExternal(out);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
+        filesCnt = in.readInt();
+        dirCnt = in.readInt();
+        totalLen = in.readLong();
+
+        path = new IgniteFsPath();
+        path.readExternal(in);
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsPathSummary.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsReader.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsReader.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsReader.java
new file mode 100644
index 0000000..dd0635c
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsReader.java
@@ -0,0 +1,30 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+import java.io.*;
+
+/**
+ * The simplest data input interface to read from secondary file system in dual modes.
+ */
+public interface IgniteFsReader extends Closeable {
+    /**
+     * Read up to the specified number of bytes, from a given position within a file, and return the number of bytes
+     * read.
+     *
+     * @param pos Position in the input stream to seek.
+     * @param buf Buffer into which data is read.
+     * @param off Offset in the buffer from which stream data should be written.
+     * @param len The number of bytes to read.
+     * @return Total number of bytes read into the buffer, or -1 if there is no more data (EOF).
+     * @throws IOException In case of any exception.
+     */
+    public int read(long pos, byte[] buf, int off, int len) throws IOException;
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsFileRange.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsFileRange.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsFileRange.java
index e2e8066..e37def7 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsFileRange.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsFileRange.java
@@ -17,7 +17,7 @@ import org.gridgain.grid.util.typedef.internal.*;
  */
 public class GridGgfsFileRange {
     /** File path. */
-    private GridGgfsPath path;
+    private IgniteFsPath path;
 
     /** Start position. */
     private long start;
@@ -32,7 +32,7 @@ public class GridGgfsFileRange {
      * @param start Start position.
      * @param len Length.
      */
-    public GridGgfsFileRange(GridGgfsPath path, long start, long len) {
+    public GridGgfsFileRange(IgniteFsPath path, long start, long len) {
         this.path = path;
         this.start = start;
         this.len = len;
@@ -43,7 +43,7 @@ public class GridGgfsFileRange {
      *
      * @return File path.
      */
-    public GridGgfsPath path() {
+    public IgniteFsPath path() {
         return path;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
index f65be08..e8ac409 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTask.java
@@ -26,7 +26,7 @@ import java.util.*;
  * GGFS task which can be executed on the grid using one of {@code GridGgfs.execute()} methods. Essentially GGFS task
  * is regular {@link org.apache.ignite.compute.ComputeTask} with different map logic. Instead of implementing
  * {@link org.apache.ignite.compute.ComputeTask#map(List, Object)} method to split task into jobs, you must implement
- * {@link GridGgfsTask#createJob(GridGgfsPath, GridGgfsFileRange, GridGgfsTaskArgs)} method.
+ * {@link GridGgfsTask#createJob(org.gridgain.grid.ggfs.IgniteFsPath, GridGgfsFileRange, GridGgfsTaskArgs)} method.
  * <p>
  * Each file participating in GGFS task is split into {@link GridGgfsFileRange}s first. Normally range is a number of
  * consequent bytes located on a single node (see {@code GridGgfsGroupDataBlocksKeyMapper}). In case maximum range size
@@ -88,7 +88,7 @@ public abstract class GridGgfsTask<T, R> extends ComputeTaskAdapter<GridGgfsTask
 
         Map<UUID, ClusterNode> nodes = mapSubgrid(subgrid);
 
-        for (GridGgfsPath path : args.paths()) {
+        for (IgniteFsPath path : args.paths()) {
             GridGgfsFile file = ggfs.info(path);
 
             if (file == null) {
@@ -98,11 +98,11 @@ public abstract class GridGgfsTask<T, R> extends ComputeTaskAdapter<GridGgfsTask
                     throw new GridException("Failed to process GGFS file because it doesn't exist: " + path);
             }
 
-            Collection<GridGgfsBlockLocation> aff = ggfs.affinity(path, 0, file.length(), args.maxRangeLength());
+            Collection<IgniteFsBlockLocation> aff = ggfs.affinity(path, 0, file.length(), args.maxRangeLength());
 
             long totalLen = 0;
 
-            for (GridGgfsBlockLocation loc : aff) {
+            for (IgniteFsBlockLocation loc : aff) {
                 ClusterNode node = null;
 
                 for (UUID nodeId : loc.nodeIds()) {
@@ -145,7 +145,7 @@ public abstract class GridGgfsTask<T, R> extends ComputeTaskAdapter<GridGgfsTask
      * @return GGFS job. If {@code null} is returned, the passed in file range will be skipped.
      * @throws GridException If job creation failed.
      */
-    @Nullable public abstract GridGgfsJob createJob(GridGgfsPath path, GridGgfsFileRange range,
+    @Nullable public abstract GridGgfsJob createJob(IgniteFsPath path, GridGgfsFileRange range,
         GridGgfsTaskArgs<T> args) throws GridException;
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
index c9cb5c8..469e703 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsTaskArgs.java
@@ -16,7 +16,7 @@ import java.util.*;
 /**
  * GGFS task arguments. When you initiate new GGFS task execution using one of {@code GridGgfs.execute(...)} methods,
  * all passed parameters are encapsulated in a single {@code GridGgfsTaskArgs} object. Later on this object is
- * passed to {@link GridGgfsTask#createJob(GridGgfsPath, GridGgfsFileRange, GridGgfsTaskArgs)} method.
+ * passed to {@link GridGgfsTask#createJob(org.gridgain.grid.ggfs.IgniteFsPath, GridGgfsFileRange, GridGgfsTaskArgs)} method.
  * <p>
  * Task arguments encapsulates the following data:
  * <ul>
@@ -41,7 +41,7 @@ public interface GridGgfsTaskArgs<T> {
      *
      * @return File paths to process.
      */
-    public Collection<GridGgfsPath> paths();
+    public Collection<IgniteFsPath> paths();
 
     /**
      * Gets record resolver for the task.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
index 1ed5a70..216e888 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
@@ -169,7 +169,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
     /**
      * @param res Response.
      */
-    public void response(GridGgfsPath res) {
+    public void response(IgniteFsPath res) {
         resType = RES_TYPE_GGFS_PATH;
 
         this.res = res;
@@ -178,7 +178,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
     /**
      * @param res Path summary response.
      */
-    public void response(GridGgfsPathSummary res) {
+    public void response(IgniteFsPathSummary res) {
         resType = RES_TYPE_GGFS_PATH_SUMMARY;
 
         this.res = res;
@@ -196,7 +196,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
     /**
      * @param res Response.
      */
-    public void paths(Collection<GridGgfsPath> res) {
+    public void paths(Collection<IgniteFsPath> res) {
         resType = RES_TYPE_COL_GGFS_PATH;
 
         this.res = res;
@@ -205,7 +205,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
     /**
      * @param res Response.
      */
-    public void locations(Collection<GridGgfsBlockLocation> res) {
+    public void locations(Collection<IgniteFsBlockLocation> res) {
         resType = RES_TYPE_COL_GGFS_BLOCK_LOCATION;
 
         this.res = res;
@@ -255,7 +255,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
         if (errCode == ERR_FILE_NOT_FOUND)
             throw new GridGgfsFileNotFoundException(err);
         else if (errCode == ERR_PATH_ALREADY_EXISTS)
-            throw new GridGgfsPathAlreadyExistsException(err);
+            throw new IgniteFsPathAlreadyExistsException(err);
         else if (errCode == ERR_DIRECTORY_NOT_EMPTY)
             throw new GridGgfsDirectoryNotEmptyException(err);
         else if (errCode == ERR_PARENT_NOT_DIRECTORY)
@@ -326,7 +326,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
     private int errorCode(GridException e, boolean checkIo) {
         if (X.hasCause(e, GridGgfsFileNotFoundException.class))
             return ERR_FILE_NOT_FOUND;
-        else if (GridGgfsPathAlreadyExistsException.class.isInstance(e))
+        else if (IgniteFsPathAlreadyExistsException.class.isInstance(e))
             return ERR_PATH_ALREADY_EXISTS;
         else if (GridGgfsDirectoryNotEmptyException.class.isInstance(e))
             return ERR_DIRECTORY_NOT_EMPTY;
@@ -467,7 +467,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
                 boolean hasVal = in.readBoolean();
 
                 if (hasVal) {
-                    GridGgfsPath path = new GridGgfsPath();
+                    IgniteFsPath path = new IgniteFsPath();
 
                     path.readExternal(in);
 
@@ -481,7 +481,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
                 boolean hasVal = in.readBoolean();
 
                 if (hasVal) {
-                    GridGgfsPathSummary sum = new GridGgfsPathSummary();
+                    IgniteFsPathSummary sum = new IgniteFsPathSummary();
 
                     sum.readExternal(in);
 
@@ -570,7 +570,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
             }
 
             case RES_TYPE_COL_GGFS_PATH: {
-                Collection<GridGgfsPath> paths = null;
+                Collection<IgniteFsPath> paths = null;
 
                 int size = in.readInt();
 
@@ -578,7 +578,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
                     paths = new ArrayList<>(size);
 
                     for (int i = 0; i < size; i++) {
-                        GridGgfsPath path = new GridGgfsPath();
+                        IgniteFsPath path = new IgniteFsPath();
 
                         path.readExternal(in);
 
@@ -592,7 +592,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
             }
 
             case RES_TYPE_COL_GGFS_BLOCK_LOCATION: {
-                Collection<GridGgfsBlockLocation> locations = null;
+                Collection<IgniteFsBlockLocation> locations = null;
 
                 int size = in.readInt();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsLogger.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsLogger.java b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsLogger.java
index 36741d2..b1b7d8f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsLogger.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsLogger.java
@@ -248,7 +248,7 @@ public final class GridGgfsLogger {
      * @param bufSize Buffer size.
      * @param dataLen Data length.
      */
-    public void logOpen(long streamId, GridGgfsPath path, GridGgfsMode mode, int bufSize, long dataLen) {
+    public void logOpen(long streamId, IgniteFsPath path, GridGgfsMode mode, int bufSize, long dataLen) {
         addEntry(new Entry(TYPE_OPEN_IN, path.toString(), mode, streamId, bufSize, dataLen, null, null, null, null,
             null, null, null, null, null, null, null, null, null, null));
     }
@@ -264,7 +264,7 @@ public final class GridGgfsLogger {
      * @param replication Replication factor.
      * @param blockSize Block size.
      */
-    public void logCreate(long streamId, GridGgfsPath path, GridGgfsMode mode, boolean overwrite, int bufSize,
+    public void logCreate(long streamId, IgniteFsPath path, GridGgfsMode mode, boolean overwrite, int bufSize,
         int replication, long blockSize) {
         addEntry(new Entry(TYPE_OPEN_OUT, path.toString(), mode, streamId, bufSize, null, false, overwrite, replication,
             blockSize, null, null, null, null, null, null, null, null, null, null));
@@ -278,7 +278,7 @@ public final class GridGgfsLogger {
      * @param mode Mode.
      * @param bufSize Buffer size.
      */
-    public void logAppend(long streamId, GridGgfsPath path, GridGgfsMode mode, int bufSize) {
+    public void logAppend(long streamId, IgniteFsPath path, GridGgfsMode mode, int bufSize) {
         addEntry(new Entry(TYPE_OPEN_OUT, path.toString(), mode, streamId, bufSize, null, true, null, null, null, null,
             null, null, null, null, null, null, null, null, null));
     }
@@ -370,7 +370,7 @@ public final class GridGgfsLogger {
      * @param path Path.
      * @param mode Mode.
      */
-    public void logMakeDirectory(GridGgfsPath path, GridGgfsMode mode) {
+    public void logMakeDirectory(IgniteFsPath path, GridGgfsMode mode) {
         addEntry(new Entry(TYPE_DIR_MAKE, path.toString(), mode, null, null, null, null, null, null, null, null, null,
             null, null, null, null, null, null, null, null));
     }
@@ -382,7 +382,7 @@ public final class GridGgfsLogger {
      * @param mode Mode.
      * @param files Files.
      */
-    public void logListDirectory(GridGgfsPath path, GridGgfsMode mode, String[] files) {
+    public void logListDirectory(IgniteFsPath path, GridGgfsMode mode, String[] files) {
         addEntry(new Entry(TYPE_DIR_LIST, path.toString(), mode, null, null, null, null, null, null, null, null, null,
             null, null, null, null, null, null, null, files));
     }
@@ -394,7 +394,7 @@ public final class GridGgfsLogger {
      * @param mode Mode.
      * @param destPath Destination path.
      */
-    public void logRename(GridGgfsPath path, GridGgfsMode mode, GridGgfsPath destPath) {
+    public void logRename(IgniteFsPath path, GridGgfsMode mode, IgniteFsPath destPath) {
         addEntry(new Entry(TYPE_RENAME, path.toString(), mode, null, null, null, null, null, null, null, null, null,
             null, null, null, null, null, destPath.toString(), null, null));
     }
@@ -406,7 +406,7 @@ public final class GridGgfsLogger {
      * @param mode Mode.
      * @param recursive Recursive flag.
      */
-    public void logDelete(GridGgfsPath path, GridGgfsMode mode, boolean recursive) {
+    public void logDelete(IgniteFsPath path, GridGgfsMode mode, boolean recursive) {
         addEntry(new Entry(TYPE_DELETE, path.toString(), mode, null, null, null, null, null, null, null, null, null,
             null, null, null, null, null, null, recursive, null));
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsMarshaller.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsMarshaller.java b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsMarshaller.java
index 22d8fa5..24a8807 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsMarshaller.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsMarshaller.java
@@ -308,7 +308,7 @@ public class GridGgfsMarshaller {
      * @param path Path to write.
      * @throws IOException If write failed.
      */
-    private void writePath(ObjectOutput out, @Nullable GridGgfsPath path) throws IOException {
+    private void writePath(ObjectOutput out, @Nullable IgniteFsPath path) throws IOException {
         out.writeBoolean(path != null);
 
         if (path != null)
@@ -316,15 +316,15 @@ public class GridGgfsMarshaller {
     }
 
     /**
-     * Reads GGFS path from data input that was written by {@link #writePath(ObjectOutput, GridGgfsPath)}
+     * Reads GGFS path from data input that was written by {@link #writePath(ObjectOutput, org.gridgain.grid.ggfs.IgniteFsPath)}
      * method.
      *
      * @param in Data input.
      * @return Written path or {@code null}.
      */
-    @Nullable private GridGgfsPath readPath(ObjectInput in) throws IOException {
+    @Nullable private IgniteFsPath readPath(ObjectInput in) throws IOException {
         if(in.readBoolean()) {
-            GridGgfsPath path = new GridGgfsPath();
+            IgniteFsPath path = new IgniteFsPath();
 
             path.readExternal(in);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsPathControlRequest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsPathControlRequest.java b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsPathControlRequest.java
index 4da7ba6..00b7718 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsPathControlRequest.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsPathControlRequest.java
@@ -20,10 +20,10 @@ import java.util.*;
  */
 public class GridGgfsPathControlRequest extends GridGgfsMessage {
     /** Main path. */
-    private GridGgfsPath path;
+    private IgniteFsPath path;
 
     /** Second path, rename command. */
-    private GridGgfsPath destPath;
+    private IgniteFsPath destPath;
 
     /** Boolean flag, meaning depends on command. */
     private boolean flag;
@@ -58,14 +58,14 @@ public class GridGgfsPathControlRequest extends GridGgfsMessage {
     /**
      * @param path Path.
      */
-    public void path(GridGgfsPath path) {
+    public void path(IgniteFsPath path) {
         this.path = path;
     }
 
     /**
      * @param destPath Destination path (rename only).
      */
-    public void destinationPath(GridGgfsPath destPath) {
+    public void destinationPath(IgniteFsPath destPath) {
         this.destPath = destPath;
     }
 
@@ -142,14 +142,14 @@ public class GridGgfsPathControlRequest extends GridGgfsMessage {
     /**
      * @return Path.
      */
-    public GridGgfsPath path() {
+    public IgniteFsPath path() {
         return path;
     }
 
     /**
      * @return Destination path (rename only).
      */
-    public GridGgfsPath destinationPath() {
+    public IgniteFsPath destinationPath() {
         return destPath;
     }
 


[10/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
index 221cea0..2cc67ec 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
@@ -42,13 +42,13 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testDefaultDirectories() throws Exception {
-        GridGgfsPath gg = new GridGgfsPath("/gridgain");
-        GridGgfsPath[] paths = paths(
-            gg, new GridGgfsPath(gg, "sync"), new GridGgfsPath(gg, "async"), new GridGgfsPath(gg, "primary"));
+        IgniteFsPath gg = new IgniteFsPath("/gridgain");
+        IgniteFsPath[] paths = paths(
+            gg, new IgniteFsPath(gg, "sync"), new IgniteFsPath(gg, "async"), new IgniteFsPath(gg, "primary"));
 
         create(ggfs, paths, null);
 
-        for (GridGgfsPath p : paths)
+        for (IgniteFsPath p : paths)
             assert ggfs.exists(p);
 
         assert ggfs.listFiles(gg).size() == 3;
@@ -142,8 +142,8 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testRenameFileParentRootSourceMissing() throws Exception {
-        GridGgfsPath file1 = new GridGgfsPath("/file1");
-        GridGgfsPath file2 = new GridGgfsPath("/file2");
+        IgniteFsPath file1 = new IgniteFsPath("/file1");
+        IgniteFsPath file2 = new IgniteFsPath("/file2");
 
         create(ggfsSecondary, null, paths(file1));
         create(ggfs, null, null);
@@ -191,8 +191,8 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testRenameDirectoryParentRootSourceMissing() throws Exception {
-        GridGgfsPath dir1 = new GridGgfsPath("/dir1");
-        GridGgfsPath dir2 = new GridGgfsPath("/dir2");
+        IgniteFsPath dir1 = new IgniteFsPath("/dir1");
+        IgniteFsPath dir2 = new IgniteFsPath("/dir2");
 
         create(ggfsSecondary, paths(dir1), null);
         create(ggfs, null, null);
@@ -215,7 +215,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         ggfs.rename(FILE, SUBDIR_NEW);
 
         checkExist(ggfs, SUBDIR);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, FILE.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, FILE.name()));
         checkNotExist(ggfs, ggfsSecondary, FILE);
     }
 
@@ -231,7 +231,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         ggfs.rename(FILE, SUBDIR_NEW);
 
         checkExist(ggfs, DIR, SUBDIR);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, FILE.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, FILE.name()));
         checkNotExist(ggfs, ggfsSecondary, FILE);
     }
 
@@ -247,7 +247,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         ggfs.rename(FILE, SUBDIR_NEW);
 
         checkExist(ggfs, SUBDIR_NEW);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, FILE.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, FILE.name()));
         checkNotExist(ggfs, ggfsSecondary, FILE);
     }
 
@@ -263,7 +263,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         ggfs.rename(FILE, SUBDIR_NEW);
 
         checkExist(ggfs, DIR_NEW, SUBDIR_NEW);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, FILE.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, FILE.name()));
         checkNotExist(ggfs, ggfsSecondary, FILE);
     }
 
@@ -279,7 +279,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         ggfs.rename(FILE, SUBDIR_NEW);
 
         checkExist(ggfs, SUBDIR, SUBDIR_NEW);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, FILE.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, FILE.name()));
         checkNotExist(ggfs, ggfsSecondary, FILE);
     }
 
@@ -295,7 +295,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         ggfs.rename(FILE, SUBDIR_NEW);
 
         checkExist(ggfs, DIR, SUBDIR, DIR_NEW, SUBDIR_NEW);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, FILE.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, FILE.name()));
         checkNotExist(ggfs, ggfsSecondary, FILE);
     }
 
@@ -308,10 +308,10 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         create(ggfsSecondary, paths(DIR, SUBDIR), paths(FILE));
         create(ggfs, paths(DIR), null);
 
-        ggfs.rename(FILE, new GridGgfsPath());
+        ggfs.rename(FILE, new IgniteFsPath());
 
         checkExist(ggfs, SUBDIR);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath("/" + FILE.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath("/" + FILE.name()));
         checkNotExist(ggfs, ggfsSecondary, FILE);
     }
 
@@ -324,10 +324,10 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         create(ggfsSecondary, paths(DIR, SUBDIR), paths(FILE));
         create(ggfs, null, null);
 
-        ggfs.rename(FILE, new GridGgfsPath());
+        ggfs.rename(FILE, new IgniteFsPath());
 
         checkExist(ggfs, DIR, SUBDIR);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath("/" + FILE.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath("/" + FILE.name()));
         checkNotExist(ggfs, ggfsSecondary, FILE);
     }
 
@@ -337,14 +337,14 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testMoveFileSourceParentRootSourceMissing() throws Exception {
-        GridGgfsPath file = new GridGgfsPath("/" + FILE.name());
+        IgniteFsPath file = new IgniteFsPath("/" + FILE.name());
 
         create(ggfsSecondary, paths(DIR_NEW, SUBDIR_NEW), paths(file));
         create(ggfs, paths(DIR_NEW, SUBDIR_NEW), null);
 
         ggfs.rename(file, SUBDIR_NEW);
 
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, FILE.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, FILE.name()));
         checkNotExist(ggfs, ggfsSecondary, file);
     }
 
@@ -354,7 +354,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testMoveFileSourceParentRootDestinationMissingPartially() throws Exception {
-        GridGgfsPath file = new GridGgfsPath("/" + FILE.name());
+        IgniteFsPath file = new IgniteFsPath("/" + FILE.name());
 
         create(ggfsSecondary, paths(DIR_NEW, SUBDIR_NEW), paths(file));
         create(ggfs, paths(DIR_NEW), null);
@@ -362,7 +362,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         ggfs.rename(file, SUBDIR_NEW);
 
         checkExist(ggfs, SUBDIR_NEW);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, FILE.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, FILE.name()));
         checkNotExist(ggfs, ggfsSecondary, file);
     }
 
@@ -372,7 +372,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testMoveFileSourceParentRootDestinationMissing() throws Exception {
-        GridGgfsPath file = new GridGgfsPath("/" + FILE.name());
+        IgniteFsPath file = new IgniteFsPath("/" + FILE.name());
 
         create(ggfsSecondary, paths(DIR_NEW, SUBDIR_NEW), paths(file));
         create(ggfs, null, null);
@@ -380,7 +380,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         ggfs.rename(file, SUBDIR_NEW);
 
         checkExist(ggfs, DIR_NEW, SUBDIR_NEW);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, FILE.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, FILE.name()));
         checkNotExist(ggfs, ggfsSecondary, file);
     }
 
@@ -486,7 +486,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testMoveRenameFileDestinationRootSourceMissingPartially() throws Exception {
-        GridGgfsPath file = new GridGgfsPath("/" + FILE.name());
+        IgniteFsPath file = new IgniteFsPath("/" + FILE.name());
 
         create(ggfsSecondary, paths(DIR, SUBDIR), paths(FILE));
         create(ggfs, paths(DIR), null);
@@ -504,7 +504,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testMoveRenameFileDestinationRootSourceMissing() throws Exception {
-        GridGgfsPath file = new GridGgfsPath("/" + FILE.name());
+        IgniteFsPath file = new IgniteFsPath("/" + FILE.name());
 
         create(ggfsSecondary, paths(DIR, SUBDIR), paths(FILE));
         create(ggfs, null, null);
@@ -522,7 +522,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testMoveRenameFileSourceParentRootSourceMissing() throws Exception {
-        GridGgfsPath file = new GridGgfsPath("/" + FILE_NEW.name());
+        IgniteFsPath file = new IgniteFsPath("/" + FILE_NEW.name());
 
         create(ggfsSecondary, paths(DIR_NEW, SUBDIR_NEW), paths(file));
         create(ggfs, paths(DIR_NEW, SUBDIR_NEW), null);
@@ -539,7 +539,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testMoveRenameFileSourceParentRootDestinationMissingPartially() throws Exception {
-        GridGgfsPath file = new GridGgfsPath("/" + FILE_NEW.name());
+        IgniteFsPath file = new IgniteFsPath("/" + FILE_NEW.name());
 
         create(ggfsSecondary, paths(DIR_NEW, SUBDIR_NEW), paths(file));
         create(ggfs, paths(DIR_NEW), null);
@@ -557,7 +557,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testMoveRenameFileSourceParentRootDestinationMissing() throws Exception {
-        GridGgfsPath file = new GridGgfsPath("/" + FILE_NEW.name());
+        IgniteFsPath file = new IgniteFsPath("/" + FILE_NEW.name());
 
         create(ggfsSecondary, paths(DIR_NEW, SUBDIR_NEW), paths(file));
         create(ggfs, null, null);
@@ -581,7 +581,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         ggfs.rename(SUBSUBDIR, SUBDIR_NEW);
 
         checkExist(ggfs, SUBDIR);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, SUBSUBDIR.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, SUBSUBDIR.name()));
         checkNotExist(ggfs, ggfsSecondary, SUBSUBDIR);
     }
 
@@ -598,7 +598,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
 
         checkExist(ggfs, DIR);
         checkExist(ggfs, SUBDIR);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, SUBSUBDIR.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, SUBSUBDIR.name()));
         checkNotExist(ggfs, ggfsSecondary, SUBSUBDIR);
     }
 
@@ -614,7 +614,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         ggfs.rename(SUBSUBDIR, SUBDIR_NEW);
 
         checkExist(ggfs, SUBDIR_NEW);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, SUBSUBDIR.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, SUBSUBDIR.name()));
         checkNotExist(ggfs, ggfsSecondary, SUBSUBDIR);
     }
 
@@ -630,7 +630,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         ggfs.rename(SUBSUBDIR, SUBDIR_NEW);
 
         checkExist(ggfs, DIR_NEW, SUBDIR_NEW);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, SUBSUBDIR.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, SUBSUBDIR.name()));
         checkNotExist(ggfs, ggfsSecondary, SUBSUBDIR);
     }
 
@@ -646,7 +646,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         ggfs.rename(SUBSUBDIR, SUBDIR_NEW);
 
         checkExist(ggfs, SUBDIR, SUBDIR_NEW);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, SUBSUBDIR.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, SUBSUBDIR.name()));
         checkNotExist(ggfs, ggfsSecondary, SUBSUBDIR);
     }
 
@@ -662,7 +662,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         ggfs.rename(SUBSUBDIR, SUBDIR_NEW);
 
         checkExist(ggfs, DIR, SUBDIR, DIR_NEW, SUBDIR_NEW);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, SUBSUBDIR.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, SUBSUBDIR.name()));
         checkNotExist(ggfs, ggfsSecondary, SUBSUBDIR);
     }
 
@@ -675,10 +675,10 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         create(ggfsSecondary, paths(DIR, SUBDIR, SUBSUBDIR), null);
         create(ggfs, paths(DIR), null);
 
-        ggfs.rename(SUBSUBDIR, new GridGgfsPath());
+        ggfs.rename(SUBSUBDIR, new IgniteFsPath());
 
         checkExist(ggfs, SUBDIR);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath("/" + SUBSUBDIR.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath("/" + SUBSUBDIR.name()));
         checkNotExist(ggfs, ggfsSecondary, SUBSUBDIR);
     }
 
@@ -691,10 +691,10 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         create(ggfsSecondary, paths(DIR, SUBDIR, SUBSUBDIR), null);
         create(ggfs, null, null);
 
-        ggfs.rename(SUBSUBDIR, new GridGgfsPath());
+        ggfs.rename(SUBSUBDIR, new IgniteFsPath());
 
         checkExist(ggfs, DIR, SUBDIR);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath("/" + SUBSUBDIR.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath("/" + SUBSUBDIR.name()));
         checkNotExist(ggfs, ggfsSecondary, SUBSUBDIR);
     }
 
@@ -704,14 +704,14 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testMoveDirectorySourceParentRootSourceMissing() throws Exception {
-        GridGgfsPath dir = new GridGgfsPath("/" + SUBSUBDIR.name());
+        IgniteFsPath dir = new IgniteFsPath("/" + SUBSUBDIR.name());
 
         create(ggfsSecondary, paths(DIR_NEW, SUBDIR_NEW, dir), null);
         create(ggfs, paths(DIR_NEW, SUBDIR_NEW), null);
 
         ggfs.rename(dir, SUBDIR_NEW);
 
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, SUBSUBDIR.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, SUBSUBDIR.name()));
         checkNotExist(ggfs, ggfsSecondary, dir);
     }
 
@@ -721,7 +721,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testMoveDirectorySourceParentRootDestinationMissingPartially() throws Exception {
-        GridGgfsPath dir = new GridGgfsPath("/" + SUBSUBDIR.name());
+        IgniteFsPath dir = new IgniteFsPath("/" + SUBSUBDIR.name());
 
         create(ggfsSecondary, paths(DIR_NEW, SUBDIR_NEW, dir), null);
         create(ggfs, paths(DIR_NEW), null);
@@ -729,7 +729,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         ggfs.rename(dir, SUBDIR_NEW);
 
         checkExist(ggfs, SUBDIR_NEW);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, SUBSUBDIR.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, SUBSUBDIR.name()));
         checkNotExist(ggfs, ggfsSecondary, dir);
     }
 
@@ -739,7 +739,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testMoveDirectorySourceParentRootDestinationMissing() throws Exception {
-        GridGgfsPath dir = new GridGgfsPath("/" + SUBSUBDIR.name());
+        IgniteFsPath dir = new IgniteFsPath("/" + SUBSUBDIR.name());
 
         create(ggfsSecondary, paths(DIR_NEW, SUBDIR_NEW, dir), null);
         create(ggfs, null, null);
@@ -747,7 +747,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         ggfs.rename(dir, SUBDIR_NEW);
 
         checkExist(ggfs, DIR_NEW, SUBDIR_NEW);
-        checkExist(ggfs, ggfsSecondary, new GridGgfsPath(SUBDIR_NEW, SUBSUBDIR.name()));
+        checkExist(ggfs, ggfsSecondary, new IgniteFsPath(SUBDIR_NEW, SUBSUBDIR.name()));
         checkNotExist(ggfs, ggfsSecondary, dir);
     }
 
@@ -854,7 +854,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testMoveRenameDirectoryDestinationRootSourceMissingPartially() throws Exception {
-        GridGgfsPath dir = new GridGgfsPath("/" + SUBSUBDIR.name());
+        IgniteFsPath dir = new IgniteFsPath("/" + SUBSUBDIR.name());
 
         create(ggfsSecondary, paths(DIR, SUBDIR, SUBSUBDIR), null);
         create(ggfs, paths(DIR), null);
@@ -872,7 +872,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testMoveRenameDirectoryDestinationRootSourceMissing() throws Exception {
-        GridGgfsPath dir = new GridGgfsPath("/" + SUBSUBDIR.name());
+        IgniteFsPath dir = new IgniteFsPath("/" + SUBSUBDIR.name());
 
         create(ggfsSecondary, paths(DIR, SUBDIR, SUBSUBDIR), null);
         create(ggfs, null, null);
@@ -890,7 +890,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testMoveRenameDirectorySourceParentRootSourceMissing() throws Exception {
-        GridGgfsPath dir = new GridGgfsPath("/" + SUBSUBDIR_NEW.name());
+        IgniteFsPath dir = new IgniteFsPath("/" + SUBSUBDIR_NEW.name());
 
         create(ggfsSecondary, paths(DIR_NEW, SUBDIR_NEW, dir), null);
         create(ggfs, paths(DIR_NEW, SUBDIR_NEW), null);
@@ -907,7 +907,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testMoveRenameDirectorySourceParentRootDestinationMissingPartially() throws Exception {
-        GridGgfsPath dir = new GridGgfsPath("/" + SUBSUBDIR_NEW.name());
+        IgniteFsPath dir = new IgniteFsPath("/" + SUBSUBDIR_NEW.name());
 
         create(ggfsSecondary, paths(DIR_NEW, SUBDIR_NEW, dir), null);
         create(ggfs, paths(DIR_NEW), null);
@@ -925,7 +925,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
      * @throws Exception If failed.
      */
     public void testMoveRenameDirectorySourceParentRootDestinationMissing() throws Exception {
-        GridGgfsPath dir = new GridGgfsPath("/" + SUBSUBDIR_NEW.name());
+        IgniteFsPath dir = new IgniteFsPath("/" + SUBSUBDIR_NEW.name());
 
         create(ggfsSecondary, paths(DIR_NEW, SUBDIR_NEW, dir), null);
         create(ggfs, null, null);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java
index d62709a..2b73c07 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java
@@ -175,8 +175,8 @@ public class GridGgfsMetaManagerSelfTest extends GridGgfsCommonAbstractTest {
             assertNull(mgr.updateProperties(ROOT_ID, fileId, "not_exists", F.<String, String>asMap(key2, null)));
         }
 
-        mgr.removeIfEmpty(ROOT_ID, "dir", dir.id(), new GridGgfsPath("/dir"), true);
-        mgr.removeIfEmpty(ROOT_ID, "file", file.id(), new GridGgfsPath("/file"), true);
+        mgr.removeIfEmpty(ROOT_ID, "dir", dir.id(), new IgniteFsPath("/dir"), true);
+        mgr.removeIfEmpty(ROOT_ID, "file", file.id(), new IgniteFsPath("/file"), true);
 
         assertNull(mgr.updateProperties(ROOT_ID, dir.id(), "dir", F.asMap("p", "7")));
         assertNull(mgr.updateProperties(ROOT_ID, file.id(), "file", F.asMap("q", "8")));
@@ -230,15 +230,15 @@ public class GridGgfsMetaManagerSelfTest extends GridGgfsCommonAbstractTest {
         }
 
         // Validate 'file ID' operations.
-        assertEquals(ROOT_ID, mgr.fileId(new GridGgfsPath("/")));
-        assertEquals(a.id(), mgr.fileId(new GridGgfsPath("/a")));
-        assertEquals(b.id(), mgr.fileId(new GridGgfsPath("/a/b")));
-        assertEquals(f1.id(), mgr.fileId(new GridGgfsPath("/f1")));
-        assertEquals(f2.id(), mgr.fileId(new GridGgfsPath("/a/f2")));
-        assertEquals(f3.id(), mgr.fileId(new GridGgfsPath("/a/b/f3")));
-        assertNull(mgr.fileId(new GridGgfsPath("/f4")));
-        assertNull(mgr.fileId(new GridGgfsPath("/a/f5")));
-        assertNull(mgr.fileId(new GridGgfsPath("/a/b/f6")));
+        assertEquals(ROOT_ID, mgr.fileId(new IgniteFsPath("/")));
+        assertEquals(a.id(), mgr.fileId(new IgniteFsPath("/a")));
+        assertEquals(b.id(), mgr.fileId(new IgniteFsPath("/a/b")));
+        assertEquals(f1.id(), mgr.fileId(new IgniteFsPath("/f1")));
+        assertEquals(f2.id(), mgr.fileId(new IgniteFsPath("/a/f2")));
+        assertEquals(f3.id(), mgr.fileId(new IgniteFsPath("/a/b/f3")));
+        assertNull(mgr.fileId(new IgniteFsPath("/f4")));
+        assertNull(mgr.fileId(new IgniteFsPath("/a/f5")));
+        assertNull(mgr.fileId(new IgniteFsPath("/a/b/f6")));
 
         assertEquals(a.id(), mgr.fileId(ROOT_ID, "a"));
         assertEquals(b.id(), mgr.fileId(a.id(), "b"));
@@ -249,16 +249,16 @@ public class GridGgfsMetaManagerSelfTest extends GridGgfsCommonAbstractTest {
         assertNull(mgr.fileId(a.id(), "f5"));
         assertNull(mgr.fileId(b.id(), "f6"));
 
-        assertEquals(Arrays.asList(ROOT_ID), mgr.fileIds(new GridGgfsPath("/")));
-        assertEquals(Arrays.asList(ROOT_ID, a.id()), mgr.fileIds(new GridGgfsPath("/a")));
-        assertEquals(Arrays.asList(ROOT_ID, a.id(), b.id()), mgr.fileIds(new GridGgfsPath("/a/b")));
-        assertEquals(Arrays.asList(ROOT_ID, f1.id()), mgr.fileIds(new GridGgfsPath("/f1")));
-        assertEquals(Arrays.asList(ROOT_ID, a.id(), f2.id()), mgr.fileIds(new GridGgfsPath("/a/f2")));
-        assertEquals(Arrays.asList(ROOT_ID, a.id(), b.id(), f3.id()), mgr.fileIds(new GridGgfsPath("/a/b/f3")));
-        assertEquals(Arrays.asList(ROOT_ID, null), mgr.fileIds(new GridGgfsPath("/f4")));
-        assertEquals(Arrays.asList(ROOT_ID, a.id(), null), mgr.fileIds(new GridGgfsPath("/a/f5")));
-        assertEquals(Arrays.asList(ROOT_ID, a.id(), b.id(), null), mgr.fileIds(new GridGgfsPath("/a/b/f6")));
-        assertEquals(Arrays.asList(ROOT_ID, null, null, null, null), mgr.fileIds(new GridGgfsPath("/f7/a/b/f6")));
+        assertEquals(Arrays.asList(ROOT_ID), mgr.fileIds(new IgniteFsPath("/")));
+        assertEquals(Arrays.asList(ROOT_ID, a.id()), mgr.fileIds(new IgniteFsPath("/a")));
+        assertEquals(Arrays.asList(ROOT_ID, a.id(), b.id()), mgr.fileIds(new IgniteFsPath("/a/b")));
+        assertEquals(Arrays.asList(ROOT_ID, f1.id()), mgr.fileIds(new IgniteFsPath("/f1")));
+        assertEquals(Arrays.asList(ROOT_ID, a.id(), f2.id()), mgr.fileIds(new IgniteFsPath("/a/f2")));
+        assertEquals(Arrays.asList(ROOT_ID, a.id(), b.id(), f3.id()), mgr.fileIds(new IgniteFsPath("/a/b/f3")));
+        assertEquals(Arrays.asList(ROOT_ID, null), mgr.fileIds(new IgniteFsPath("/f4")));
+        assertEquals(Arrays.asList(ROOT_ID, a.id(), null), mgr.fileIds(new IgniteFsPath("/a/f5")));
+        assertEquals(Arrays.asList(ROOT_ID, a.id(), b.id(), null), mgr.fileIds(new IgniteFsPath("/a/b/f6")));
+        assertEquals(Arrays.asList(ROOT_ID, null, null, null, null), mgr.fileIds(new IgniteFsPath("/f7/a/b/f6")));
 
         // Validate 'rename' operation.
         final IgniteUuid rndId = IgniteUuid.randomUuid();
@@ -309,19 +309,19 @@ public class GridGgfsMetaManagerSelfTest extends GridGgfsCommonAbstractTest {
         // Validate 'remove' operation.
         for (int i = 0; i < 100; i++) {
             // One of participants doesn't exist.
-            assertNull(mgr.removeIfEmpty(ROOT_ID, "a", IgniteUuid.randomUuid(), new GridGgfsPath("/a"), true));
+            assertNull(mgr.removeIfEmpty(ROOT_ID, "a", IgniteUuid.randomUuid(), new IgniteFsPath("/a"), true));
             assertNull(mgr.removeIfEmpty(IgniteUuid.randomUuid(), "a", IgniteUuid.randomUuid(),
-                new GridGgfsPath("/" + IgniteUuid.randomUuid() + "/a"), true));
+                new IgniteFsPath("/" + IgniteUuid.randomUuid() + "/a"), true));
         }
 
-        expectsRemoveFail(ROOT_ID, "a", a.id(), new GridGgfsPath("/a"),
+        expectsRemoveFail(ROOT_ID, "a", a.id(), new IgniteFsPath("/a"),
             "Failed to remove file (directory is not empty)");
-        expectsRemoveFail(a.id(), "b", b.id(), new GridGgfsPath("/a/b"),
+        expectsRemoveFail(a.id(), "b", b.id(), new IgniteFsPath("/a/b"),
             "Failed to remove file (directory is not empty)");
-        assertNull(mgr.removeIfEmpty(ROOT_ID, "a", f1.id(), new GridGgfsPath("/a"), true));
-        assertNull(mgr.removeIfEmpty(a.id(), "b", f1.id(), new GridGgfsPath("/a/b"), true));
+        assertNull(mgr.removeIfEmpty(ROOT_ID, "a", f1.id(), new IgniteFsPath("/a"), true));
+        assertNull(mgr.removeIfEmpty(a.id(), "b", f1.id(), new IgniteFsPath("/a/b"), true));
 
-        assertEquals(f3, mgr.removeIfEmpty(b.id(), "f3", f3.id(), new GridGgfsPath("/a/b/f3"), true));
+        assertEquals(f3, mgr.removeIfEmpty(b.id(), "f3", f3.id(), new IgniteFsPath("/a/b/f3"), true));
 
         assertEquals(F.asMap("a", new GridGgfsListingEntry(a), "f1", new GridGgfsListingEntry(f1)),
             mgr.directoryListing(ROOT_ID));
@@ -331,7 +331,7 @@ public class GridGgfsMetaManagerSelfTest extends GridGgfsCommonAbstractTest {
 
         assertEmpty(mgr.directoryListing(b.id()));
 
-        assertEquals(b, mgr.removeIfEmpty(a.id(), "b", b.id(), new GridGgfsPath("/a/b"), true));
+        assertEquals(b, mgr.removeIfEmpty(a.id(), "b", b.id(), new IgniteFsPath("/a/b"), true));
 
         assertEquals(F.asMap("a", new GridGgfsListingEntry(a), "f1", new GridGgfsListingEntry(f1)),
             mgr.directoryListing(ROOT_ID));
@@ -351,7 +351,7 @@ public class GridGgfsMetaManagerSelfTest extends GridGgfsCommonAbstractTest {
         assertEquals(f2.id(), newF2.id());
         assertNotSame(f2, newF2);
 
-        assertEquals(newF2, mgr.removeIfEmpty(a.id(), "f2", f2.id(), new GridGgfsPath("/a/f2"), true));
+        assertEquals(newF2, mgr.removeIfEmpty(a.id(), "f2", f2.id(), new IgniteFsPath("/a/f2"), true));
 
         assertEquals(F.asMap("a", new GridGgfsListingEntry(a), "f1", new GridGgfsListingEntry(f1)),
             mgr.directoryListing(ROOT_ID));
@@ -359,14 +359,14 @@ public class GridGgfsMetaManagerSelfTest extends GridGgfsCommonAbstractTest {
         assertEmpty(mgr.directoryListing(a.id()));
         assertEmpty(mgr.directoryListing(b.id()));
 
-        assertEquals(f1, mgr.removeIfEmpty(ROOT_ID, "f1", f1.id(), new GridGgfsPath("/f1"), true));
+        assertEquals(f1, mgr.removeIfEmpty(ROOT_ID, "f1", f1.id(), new IgniteFsPath("/f1"), true));
 
         assertEquals(F.asMap("a", new GridGgfsListingEntry(a)), mgr.directoryListing(ROOT_ID));
 
         assertEmpty(mgr.directoryListing(a.id()));
         assertEmpty(mgr.directoryListing(b.id()));
 
-        assertEquals(a, mgr.removeIfEmpty(ROOT_ID, "a", a.id(), new GridGgfsPath("/a"), true));
+        assertEquals(a, mgr.removeIfEmpty(ROOT_ID, "a", a.id(), new IgniteFsPath("/a"), true));
 
         assertEmpty(mgr.directoryListing(ROOT_ID));
         assertEmpty(mgr.directoryListing(a.id()));
@@ -446,7 +446,7 @@ public class GridGgfsMetaManagerSelfTest extends GridGgfsCommonAbstractTest {
      * @param msg Failure message if expected exception was not thrown.
      */
     private void expectsRemoveFail(final IgniteUuid parentId, final String fileName, final IgniteUuid fileId,
-        final GridGgfsPath path, @Nullable String msg) {
+        final IgniteFsPath path, @Nullable String msg) {
         assertThrows(log, new Callable() {
             @Nullable @Override public Object call() throws Exception {
                 mgr.removeIfEmpty(parentId, fileName, fileId, path, true);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
index b8fbbee..1dcca80 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
@@ -211,7 +211,7 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
         assertEquals(0, m.filesOpenedForRead());
         assertEquals(0, m.filesOpenedForWrite());
 
-        fs.mkdirs(new GridGgfsPath("/dir1"));
+        fs.mkdirs(new IgniteFsPath("/dir1"));
 
         m = fs.metrics();
 
@@ -221,8 +221,8 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
         assertEquals(0, m.filesOpenedForRead());
         assertEquals(0, m.filesOpenedForWrite());
 
-        fs.mkdirs(new GridGgfsPath("/dir1/dir2/dir3"));
-        fs.mkdirs(new GridGgfsPath("/dir4"));
+        fs.mkdirs(new IgniteFsPath("/dir1/dir2/dir3"));
+        fs.mkdirs(new IgniteFsPath("/dir4"));
 
         m = fs.metrics();
 
@@ -232,9 +232,9 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
         assertEquals(0, m.filesOpenedForRead());
         assertEquals(0, m.filesOpenedForWrite());
 
-        GridGgfsOutputStream out1 = fs.create(new GridGgfsPath("/dir1/file1"), false);
-        GridGgfsOutputStream out2 = fs.create(new GridGgfsPath("/dir1/file2"), false);
-        GridGgfsOutputStream out3 = fs.create(new GridGgfsPath("/dir1/dir2/file"), false);
+        GridGgfsOutputStream out1 = fs.create(new IgniteFsPath("/dir1/file1"), false);
+        GridGgfsOutputStream out2 = fs.create(new IgniteFsPath("/dir1/file2"), false);
+        GridGgfsOutputStream out3 = fs.create(new IgniteFsPath("/dir1/dir2/file"), false);
 
         m = fs.metrics();
 
@@ -269,7 +269,7 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
         assertEquals(0, m.filesOpenedForRead());
         assertEquals(0, m.filesOpenedForWrite());
 
-        GridGgfsOutputStream out = fs.append(new GridGgfsPath("/dir1/file1"), false);
+        GridGgfsOutputStream out = fs.append(new IgniteFsPath("/dir1/file1"), false);
 
         out.write(new byte[20]);
 
@@ -293,8 +293,8 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
         assertEquals(0, m.filesOpenedForRead());
         assertEquals(0, m.filesOpenedForWrite());
 
-        GridGgfsInputStream in1 = fs.open(new GridGgfsPath("/dir1/file1"));
-        GridGgfsInputStream in2 = fs.open(new GridGgfsPath("/dir1/file2"));
+        GridGgfsInputStream in1 = fs.open(new IgniteFsPath("/dir1/file1"));
+        GridGgfsInputStream in2 = fs.open(new IgniteFsPath("/dir1/file2"));
 
         m = fs.metrics();
 
@@ -315,8 +315,8 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
         assertEquals(0, m.filesOpenedForRead());
         assertEquals(0, m.filesOpenedForWrite());
 
-        fs.delete(new GridGgfsPath("/dir1/file1"), false);
-        fs.delete(new GridGgfsPath("/dir1/dir2"), true);
+        fs.delete(new IgniteFsPath("/dir1/file1"), false);
+        fs.delete(new IgniteFsPath("/dir1/dir2"), true);
 
         m = fs.metrics();
 
@@ -326,7 +326,7 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
         assertEquals(0, m.filesOpenedForRead());
         assertEquals(0, m.filesOpenedForWrite());
 
-        fs.delete(new GridGgfsPath("/"), true);
+        fs.delete(new IgniteFsPath("/"), true);
 
         m = fs.metrics();
 
@@ -341,12 +341,12 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
     public void testMultipleClose() throws Exception {
         IgniteFs fs = ggfsPrimary[0];
 
-        GridGgfsOutputStream out = fs.create(new GridGgfsPath("/file"), false);
+        GridGgfsOutputStream out = fs.create(new IgniteFsPath("/file"), false);
 
         out.close();
         out.close();
 
-        GridGgfsInputStream in = fs.open(new GridGgfsPath("/file"));
+        GridGgfsInputStream in = fs.open(new IgniteFsPath("/file"));
 
         in.close();
         in.close();
@@ -365,9 +365,9 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
     public void testBlockMetrics() throws Exception {
         GridGgfsEx ggfs = (GridGgfsEx)ggfsPrimary[0];
 
-        GridGgfsPath fileRemote = new GridGgfsPath("/fileRemote");
-        GridGgfsPath file1 = new GridGgfsPath("/file1");
-        GridGgfsPath file2 = new GridGgfsPath("/file2");
+        IgniteFsPath fileRemote = new IgniteFsPath("/fileRemote");
+        IgniteFsPath file1 = new IgniteFsPath("/file1");
+        IgniteFsPath file2 = new IgniteFsPath("/file2");
 
         // Create remote file and write some data to it.
         GridGgfsOutputStream out = ggfsSecondary.create(fileRemote, 256, true, null, 1, 256, null);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolverSelfTest.java
index e6c8910..3c397de 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModeResolverSelfTest.java
@@ -27,22 +27,22 @@ public class GridGgfsModeResolverSelfTest extends TestCase {
     /** {@inheritDoc} */
     @Override protected void setUp() throws Exception {
         resolver = new GridGgfsModeResolver(DUAL_SYNC, Arrays.asList(
-            new T2<>(new GridGgfsPath("/a/b/"), PRIMARY),
-            new T2<>(new GridGgfsPath("/a/b/c/d"), PROXY)));
+            new T2<>(new IgniteFsPath("/a/b/"), PRIMARY),
+            new T2<>(new IgniteFsPath("/a/b/c/d"), PROXY)));
     }
 
     /**
      * @throws Exception If failed.
      */
     public void testResolve() throws Exception {
-        assertEquals(DUAL_SYNC, resolver.resolveMode(new GridGgfsPath("/")));
-        assertEquals(DUAL_SYNC, resolver.resolveMode(new GridGgfsPath("/a")));
-        assertEquals(DUAL_SYNC, resolver.resolveMode(new GridGgfsPath("/a/1")));
-        assertEquals(PRIMARY, resolver.resolveMode(new GridGgfsPath("/a/b")));
-        assertEquals(PRIMARY, resolver.resolveMode(new GridGgfsPath("/a/b/c")));
-        assertEquals(PRIMARY, resolver.resolveMode(new GridGgfsPath("/a/b/c/2")));
-        assertEquals(PROXY, resolver.resolveMode(new GridGgfsPath("/a/b/c/d")));
-        assertEquals(PROXY, resolver.resolveMode(new GridGgfsPath("/a/b/c/d/e")));
+        assertEquals(DUAL_SYNC, resolver.resolveMode(new IgniteFsPath("/")));
+        assertEquals(DUAL_SYNC, resolver.resolveMode(new IgniteFsPath("/a")));
+        assertEquals(DUAL_SYNC, resolver.resolveMode(new IgniteFsPath("/a/1")));
+        assertEquals(PRIMARY, resolver.resolveMode(new IgniteFsPath("/a/b")));
+        assertEquals(PRIMARY, resolver.resolveMode(new IgniteFsPath("/a/b/c")));
+        assertEquals(PRIMARY, resolver.resolveMode(new IgniteFsPath("/a/b/c/2")));
+        assertEquals(PROXY, resolver.resolveMode(new IgniteFsPath("/a/b/c/d")));
+        assertEquals(PROXY, resolver.resolveMode(new IgniteFsPath("/a/b/c/d/e")));
     }
 
     /**
@@ -50,20 +50,20 @@ public class GridGgfsModeResolverSelfTest extends TestCase {
      */
     public void testResolveChildren() throws Exception {
         assertEquals(new HashSet<GridGgfsMode>(){{add(DUAL_SYNC); add(PRIMARY); add(PROXY);}},
-            resolver.resolveChildrenModes(new GridGgfsPath("/")));
+            resolver.resolveChildrenModes(new IgniteFsPath("/")));
         assertEquals(new HashSet<GridGgfsMode>(){{add(DUAL_SYNC); add(PRIMARY); add(PROXY);}},
-            resolver.resolveChildrenModes(new GridGgfsPath("/a")));
+            resolver.resolveChildrenModes(new IgniteFsPath("/a")));
         assertEquals(new HashSet<GridGgfsMode>(){{add(DUAL_SYNC);}},
-            resolver.resolveChildrenModes(new GridGgfsPath("/a/1")));
+            resolver.resolveChildrenModes(new IgniteFsPath("/a/1")));
         assertEquals(new HashSet<GridGgfsMode>(){{add(PRIMARY); add(PROXY);}},
-            resolver.resolveChildrenModes(new GridGgfsPath("/a/b")));
+            resolver.resolveChildrenModes(new IgniteFsPath("/a/b")));
         assertEquals(new HashSet<GridGgfsMode>(){{add(PRIMARY); add(PROXY);}},
-            resolver.resolveChildrenModes(new GridGgfsPath("/a/b/c")));
+            resolver.resolveChildrenModes(new IgniteFsPath("/a/b/c")));
         assertEquals(new HashSet<GridGgfsMode>(){{add(PRIMARY);}},
-            resolver.resolveChildrenModes(new GridGgfsPath("/a/b/c/2")));
+            resolver.resolveChildrenModes(new IgniteFsPath("/a/b/c/2")));
         assertEquals(new HashSet<GridGgfsMode>(){{add(PROXY);}},
-            resolver.resolveChildrenModes(new GridGgfsPath("/a/b/c/d")));
+            resolver.resolveChildrenModes(new IgniteFsPath("/a/b/c/d")));
         assertEquals(new HashSet<GridGgfsMode>(){{add(PROXY);}},
-            resolver.resolveChildrenModes(new GridGgfsPath("/a/b/c/d/e")));
+            resolver.resolveChildrenModes(new IgniteFsPath("/a/b/c/d/e")));
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
index 962fd1c..ebf6b8d 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
@@ -480,7 +480,7 @@ public class GridGgfsModesSelfTest extends GridGgfsCommonAbstractTest {
     private void checkMode(String pathStr, GridGgfsMode expMode) throws Exception {
         assert ggfs != null;
 
-        GridGgfsPath path = new GridGgfsPath(pathStr);
+        IgniteFsPath path = new IgniteFsPath(pathStr);
 
         GridGgfsModeResolver rslvr = ggfs.modeResolver();
 
@@ -508,8 +508,8 @@ public class GridGgfsModesSelfTest extends GridGgfsCommonAbstractTest {
         boolean primaryNotUsed = mode == PROXY;
         boolean secondaryUsed = mode != PRIMARY;
 
-        GridGgfsPath dir = new GridGgfsPath("/dir");
-        GridGgfsPath file = new GridGgfsPath("/dir/file");
+        IgniteFsPath dir = new IgniteFsPath("/dir");
+        IgniteFsPath file = new IgniteFsPath("/dir/file");
 
         // Create new directory.
         ggfs.mkdirs(dir);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
index 762242f..575e955 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
@@ -160,7 +160,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testUpdateProperties() throws Exception {
-        GridGgfsPath p = path("/tmp/my");
+        IgniteFsPath p = path("/tmp/my");
 
         ggfs.mkdirs(p);
 
@@ -193,7 +193,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
 
     /** @throws Exception If failed. */
     public void testCreate() throws Exception {
-        GridGgfsPath path = path("/file");
+        IgniteFsPath path = path("/file");
 
         try (GridGgfsOutputStream os = ggfs.create(path, false)) {
             assert os != null;
@@ -350,7 +350,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
         assert ggfs.exists(path("/A/B1/C1"));
 
         // List items.
-        Collection<GridGgfsPath> paths = ggfs.listPaths(path("/"));
+        Collection<IgniteFsPath> paths = ggfs.listPaths(path("/"));
 
         assert paths.size() == 3 : "Unexpected paths: " + paths;
 
@@ -380,12 +380,12 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
         ggfs.delete(path("/A1/B1/C3"), false);
         assertNull(ggfs.info(path("/A1/B1/C3")));
 
-        assertEquals(Collections.<GridGgfsPath>emptyList(), ggfs.listPaths(path("/A1/B1")));
+        assertEquals(Collections.<IgniteFsPath>emptyList(), ggfs.listPaths(path("/A1/B1")));
 
         ggfs.delete(path("/A2/B2"), true);
         assertNull(ggfs.info(path("/A2/B2")));
 
-        assertEquals(Collections.<GridGgfsPath>emptyList(), ggfs.listPaths(path("/A2")));
+        assertEquals(Collections.<IgniteFsPath>emptyList(), ggfs.listPaths(path("/A2")));
 
         assertEquals(Arrays.asList(path("/A"), path("/A1"), path("/A2")), sorted(ggfs.listPaths(path("/"))));
 
@@ -399,10 +399,10 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
         assertEquals(Arrays.asList(path("/A"), path("/A1"), path("/A2")), sorted(ggfs.listPaths(path("/"))));
 
         ggfs.delete(path("/"), true);
-        assertEquals(Collections.<GridGgfsPath>emptyList(), ggfs.listPaths(path("/")));
+        assertEquals(Collections.<IgniteFsPath>emptyList(), ggfs.listPaths(path("/")));
 
         ggfs.delete(path("/"), false);
-        assertEquals(Collections.<GridGgfsPath>emptyList(), ggfs.listPaths(path("/")));
+        assertEquals(Collections.<IgniteFsPath>emptyList(), ggfs.listPaths(path("/")));
 
         for (GridCacheEntry<Object, Object> e : metaCache)
             info("Entry in cache [key=" + e.getKey() + ", val=" + e.getValue() + ']');
@@ -414,13 +414,13 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testSize() throws Exception {
-        GridGgfsPath dir1 = path("/dir1");
-        GridGgfsPath subDir1 = path("/dir1/subdir1");
-        GridGgfsPath dir2 = path("/dir2");
+        IgniteFsPath dir1 = path("/dir1");
+        IgniteFsPath subDir1 = path("/dir1/subdir1");
+        IgniteFsPath dir2 = path("/dir2");
 
-        GridGgfsPath fileDir1 = path("/dir1/file");
-        GridGgfsPath fileSubdir1 = path("/dir1/subdir1/file");
-        GridGgfsPath fileDir2 = path("/dir2/file");
+        IgniteFsPath fileDir1 = path("/dir1/file");
+        IgniteFsPath fileSubdir1 = path("/dir1/subdir1/file");
+        IgniteFsPath fileDir2 = path("/dir2/file");
 
         GridGgfsOutputStream os = ggfs.create(fileDir1, false);
         os.write(new byte[1000]);
@@ -512,11 +512,11 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
             F.t("/C1", "/A/B1")
         );
 
-        final GridGgfsPath root = path("/");
+        final IgniteFsPath root = path("/");
 
         for (IgniteBiTuple<String, String> e : chain) {
-            final GridGgfsPath p1 = path(e.get1());
-            final GridGgfsPath p2 = path(e.get2());
+            final IgniteFsPath p1 = path(e.get1());
+            final IgniteFsPath p2 = path(e.get2());
 
             assertTrue("Entry: " + e, ggfs.exists(p1));
             ggfs.rename(p1, p2);
@@ -583,24 +583,24 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
         // Cleanup.
         ggfs.delete(root, true);
 
-        assertEquals(Collections.<GridGgfsPath>emptyList(), ggfs.listPaths(root));
+        assertEquals(Collections.<IgniteFsPath>emptyList(), ggfs.listPaths(root));
     }
 
     /**
      * @param path Path.
      * @return GGFS path.
      */
-    private GridGgfsPath path(String path) {
+    private IgniteFsPath path(String path) {
         assert path != null;
 
-        return new GridGgfsPath(path);
+        return new IgniteFsPath(path);
     }
 
     /**
      * @param i Path index.
      * @return GGFS path.
      */
-    private GridGgfsPath path(long i) {
+    private IgniteFsPath path(long i) {
         //return path(String.format("/%d", i));
         return path(String.format("/%d/q/%d/%d", i % 10, (i / 10) % 10, i));
     }
@@ -667,7 +667,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
     /** @throws Exception If failed. */
     @SuppressWarnings("BusyWait")
     public void testDeleteCacheConsistency() throws Exception {
-        GridGgfsPath path = new GridGgfsPath("/someFile");
+        IgniteFsPath path = new IgniteFsPath("/someFile");
 
         try (GridGgfsOutputStream out = ggfs.create(path, true)) {
             out.write(new byte[10 * 1024 * 1024]);
@@ -779,7 +779,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
      * @throws Exception If failed.
      */
     private void checkCreateAppendLongData(int chunkSize, int bufSize, int cnt) throws Exception {
-        GridGgfsPath path = new GridGgfsPath("/someFile");
+        IgniteFsPath path = new IgniteFsPath("/someFile");
 
         byte[] buf = new byte[chunkSize];
 
@@ -887,7 +887,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
      * @param props File properties to set.
      * @param msg Failure message if expected exception was not thrown.
      */
-    private void assertUpdatePropertiesFails(@Nullable final GridGgfsPath path,
+    private void assertUpdatePropertiesFails(@Nullable final IgniteFsPath path,
         @Nullable final Map<String, String> props,
         Class<? extends Throwable> cls, @Nullable String msg) {
         GridTestUtils.assertThrows(log, new Callable() {
@@ -955,7 +955,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
      * @throws GridException If failed.
      */
     private void assertListDir(String path, String... item) throws GridException {
-        Collection<GridGgfsFile> files = ggfs.listFiles(new GridGgfsPath(path));
+        Collection<GridGgfsFile> files = ggfs.listFiles(new IgniteFsPath(path));
 
         List<String> names = new ArrayList<>(item.length);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
index 7975403..cac49b9 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
@@ -418,7 +418,7 @@ public class GridGgfsSizeSelfTest extends GridGgfsCommonAbstractTest {
 
         startUp();
 
-        final GridGgfsPath path = new GridGgfsPath("/file");
+        final IgniteFsPath path = new IgniteFsPath("/file");
 
         // This write is expected to be successful.
         GridGgfsOutputStream os = ggfs(0).create(path, false);
@@ -472,8 +472,8 @@ public class GridGgfsSizeSelfTest extends GridGgfsCommonAbstractTest {
 
         GridGgfsImpl ggfs = ggfs(0);
 
-        final GridGgfsPath path = new GridGgfsPath("/file");
-        final GridGgfsPath otherPath = new GridGgfsPath("/fileOther");
+        final IgniteFsPath path = new IgniteFsPath("/file");
+        final IgniteFsPath otherPath = new IgniteFsPath("/fileOther");
 
         // Fill cache with data up to it's limit.
         GridGgfsOutputStream os = ggfs.create(path, false);
@@ -664,7 +664,7 @@ public class GridGgfsSizeSelfTest extends GridGgfsCommonAbstractTest {
      * @return Block key.
      * @throws Exception If failed.
      */
-    private GridGgfsBlockKey blockKey(GridGgfsPath path, long blockId) throws Exception {
+    private GridGgfsBlockKey blockKey(IgniteFsPath path, long blockId) throws Exception {
         GridGgfsEx ggfs0 = (GridGgfsEx)grid(0).fileSystem(GGFS_NAME);
 
         IgniteUuid fileId = ggfs0.context().meta().fileId(path);
@@ -754,7 +754,7 @@ public class GridGgfsSizeSelfTest extends GridGgfsCommonAbstractTest {
 
         for (int i = 0; i < FILES_CNT; i++) {
             // Create empty file locally.
-            GridGgfsPath path = new GridGgfsPath("/file-" + i);
+            IgniteFsPath path = new IgniteFsPath("/file-" + i);
 
             ggfs(0).create(path, false).close();
 
@@ -797,7 +797,7 @@ public class GridGgfsSizeSelfTest extends GridGgfsCommonAbstractTest {
     /** A file written to the file system. */
     private static class GgfsFile {
         /** Path to the file, */
-        private final GridGgfsPath path;
+        private final IgniteFsPath path;
 
         /** File length. */
         private final int len;
@@ -812,14 +812,14 @@ public class GridGgfsSizeSelfTest extends GridGgfsCommonAbstractTest {
          * @param len Length.
          * @param blocks Blocks.
          */
-        private GgfsFile(GridGgfsPath path, int len, Collection<GgfsBlock> blocks) {
+        private GgfsFile(IgniteFsPath path, int len, Collection<GgfsBlock> blocks) {
             this.path = path;
             this.len = len;
             this.blocks = blocks;
         }
 
         /** @return Path. */
-        GridGgfsPath path() {
+        IgniteFsPath path() {
             return path;
         }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
index b2875a7..3194fdf 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
@@ -163,13 +163,13 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
      * @throws Exception In case of exception.
      */
     public void testCreateFile() throws Exception {
-        GridGgfsPath root = new GridGgfsPath("/");
-        GridGgfsPath path = new GridGgfsPath("/asdf");
+        IgniteFsPath root = new IgniteFsPath("/");
+        IgniteFsPath path = new IgniteFsPath("/asdf");
 
         long max = 100L * CFG_BLOCK_SIZE / WRITING_THREADS_CNT;
 
         for (long size = 0; size <= max; size = size * 15 / 10 + 1) {
-            assertEquals(Collections.<GridGgfsPath>emptyList(), fs.listPaths(root));
+            assertEquals(Collections.<IgniteFsPath>emptyList(), fs.listPaths(root));
 
             testCreateFile(path, size, new Random().nextInt());
         }
@@ -177,7 +177,7 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
 
     /** @throws Exception If failed. */
     public void testCreateFileColocated() throws Exception {
-        GridGgfsPath path = new GridGgfsPath("/colocated");
+        IgniteFsPath path = new IgniteFsPath("/colocated");
 
         UUID uuid = UUID.randomUUID();
 
@@ -202,7 +202,7 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
 
         GridGgfsFile info = fs.info(path);
 
-        Collection<GridGgfsBlockLocation> affNodes = fs.affinity(path, 0, info.length());
+        Collection<IgniteFsBlockLocation> affNodes = fs.affinity(path, 0, info.length());
 
         assertEquals(1, affNodes.size());
         Collection<UUID> nodeIds = F.first(affNodes).nodeIds();
@@ -219,7 +219,7 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
 
         GridTestUtils.setFieldValue(fragmentizer, "fragmentizerEnabled", false);
 
-        GridGgfsPath path = new GridGgfsPath("/file");
+        IgniteFsPath path = new IgniteFsPath("/file");
 
         try {
             IgniteFs fs0 = grid(0).fileSystem("ggfs");
@@ -306,17 +306,17 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
      * @param salt Salt for file content generation.
      * @throws Exception In case of any exception.
      */
-    private void testCreateFile(final GridGgfsPath path, final long size, final int salt) throws Exception {
+    private void testCreateFile(final IgniteFsPath path, final long size, final int salt) throws Exception {
         info("Create file [path=" + path + ", size=" + size + ", salt=" + salt + ']');
 
         final AtomicInteger cnt = new AtomicInteger(0);
-        final Collection<GridGgfsPath> cleanUp = new ConcurrentLinkedQueue<>();
+        final Collection<IgniteFsPath> cleanUp = new ConcurrentLinkedQueue<>();
 
         long time = runMultiThreaded(new Callable<Object>() {
             @Override public Object call() throws Exception {
                 int id = cnt.incrementAndGet();
 
-                GridGgfsPath f = new GridGgfsPath(path.parent(), "asdf" + (id > 1 ? "-" + id : ""));
+                IgniteFsPath f = new IgniteFsPath(path.parent(), "asdf" + (id > 1 ? "-" + id : ""));
 
                 try (GridGgfsOutputStream out = fs.create(f, 0, true, null, 0, 1024, null)) {
                     assertNotNull(out);
@@ -373,7 +373,7 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
         if (log.isDebugEnabled())
             log.debug("File descriptor: " + desc);
 
-        Collection<GridGgfsBlockLocation> aff = fs.affinity(path, 0, desc.length());
+        Collection<IgniteFsBlockLocation> aff = fs.affinity(path, 0, desc.length());
 
         assertFalse("Affinity: " + aff, desc.length() != 0 && aff.isEmpty());
 
@@ -388,7 +388,7 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
 
         info("Cleanup files: " + cleanUp);
 
-        for (GridGgfsPath f : cleanUp) {
+        for (IgniteFsPath f : cleanUp) {
             fs.delete(f, true);
             assertNull(fs.info(f));
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
index 3f6ac37..f01b253 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
@@ -43,7 +43,7 @@ public class GridGgfsTaskSelfTest extends GridGgfsCommonAbstractTest {
         "word6", "word7"};
 
     /** File path. */
-    private static final GridGgfsPath FILE = new GridGgfsPath("/file");
+    private static final IgniteFsPath FILE = new IgniteFsPath("/file");
 
     /** Shared IP finder. */
     private static final GridTcpDiscoveryIpFinder IP_FINDER = new GridTcpDiscoveryVmIpFinder(true);
@@ -230,7 +230,7 @@ public class GridGgfsTaskSelfTest extends GridGgfsCommonAbstractTest {
      */
     private static class Task extends GridGgfsTask<String, IgniteBiTuple<Long, Integer>> {
         /** {@inheritDoc} */
-        @Override public GridGgfsJob createJob(GridGgfsPath path, GridGgfsFileRange range,
+        @Override public GridGgfsJob createJob(IgniteFsPath path, GridGgfsFileRange range,
             GridGgfsTaskArgs<String> args) throws GridException {
             return new Job();
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
index ac46f14..affd964 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
@@ -33,7 +33,7 @@ import static org.gridgain.grid.ggfs.GridGgfsMode.*;
  */
 public class GridGgfsAbstractRecordResolverSelfTest extends GridCommonAbstractTest {
     /** File path. */
-    protected static final GridGgfsPath FILE = new GridGgfsPath("/file");
+    protected static final IgniteFsPath FILE = new IgniteFsPath("/file");
 
     /** Shared IP finder. */
     private final GridTcpDiscoveryIpFinder ipFinder = new GridTcpDiscoveryVmIpFinder(true);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
index d66a593..9fa7c00 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
@@ -263,7 +263,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
             boolean initSecondary = paths.defaultMode() == PROXY;
 
             if (paths.pathModes() != null && !paths.pathModes().isEmpty()) {
-                for (T2<GridGgfsPath, GridGgfsMode> pathMode : paths.pathModes()) {
+                for (T2<IgniteFsPath, GridGgfsMode> pathMode : paths.pathModes()) {
                     GridGgfsMode mode = pathMode.getValue();
 
                     initSecondary |= mode == PROXY;
@@ -404,7 +404,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
                 secondaryFs.setTimes(toSecondary(p), mtime, atime);
             }
             else {
-                GridGgfsPath path = convert(p);
+                IgniteFsPath path = convert(p);
 
                 rmtClient.setTimes(path, atime, mtime);
             }
@@ -476,7 +476,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
         enterBusy();
 
         try {
-            GridGgfsPath path = convert(f);
+            IgniteFsPath path = convert(f);
             GridGgfsMode mode = mode(path);
 
             if (mode == PROXY) {
@@ -544,7 +544,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
         OutputStream out = null;
 
         try {
-            GridGgfsPath path = convert(f);
+            IgniteFsPath path = convert(f);
             GridGgfsMode mode = mode(path);
 
             if (LOG.isDebugEnabled())
@@ -622,7 +622,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
         enterBusy();
 
         try {
-            GridGgfsPath path = convert(f);
+            IgniteFsPath path = convert(f);
             GridGgfsMode mode = mode(path);
 
             if (LOG.isDebugEnabled())
@@ -687,8 +687,8 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
         enterBusy();
 
         try {
-            GridGgfsPath srcPath = convert(src);
-            GridGgfsPath dstPath = convert(dst);
+            IgniteFsPath srcPath = convert(src);
+            IgniteFsPath dstPath = convert(dst);
             GridGgfsMode mode = mode(srcPath);
 
             if (mode == PROXY) {
@@ -739,7 +739,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
         enterBusy();
 
         try {
-            GridGgfsPath path = convert(f);
+            IgniteFsPath path = convert(f);
             GridGgfsMode mode = mode(path);
 
             if (mode == PROXY) {
@@ -784,7 +784,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
         enterBusy();
 
         try {
-            GridGgfsPath path = convert(f);
+            IgniteFsPath path = convert(f);
             GridGgfsMode mode = mode(path);
 
             if (mode == PROXY) {
@@ -898,7 +898,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
         enterBusy();
 
         try {
-            GridGgfsPath path = convert(f);
+            IgniteFsPath path = convert(f);
             GridGgfsMode mode = mode(path);
 
             if (mode == PROXY) {
@@ -983,7 +983,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
                 return secondaryFs.getContentSummary(toSecondary(f));
             }
             else {
-                GridGgfsPathSummary sum = rmtClient.contentSummary(convert(f));
+                IgniteFsPathSummary sum = rmtClient.contentSummary(convert(f));
 
                 return new ContentSummary(sum.totalLength(), sum.filesCount(), sum.directoriesCount(),
                     -1, sum.totalLength(), rmtClient.fsStatus().spaceTotal());
@@ -1001,7 +1001,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
         enterBusy();
 
         try {
-            GridGgfsPath path = convert(status.getPath());
+            IgniteFsPath path = convert(status.getPath());
 
             if (mode(status.getPath()) == PROXY) {
                 if (secondaryFs == null) {
@@ -1017,7 +1017,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
             else {
                 long now = System.currentTimeMillis();
 
-                List<GridGgfsBlockLocation> affinity = new ArrayList<>(rmtClient.affinity(path, start, len));
+                List<IgniteFsBlockLocation> affinity = new ArrayList<>(rmtClient.affinity(path, start, len));
 
                 BlockLocation[] arr = new BlockLocation[affinity.size()];
 
@@ -1061,7 +1061,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
      * @param path GGFS path.
      * @return Path mode.
      */
-    public GridGgfsMode mode(GridGgfsPath path) {
+    public GridGgfsMode mode(IgniteFsPath path) {
         return modeRslvr.resolveMode(path);
     }
 
@@ -1133,7 +1133,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
      * @param path GGFS path.
      * @return Hadoop path.
      */
-    private Path convert(GridGgfsPath path) {
+    private Path convert(IgniteFsPath path) {
         return new Path(GGFS_SCHEME, uriAuthority, path.toString());
     }
 
@@ -1143,12 +1143,12 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
      * @param path Hadoop path.
      * @return GGFS path.
      */
-    @Nullable private GridGgfsPath convert(@Nullable Path path) {
+    @Nullable private IgniteFsPath convert(@Nullable Path path) {
         if (path == null)
             return null;
 
-        return path.isAbsolute() ? new GridGgfsPath(path.toUri().getPath()) :
-            new GridGgfsPath(convert(workingDir.get()), path.toUri().getPath());
+        return path.isAbsolute() ? new IgniteFsPath(path.toUri().getPath()) :
+            new IgniteFsPath(convert(workingDir.get()), path.toUri().getPath());
     }
 
     /**
@@ -1157,7 +1157,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
      * @param block GGFS affinity block location.
      * @return Hadoop affinity block location.
      */
-    private BlockLocation convert(GridGgfsBlockLocation block) {
+    private BlockLocation convert(IgniteFsBlockLocation block) {
         Collection<String> names = block.names();
         Collection<String> hosts = block.hosts();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
index 3bc1b1b..e7dc2b3 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
@@ -83,7 +83,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
     private GridGgfsHadoopWrapper rmtClient;
 
     /** Working directory. */
-    private GridGgfsPath workingDir;
+    private IgniteFsPath workingDir;
 
     /** URI. */
     private URI uri;
@@ -143,7 +143,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
             throw e;
         }
 
-        workingDir = new GridGgfsPath("/user/" + cfg.get(MRJobConfig.USER_NAME, DFLT_USER_NAME));
+        workingDir = new IgniteFsPath("/user/" + cfg.get(MRJobConfig.USER_NAME, DFLT_USER_NAME));
     }
 
     /** {@inheritDoc} */
@@ -258,7 +258,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
             boolean initSecondary = paths.defaultMode() == PROXY;
 
             if (paths.pathModes() != null) {
-                for (T2<GridGgfsPath, GridGgfsMode> pathMode : paths.pathModes()) {
+                for (T2<IgniteFsPath, GridGgfsMode> pathMode : paths.pathModes()) {
                     GridGgfsMode mode = pathMode.getValue();
 
                     initSecondary |= mode == PROXY;
@@ -421,7 +421,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
         enterBusy();
 
         try {
-            GridGgfsPath path = convert(f);
+            IgniteFsPath path = convert(f);
             GridGgfsMode mode = modeRslvr.resolveMode(path);
 
             if (mode == PROXY) {
@@ -496,7 +496,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
         OutputStream out = null;
 
         try {
-            GridGgfsPath path = convert(f);
+            IgniteFsPath path = convert(f);
             GridGgfsMode mode = modeRslvr.resolveMode(path);
 
             if (LOG.isDebugEnabled())
@@ -594,8 +594,8 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
         enterBusy();
 
         try {
-            GridGgfsPath srcPath = convert(src);
-            GridGgfsPath dstPath = convert(dst);
+            IgniteFsPath srcPath = convert(src);
+            IgniteFsPath dstPath = convert(dst);
             Set<GridGgfsMode> childrenModes = modeRslvr.resolveChildrenModes(srcPath);
 
             if (childrenModes.contains(PROXY)) {
@@ -622,7 +622,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
         enterBusy();
 
         try {
-            GridGgfsPath path = convert(f);
+            IgniteFsPath path = convert(f);
             GridGgfsMode mode = modeRslvr.resolveMode(path);
             Set<GridGgfsMode> childrenModes = modeRslvr.resolveChildrenModes(path);
 
@@ -667,7 +667,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
         enterBusy();
 
         try {
-            GridGgfsPath path = convert(f);
+            IgniteFsPath path = convert(f);
             GridGgfsMode mode = modeRslvr.resolveMode(path);
 
             if (mode == PROXY) {
@@ -727,7 +727,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
         enterBusy();
 
         try {
-            GridGgfsPath path = convert(f);
+            IgniteFsPath path = convert(f);
             GridGgfsMode mode = modeRslvr.resolveMode(path);
 
             if (mode == PROXY) {
@@ -775,7 +775,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
     @Override public BlockLocation[] getFileBlockLocations(Path path, long start, long len) throws IOException {
         A.notNull(path, "path");
 
-        GridGgfsPath ggfsPath = convert(path);
+        IgniteFsPath ggfsPath = convert(path);
 
         enterBusy();
 
@@ -785,7 +785,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
             else {
                 long now = System.currentTimeMillis();
 
-                List<GridGgfsBlockLocation> affinity = new ArrayList<>(
+                List<IgniteFsBlockLocation> affinity = new ArrayList<>(
                     rmtClient.affinity(ggfsPath, start, len));
 
                 BlockLocation[] arr = new BlockLocation[affinity.size()];
@@ -882,7 +882,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
      * @param path GGFS path.
      * @return Hadoop path.
      */
-    private Path convert(GridGgfsPath path) {
+    private Path convert(IgniteFsPath path) {
         return new Path(GGFS_SCHEME, uriAuthority, path.toString());
     }
 
@@ -892,12 +892,12 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
      * @param path Hadoop path.
      * @return GGFS path.
      */
-    @Nullable private GridGgfsPath convert(Path path) {
+    @Nullable private IgniteFsPath convert(Path path) {
         if (path == null)
             return null;
 
-        return path.isAbsolute() ? new GridGgfsPath(path.toUri().getPath()) :
-            new GridGgfsPath(workingDir, path.toUri().getPath());
+        return path.isAbsolute() ? new IgniteFsPath(path.toUri().getPath()) :
+            new IgniteFsPath(workingDir, path.toUri().getPath());
     }
 
     /**
@@ -906,7 +906,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
      * @param block GGFS affinity block location.
      * @return Hadoop affinity block location.
      */
-    private BlockLocation convert(GridGgfsBlockLocation block) {
+    private BlockLocation convert(IgniteFsBlockLocation block) {
         Collection<String> names = block.names();
         Collection<String> hosts = block.hosts();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoop.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoop.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoop.java
index 4e92279..558500c 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoop.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoop.java
@@ -44,7 +44,7 @@ public interface GridGgfsHadoop {
      * @return Future for info operation.
      * @throws GridException If failed.
      */
-    public GridGgfsFile info(GridGgfsPath path) throws GridException, IOException;
+    public GridGgfsFile info(IgniteFsPath path) throws GridException, IOException;
 
     /**
      * Command to update file properties.
@@ -54,7 +54,7 @@ public interface GridGgfsHadoop {
      * @return Future for update operation.
      * @throws GridException If failed.
      */
-    public GridGgfsFile update(GridGgfsPath path, Map<String, String> props) throws GridException, IOException;
+    public GridGgfsFile update(IgniteFsPath path, Map<String, String> props) throws GridException, IOException;
 
     /**
      * Sets last access time and last modification time for a file.
@@ -64,7 +64,7 @@ public interface GridGgfsHadoop {
      * @param modificationTime Last modification time to set.
      * @throws GridException If failed.
      */
-    public Boolean setTimes(GridGgfsPath path, long accessTime, long modificationTime) throws GridException,
+    public Boolean setTimes(IgniteFsPath path, long accessTime, long modificationTime) throws GridException,
         IOException;
 
     /**
@@ -75,7 +75,7 @@ public interface GridGgfsHadoop {
      * @return Future for rename operation.
      * @throws GridException If failed.
      */
-    public Boolean rename(GridGgfsPath src, GridGgfsPath dest) throws GridException, IOException;
+    public Boolean rename(IgniteFsPath src, IgniteFsPath dest) throws GridException, IOException;
 
     /**
      * Command to delete given path.
@@ -85,7 +85,7 @@ public interface GridGgfsHadoop {
      * @return Future for delete operation.
      * @throws GridException If failed.
      */
-    public Boolean delete(GridGgfsPath path, boolean recursive) throws GridException, IOException;
+    public Boolean delete(IgniteFsPath path, boolean recursive) throws GridException, IOException;
 
     /**
      * Command to get affinity for given path, offset and length.
@@ -96,7 +96,7 @@ public interface GridGgfsHadoop {
      * @return Future for affinity command.
      * @throws GridException If failed.
      */
-    public Collection<GridGgfsBlockLocation> affinity(GridGgfsPath path, long start, long len) throws GridException,
+    public Collection<IgniteFsBlockLocation> affinity(IgniteFsPath path, long start, long len) throws GridException,
         IOException;
 
     /**
@@ -106,7 +106,7 @@ public interface GridGgfsHadoop {
      * @return Future that will be completed when summary is received.
      * @throws GridException If failed.
      */
-    public GridGgfsPathSummary contentSummary(GridGgfsPath path) throws GridException, IOException;
+    public IgniteFsPathSummary contentSummary(IgniteFsPath path) throws GridException, IOException;
 
     /**
      * Command to create directories.
@@ -115,7 +115,7 @@ public interface GridGgfsHadoop {
      * @return Future for mkdirs operation.
      * @throws GridException If failed.
      */
-    public Boolean mkdirs(GridGgfsPath path, Map<String, String> props) throws GridException, IOException;
+    public Boolean mkdirs(IgniteFsPath path, Map<String, String> props) throws GridException, IOException;
 
     /**
      * Command to get list of files in directory.
@@ -124,7 +124,7 @@ public interface GridGgfsHadoop {
      * @return Future for listFiles operation.
      * @throws GridException If failed.
      */
-    public Collection<GridGgfsFile> listFiles(GridGgfsPath path) throws GridException, IOException;
+    public Collection<GridGgfsFile> listFiles(IgniteFsPath path) throws GridException, IOException;
 
     /**
      * Command to get directory listing.
@@ -133,7 +133,7 @@ public interface GridGgfsHadoop {
      * @return Future for listPaths operation.
      * @throws GridException If failed.
      */
-    public Collection<GridGgfsPath> listPaths(GridGgfsPath path) throws GridException, IOException;
+    public Collection<IgniteFsPath> listPaths(IgniteFsPath path) throws GridException, IOException;
 
     /**
      * Performs status request.
@@ -150,7 +150,7 @@ public interface GridGgfsHadoop {
      * @return Future for open operation.
      * @throws GridException If failed.
      */
-    public GridGgfsHadoopStreamDelegate open(GridGgfsPath path) throws GridException, IOException;
+    public GridGgfsHadoopStreamDelegate open(IgniteFsPath path) throws GridException, IOException;
 
     /**
      * Command to open file for reading.
@@ -159,7 +159,7 @@ public interface GridGgfsHadoop {
      * @return Future for open operation.
      * @throws GridException If failed.
      */
-    public GridGgfsHadoopStreamDelegate open(GridGgfsPath path, int seqReadsBeforePrefetch) throws GridException,
+    public GridGgfsHadoopStreamDelegate open(IgniteFsPath path, int seqReadsBeforePrefetch) throws GridException,
         IOException;
 
     /**
@@ -173,7 +173,7 @@ public interface GridGgfsHadoop {
      * @return Stream descriptor.
      * @throws GridException If failed.
      */
-    public GridGgfsHadoopStreamDelegate create(GridGgfsPath path, boolean overwrite, boolean colocate,
+    public GridGgfsHadoopStreamDelegate create(IgniteFsPath path, boolean overwrite, boolean colocate,
         int replication, long blockSize, @Nullable Map<String, String> props) throws GridException, IOException;
 
     /**
@@ -185,6 +185,6 @@ public interface GridGgfsHadoop {
      * @return Stream descriptor.
      * @throws GridException If failed.
      */
-    public GridGgfsHadoopStreamDelegate append(GridGgfsPath path, boolean create,
+    public GridGgfsHadoopStreamDelegate append(IgniteFsPath path, boolean create,
         @Nullable Map<String, String> props) throws GridException, IOException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f3d93762/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
index 493e455..09bb563 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
@@ -76,7 +76,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
      * @param path GGFS path.
      * @return Hadoop path.
      */
-    private Path convert(GridGgfsPath path) {
+    private Path convert(IgniteFsPath path) {
         URI uri = fileSys.getUri();
 
         return new Path(uri.getScheme(), uri.getAuthority(), path.toString());
@@ -116,7 +116,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
         else if (e instanceof PathIsNotEmptyDirectoryException)
             return new GridGgfsDirectoryNotEmptyException(e);
         else if (e instanceof PathExistsException)
-            return new GridGgfsPathAlreadyExistsException(msg, e);
+            return new IgniteFsPathAlreadyExistsException(msg, e);
         else
             return new GridGgfsException(msg, e);
     }
@@ -138,7 +138,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
     }
 
     /** {@inheritDoc} */
-    @Override public boolean exists(GridGgfsPath path) throws GridException {
+    @Override public boolean exists(IgniteFsPath path) throws GridException {
         try {
             return fileSys.exists(convert(path));
         }
@@ -148,7 +148,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public GridGgfsFile update(GridGgfsPath path, Map<String, String> props) throws GridException {
+    @Nullable @Override public GridGgfsFile update(IgniteFsPath path, Map<String, String> props) throws GridException {
         GridGgfsHadoopFSProperties props0 = new GridGgfsHadoopFSProperties(props);
 
         try {
@@ -167,7 +167,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
     }
 
     /** {@inheritDoc} */
-    @Override public void rename(GridGgfsPath src, GridGgfsPath dest) throws GridException {
+    @Override public void rename(IgniteFsPath src, IgniteFsPath dest) throws GridException {
         // Delegate to the secondary file system.
         try {
             if (!fileSys.rename(convert(src), convert(dest)))
@@ -180,7 +180,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
     }
 
     /** {@inheritDoc} */
-    @Override public boolean delete(GridGgfsPath path, boolean recursive) throws GridException {
+    @Override public boolean delete(IgniteFsPath path, boolean recursive) throws GridException {
         try {
             return fileSys.delete(convert(path), recursive);
         }
@@ -190,7 +190,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
     }
 
     /** {@inheritDoc} */
-    @Override public void mkdirs(GridGgfsPath path) throws GridException {
+    @Override public void mkdirs(IgniteFsPath path) throws GridException {
         try {
             if (!fileSys.mkdirs(convert(path)))
                 throw new GridException("Failed to make directories [path=" + path + "]");
@@ -201,7 +201,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
     }
 
     /** {@inheritDoc} */
-    @Override public void mkdirs(GridGgfsPath path, @Nullable Map<String, String> props) throws GridException {
+    @Override public void mkdirs(IgniteFsPath path, @Nullable Map<String, String> props) throws GridException {
         try {
             if (!fileSys.mkdirs(convert(path), new GridGgfsHadoopFSProperties(props).permission()))
                 throw new GridException("Failed to make directories [path=" + path + ", props=" + props + "]");
@@ -212,17 +212,17 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsPath> listPaths(GridGgfsPath path) throws GridException {
+    @Override public Collection<IgniteFsPath> listPaths(IgniteFsPath path) throws GridException {
         try {
             FileStatus[] statuses = fileSys.listStatus(convert(path));
 
             if (statuses == null)
                 throw new GridGgfsFileNotFoundException("Failed to list files (path not found): " + path);
 
-            Collection<GridGgfsPath> res = new ArrayList<>(statuses.length);
+            Collection<IgniteFsPath> res = new ArrayList<>(statuses.length);
 
             for (FileStatus status : statuses)
-                res.add(new GridGgfsPath(path, status.getPath().getName()));
+                res.add(new IgniteFsPath(path, status.getPath().getName()));
 
             return res;
         }
@@ -235,7 +235,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsFile> listFiles(GridGgfsPath path) throws GridException {
+    @Override public Collection<GridGgfsFile> listFiles(IgniteFsPath path) throws GridException {
         try {
             FileStatus[] statuses = fileSys.listStatus(convert(path));
 
@@ -249,7 +249,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
                     new GridGgfsFileInfo((int)status.getBlockSize(), status.getLen(), null, null, false,
                     properties(status));
 
-                res.add(new GridGgfsFileImpl(new GridGgfsPath(path, status.getPath().getName()), fsInfo, 1));
+                res.add(new GridGgfsFileImpl(new IgniteFsPath(path, status.getPath().getName()), fsInfo, 1));
             }
 
             return res;
@@ -263,12 +263,12 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsReader open(GridGgfsPath path, int bufSize) {
+    @Override public IgniteFsReader open(IgniteFsPath path, int bufSize) {
         return new GridGgfsHadoopReader(fileSys, convert(path), bufSize);
     }
 
     /** {@inheritDoc} */
-    @Override public OutputStream create(GridGgfsPath path, boolean overwrite) throws GridException {
+    @Override public OutputStream create(IgniteFsPath path, boolean overwrite) throws GridException {
         try {
             return fileSys.create(convert(path), overwrite);
         }
@@ -278,7 +278,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
     }
 
     /** {@inheritDoc} */
-    @Override public OutputStream create(GridGgfsPath path, int bufSize, boolean overwrite, int replication,
+    @Override public OutputStream create(IgniteFsPath path, int bufSize, boolean overwrite, int replication,
         long blockSize, @Nullable Map<String, String> props) throws GridException {
         GridGgfsHadoopFSProperties props0 =
             new GridGgfsHadoopFSProperties(props != null ? props : Collections.<String, String>emptyMap());
@@ -295,7 +295,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
     }
 
     /** {@inheritDoc} */
-    @Override public OutputStream append(GridGgfsPath path, int bufSize, boolean create,
+    @Override public OutputStream append(IgniteFsPath path, int bufSize, boolean create,
         @Nullable Map<String, String> props) throws GridException {
         try {
             return fileSys.append(convert(path), bufSize);
@@ -306,7 +306,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile info(final GridGgfsPath path) throws GridException {
+    @Override public GridGgfsFile info(final IgniteFsPath path) throws GridException {
         try {
             final FileStatus status = fileSys.getFileStatus(convert(path));
 
@@ -316,7 +316,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
             final Map<String, String> props = properties(status);
 
             return new GridGgfsFile() {
-                @Override public GridGgfsPath path() {
+                @Override public IgniteFsPath path() {
                     return path;
                 }
 


[21/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
# Renaming


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

Branch: refs/heads/master
Commit: 1d26f5fdfaa44ff74368515215b47372abc97fb6
Parents: 3ba3dc4
Author: sboikov <sb...@gridgain.com>
Authored: Fri Dec 5 11:21:05 2014 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Dec 5 11:21:05 2014 +0300

----------------------------------------------------------------------
 .../org/gridgain/examples/ggfs/GgfsExample.java |   2 +-
 .../main/java/org/apache/ignite/IgniteFs.java   |   8 +-
 .../gridgain/grid/ggfs/GridGgfsInputStream.java |  72 ------
 .../GridGgfsInvalidHdfsVersionException.java    |  34 ---
 .../grid/ggfs/GridGgfsInvalidPathException.java |  49 ----
 .../org/gridgain/grid/ggfs/GridGgfsMetrics.java | 151 ------------
 .../GridGgfsParentNotDirectoryException.java    |   2 +-
 .../ggfs/IgniteFsFileNotFoundException.java     |   2 +-
 .../gridgain/grid/ggfs/IgniteFsInputStream.java |  72 ++++++
 .../IgniteFsInvalidHdfsVersionException.java    |  34 +++
 .../grid/ggfs/IgniteFsInvalidPathException.java |  49 ++++
 .../org/gridgain/grid/ggfs/IgniteFsMetrics.java | 151 ++++++++++++
 .../IgniteFsPathAlreadyExistsException.java     |   2 +-
 .../GridGgfsInputStreamJobAdapter.java          |   4 +-
 .../grid/ggfs/mapreduce/GridGgfsJob.java        |   6 +-
 .../mapreduce/GridGgfsRangeInputStream.java     |  10 +-
 .../ggfs/mapreduce/GridGgfsRecordResolver.java  |   2 +-
 .../GridGgfsByteDelimiterRecordResolver.java    |   6 +-
 .../GridGgfsFixedLengthRecordResolver.java      |   2 +-
 .../ggfs/common/GridGgfsControlResponse.java    |   4 +-
 .../processors/ggfs/GridGgfsAsyncImpl.java      |   2 +-
 .../kernal/processors/ggfs/GridGgfsImpl.java    |  22 +-
 .../ggfs/GridGgfsInputStreamAdapter.java        |   2 +-
 .../ggfs/GridGgfsInputStreamImpl.java           |   2 +-
 .../kernal/processors/ggfs/GridGgfsJobImpl.java |   2 +-
 .../processors/ggfs/GridGgfsMetaManager.java    |  16 +-
 .../processors/ggfs/GridGgfsMetricsAdapter.java | 231 -------------------
 .../processors/ggfs/IgniteFsMetricsAdapter.java | 231 +++++++++++++++++++
 .../kernal/visor/ggfs/VisorGgfsMetrics.java     |   4 +-
 .../ggfs/GridGgfsEventsAbstractSelfTest.java    |   2 +-
 .../grid/ggfs/GridGgfsFragmentizerSelfTest.java |   6 +-
 ...heGgfsPerBlockLruEvictionPolicySelfTest.java |   8 +-
 .../ggfs/GridGgfsAbstractSelfTest.java          |   4 +-
 .../ggfs/GridGgfsDualAbstractSelfTest.java      |   6 +-
 .../ggfs/GridGgfsMetricsSelfTest.java           |  16 +-
 .../processors/ggfs/GridGgfsModesSelfTest.java  |   6 +-
 .../ggfs/GridGgfsProcessorSelfTest.java         |   6 +-
 .../processors/ggfs/GridGgfsSizeSelfTest.java   |   2 +-
 .../ggfs/GridGgfsStreamsSelfTest.java           |   6 +-
 .../processors/ggfs/GridGgfsTaskSelfTest.java   |   2 +-
 .../GridGgfsAbstractRecordResolverSelfTest.java |   2 +-
 ...GgfsByteDelimiterRecordResolverSelfTest.java |   4 +-
 ...idGgfsFixedLengthRecordResolverSelfTest.java |   4 +-
 ...sNewLineDelimiterRecordResolverSelfTest.java |   4 +-
 ...fsStringDelimiterRecordResolverSelfTest.java |   4 +-
 .../hadoop/GridGgfsHadoopFileSystemWrapper.java |   2 +-
 ...dGgfsHadoop20FileSystemAbstractSelfTest.java |   2 +-
 .../GridGgfsHadoopDualAbstractSelfTest.java     |   2 +-
 ...idHadoopDefaultMapReducePlannerSelfTest.java |   2 +-
 49 files changed, 632 insertions(+), 632 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java
index 8049b75..ecdd947 100644
--- a/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java
+++ b/examples/src/main/java/org/gridgain/examples/ggfs/GgfsExample.java
@@ -220,7 +220,7 @@ public final class GgfsExample {
 
         byte[] data = new byte[(int)fs.info(path).length()];
 
-        try (GridGgfsInputStream in = fs.open(path)) {
+        try (IgniteFsInputStream in = fs.open(path)) {
             in.read(data);
         }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
index b2780fc..cf9f9a6 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
@@ -88,7 +88,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @throws GridException In case of error.
      * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist.
      */
-    public GridGgfsInputStream open(IgniteFsPath path) throws GridException;
+    public IgniteFsInputStream open(IgniteFsPath path) throws GridException;
 
     /**
      * Opens a file for reading.
@@ -99,7 +99,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @throws GridException In case of error.
      * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist.
      */
-    @Override public GridGgfsInputStream open(IgniteFsPath path, int bufSize) throws GridException;
+    @Override public IgniteFsInputStream open(IgniteFsPath path, int bufSize) throws GridException;
 
     /**
      * Opens a file for reading.
@@ -111,7 +111,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @throws GridException In case of error.
      * @throws org.gridgain.grid.ggfs.IgniteFsFileNotFoundException If path doesn't exist.
      */
-    public GridGgfsInputStream open(IgniteFsPath path, int bufSize, int seqReadsBeforePrefetch) throws GridException;
+    public IgniteFsInputStream open(IgniteFsPath path, int bufSize, int seqReadsBeforePrefetch) throws GridException;
 
     /**
      * Creates a file and opens it for writing.
@@ -229,7 +229,7 @@ public interface IgniteFs extends IgniteFsFileSystem, IgniteAsyncSupport {
      * @return Metrics.
      * @throws GridException In case of error.
      */
-    public GridGgfsMetrics metrics() throws GridException;
+    public IgniteFsMetrics metrics() throws GridException;
 
     /**
      * Resets metrics for this file system.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInputStream.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInputStream.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInputStream.java
deleted file mode 100644
index e3f8c0b..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInputStream.java
+++ /dev/null
@@ -1,72 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import java.io.*;
-
-/**
- * {@code GGFS} input stream to read data from the file system.
- * It provides several additional methods for asynchronous access.
- */
-public abstract class GridGgfsInputStream extends InputStream implements IgniteFsReader {
-    /**
-     * Gets file length during file open.
-     *
-     * @return File length.
-     */
-    public abstract long length();
-
-    /**
-     * Seek to the specified position.
-     *
-     * @param pos Position to seek to.
-     * @throws IOException In case of IO exception.
-     */
-    public abstract void seek(long pos) throws IOException;
-
-    /**
-     * Get the current position in the input stream.
-     *
-     * @return The current position in the input stream.
-     * @throws IOException In case of IO exception.
-     */
-    public abstract long position() throws IOException;
-
-    /**
-     * Read bytes from the given position in the stream to the given buffer.
-     * Continues to read until passed buffer becomes filled.
-     *
-     * @param pos Position in the input stream to seek.
-     * @param buf Buffer into which data is read.
-     * @throws IOException In case of IO exception.
-     */
-    public abstract void readFully(long pos, byte[] buf) throws IOException;
-
-    /**
-     *
-     * @param pos Position in the input stream to seek.
-     * @param buf Buffer into which data is read.
-     * @param off Offset in the buffer from which stream data should be written.
-     * @param len The number of bytes to read.
-     * @throws IOException In case of IO exception.
-     */
-    public abstract void readFully(long pos, byte[] buf, int off, int len) throws IOException;
-
-    /**
-     *
-     * @param pos Position in the input stream to seek.
-     * @param buf Buffer into which data is read.
-     * @param off Offset in the buffer from which stream data should be written.
-     * @param len The number of bytes to read.
-     * @return Total number of bytes read into the buffer, or -1 if there is no more data (EOF).
-     * @throws IOException In case of IO exception.
-     */
-    @Override public abstract int read(long pos, byte[] buf, int off, int len) throws IOException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidHdfsVersionException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidHdfsVersionException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidHdfsVersionException.java
deleted file mode 100644
index 1bb28c2..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidHdfsVersionException.java
+++ /dev/null
@@ -1,34 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-/**
- * Exception thrown when GridGain detects that remote HDFS version differs from version of HDFS libraries
- * in GridGain classpath.
- */
-public class GridGgfsInvalidHdfsVersionException extends IgniteFsException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * @param msg Error message.
-     */
-    public GridGgfsInvalidHdfsVersionException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * @param msg Error message.
-     * @param cause Error cause.
-     */
-    public GridGgfsInvalidHdfsVersionException(String msg, Throwable cause) {
-        super(msg, cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidPathException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidPathException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidPathException.java
deleted file mode 100644
index 76627a8..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsInvalidPathException.java
+++ /dev/null
@@ -1,49 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-import org.jetbrains.annotations.*;
-
-/**
- * {@code GGFS} exception indicating that operation target is invalid
- * (e.g. not a file while expecting to be a file).
- */
-public class GridGgfsInvalidPathException extends IgniteFsException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Creates exception with given error message.
-     *
-     * @param msg Error message.
-     */
-    public GridGgfsInvalidPathException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * Creates exception with given exception cause.
-     *
-     * @param cause Exception cause.
-     */
-    public GridGgfsInvalidPathException(Throwable cause) {
-        super(cause);
-    }
-
-    /**
-     * Creates exception with given error message and exception cause.
-     *
-     * @param msg Error message.
-     * @param cause Error cause.
-     */
-    public GridGgfsInvalidPathException(String msg, @Nullable Throwable cause) {
-        super(msg, cause);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMetrics.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMetrics.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMetrics.java
deleted file mode 100644
index 31fffea..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsMetrics.java
+++ /dev/null
@@ -1,151 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.ggfs;
-
-/**
- * {@code GGFS} metrics snapshot for the file system. Note, that some metrics are global and
- * some are local (i.e. per each node).
- */
-public interface GridGgfsMetrics {
-    /**
-     * Gets local used space in bytes. This is the sum of all file chunks stored on local node.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Node used space in bytes.
-     */
-    public long localSpaceSize();
-
-    /**
-     * Gets maximum amount of data that can be stored on local node. This metrics is either
-     * equal to {@link IgniteFsConfiguration#getMaxSpaceSize()}, or, if it is {@code 0}, equal to
-     * {@code 80%} of maximum heap size allocated for JVM.
-     *
-     * @return Maximum GGFS local space size.
-     */
-    public long maxSpaceSize();
-
-    /**
-    * Get used space in bytes used in the secondary file system.
-    * <p>
-    * This is a global metric.
-    *
-    * @return Used space in the secondary file system or {@code 0} in case no secondary file system is configured.
-    */
-    public long secondarySpaceSize();
-
-    /**
-     * Gets number of directories created in file system.
-     * <p>
-     * This is a global metric.
-     *
-     * @return Number of directories.
-     */
-    public int directoriesCount();
-
-    /**
-     * Gets number of files stored in file system.
-     * <p>
-     * This is a global metric.
-     *
-     * @return Number of files.
-     */
-    public int filesCount();
-
-    /**
-     * Gets number of files that are currently opened for reading.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Number of opened files.
-     */
-    public int filesOpenedForRead();
-
-    /**
-     * Gets number of files that are currently opened for writing.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Number of opened files.
-     */
-    public int filesOpenedForWrite();
-
-    /**
-     * Gets total blocks read, local and remote.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Total blocks read.
-     */
-    public long blocksReadTotal();
-
-    /**
-     * Gets total remote blocks read.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Total blocks remote read.
-     */
-    public long blocksReadRemote();
-
-    /**
-     * Gets total blocks written, local and remote.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Total blocks written.
-     */
-    public long blocksWrittenTotal();
-
-    /**
-     * Gets total remote blocks written.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Total blocks written.
-     */
-    public long blocksWrittenRemote();
-
-    /**
-     * Gets total bytes read.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Total bytes read.
-     */
-    public long bytesRead();
-
-    /**
-     * Gets total bytes read time.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Total bytes read time.
-     */
-    public long bytesReadTime();
-
-    /**
-     * Gets total bytes written.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Total bytes written.
-     */
-    public long bytesWritten();
-
-    /**
-     * Gets total bytes write time.
-     * <p>
-     * This is a local metric.
-     *
-     * @return Total bytes write time.
-     */
-    public long bytesWriteTime();
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsParentNotDirectoryException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsParentNotDirectoryException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsParentNotDirectoryException.java
index b953f38..dc71dd2 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsParentNotDirectoryException.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/GridGgfsParentNotDirectoryException.java
@@ -14,7 +14,7 @@ import org.jetbrains.annotations.*;
 /**
  * Exception thrown when parent supposed to be a directory is a file.
  */
-public class GridGgfsParentNotDirectoryException extends GridGgfsInvalidPathException {
+public class GridGgfsParentNotDirectoryException extends IgniteFsInvalidPathException {
     /** */
     private static final long serialVersionUID = 0L;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileNotFoundException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileNotFoundException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileNotFoundException.java
index 8106679..def5bc4 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileNotFoundException.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsFileNotFoundException.java
@@ -12,7 +12,7 @@ package org.gridgain.grid.ggfs;
 /**
  * {@code GGFS} exception indicating that target resource is not found.
  */
-public class IgniteFsFileNotFoundException extends GridGgfsInvalidPathException {
+public class IgniteFsFileNotFoundException extends IgniteFsInvalidPathException {
     /** */
     private static final long serialVersionUID = 0L;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInputStream.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInputStream.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInputStream.java
new file mode 100644
index 0000000..8fb669e
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInputStream.java
@@ -0,0 +1,72 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+import java.io.*;
+
+/**
+ * {@code GGFS} input stream to read data from the file system.
+ * It provides several additional methods for asynchronous access.
+ */
+public abstract class IgniteFsInputStream extends InputStream implements IgniteFsReader {
+    /**
+     * Gets file length during file open.
+     *
+     * @return File length.
+     */
+    public abstract long length();
+
+    /**
+     * Seek to the specified position.
+     *
+     * @param pos Position to seek to.
+     * @throws IOException In case of IO exception.
+     */
+    public abstract void seek(long pos) throws IOException;
+
+    /**
+     * Get the current position in the input stream.
+     *
+     * @return The current position in the input stream.
+     * @throws IOException In case of IO exception.
+     */
+    public abstract long position() throws IOException;
+
+    /**
+     * Read bytes from the given position in the stream to the given buffer.
+     * Continues to read until passed buffer becomes filled.
+     *
+     * @param pos Position in the input stream to seek.
+     * @param buf Buffer into which data is read.
+     * @throws IOException In case of IO exception.
+     */
+    public abstract void readFully(long pos, byte[] buf) throws IOException;
+
+    /**
+     *
+     * @param pos Position in the input stream to seek.
+     * @param buf Buffer into which data is read.
+     * @param off Offset in the buffer from which stream data should be written.
+     * @param len The number of bytes to read.
+     * @throws IOException In case of IO exception.
+     */
+    public abstract void readFully(long pos, byte[] buf, int off, int len) throws IOException;
+
+    /**
+     *
+     * @param pos Position in the input stream to seek.
+     * @param buf Buffer into which data is read.
+     * @param off Offset in the buffer from which stream data should be written.
+     * @param len The number of bytes to read.
+     * @return Total number of bytes read into the buffer, or -1 if there is no more data (EOF).
+     * @throws IOException In case of IO exception.
+     */
+    @Override public abstract int read(long pos, byte[] buf, int off, int len) throws IOException;
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInvalidHdfsVersionException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInvalidHdfsVersionException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInvalidHdfsVersionException.java
new file mode 100644
index 0000000..7004311
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInvalidHdfsVersionException.java
@@ -0,0 +1,34 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+/**
+ * Exception thrown when GridGain detects that remote HDFS version differs from version of HDFS libraries
+ * in GridGain classpath.
+ */
+public class IgniteFsInvalidHdfsVersionException extends IgniteFsException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * @param msg Error message.
+     */
+    public IgniteFsInvalidHdfsVersionException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * @param msg Error message.
+     * @param cause Error cause.
+     */
+    public IgniteFsInvalidHdfsVersionException(String msg, Throwable cause) {
+        super(msg, cause);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInvalidPathException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInvalidPathException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInvalidPathException.java
new file mode 100644
index 0000000..0e7fe00
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsInvalidPathException.java
@@ -0,0 +1,49 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+import org.jetbrains.annotations.*;
+
+/**
+ * {@code GGFS} exception indicating that operation target is invalid
+ * (e.g. not a file while expecting to be a file).
+ */
+public class IgniteFsInvalidPathException extends IgniteFsException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Creates exception with given error message.
+     *
+     * @param msg Error message.
+     */
+    public IgniteFsInvalidPathException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * Creates exception with given exception cause.
+     *
+     * @param cause Exception cause.
+     */
+    public IgniteFsInvalidPathException(Throwable cause) {
+        super(cause);
+    }
+
+    /**
+     * Creates exception with given error message and exception cause.
+     *
+     * @param msg Error message.
+     * @param cause Error cause.
+     */
+    public IgniteFsInvalidPathException(String msg, @Nullable Throwable cause) {
+        super(msg, cause);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsMetrics.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsMetrics.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsMetrics.java
new file mode 100644
index 0000000..d4f7fc6
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsMetrics.java
@@ -0,0 +1,151 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.ggfs;
+
+/**
+ * {@code GGFS} metrics snapshot for the file system. Note, that some metrics are global and
+ * some are local (i.e. per each node).
+ */
+public interface IgniteFsMetrics {
+    /**
+     * Gets local used space in bytes. This is the sum of all file chunks stored on local node.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Node used space in bytes.
+     */
+    public long localSpaceSize();
+
+    /**
+     * Gets maximum amount of data that can be stored on local node. This metrics is either
+     * equal to {@link IgniteFsConfiguration#getMaxSpaceSize()}, or, if it is {@code 0}, equal to
+     * {@code 80%} of maximum heap size allocated for JVM.
+     *
+     * @return Maximum GGFS local space size.
+     */
+    public long maxSpaceSize();
+
+    /**
+    * Get used space in bytes used in the secondary file system.
+    * <p>
+    * This is a global metric.
+    *
+    * @return Used space in the secondary file system or {@code 0} in case no secondary file system is configured.
+    */
+    public long secondarySpaceSize();
+
+    /**
+     * Gets number of directories created in file system.
+     * <p>
+     * This is a global metric.
+     *
+     * @return Number of directories.
+     */
+    public int directoriesCount();
+
+    /**
+     * Gets number of files stored in file system.
+     * <p>
+     * This is a global metric.
+     *
+     * @return Number of files.
+     */
+    public int filesCount();
+
+    /**
+     * Gets number of files that are currently opened for reading.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Number of opened files.
+     */
+    public int filesOpenedForRead();
+
+    /**
+     * Gets number of files that are currently opened for writing.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Number of opened files.
+     */
+    public int filesOpenedForWrite();
+
+    /**
+     * Gets total blocks read, local and remote.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Total blocks read.
+     */
+    public long blocksReadTotal();
+
+    /**
+     * Gets total remote blocks read.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Total blocks remote read.
+     */
+    public long blocksReadRemote();
+
+    /**
+     * Gets total blocks written, local and remote.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Total blocks written.
+     */
+    public long blocksWrittenTotal();
+
+    /**
+     * Gets total remote blocks written.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Total blocks written.
+     */
+    public long blocksWrittenRemote();
+
+    /**
+     * Gets total bytes read.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Total bytes read.
+     */
+    public long bytesRead();
+
+    /**
+     * Gets total bytes read time.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Total bytes read time.
+     */
+    public long bytesReadTime();
+
+    /**
+     * Gets total bytes written.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Total bytes written.
+     */
+    public long bytesWritten();
+
+    /**
+     * Gets total bytes write time.
+     * <p>
+     * This is a local metric.
+     *
+     * @return Total bytes write time.
+     */
+    public long bytesWriteTime();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathAlreadyExistsException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathAlreadyExistsException.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathAlreadyExistsException.java
index 7ca2581..4126657 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathAlreadyExistsException.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/IgniteFsPathAlreadyExistsException.java
@@ -14,7 +14,7 @@ import org.jetbrains.annotations.*;
 /**
  * Exception thrown when target path supposed to be created already exists.
  */
-public class IgniteFsPathAlreadyExistsException extends GridGgfsInvalidPathException {
+public class IgniteFsPathAlreadyExistsException extends IgniteFsInvalidPathException {
     /** */
     private static final long serialVersionUID = 0L;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsInputStreamJobAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsInputStreamJobAdapter.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsInputStreamJobAdapter.java
index 6a1fc3f..a5ac21d 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsInputStreamJobAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsInputStreamJobAdapter.java
@@ -17,7 +17,7 @@ import org.gridgain.grid.util.*;
 import java.io.*;
 
 /**
- * Convenient {@link GridGgfsJob} adapter. It limits data returned from {@link GridGgfsInputStream} to bytes within
+ * Convenient {@link GridGgfsJob} adapter. It limits data returned from {@link org.gridgain.grid.ggfs.IgniteFsInputStream} to bytes within
  * the {@link GridGgfsFileRange} assigned to the job.
  * <p>
  * Under the covers it simply puts job's {@code GridGgfsInputStream} position to range start and wraps in into
@@ -25,7 +25,7 @@ import java.io.*;
  */
 public abstract class GridGgfsInputStreamJobAdapter extends GridGgfsJobAdapter {
     /** {@inheritDoc} */
-    @Override public final Object execute(IgniteFs ggfs, GridGgfsFileRange range, GridGgfsInputStream in)
+    @Override public final Object execute(IgniteFs ggfs, GridGgfsFileRange range, IgniteFsInputStream in)
         throws GridException, IOException {
         in.seek(range.start());
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsJob.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsJob.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsJob.java
index ae027db..84617dd 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsJob.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsJob.java
@@ -19,8 +19,8 @@ import java.io.*;
  * Defines executable unit for {@link GridGgfsTask}. Before this job is executed, it is assigned one of the
  * ranges provided by the {@link GridGgfsRecordResolver} passed to one of the {@code GridGgfs.execute(...)} methods.
  * <p>
- * {@link #execute(org.apache.ignite.IgniteFs, GridGgfsFileRange, GridGgfsInputStream)} method is given {@link GridGgfsFileRange} this
- * job is expected to operate on, and already opened {@link GridGgfsInputStream} for the file this range belongs to.
+ * {@link #execute(org.apache.ignite.IgniteFs, GridGgfsFileRange, org.gridgain.grid.ggfs.IgniteFsInputStream)} method is given {@link GridGgfsFileRange} this
+ * job is expected to operate on, and already opened {@link org.gridgain.grid.ggfs.IgniteFsInputStream} for the file this range belongs to.
  * <p>
  * Note that provided input stream has position already adjusted to range start. However, it will not
  * automatically stop on range end. This is done to provide capability in some cases to look beyond
@@ -45,7 +45,7 @@ public interface GridGgfsJob {
      * @throws GridException If execution failed.
      * @throws IOException If file system operation resulted in IO exception.
      */
-    public Object execute(IgniteFs ggfs, GridGgfsFileRange range, GridGgfsInputStream in) throws GridException,
+    public Object execute(IgniteFs ggfs, GridGgfsFileRange range, IgniteFsInputStream in) throws GridException,
         IOException;
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRangeInputStream.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRangeInputStream.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRangeInputStream.java
index c308f1f..fc0e6be 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRangeInputStream.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRangeInputStream.java
@@ -16,14 +16,14 @@ import org.jetbrains.annotations.*;
 import java.io.*;
 
 /**
- * Decorator for regular {@link GridGgfsInputStream} which streams only data within the given range.
+ * Decorator for regular {@link org.gridgain.grid.ggfs.IgniteFsInputStream} which streams only data within the given range.
  * This stream is used for {@link GridGgfsInputStreamJobAdapter} convenience adapter to create
  * jobs which will be working only with the assigned range. You can also use it explicitly when
  * working with {@link GridGgfsJob} directly.
  */
-public final class GridGgfsRangeInputStream extends GridGgfsInputStream {
+public final class GridGgfsRangeInputStream extends IgniteFsInputStream {
     /** Base input stream. */
-    private final GridGgfsInputStream is;
+    private final IgniteFsInputStream is;
 
     /** Start position. */
     private final long start;
@@ -42,7 +42,7 @@ public final class GridGgfsRangeInputStream extends GridGgfsInputStream {
      * @param maxLen Maximum stream length.
      * @throws IOException In case of exception.
      */
-    public GridGgfsRangeInputStream(GridGgfsInputStream is, long start, long maxLen) throws IOException {
+    public GridGgfsRangeInputStream(IgniteFsInputStream is, long start, long maxLen) throws IOException {
         if (is == null)
             throw new IllegalArgumentException("Input stream cannot be null.");
 
@@ -77,7 +77,7 @@ public final class GridGgfsRangeInputStream extends GridGgfsInputStream {
      * @param range File range.
      * @throws IOException In case of exception.
      */
-    public GridGgfsRangeInputStream(GridGgfsInputStream is, GridGgfsFileRange range) throws IOException {
+    public GridGgfsRangeInputStream(IgniteFsInputStream is, GridGgfsFileRange range) throws IOException {
         this(is, range.start(), range.length());
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRecordResolver.java
index 645e646..e8d64d0 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRecordResolver.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/GridGgfsRecordResolver.java
@@ -45,6 +45,6 @@ public interface GridGgfsRecordResolver extends Serializable {
      * @throws GridException If resolve failed.
      * @throws IOException If resolve failed.
      */
-    @Nullable public GridGgfsFileRange resolveRecords(IgniteFs ggfs, GridGgfsInputStream stream,
+    @Nullable public GridGgfsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
         GridGgfsFileRange suggestedRecord) throws GridException, IOException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java
index 6fca396..fb9cf0e 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsByteDelimiterRecordResolver.java
@@ -70,7 +70,7 @@ public class GridGgfsByteDelimiterRecordResolver implements GridGgfsRecordResolv
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFileRange resolveRecords(IgniteFs ggfs, GridGgfsInputStream stream,
+    @Override public GridGgfsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
         GridGgfsFileRange suggestedRecord) throws GridException, IOException {
         long suggestedStart = suggestedRecord.start();
         long suggestedEnd = suggestedStart + suggestedRecord.length();
@@ -138,7 +138,7 @@ public class GridGgfsByteDelimiterRecordResolver implements GridGgfsRecordResolv
      * @return The first found delimiter.
      * @throws IOException In case of IO exception.
      */
-    @Nullable private IgniteBiTuple<State, Delimiter> findFirstDelimiter(GridGgfsInputStream stream, long startPos)
+    @Nullable private IgniteBiTuple<State, Delimiter> findFirstDelimiter(IgniteFsInputStream stream, long startPos)
         throws IOException {
         State state;
         Delimiter delim;
@@ -169,7 +169,7 @@ public class GridGgfsByteDelimiterRecordResolver implements GridGgfsRecordResolv
      * @return Next delimiter and updated map.
      * @throws IOException In case of exception.
      */
-    private Delimiter nextDelimiter(GridGgfsInputStream is, State state) throws IOException {
+    private Delimiter nextDelimiter(IgniteFsInputStream is, State state) throws IOException {
         assert is != null;
         assert state != null;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java
index 5fbd5bd..212b780 100644
--- a/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java
+++ b/modules/core/src/main/java/org/gridgain/grid/ggfs/mapreduce/records/GridGgfsFixedLengthRecordResolver.java
@@ -45,7 +45,7 @@ public class GridGgfsFixedLengthRecordResolver implements GridGgfsRecordResolver
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFileRange resolveRecords(IgniteFs ggfs, GridGgfsInputStream stream,
+    @Override public GridGgfsFileRange resolveRecords(IgniteFs ggfs, IgniteFsInputStream stream,
         GridGgfsFileRange suggestedRecord)
         throws GridException, IOException {
         long suggestedEnd = suggestedRecord.start() + suggestedRecord.length();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
index 8abd967..919a0cd 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/ggfs/common/GridGgfsControlResponse.java
@@ -261,7 +261,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
         else if (errCode == ERR_PARENT_NOT_DIRECTORY)
             throw new GridGgfsParentNotDirectoryException(err);
         else if (errCode == ERR_INVALID_HDFS_VERSION)
-            throw new GridGgfsInvalidHdfsVersionException(err);
+            throw new IgniteFsInvalidHdfsVersionException(err);
         else if (errCode == ERR_CORRUPTED_FILE)
             throw new IgniteFsCorruptedFileException(err);
         else if (errCode == ERR_GGFS_GENERIC)
@@ -332,7 +332,7 @@ public class GridGgfsControlResponse extends GridGgfsMessage {
             return ERR_DIRECTORY_NOT_EMPTY;
         else if (GridGgfsParentNotDirectoryException.class.isInstance(e))
             return ERR_PARENT_NOT_DIRECTORY;
-        else if (GridGgfsInvalidHdfsVersionException.class.isInstance(e))
+        else if (IgniteFsInvalidHdfsVersionException.class.isInstance(e))
             return ERR_INVALID_HDFS_VERSION;
         else if (X.hasCause(e, IgniteFsCorruptedFileException.class))
             return ERR_CORRUPTED_FILE;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
index 62726bd..6b33e17 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAsyncImpl.java
@@ -219,7 +219,7 @@ public class GridGgfsAsyncImpl extends IgniteAsyncSupportAdapter implements Grid
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsMetrics metrics() throws GridException {
+    @Override public IgniteFsMetrics metrics() throws GridException {
         return ggfs.metrics();
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
index 9c804a4..45a8add 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsImpl.java
@@ -630,15 +630,15 @@ public final class GridGgfsImpl implements GridGgfsEx {
 
                 // Cannot rename root directory.
                 if (src.parent() == null)
-                    throw new GridGgfsInvalidPathException("Failed to rename root directory.");
+                    throw new IgniteFsInvalidPathException("Failed to rename root directory.");
 
                 // Cannot move directory of upper level to self sub-dir.
                 if (dest.isSubDirectoryOf(src))
-                    throw new GridGgfsInvalidPathException("Failed to rename directory (cannot move directory of " +
+                    throw new IgniteFsInvalidPathException("Failed to rename directory (cannot move directory of " +
                         "upper level to self sub-dir) [src=" + src + ", dest=" + dest + ']');
 
                 if (evictExclude(src, mode == PRIMARY) != evictExclude(dest, modeRslvr.resolveMode(dest) == PRIMARY))
-                    throw new GridGgfsInvalidPathException("Cannot move file to a path with different eviction " +
+                    throw new IgniteFsInvalidPathException("Cannot move file to a path with different eviction " +
                         "exclude setting (need to copy and remove)");
 
                 if (!childrenModes.equals(Collections.singleton(PRIMARY))) {
@@ -1087,7 +1087,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 }
 
                 if (!info.isFile())
-                    throw new GridGgfsInvalidPathException("Failed to open file (not a file): " + path);
+                    throw new IgniteFsInvalidPathException("Failed to open file (not a file): " + path);
 
                 // Input stream to read data from grid cache with separate blocks.
                 GgfsEventAwareInputStream os = new GgfsEventAwareInputStream(ggfsCtx, path, info,
@@ -1193,7 +1193,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 IgniteUuid parentId = ids.size() >= 2 ? ids.get(ids.size() - 2) : null;
 
                 if (parentId == null)
-                    throw new GridGgfsInvalidPathException("Failed to resolve parent directory: " + path);
+                    throw new IgniteFsInvalidPathException("Failed to resolve parent directory: " + path);
 
                 String fileName = path.name();
 
@@ -1298,7 +1298,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                     }
 
                     if (parentId == null)
-                        throw new GridGgfsInvalidPathException("Failed to resolve parent directory: " + path);
+                        throw new IgniteFsInvalidPathException("Failed to resolve parent directory: " + path);
 
                     info = new GridGgfsFileInfo(cfg.getBlockSize(), /**affinity key*/null, evictExclude(path,
                         mode == PRIMARY), props);
@@ -1313,7 +1313,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                 }
 
                 if (!info.isFile())
-                    throw new GridGgfsInvalidPathException("Failed to open file (not a file): " + path);
+                    throw new IgniteFsInvalidPathException("Failed to open file (not a file): " + path);
 
                 info = meta.lock(info.id());
 
@@ -1417,7 +1417,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                     throw new IgniteFsFileNotFoundException("File not found: " + path);
 
                 if (!info.isFile())
-                    throw new GridGgfsInvalidPathException("Failed to get affinity info for file (not a file): " +
+                    throw new IgniteFsInvalidPathException("Failed to get affinity info for file (not a file): " +
                         path);
 
                 return data.affinity(info, start, len, maxLen);
@@ -1431,7 +1431,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsMetrics metrics() throws GridException {
+    @Override public IgniteFsMetrics metrics() throws GridException {
         if (enterBusy()) {
             try {
                 IgniteFsPathSummary sum = new IgniteFsPathSummary();
@@ -1451,7 +1451,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                     }
                 }
 
-                return new GridGgfsMetricsAdapter(
+                return new IgniteFsMetricsAdapter(
                     ggfsCtx.data().spaceSize(),
                     ggfsCtx.data().maxSpaceSize(),
                     secondarySpaceSize,
@@ -2011,7 +2011,7 @@ public final class GridGgfsImpl implements GridGgfsEx {
                         if (ggfs == null)
                             return F.t(0L, 0L);
 
-                        GridGgfsMetrics metrics = ggfs.metrics();
+                        IgniteFsMetrics metrics = ggfs.metrics();
 
                         long loc = metrics.localSpaceSize();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamAdapter.java
index b6b5195..dea1fc2 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamAdapter.java
@@ -16,7 +16,7 @@ import java.io.*;
 /**
  * Implementation adapter providing necessary methods.
  */
-public abstract class GridGgfsInputStreamAdapter extends GridGgfsInputStream {
+public abstract class GridGgfsInputStreamAdapter extends IgniteFsInputStream {
     /** {@inheritDoc} */
     @Override public long length() {
         return fileInfo().length();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java
index da60ae4..91e0b4a 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsInputStreamImpl.java
@@ -118,7 +118,7 @@ public class GridGgfsInputStreamImpl extends GridGgfsInputStreamAdapter {
         meta = ggfsCtx.meta();
         data = ggfsCtx.data();
 
-        log = ggfsCtx.kernalContext().log(GridGgfsInputStream.class);
+        log = ggfsCtx.kernalContext().log(IgniteFsInputStream.class);
 
         maxLocCacheSize = (prefetchBlocks > 0 ? prefetchBlocks : 1) * 3 / 2;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
index 3ef20fe..f460d5d 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsJobImpl.java
@@ -74,7 +74,7 @@ public class GridGgfsJobImpl implements ComputeJob, GridInternalWrapper<GridGgfs
     @Override public Object execute() throws GridException {
         IgniteFs ggfs = ignite.fileSystem(ggfsName);
 
-        try (GridGgfsInputStream in = ggfs.open(path)) {
+        try (IgniteFsInputStream in = ggfs.open(path)) {
             GridGgfsFileRange split = new GridGgfsFileRange(path, start, len);
 
             if (rslvr != null) {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
index 2db4380..eb862f2 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
@@ -730,7 +730,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
             throw new IgniteFsFileNotFoundException("Failed to lock parent directory (not found): " + parentId);
 
         if (!parentInfo.isDirectory())
-            throw new GridGgfsInvalidPathException("Parent file is not a directory: " + parentInfo);
+            throw new IgniteFsInvalidPathException("Parent file is not a directory: " + parentInfo);
 
         Map<String, GridGgfsListingEntry> parentListing = parentInfo.listing();
 
@@ -831,7 +831,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                 " [srcParentId=" + srcParentId + ']');
 
         if (!srcInfo.isDirectory())
-            throw new GridGgfsInvalidPathException("Source is not a directory: " + srcInfo);
+            throw new IgniteFsInvalidPathException("Source is not a directory: " + srcInfo);
 
         GridGgfsFileInfo destInfo = infoMap.get(destParentId);
 
@@ -840,7 +840,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                 " [destParentId=" + destParentId + ']');
 
         if (!destInfo.isDirectory())
-            throw new GridGgfsInvalidPathException("Destination is not a directory: " + destInfo);
+            throw new IgniteFsInvalidPathException("Destination is not a directory: " + destInfo);
 
         GridGgfsFileInfo fileInfo = infoMap.get(fileId);
 
@@ -859,7 +859,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
 
         // If stored file already exist.
         if (destEntry != null)
-            throw new GridGgfsInvalidPathException("Failed to add file name into the destination directory " +
+            throw new IgniteFsInvalidPathException("Failed to add file name into the destination directory " +
                 "(file already exists) [fileId=" + fileId + ", destFileName=" + destFileName +
                 ", destParentId=" + destParentId + ", destEntry=" + destEntry + ']');
 
@@ -1833,7 +1833,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
 
                 if (info != null) {
                     if (!info.isFile())
-                        throw new GridGgfsInvalidPathException("Failed to open file (not a file): " + path);
+                        throw new IgniteFsInvalidPathException("Failed to open file (not a file): " + path);
 
                     return new GridGgfsSecondaryInputStreamDescriptor(info, fs.open(path, bufSize));
                 }
@@ -1848,7 +1848,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                             if (info == null)
                                 throw new IgniteFsFileNotFoundException("File not found: " + path);
                             if (!info.isFile())
-                                throw new GridGgfsInvalidPathException("Failed to open file (not a file): " + path);
+                                throw new IgniteFsInvalidPathException("Failed to open file (not a file): " + path);
 
                             return new GridGgfsSecondaryInputStreamDescriptor(infos.get(path), fs.open(path, bufSize));
                         }
@@ -2587,14 +2587,14 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                     GridGgfsFileInfo parentInfo = infoMap.get(parentId);
 
                     if (parentInfo == null)
-                        throw new GridGgfsInvalidPathException("Failed to update times (parent was not found): " +
+                        throw new IgniteFsInvalidPathException("Failed to update times (parent was not found): " +
                             fileName);
 
                     GridGgfsListingEntry entry = parentInfo.listing().get(fileName);
 
                     // Validate listing.
                     if (entry == null || !entry.fileId().equals(fileId))
-                        throw new GridGgfsInvalidPathException("Failed to update times (file concurrently modified): " +
+                        throw new IgniteFsInvalidPathException("Failed to update times (file concurrently modified): " +
                             fileName);
 
                     assert parentInfo.isDirectory();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsAdapter.java
deleted file mode 100644
index 574ccab..0000000
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsAdapter.java
+++ /dev/null
@@ -1,231 +0,0 @@
-/* @java.file.header */
-
-/*  _________        _____ __________________        _____
- *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
- *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
- *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
- *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
- */
-
-package org.gridgain.grid.kernal.processors.ggfs;
-
-import org.gridgain.grid.ggfs.*;
-import org.gridgain.grid.util.typedef.internal.*;
-
-import java.io.*;
-
-/**
- * GGFS metrics adapter.
- */
-public class GridGgfsMetricsAdapter implements GridGgfsMetrics, Externalizable {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** Used space on local node. */
-    private long locSpaceSize;
-
-    /** Maximum space. */
-    private long maxSpaceSize;
-
-    /** Secondary file system used space. */
-    private long secondarySpaceSize;
-
-    /** Number of directories. */
-    private int dirsCnt;
-
-    /** Number of files. */
-    private int filesCnt;
-
-    /** Number of files opened for read. */
-    private int filesOpenedForRead;
-
-    /** Number of files opened for write. */
-    private int filesOpenedForWrite;
-
-    /** Total blocks read. */
-    private long blocksReadTotal;
-
-    /** Total blocks remote read. */
-    private long blocksReadRmt;
-
-    /** Total blocks write. */
-    private long blocksWrittenTotal;
-
-    /** Total blocks write remote. */
-    private long blocksWrittenRmt;
-
-    /** Total bytes read. */
-    private long bytesRead;
-
-    /** Total bytes read time. */
-    private long bytesReadTime;
-
-    /** Total bytes write. */
-    private long bytesWritten;
-
-    /** Total bytes write time. */
-    private long bytesWriteTime;
-
-    /**
-     * {@link Externalizable} support.
-     */
-    public GridGgfsMetricsAdapter() {
-        // No-op.
-    }
-
-    /**
-     * @param locSpaceSize Used space on local node.
-     * @param maxSpaceSize Maximum space size.
-     * @param secondarySpaceSize Secondary space size.
-     * @param dirsCnt Number of directories.
-     * @param filesCnt Number of files.
-     * @param filesOpenedForRead Number of files opened for read.
-     * @param filesOpenedForWrite Number of files opened for write.
-     * @param blocksReadTotal Total blocks read.
-     * @param blocksReadRmt Total blocks read remotely.
-     * @param blocksWrittenTotal Total blocks written.
-     * @param blocksWrittenRmt Total blocks written remotely.
-     * @param bytesRead Total bytes read.
-     * @param bytesReadTime Total bytes read time.
-     * @param bytesWritten Total bytes written.
-     * @param bytesWriteTime Total bytes write time.
-     */
-    public GridGgfsMetricsAdapter(long locSpaceSize, long maxSpaceSize, long secondarySpaceSize, int dirsCnt,
-        int filesCnt, int filesOpenedForRead, int filesOpenedForWrite, long blocksReadTotal, long blocksReadRmt,
-        long blocksWrittenTotal, long blocksWrittenRmt, long bytesRead, long bytesReadTime, long bytesWritten,
-        long bytesWriteTime) {
-        this.locSpaceSize = locSpaceSize;
-        this.maxSpaceSize = maxSpaceSize;
-        this.secondarySpaceSize = secondarySpaceSize;
-        this.dirsCnt = dirsCnt;
-        this.filesCnt = filesCnt;
-        this.filesOpenedForRead = filesOpenedForRead;
-        this.filesOpenedForWrite = filesOpenedForWrite;
-        this.blocksReadTotal = blocksReadTotal;
-        this.blocksReadRmt = blocksReadRmt;
-        this.blocksWrittenTotal = blocksWrittenTotal;
-        this.blocksWrittenRmt = blocksWrittenRmt;
-        this.bytesRead = bytesRead;
-        this.bytesReadTime = bytesReadTime;
-        this.bytesWritten = bytesWritten;
-        this.bytesWriteTime = bytesWriteTime;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long localSpaceSize() {
-        return locSpaceSize;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long maxSpaceSize() {
-        return maxSpaceSize;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long secondarySpaceSize() {
-        return secondarySpaceSize;
-    }
-
-    /** {@inheritDoc} */
-    @Override public int directoriesCount() {
-        return dirsCnt;
-    }
-
-    /** {@inheritDoc} */
-    @Override public int filesCount() {
-        return filesCnt;
-    }
-
-    /** {@inheritDoc} */
-    @Override public int filesOpenedForRead() {
-        return filesOpenedForRead;
-    }
-
-    /** {@inheritDoc} */
-    @Override public int filesOpenedForWrite() {
-        return filesOpenedForWrite;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long blocksReadTotal() {
-        return blocksReadTotal;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long blocksReadRemote() {
-        return blocksReadRmt;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long blocksWrittenTotal() {
-        return blocksWrittenTotal;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long blocksWrittenRemote() {
-        return blocksWrittenRmt;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long bytesRead() {
-        return bytesRead;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long bytesReadTime() {
-        return bytesReadTime;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long bytesWritten() {
-        return bytesWritten;
-    }
-
-    /** {@inheritDoc} */
-    @Override public long bytesWriteTime() {
-        return bytesWriteTime;
-    }
-
-    /** {@inheritDoc} */
-    @Override public void writeExternal(ObjectOutput out) throws IOException {
-        out.writeLong(locSpaceSize);
-        out.writeLong(maxSpaceSize);
-        out.writeLong(secondarySpaceSize);
-        out.writeInt(dirsCnt);
-        out.writeInt(filesCnt);
-        out.writeInt(filesOpenedForRead);
-        out.writeInt(filesOpenedForWrite);
-        out.writeLong(blocksReadTotal);
-        out.writeLong(blocksReadRmt);
-        out.writeLong(blocksWrittenTotal);
-        out.writeLong(blocksWrittenRmt);
-        out.writeLong(bytesRead);
-        out.writeLong(bytesReadTime);
-        out.writeLong(bytesWritten);
-        out.writeLong(bytesWriteTime);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void readExternal(ObjectInput in) throws IOException {
-        locSpaceSize = in.readLong();
-        maxSpaceSize = in.readLong();
-        secondarySpaceSize = in.readLong();
-        dirsCnt = in.readInt();
-        filesCnt = in.readInt();
-        filesOpenedForRead = in.readInt();
-        filesOpenedForWrite = in.readInt();
-        blocksReadTotal = in.readLong();
-        blocksReadRmt = in.readLong();
-        blocksWrittenTotal = in.readLong();
-        blocksWrittenRmt = in.readLong();
-        bytesRead = in.readLong();
-        bytesReadTime = in.readLong();
-        bytesWritten = in.readLong();
-        bytesWriteTime = in.readLong();
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(GridGgfsMetricsAdapter.class, this);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsMetricsAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsMetricsAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsMetricsAdapter.java
new file mode 100644
index 0000000..36627f8
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsMetricsAdapter.java
@@ -0,0 +1,231 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.kernal.processors.ggfs;
+
+import org.gridgain.grid.ggfs.*;
+import org.gridgain.grid.util.typedef.internal.*;
+
+import java.io.*;
+
+/**
+ * GGFS metrics adapter.
+ */
+public class IgniteFsMetricsAdapter implements IgniteFsMetrics, Externalizable {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** Used space on local node. */
+    private long locSpaceSize;
+
+    /** Maximum space. */
+    private long maxSpaceSize;
+
+    /** Secondary file system used space. */
+    private long secondarySpaceSize;
+
+    /** Number of directories. */
+    private int dirsCnt;
+
+    /** Number of files. */
+    private int filesCnt;
+
+    /** Number of files opened for read. */
+    private int filesOpenedForRead;
+
+    /** Number of files opened for write. */
+    private int filesOpenedForWrite;
+
+    /** Total blocks read. */
+    private long blocksReadTotal;
+
+    /** Total blocks remote read. */
+    private long blocksReadRmt;
+
+    /** Total blocks write. */
+    private long blocksWrittenTotal;
+
+    /** Total blocks write remote. */
+    private long blocksWrittenRmt;
+
+    /** Total bytes read. */
+    private long bytesRead;
+
+    /** Total bytes read time. */
+    private long bytesReadTime;
+
+    /** Total bytes write. */
+    private long bytesWritten;
+
+    /** Total bytes write time. */
+    private long bytesWriteTime;
+
+    /**
+     * {@link Externalizable} support.
+     */
+    public IgniteFsMetricsAdapter() {
+        // No-op.
+    }
+
+    /**
+     * @param locSpaceSize Used space on local node.
+     * @param maxSpaceSize Maximum space size.
+     * @param secondarySpaceSize Secondary space size.
+     * @param dirsCnt Number of directories.
+     * @param filesCnt Number of files.
+     * @param filesOpenedForRead Number of files opened for read.
+     * @param filesOpenedForWrite Number of files opened for write.
+     * @param blocksReadTotal Total blocks read.
+     * @param blocksReadRmt Total blocks read remotely.
+     * @param blocksWrittenTotal Total blocks written.
+     * @param blocksWrittenRmt Total blocks written remotely.
+     * @param bytesRead Total bytes read.
+     * @param bytesReadTime Total bytes read time.
+     * @param bytesWritten Total bytes written.
+     * @param bytesWriteTime Total bytes write time.
+     */
+    public IgniteFsMetricsAdapter(long locSpaceSize, long maxSpaceSize, long secondarySpaceSize, int dirsCnt,
+                                  int filesCnt, int filesOpenedForRead, int filesOpenedForWrite, long blocksReadTotal, long blocksReadRmt,
+                                  long blocksWrittenTotal, long blocksWrittenRmt, long bytesRead, long bytesReadTime, long bytesWritten,
+                                  long bytesWriteTime) {
+        this.locSpaceSize = locSpaceSize;
+        this.maxSpaceSize = maxSpaceSize;
+        this.secondarySpaceSize = secondarySpaceSize;
+        this.dirsCnt = dirsCnt;
+        this.filesCnt = filesCnt;
+        this.filesOpenedForRead = filesOpenedForRead;
+        this.filesOpenedForWrite = filesOpenedForWrite;
+        this.blocksReadTotal = blocksReadTotal;
+        this.blocksReadRmt = blocksReadRmt;
+        this.blocksWrittenTotal = blocksWrittenTotal;
+        this.blocksWrittenRmt = blocksWrittenRmt;
+        this.bytesRead = bytesRead;
+        this.bytesReadTime = bytesReadTime;
+        this.bytesWritten = bytesWritten;
+        this.bytesWriteTime = bytesWriteTime;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long localSpaceSize() {
+        return locSpaceSize;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long maxSpaceSize() {
+        return maxSpaceSize;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long secondarySpaceSize() {
+        return secondarySpaceSize;
+    }
+
+    /** {@inheritDoc} */
+    @Override public int directoriesCount() {
+        return dirsCnt;
+    }
+
+    /** {@inheritDoc} */
+    @Override public int filesCount() {
+        return filesCnt;
+    }
+
+    /** {@inheritDoc} */
+    @Override public int filesOpenedForRead() {
+        return filesOpenedForRead;
+    }
+
+    /** {@inheritDoc} */
+    @Override public int filesOpenedForWrite() {
+        return filesOpenedForWrite;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long blocksReadTotal() {
+        return blocksReadTotal;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long blocksReadRemote() {
+        return blocksReadRmt;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long blocksWrittenTotal() {
+        return blocksWrittenTotal;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long blocksWrittenRemote() {
+        return blocksWrittenRmt;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long bytesRead() {
+        return bytesRead;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long bytesReadTime() {
+        return bytesReadTime;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long bytesWritten() {
+        return bytesWritten;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long bytesWriteTime() {
+        return bytesWriteTime;
+    }
+
+    /** {@inheritDoc} */
+    @Override public void writeExternal(ObjectOutput out) throws IOException {
+        out.writeLong(locSpaceSize);
+        out.writeLong(maxSpaceSize);
+        out.writeLong(secondarySpaceSize);
+        out.writeInt(dirsCnt);
+        out.writeInt(filesCnt);
+        out.writeInt(filesOpenedForRead);
+        out.writeInt(filesOpenedForWrite);
+        out.writeLong(blocksReadTotal);
+        out.writeLong(blocksReadRmt);
+        out.writeLong(blocksWrittenTotal);
+        out.writeLong(blocksWrittenRmt);
+        out.writeLong(bytesRead);
+        out.writeLong(bytesReadTime);
+        out.writeLong(bytesWritten);
+        out.writeLong(bytesWriteTime);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readExternal(ObjectInput in) throws IOException {
+        locSpaceSize = in.readLong();
+        maxSpaceSize = in.readLong();
+        secondarySpaceSize = in.readLong();
+        dirsCnt = in.readInt();
+        filesCnt = in.readInt();
+        filesOpenedForRead = in.readInt();
+        filesOpenedForWrite = in.readInt();
+        blocksReadTotal = in.readLong();
+        blocksReadRmt = in.readLong();
+        blocksWrittenTotal = in.readLong();
+        blocksWrittenRmt = in.readLong();
+        bytesRead = in.readLong();
+        bytesReadTime = in.readLong();
+        bytesWritten = in.readLong();
+        bytesWriteTime = in.readLong();
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsMetricsAdapter.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsMetrics.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsMetrics.java b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsMetrics.java
index ce43815..67ff249 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsMetrics.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/ggfs/VisorGgfsMetrics.java
@@ -15,7 +15,7 @@ import org.gridgain.grid.util.typedef.internal.*;
 import java.io.*;
 
 /**
- * Data transfer object for {@link GridGgfsMetrics}.
+ * Data transfer object for {@link org.gridgain.grid.ggfs.IgniteFsMetrics}.
  */
 public class VisorGgfsMetrics implements Serializable {
     /** */
@@ -67,7 +67,7 @@ public class VisorGgfsMetrics implements Serializable {
      * @param m GGFS metrics.
      * @return Data transfer object for given GGFS metrics.
      */
-    public static VisorGgfsMetrics from(GridGgfsMetrics m) {
+    public static VisorGgfsMetrics from(IgniteFsMetrics m) {
         assert m != null;
 
         VisorGgfsMetrics metrics = new VisorGgfsMetrics();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
index 9254490..bf46e18 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
@@ -781,7 +781,7 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
         }
 
         // Will generate EVT_GGFS_FILE_OPENED_READ, GGFS_FILE_CLOSED_READ.
-        try (GridGgfsInputStream is = ggfs.open(file, 256)) {
+        try (IgniteFsInputStream is = ggfs.open(file, 256)) {
             is.readFully(0, buf); // Will generate no events.
         }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java
index 67169eb..08e88b8 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerSelfTest.java
@@ -46,7 +46,7 @@ public class GridGgfsFragmentizerSelfTest extends GridGgfsFragmentizerAbstractSe
         long start = System.currentTimeMillis();
 
         do {
-            try (GridGgfsInputStream in = ggfs.open(path)) {
+            try (IgniteFsInputStream in = ggfs.open(path)) {
                 for (int i = 0; i < 10 * GGFS_GROUP_SIZE; i++) {
                     for (int j = 0; j < GGFS_BLOCK_SIZE; j++)
                         assertEquals(i & 0xFF, in.read());
@@ -125,7 +125,7 @@ public class GridGgfsFragmentizerSelfTest extends GridGgfsFragmentizerAbstractSe
 
         IgniteFs ggfs = grid(0).fileSystem("ggfs");
 
-        try (GridGgfsInputStream in = ggfs.open(path)) {
+        try (IgniteFsInputStream in = ggfs.open(path)) {
             i = 0;
 
             int read = 0;
@@ -192,7 +192,7 @@ public class GridGgfsFragmentizerSelfTest extends GridGgfsFragmentizerAbstractSe
             }
         }
 
-        try (GridGgfsInputStream in = ggfs.open(path)) {
+        try (IgniteFsInputStream in = ggfs.open(path)) {
             cnt = 0;
 
             int read = 0;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
index b21ba0d..01d6586 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
@@ -318,7 +318,7 @@ public class GridCacheGgfsPerBlockLruEvictionPolicySelfTest extends GridGgfsComm
 
                 return null;
             }
-        }, GridGgfsInvalidPathException.class, "Cannot move file to a path with different eviction exclude setting " +
+        }, IgniteFsInvalidPathException.class, "Cannot move file to a path with different eviction exclude setting " +
             "(need to copy and remove)");
 
         GridTestUtils.assertThrows(log, new Callable<Object>() {
@@ -327,7 +327,7 @@ public class GridCacheGgfsPerBlockLruEvictionPolicySelfTest extends GridGgfsComm
 
                 return null;
             }
-        }, GridGgfsInvalidPathException.class, "Cannot move file to a path with different eviction exclude setting " +
+        }, IgniteFsInvalidPathException.class, "Cannot move file to a path with different eviction exclude setting " +
             "(need to copy and remove)");
     }
 
@@ -422,7 +422,7 @@ public class GridCacheGgfsPerBlockLruEvictionPolicySelfTest extends GridGgfsComm
      * @throws Exception If failed.
      */
     private void read(IgniteFsPath path, int off, int len) throws Exception {
-        GridGgfsInputStream is = ggfsPrimary.open(path);
+        IgniteFsInputStream is = ggfsPrimary.open(path);
 
         is.readFully(off, new byte[len]);
 
@@ -455,7 +455,7 @@ public class GridCacheGgfsPerBlockLruEvictionPolicySelfTest extends GridGgfsComm
         assert GridTestUtils.waitForCondition(new GridAbsPredicate() {
             @Override public boolean apply() {
                 try {
-                    GridGgfsMetrics metrics = ggfsPrimary.metrics();
+                    IgniteFsMetrics metrics = ggfsPrimary.metrics();
 
                     return metrics.blocksReadTotal() == blocksRead && metrics.blocksReadRemote() == blocksReadRmt;
                 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
index c7dcfb4..f722fdd 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
@@ -853,7 +853,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
         GridTestUtils.assertThrows(log(), new Callable<Object>() {
             @Override public Object call() throws Exception {
-                GridGgfsInputStream is = null;
+                IgniteFsInputStream is = null;
 
                 try {
                     is = ggfs.open(FILE);
@@ -2339,7 +2339,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
     protected void checkFileContent(GridGgfsImpl ggfs, IgniteFsPath file, @Nullable byte[]... chunks)
         throws IOException, GridException {
         if (chunks != null && chunks.length > 0) {
-            GridGgfsInputStream is = null;
+            IgniteFsInputStream is = null;
 
             try {
                 is = ggfs.open(file);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
index 57fadf9..9df3b88 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
@@ -1145,7 +1145,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         // Read the first block.
         int totalRead = 0;
 
-        GridGgfsInputStream in = ggfs.open(FILE, blockSize);
+        IgniteFsInputStream in = ggfs.open(FILE, blockSize);
 
         final byte[] readBuf = new byte[1024];
 
@@ -1176,7 +1176,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         // Let's wait for file will be deleted.
         U.sleep(300);
 
-        final GridGgfsInputStream in0 = in;
+        final IgniteFsInputStream in0 = in;
 
         // Try reading the second block. Should fail.
         GridTestUtils.assertThrows(log, new Callable<Object>() {
@@ -1224,7 +1224,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         // Read the first two blocks.
         int totalRead = 0;
 
-        GridGgfsInputStream in = ggfs.open(FILE, blockSize);
+        IgniteFsInputStream in = ggfs.open(FILE, blockSize);
 
         final byte[] readBuf = new byte[1024];
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
index 84a6736..efd5418 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
@@ -203,7 +203,7 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
 
         assertNotNull(fs);
 
-        GridGgfsMetrics m = fs.metrics();
+        IgniteFsMetrics m = fs.metrics();
 
         assertNotNull(m);
         assertEquals(0, m.directoriesCount());
@@ -293,8 +293,8 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
         assertEquals(0, m.filesOpenedForRead());
         assertEquals(0, m.filesOpenedForWrite());
 
-        GridGgfsInputStream in1 = fs.open(new IgniteFsPath("/dir1/file1"));
-        GridGgfsInputStream in2 = fs.open(new IgniteFsPath("/dir1/file2"));
+        IgniteFsInputStream in1 = fs.open(new IgniteFsPath("/dir1/file1"));
+        IgniteFsInputStream in2 = fs.open(new IgniteFsPath("/dir1/file2"));
 
         m = fs.metrics();
 
@@ -346,12 +346,12 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
         out.close();
         out.close();
 
-        GridGgfsInputStream in = fs.open(new IgniteFsPath("/file"));
+        IgniteFsInputStream in = fs.open(new IgniteFsPath("/file"));
 
         in.close();
         in.close();
 
-        GridGgfsMetrics m = fs.metrics();
+        IgniteFsMetrics m = fs.metrics();
 
         assertEquals(0, m.filesOpenedForWrite());
         assertEquals(0, m.filesOpenedForRead());
@@ -378,7 +378,7 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
         out.close();
 
         // Start metrics measuring.
-        GridGgfsMetrics initMetrics = ggfs.metrics();
+        IgniteFsMetrics initMetrics = ggfs.metrics();
 
         // Create empty file.
         ggfs.create(file1, 256, true, null, 1, 256, null).close();
@@ -442,7 +442,7 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
 
         checkBlockMetrics(initMetrics, ggfs.metrics(), 5, 1, blockSize * 3 + rmtBlockSize * 2, 3, 0, blockSize * 3);
 
-        GridGgfsMetrics metrics = ggfs.metrics();
+        IgniteFsMetrics metrics = ggfs.metrics();
 
         assert metrics.secondarySpaceSize() == rmtBlockSize;
 
@@ -510,7 +510,7 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
      * @param bytesWrite Bytes write.
      * @throws Exception If failed.
      */
-    private void checkBlockMetrics(GridGgfsMetrics initMetrics, GridGgfsMetrics metrics, long blocksRead,
+    private void checkBlockMetrics(IgniteFsMetrics initMetrics, IgniteFsMetrics metrics, long blocksRead,
         long blocksReadRemote, long bytesRead, long blocksWrite, long blocksWriteRemote, long bytesWrite)
         throws Exception {
         assert metrics != null;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/1d26f5fd/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
index 4a7d98b..1323c4b 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
@@ -529,7 +529,7 @@ public class GridGgfsModesSelfTest extends GridGgfsCommonAbstractTest {
         os.close();
 
         // Check file content.
-        GridGgfsInputStream is = ggfs.open(file);
+        IgniteFsInputStream is = ggfs.open(file);
 
         assertEquals(testData.length, is.length());
 
@@ -547,7 +547,7 @@ public class GridGgfsModesSelfTest extends GridGgfsCommonAbstractTest {
 
             // In ASYNC mode we wait at most 2 seconds for background writer to finish.
             for (int i = 0; i < 20; i++) {
-                GridGgfsInputStream isSecondary = null;
+                IgniteFsInputStream isSecondary = null;
 
                 try {
                     isSecondary = ggfsSecondary.open(file);
@@ -562,7 +562,7 @@ public class GridGgfsModesSelfTest extends GridGgfsCommonAbstractTest {
                 }
             }
 
-            GridGgfsInputStream isSecondary = ggfsSecondary.open(file);
+            IgniteFsInputStream isSecondary = ggfsSecondary.open(file);
 
             assertEquals(testData.length, isSecondary.length());
 


[18/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
index 79e17de..2db4380 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManager.java
@@ -488,7 +488,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                     GridGgfsFileInfo oldInfo = info(fileId);
 
                     if (oldInfo == null)
-                        throw new GridGgfsFileNotFoundException("Failed to unlock file (file not found): " + fileId);
+                        throw new IgniteFsFileNotFoundException("Failed to unlock file (file not found): " + fileId);
 
                     if (!info.lockId().equals(oldInfo.lockId()))
                         throw new GridException("Failed to unlock file (inconsistent file lock ID) [fileId=" + fileId +
@@ -727,7 +727,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
         assert validTxState(true);
 
         if (parentInfo == null)
-            throw new GridGgfsFileNotFoundException("Failed to lock parent directory (not found): " + parentId);
+            throw new IgniteFsFileNotFoundException("Failed to lock parent directory (not found): " + parentId);
 
         if (!parentInfo.isDirectory())
             throw new GridGgfsInvalidPathException("Parent file is not a directory: " + parentInfo);
@@ -827,7 +827,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
         GridGgfsFileInfo srcInfo = infoMap.get(srcParentId);
 
         if (srcInfo == null)
-            throw new GridGgfsFileNotFoundException("Failed to lock source directory (not found?)" +
+            throw new IgniteFsFileNotFoundException("Failed to lock source directory (not found?)" +
                 " [srcParentId=" + srcParentId + ']');
 
         if (!srcInfo.isDirectory())
@@ -836,7 +836,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
         GridGgfsFileInfo destInfo = infoMap.get(destParentId);
 
         if (destInfo == null)
-            throw new GridGgfsFileNotFoundException("Failed to lock destination directory (not found?)" +
+            throw new IgniteFsFileNotFoundException("Failed to lock destination directory (not found?)" +
                 " [destParentId=" + destParentId + ']');
 
         if (!destInfo.isDirectory())
@@ -845,7 +845,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
         GridGgfsFileInfo fileInfo = infoMap.get(fileId);
 
         if (fileInfo == null)
-            throw new GridGgfsFileNotFoundException("Failed to lock target file (not found?) [fileId=" +
+            throw new IgniteFsFileNotFoundException("Failed to lock target file (not found?) [fileId=" +
                 fileId + ']');
 
         GridGgfsListingEntry srcEntry = srcInfo.listing().get(srcFileName);
@@ -853,7 +853,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
 
         // If source file does not exist or was re-created.
         if (srcEntry == null || !srcEntry.fileId().equals(fileId))
-            throw new GridGgfsFileNotFoundException("Failed to remove file name from the source directory" +
+            throw new IgniteFsFileNotFoundException("Failed to remove file name from the source directory" +
                 " (file not found) [fileId=" + fileId + ", srcFileName=" + srcFileName +
                 ", srcParentId=" + srcParentId + ", srcEntry=" + srcEntry + ']');
 
@@ -1577,7 +1577,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return Output stream descriptor.
      * @throws GridException If file creation failed.
      */
-    public GridGgfsSecondaryOutputStreamDescriptor createDual(final GridGgfsFileSystem fs, final IgniteFsPath path,
+    public GridGgfsSecondaryOutputStreamDescriptor createDual(final IgniteFsFileSystem fs, final IgniteFsPath path,
         final boolean simpleCreate, @Nullable final Map<String, String> props, final boolean overwrite, final int bufSize,
         final short replication, final long blockSize, final IgniteUuid affKey)
         throws GridException {
@@ -1637,7 +1637,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                             }
 
                             // Get created file info.
-                            GridGgfsFile status = fs.info(path);
+                            IgniteFsFile status = fs.info(path);
 
                             if (status == null)
                                 throw new IgniteFsException("Failed to open output stream to the file created in " +
@@ -1737,7 +1737,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return Output stream descriptor.
      * @throws GridException If output stream open for append has failed.
      */
-    public GridGgfsSecondaryOutputStreamDescriptor appendDual(final GridGgfsFileSystem fs, final IgniteFsPath path,
+    public GridGgfsSecondaryOutputStreamDescriptor appendDual(final IgniteFsFileSystem fs, final IgniteFsPath path,
         final int bufSize) throws GridException {
         if (busyLock.enterBusy()) {
             try {
@@ -1820,7 +1820,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return Input stream descriptor.
      * @throws GridException If input stream open has failed.
      */
-    public GridGgfsSecondaryInputStreamDescriptor openDual(final GridGgfsFileSystem fs, final IgniteFsPath path,
+    public GridGgfsSecondaryInputStreamDescriptor openDual(final IgniteFsFileSystem fs, final IgniteFsPath path,
         final int bufSize)
         throws GridException {
         if (busyLock.enterBusy()) {
@@ -1846,7 +1846,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                             GridGgfsFileInfo info = infos.get(path);
 
                             if (info == null)
-                                throw new GridGgfsFileNotFoundException("File not found: " + path);
+                                throw new IgniteFsFileNotFoundException("File not found: " + path);
                             if (!info.isFile())
                                 throw new GridGgfsInvalidPathException("Failed to open file (not a file): " + path);
 
@@ -1884,7 +1884,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return File info or {@code null} if file not found.
      * @throws GridException If sync task failed.
      */
-    @Nullable public GridGgfsFileInfo synchronizeFileDual(final GridGgfsFileSystem fs, final IgniteFsPath path)
+    @Nullable public GridGgfsFileInfo synchronizeFileDual(final IgniteFsFileSystem fs, final IgniteFsPath path)
         throws GridException {
         assert fs != null;
         assert path != null;
@@ -1935,7 +1935,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return {@code True} in case rename was successful.
      * @throws GridException If directory creation failed.
      */
-    public boolean mkdirsDual(final GridGgfsFileSystem fs, final IgniteFsPath path, final Map<String, String> props)
+    public boolean mkdirsDual(final IgniteFsFileSystem fs, final IgniteFsPath path, final Map<String, String> props)
         throws GridException {
         if (busyLock.enterBusy()) {
             try {
@@ -2019,7 +2019,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return Operation result.
      * @throws GridException If failed.
      */
-    public boolean renameDual(final GridGgfsFileSystem fs, final IgniteFsPath src, final IgniteFsPath dest) throws
+    public boolean renameDual(final IgniteFsFileSystem fs, final IgniteFsPath src, final IgniteFsPath dest) throws
         GridException {
         if (busyLock.enterBusy()) {
             try {
@@ -2042,10 +2042,10 @@ public class GridGgfsMetaManager extends GridGgfsManager {
 
                         // Source path and destination (or destination parent) must exist.
                         if (srcInfo == null)
-                            throw new GridGgfsFileNotFoundException("Failed to rename (source path not found): " + src);
+                            throw new IgniteFsFileNotFoundException("Failed to rename (source path not found): " + src);
 
                         if (destInfo == null && destParentInfo == null)
-                            throw new GridGgfsFileNotFoundException("Failed to rename (destination path not found): " +
+                            throw new IgniteFsFileNotFoundException("Failed to rename (destination path not found): " +
                                 dest);
 
                         // Delegate to the secondary file system.
@@ -2120,7 +2120,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return Operation result.
      * @throws GridException If delete failed.
      */
-    public boolean deleteDual(final GridGgfsFileSystem fs, final IgniteFsPath path, final boolean recursive)
+    public boolean deleteDual(final IgniteFsFileSystem fs, final IgniteFsPath path, final boolean recursive)
         throws GridException {
         if (busyLock.enterBusy()) {
             try {
@@ -2186,7 +2186,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return Update file info.
      * @throws GridException If update failed.
      */
-    public GridGgfsFileInfo updateDual(final GridGgfsFileSystem fs, final IgniteFsPath path, final Map<String, String> props)
+    public GridGgfsFileInfo updateDual(final IgniteFsFileSystem fs, final IgniteFsPath path, final Map<String, String> props)
         throws GridException {
         assert fs != null;
         assert path != null;
@@ -2239,7 +2239,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return File info of the end path.
      * @throws GridException If failed.
      */
-    private GridGgfsFileInfo synchronize(GridGgfsFileSystem fs, IgniteFsPath startPath, GridGgfsFileInfo startPathInfo,
+    private GridGgfsFileInfo synchronize(IgniteFsFileSystem fs, IgniteFsPath startPath, GridGgfsFileInfo startPathInfo,
         IgniteFsPath endPath, boolean strict, @Nullable Map<IgniteFsPath, GridGgfsFileInfo> created)
         throws GridException {
         assert fs != null;
@@ -2261,7 +2261,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                 parentInfo = created.get(curPath);
             else {
                 // Get file status from the secondary file system.
-                GridGgfsFile status = fs.info(curPath);
+                IgniteFsFile status = fs.info(curPath);
 
                 if (status != null) {
                     if (!status.isDirectory() && !curPath.equals(endPath))
@@ -2311,7 +2311,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return Result of task execution.
      * @throws GridException If failed.
      */
-    private <T> T synchronizeAndExecute(SynchronizationTask<T> task, GridGgfsFileSystem fs, boolean strict,
+    private <T> T synchronizeAndExecute(SynchronizationTask<T> task, IgniteFsFileSystem fs, boolean strict,
         IgniteFsPath... paths)
         throws GridException {
         return synchronizeAndExecute(task, fs, strict, null, paths);
@@ -2329,7 +2329,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
      * @return Result of task execution.
      * @throws GridException If failed.
      */
-    private <T> T synchronizeAndExecute(SynchronizationTask<T> task, GridGgfsFileSystem fs, boolean strict,
+    private <T> T synchronizeAndExecute(SynchronizationTask<T> task, IgniteFsFileSystem fs, boolean strict,
         @Nullable Collection<IgniteUuid> extraLockIds, IgniteFsPath... paths) throws GridException {
         assert task != null;
         assert fs != null;
@@ -2581,7 +2581,7 @@ public class GridGgfsMetaManager extends GridGgfsManager {
                     GridGgfsFileInfo fileInfo = infoMap.get(fileId);
 
                     if (fileInfo == null)
-                        throw new GridGgfsFileNotFoundException("Failed to update times (path was not found): " +
+                        throw new IgniteFsFileNotFoundException("Failed to update times (path was not found): " +
                             fileName);
 
                     GridGgfsFileInfo parentInfo = infoMap.get(parentId);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java
index 854fda0..8e58787 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsOutputStreamImpl.java
@@ -358,7 +358,7 @@ class GridGgfsOutputStreamImpl extends GridGgfsOutputStreamAdapter {
                 try {
                     meta.unlock(fileInfo, modificationTime);
                 }
-                catch (GridGgfsFileNotFoundException ignore) {
+                catch (IgniteFsFileNotFoundException ignore) {
                     data.delete(fileInfo); // Safety to ensure that all data blocks are deleted.
 
                     throw new IOException("File was concurrently deleted: " + path);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
index dc83ed5..0b37e55 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessor.java
@@ -262,7 +262,7 @@ public class GridGgfsProcessor extends GridGgfsProcessorAdapter {
 
             GridCacheAffinityKeyMapper affMapper = cacheCfg.getAffinityMapper();
 
-            if (!(affMapper instanceof GridGgfsGroupDataBlocksKeyMapper))
+            if (!(affMapper instanceof IgniteFsGroupDataBlocksKeyMapper))
                 // Do not create GGFS attributes for such a node nor throw error about invalid configuration.
                 // Configuration will be validated later, while starting GridGgfsProcessor.
                 continue;
@@ -270,7 +270,7 @@ public class GridGgfsProcessor extends GridGgfsProcessorAdapter {
             attrVals.add(new GridGgfsAttributes(
                 ggfsCfg.getName(),
                 ggfsCfg.getBlockSize(),
-                ((GridGgfsGroupDataBlocksKeyMapper)affMapper).groupSize(),
+                ((IgniteFsGroupDataBlocksKeyMapper)affMapper).groupSize(),
                 ggfsCfg.getMetaCacheName(),
                 ggfsCfg.getDataCacheName(),
                 ggfsCfg.getDefaultMode(),
@@ -323,9 +323,9 @@ public class GridGgfsProcessor extends GridGgfsProcessorAdapter {
             if (F.eq(cfg.getDataCacheName(), cfg.getMetaCacheName()))
                 throw new GridException("Cannot use same cache as both data and meta cache: " + cfg.getName());
 
-            if (!(dataCache.configuration().getAffinityMapper() instanceof GridGgfsGroupDataBlocksKeyMapper))
+            if (!(dataCache.configuration().getAffinityMapper() instanceof IgniteFsGroupDataBlocksKeyMapper))
                 throw new GridException("Invalid GGFS data cache configuration (key affinity mapper class should be " +
-                    GridGgfsGroupDataBlocksKeyMapper.class.getSimpleName() + "): " + cfg);
+                    IgniteFsGroupDataBlocksKeyMapper.class.getSimpleName() + "): " + cfg);
 
             long maxSpaceSize = cfg.getMaxSpaceSize();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsFileImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsFileImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsFileImpl.java
new file mode 100644
index 0000000..28b2cd6
--- /dev/null
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/ggfs/IgniteFsFileImpl.java
@@ -0,0 +1,237 @@
+/* @java.file.header */
+
+/*  _________        _____ __________________        _____
+ *  __  ____/___________(_)______  /__  ____/______ ____(_)_______
+ *  _  / __  __  ___/__  / _  __  / _  / __  _  __ `/__  / __  __ \
+ *  / /_/ /  _  /    _  /  / /_/ /  / /_/ /  / /_/ / _  /  _  / / /
+ *  \____/   /_/     /_/   \_,__/   \____/   \__,_/  /_/   /_/ /_/
+ */
+
+package org.gridgain.grid.kernal.processors.ggfs;
+
+import org.apache.ignite.lang.*;
+import org.gridgain.grid.ggfs.*;
+import org.gridgain.grid.util.typedef.internal.*;
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+import java.util.*;
+
+/**
+ * File or directory information.
+ */
+public final class IgniteFsFileImpl implements IgniteFsFile, Externalizable {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** Path to this file. */
+    private IgniteFsPath path;
+
+    /** File id. */
+    private IgniteUuid fileId;
+
+    /** Block size. */
+    private int blockSize;
+
+    /** Group block size. */
+    private long grpBlockSize;
+
+    /** File length. */
+    private long len;
+
+    /** Last access time. */
+    private long accessTime;
+
+    /** Last modification time. */
+    private long modificationTime;
+
+    /** Properties. */
+    private Map<String, String> props;
+
+    /**
+     * Empty constructor required by {@link Externalizable}.
+     */
+    public IgniteFsFileImpl() {
+        // No-op.
+    }
+
+    /**
+     * Constructs directory info.
+     *
+     * @param path Path.
+     */
+    public IgniteFsFileImpl(IgniteFsPath path, GridGgfsFileInfo info, long globalGrpBlockSize) {
+        A.notNull(path, "path");
+        A.notNull(info, "info");
+
+        this.path = path;
+        fileId = info.id();
+
+        if (info.isFile()) {
+            blockSize = info.blockSize();
+            len = info.length();
+
+            grpBlockSize = info.affinityKey() == null ? globalGrpBlockSize :
+                info.length() == 0 ? globalGrpBlockSize : info.length();
+        }
+
+        props = info.properties();
+
+        if (props == null)
+            props = Collections.emptyMap();
+
+        accessTime = info.accessTime();
+        modificationTime = info.modificationTime();
+    }
+
+    /**
+     * Constructs file instance.
+     *
+     * @param path Path.
+     * @param entry Listing entry.
+     */
+    public IgniteFsFileImpl(IgniteFsPath path, GridGgfsListingEntry entry, long globalGrpSize) {
+        A.notNull(path, "path");
+        A.notNull(entry, "entry");
+
+        this.path = path;
+        fileId = entry.fileId();
+
+        blockSize = entry.blockSize();
+
+        grpBlockSize = entry.affinityKey() == null ? globalGrpSize :
+            entry.length() == 0 ? globalGrpSize : entry.length();
+
+        len = entry.length();
+        props = entry.properties();
+
+        accessTime = entry.accessTime();
+        modificationTime = entry.modificationTime();
+    }
+
+    /** {@inheritDoc} */
+    @Override public IgniteFsPath path() {
+        return path;
+    }
+
+    /**
+     * @return File ID.
+     */
+    public IgniteUuid fileId() {
+        return fileId;
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean isFile() {
+        return blockSize > 0;
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean isDirectory() {
+        return blockSize == 0;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long length() {
+        return len;
+    }
+
+    /** {@inheritDoc} */
+    @Override public int blockSize() {
+        return blockSize;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long groupBlockSize() {
+        return grpBlockSize;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long accessTime() {
+        return accessTime;
+    }
+
+    /** {@inheritDoc} */
+    @Override public long modificationTime() {
+        return modificationTime;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String property(String name) throws IllegalArgumentException {
+        String val = props.get(name);
+
+        if (val ==  null)
+            throw new IllegalArgumentException("File property not found [path=" + path + ", name=" + name + ']');
+
+        return val;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String property(String name, @Nullable String dfltVal) {
+        String val = props.get(name);
+
+        return val == null ? dfltVal : val;
+    }
+
+    /** {@inheritDoc} */
+    @Override public Map<String, String> properties() {
+        return props;
+    }
+
+    /**
+     * Writes object to data output.
+     *
+     * @param out Data output.
+     */
+    @Override public void writeExternal(ObjectOutput out) throws IOException {
+        path.writeExternal(out);
+
+        out.writeInt(blockSize);
+        out.writeLong(grpBlockSize);
+        out.writeLong(len);
+        U.writeStringMap(out, props);
+        out.writeLong(accessTime);
+        out.writeLong(modificationTime);
+    }
+
+    /**
+     * Reads object from data input.
+     *
+     * @param in Data input.
+     */
+    @Override public void readExternal(ObjectInput in) throws IOException {
+        path = new IgniteFsPath();
+
+        path.readExternal(in);
+
+        blockSize = in.readInt();
+        grpBlockSize = in.readLong();
+        len = in.readLong();
+        props = U.readStringMap(in);
+        accessTime = in.readLong();
+        modificationTime = in.readLong();
+    }
+
+    /** {@inheritDoc} */
+    @Override public int hashCode() {
+        return path.hashCode();
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean equals(Object o) {
+        if (o == this)
+            return true;
+
+        if (o == null || getClass() != o.getClass())
+            return false;
+
+        IgniteFsFileImpl that = (IgniteFsFileImpl)o;
+
+        return path.equals(that.path);
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(IgniteFsFileImpl.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java
index fb8d9fc..0ac5d5d 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/visor/node/VisorGgfsConfiguration.java
@@ -128,7 +128,7 @@ public class VisorGgfsConfiguration implements Serializable {
         cfg.perNodeBatchSize(ggfs.getPerNodeBatchSize());
         cfg.perNodeParallelBatchCount(ggfs.getPerNodeParallelBatchCount());
 
-        GridGgfsFileSystem secFs = ggfs.getSecondaryFileSystem();
+        IgniteFsFileSystem secFs = ggfs.getSecondaryFileSystem();
 
         if (secFs != null) {
             Map<String, String> props = secFs.properties();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/config/ggfs-loopback.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/ggfs-loopback.xml b/modules/core/src/test/config/ggfs-loopback.xml
index 1721ae8..a6b911d 100644
--- a/modules/core/src/test/config/ggfs-loopback.xml
+++ b/modules/core/src/test/config/ggfs-loopback.xml
@@ -109,7 +109,7 @@
                     <property name="distributionMode" value="PARTITIONED_ONLY"/>
                     <property name="backups" value="0"/>
                     <property name="affinityMapper">
-                        <bean class="org.gridgain.grid.ggfs.GridGgfsGroupDataBlocksKeyMapper">
+                        <bean class="org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper">
                             <!-- Haw many blocks in row will be stored on the same node. -->
                             <constructor-arg value="512"/>
                         </bean>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/config/ggfs-no-endpoint.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/ggfs-no-endpoint.xml b/modules/core/src/test/config/ggfs-no-endpoint.xml
index 741edbf..cd4fa1e 100644
--- a/modules/core/src/test/config/ggfs-no-endpoint.xml
+++ b/modules/core/src/test/config/ggfs-no-endpoint.xml
@@ -109,7 +109,7 @@
                     <property name="distributionMode" value="PARTITIONED_ONLY"/>
                     <property name="backups" value="0"/>
                     <property name="affinityMapper">
-                        <bean class="org.gridgain.grid.ggfs.GridGgfsGroupDataBlocksKeyMapper">
+                        <bean class="org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper">
                             <!-- Haw many blocks in row will be stored on the same node. -->
                             <constructor-arg value="512"/>
                         </bean>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/config/ggfs-shmem.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/ggfs-shmem.xml b/modules/core/src/test/config/ggfs-shmem.xml
index 271ace7..84d1f72 100644
--- a/modules/core/src/test/config/ggfs-shmem.xml
+++ b/modules/core/src/test/config/ggfs-shmem.xml
@@ -109,7 +109,7 @@
                     <property name="distributionMode" value="PARTITIONED_ONLY"/>
                     <property name="backups" value="0"/>
                     <property name="affinityMapper">
-                        <bean class="org.gridgain.grid.ggfs.GridGgfsGroupDataBlocksKeyMapper">
+                        <bean class="org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper">
                             <!-- Haw many blocks in row will be stored on the same node. -->
                             <constructor-arg value="512"/>
                         </bean>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
index 202d168..9254490 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsEventsAbstractSelfTest.java
@@ -58,7 +58,7 @@ public abstract class GridGgfsEventsAbstractSelfTest extends GridCommonAbstractT
         cacheCfg.setDistributionMode(PARTITIONED_ONLY);
         cacheCfg.setWriteSynchronizationMode(FULL_SYNC);
         cacheCfg.setEvictionPolicy(null);
-        cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+        cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         cacheCfg.setBackups(0);
         cacheCfg.setQueryIndexEnabled(false);
         cacheCfg.setAtomicityMode(TRANSACTIONAL);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java
index d1c6ea9..94cfd3c 100644
--- a/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/ggfs/GridGgfsFragmentizerAbstractSelfTest.java
@@ -103,7 +103,7 @@ public class GridGgfsFragmentizerAbstractSelfTest extends GridGgfsCommonAbstract
 
         cfg.setCacheMode(PARTITIONED);
         cfg.setBackups(0);
-        cfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(GGFS_GROUP_SIZE));
+        cfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(GGFS_GROUP_SIZE));
         cfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
         cfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
         cfg.setQueryIndexEnabled(false);
@@ -125,13 +125,13 @@ public class GridGgfsFragmentizerAbstractSelfTest extends GridGgfsCommonAbstract
         IgniteUuid fileId = meta.fileId(path);
 
         if (fileId == null)
-            throw new GridGgfsFileNotFoundException("File not found: " + path);
+            throw new IgniteFsFileNotFoundException("File not found: " + path);
 
         GridGgfsFileInfo fileInfo = meta.info(fileId);
 
         do {
             if (fileInfo == null)
-                throw new GridGgfsFileNotFoundException("File not found: " + path);
+                throw new IgniteFsFileNotFoundException("File not found: " + path);
 
             if (fileInfo.fileMap().ranges().isEmpty())
                 return;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
index d34f6de..b21ba0d 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridCacheGgfsPerBlockLruEvictionPolicySelfTest.java
@@ -102,7 +102,7 @@ public class GridCacheGgfsPerBlockLruEvictionPolicySelfTest extends GridGgfsComm
         evictPlc = new GridCacheGgfsPerBlockLruEvictionPolicy();
 
         dataCacheCfg.setEvictionPolicy(evictPlc);
-        dataCacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+        dataCacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         dataCacheCfg.setBackups(0);
         dataCacheCfg.setQueryIndexEnabled(false);
 
@@ -159,7 +159,7 @@ public class GridCacheGgfsPerBlockLruEvictionPolicySelfTest extends GridGgfsComm
         dataCacheCfg.setCacheMode(PARTITIONED);
         dataCacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
         dataCacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
-        dataCacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+        dataCacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         dataCacheCfg.setBackups(0);
         dataCacheCfg.setQueryIndexEnabled(false);
         dataCacheCfg.setAtomicityMode(TRANSACTIONAL);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
index b099ed3..c7dcfb4 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsAbstractSelfTest.java
@@ -168,7 +168,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @throws Exception If failed.
      */
     protected Ignite startGridWithGgfs(String gridName, String ggfsName, GridGgfsMode mode,
-        @Nullable GridGgfsFileSystem secondaryFs, @Nullable String restCfg) throws Exception {
+        @Nullable IgniteFsFileSystem secondaryFs, @Nullable String restCfg) throws Exception {
         IgniteFsConfiguration ggfsCfg = new IgniteFsConfiguration();
 
         ggfsCfg.setDataCacheName("dataCache");
@@ -187,7 +187,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
         dataCacheCfg.setCacheMode(PARTITIONED);
         dataCacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
         dataCacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
-        dataCacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(2));
+        dataCacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(2));
         dataCacheCfg.setBackups(0);
         dataCacheCfg.setQueryIndexEnabled(false);
         dataCacheCfg.setAtomicityMode(TRANSACTIONAL);
@@ -271,15 +271,15 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
     public void testListFiles() throws Exception {
         create(ggfs, paths(DIR, SUBDIR, SUBSUBDIR), paths(FILE));
 
-        Collection<GridGgfsFile> paths = ggfs.listFiles(SUBDIR);
+        Collection<IgniteFsFile> paths = ggfs.listFiles(SUBDIR);
 
         assert paths != null;
         assert paths.size() == 2;
 
-        Iterator<GridGgfsFile> iter = paths.iterator();
+        Iterator<IgniteFsFile> iter = paths.iterator();
 
-        GridGgfsFile path1 = iter.next();
-        GridGgfsFile path2 = iter.next();
+        IgniteFsFile path1 = iter.next();
+        IgniteFsFile path2 = iter.next();
 
         assert (SUBSUBDIR.equals(path1.path()) && FILE.equals(path2.path())) ||
             (FILE.equals(path1.path()) && SUBSUBDIR.equals(path2.path()));
@@ -291,7 +291,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @throws Exception If failed.
      */
     public void testListFilesPathDoesNotExist() throws Exception {
-        Collection<GridGgfsFile> paths = null;
+        Collection<IgniteFsFile> paths = null;
 
         try {
             paths = ggfs.listFiles(SUBDIR);
@@ -311,7 +311,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
     public void testInfo() throws Exception {
         create(ggfs, paths(DIR), null);
 
-        GridGgfsFile info = ggfs.info(DIR);
+        IgniteFsFile info = ggfs.info(DIR);
 
         assert info != null;
 
@@ -324,7 +324,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @throws Exception If failed.
      */
     public void testInfoPathDoesNotExist() throws Exception {
-        GridGgfsFile info = null;
+        IgniteFsFile info = null;
 
         try {
             info = ggfs.info(DIR);
@@ -864,7 +864,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
 
                 return null;
             }
-        }, GridGgfsFileNotFoundException.class, "File not found: " + FILE);
+        }, IgniteFsFileNotFoundException.class, "File not found: " + FILE);
     }
 
     /**
@@ -2124,7 +2124,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @param files Files.
      * @throws Exception If failed.
      */
-    public static void create(GridGgfsFileSystem ggfs, @Nullable IgniteFsPath[] dirs, @Nullable IgniteFsPath[] files)
+    public static void create(IgniteFsFileSystem ggfs, @Nullable IgniteFsPath[] dirs, @Nullable IgniteFsPath[] files)
         throws Exception {
         if (dirs != null) {
             for (IgniteFsPath dir : dirs)
@@ -2150,7 +2150,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @throws IOException In case of IO exception.
      * @throws GridException In case of Grid exception.
      */
-    protected static void createFile(GridGgfsFileSystem ggfs, IgniteFsPath file, boolean overwrite,
+    protected static void createFile(IgniteFsFileSystem ggfs, IgniteFsPath file, boolean overwrite,
         @Nullable byte[]... chunks) throws IOException, GridException {
         OutputStream os = null;
 
@@ -2236,7 +2236,7 @@ public abstract class GridGgfsAbstractSelfTest extends GridGgfsCommonAbstractTes
      * @param ggfs GGFS.
      * @param file File.
      */
-    public static void awaitFileClose(GridGgfsFileSystem ggfs, IgniteFsPath file) {
+    public static void awaitFileClose(IgniteFsFileSystem ggfs, IgniteFsPath file) {
         try {
             ggfs.update(file, Collections.singletonMap("prop", "val"));
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsCacheSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsCacheSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsCacheSelfTest.java
index 5add5ee..71945ee 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsCacheSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsCacheSelfTest.java
@@ -72,7 +72,7 @@ public class GridGgfsCacheSelfTest extends GridGgfsCommonAbstractTest {
             cacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
 
             cacheCfg.setBackups(0);
-            cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+            cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         }
 
         cacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java
index e3e953a..605b1c0 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDataManagerSelfTest.java
@@ -111,7 +111,7 @@ public class GridGgfsDataManagerSelfTest extends GridGgfsCommonAbstractTest {
             cacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
 
             cacheCfg.setBackups(0);
-            cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(DATA_BLOCK_GROUP_CNT));
+            cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(DATA_BLOCK_GROUP_CNT));
         }
 
         cacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
index 2cc67ec..57fadf9 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsDualAbstractSelfTest.java
@@ -74,15 +74,15 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
     public void testListFilesPathMissing() throws Exception {
         create(ggfsSecondary, paths(DIR, SUBDIR, SUBSUBDIR), paths(FILE));
 
-        Collection<GridGgfsFile> paths = ggfs.listFiles(SUBDIR);
+        Collection<IgniteFsFile> paths = ggfs.listFiles(SUBDIR);
 
         assert paths != null;
         assert paths.size() == 2;
 
-        Iterator<GridGgfsFile> iter = paths.iterator();
+        Iterator<IgniteFsFile> iter = paths.iterator();
 
-        GridGgfsFile path1 = iter.next();
-        GridGgfsFile path2 = iter.next();
+        IgniteFsFile path1 = iter.next();
+        IgniteFsFile path2 = iter.next();
 
         assert (SUBSUBDIR.equals(path1.path()) && FILE.equals(path2.path())) ||
             (FILE.equals(path1.path()) && SUBSUBDIR.equals(path2.path()));
@@ -97,7 +97,7 @@ public abstract class GridGgfsDualAbstractSelfTest extends GridGgfsAbstractSelfT
         create(ggfsSecondary, paths(DIR), null);
         create(ggfs, null, null);
 
-        GridGgfsFile info = ggfs.info(DIR);
+        IgniteFsFile info = ggfs.info(DIR);
 
         assert info != null;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsGroupDataBlockKeyMapperHashSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsGroupDataBlockKeyMapperHashSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsGroupDataBlockKeyMapperHashSelfTest.java
index a2ea6ba..e1140b4 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsGroupDataBlockKeyMapperHashSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsGroupDataBlockKeyMapperHashSelfTest.java
@@ -16,7 +16,7 @@ import org.gridgain.grid.util.typedef.internal.*;
 import java.util.concurrent.*;
 
 /**
- * Tests for {@link GridGgfsGroupDataBlocksKeyMapper} hash.
+ * Tests for {@link org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper} hash.
  */
 public class GridGgfsGroupDataBlockKeyMapperHashSelfTest extends GridGgfsCommonAbstractTest {
     /**
@@ -46,7 +46,7 @@ public class GridGgfsGroupDataBlockKeyMapperHashSelfTest extends GridGgfsCommonA
      * @param partCnt Total partitions count.
      * @return Partition index.
      */
-    private int partition(GridGgfsGroupDataBlocksKeyMapper mapper, IgniteUuid fileId, long blockId, int partCnt) {
+    private int partition(IgniteFsGroupDataBlocksKeyMapper mapper, IgniteUuid fileId, long blockId, int partCnt) {
         return U.safeAbs((Integer) mapper.affinityKey(new GridGgfsBlockKey(fileId, null, false, blockId)) % partCnt);
     }
 
@@ -58,7 +58,7 @@ public class GridGgfsGroupDataBlockKeyMapperHashSelfTest extends GridGgfsCommonA
     public void checkDistribution(int grpSize, int partCnt) throws Exception {
         IgniteUuid fileId = IgniteUuid.randomUuid();
 
-        GridGgfsGroupDataBlocksKeyMapper mapper = new GridGgfsGroupDataBlocksKeyMapper(grpSize);
+        IgniteFsGroupDataBlocksKeyMapper mapper = new IgniteFsGroupDataBlocksKeyMapper(grpSize);
 
         int lastPart = 0;
 
@@ -98,7 +98,7 @@ public class GridGgfsGroupDataBlockKeyMapperHashSelfTest extends GridGgfsCommonA
     public void checkIntOverflowDistribution(int partCnt) throws Exception {
         IgniteUuid fileId = IgniteUuid.randomUuid();
 
-        GridGgfsGroupDataBlocksKeyMapper mapper = new GridGgfsGroupDataBlocksKeyMapper(1);
+        IgniteFsGroupDataBlocksKeyMapper mapper = new IgniteFsGroupDataBlocksKeyMapper(1);
 
         int part1 = partition(mapper, fileId, Integer.MAX_VALUE - 1, partCnt);
         int part2 = partition(mapper, fileId, Integer.MAX_VALUE, partCnt);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java
index b1ea25b..2d3fa9c 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetaManagerSelfTest.java
@@ -92,7 +92,7 @@ public class GridGgfsMetaManagerSelfTest extends GridGgfsCommonAbstractTest {
             cacheCfg.setDistributionMode(PARTITIONED_ONLY);
 
             cacheCfg.setBackups(0);
-            cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+            cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         }
 
         cacheCfg.setQueryIndexEnabled(false);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
index db70a00..84a6736 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsMetricsSelfTest.java
@@ -112,7 +112,7 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
         dataCacheCfg.setCacheMode(PARTITIONED);
         dataCacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
         dataCacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
-        dataCacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+        dataCacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         dataCacheCfg.setBackups(0);
         dataCacheCfg.setQueryIndexEnabled(false);
         dataCacheCfg.setAtomicityMode(TRANSACTIONAL);
@@ -164,7 +164,7 @@ public class GridGgfsMetricsSelfTest extends GridGgfsCommonAbstractTest {
         dataCacheCfg.setCacheMode(PARTITIONED);
         dataCacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
         dataCacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
-        dataCacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+        dataCacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         dataCacheCfg.setBackups(0);
         dataCacheCfg.setQueryIndexEnabled(false);
         dataCacheCfg.setAtomicityMode(TRANSACTIONAL);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
index 55a7bb9..4a7d98b 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsModesSelfTest.java
@@ -98,7 +98,7 @@ public class GridGgfsModesSelfTest extends GridGgfsCommonAbstractTest {
         cacheCfg.setCacheMode(PARTITIONED);
         cacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
         cacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
-        cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+        cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         cacheCfg.setBackups(0);
         cacheCfg.setQueryIndexEnabled(false);
         cacheCfg.setAtomicityMode(TRANSACTIONAL);
@@ -152,7 +152,7 @@ public class GridGgfsModesSelfTest extends GridGgfsCommonAbstractTest {
         cacheCfg.setCacheMode(PARTITIONED);
         cacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
         cacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
-        cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+        cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         cacheCfg.setBackups(0);
         cacheCfg.setQueryIndexEnabled(false);
         cacheCfg.setAtomicityMode(TRANSACTIONAL);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
index 1f90684..e425bc8 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorSelfTest.java
@@ -127,7 +127,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
             cacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
 
             cacheCfg.setBackups(0);
-            cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+            cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         }
 
         cacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
@@ -198,7 +198,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
         try (GridGgfsOutputStream os = ggfs.create(path, false)) {
             assert os != null;
 
-            GridGgfsFileImpl info = (GridGgfsFileImpl)ggfs.info(path);
+            IgniteFsFileImpl info = (IgniteFsFileImpl)ggfs.info(path);
 
             for (int i = 0; i < nodesCount(); i++) {
                 GridGgfsFileInfo fileInfo = (GridGgfsFileInfo)grid(i).cachex(metaCacheName).peek(info.fileId());
@@ -300,7 +300,7 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
         GridTestUtils.runMultiThreaded(new Callable<Object>() {
             @Override public Object call() throws Exception {
                 for (int cur = cnt.incrementAndGet(); cur < max; cur = cnt.incrementAndGet()) {
-                    GridGgfsFile info = ggfs.info(path(cur));
+                    IgniteFsFile info = ggfs.info(path(cur));
 
                     assertNotNull("Expects file exist: " + cur, info);
                     assertTrue("Expects file is a directory: " + cur, info.isDirectory());
@@ -955,11 +955,11 @@ public class GridGgfsProcessorSelfTest extends GridGgfsCommonAbstractTest {
      * @throws GridException If failed.
      */
     private void assertListDir(String path, String... item) throws GridException {
-        Collection<GridGgfsFile> files = ggfs.listFiles(new IgniteFsPath(path));
+        Collection<IgniteFsFile> files = ggfs.listFiles(new IgniteFsPath(path));
 
         List<String> names = new ArrayList<>(item.length);
 
-        for (GridGgfsFile file : files)
+        for (IgniteFsFile file : files)
             names.add(file.path().name());
 
         Arrays.sort(item);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java
index de5f837..612a4a0 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsProcessorValidationSelfTest.java
@@ -474,7 +474,7 @@ public class GridGgfsProcessorValidationSelfTest extends GridGgfsCommonAbstractT
     }
 
     /**
-     * @param grpSize Group size to use in {@link GridGgfsGroupDataBlocksKeyMapper}.
+     * @param grpSize Group size to use in {@link org.gridgain.grid.ggfs.IgniteFsGroupDataBlocksKeyMapper}.
      * @param cacheNames 2 Optional caches names.
      * @return 2 preconfigured data caches.
      */
@@ -490,7 +490,7 @@ public class GridGgfsProcessorValidationSelfTest extends GridGgfsCommonAbstractT
             GridCacheConfiguration dataCache = defaultCacheConfiguration();
 
             dataCache.setName(cacheNames[i]);
-            dataCache.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(grpSize));
+            dataCache.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(grpSize));
             dataCache.setAtomicityMode(TRANSACTIONAL);
             dataCache.setQueryIndexEnabled(false);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationAbstractSelfTest.java
index cbc49e2..73a5556 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsServerManagerIpcEndpointRegistrationAbstractSelfTest.java
@@ -123,7 +123,7 @@ public abstract class GridGgfsServerManagerIpcEndpointRegistrationAbstractSelfTe
 
         cc.setName("partitioned");
         cc.setCacheMode(GridCacheMode.PARTITIONED);
-        cc.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+        cc.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         cc.setBackups(0);
         cc.setAtomicityMode(TRANSACTIONAL);
         cc.setQueryIndexEnabled(false);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
index c4a08eb..730338a 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsSizeSelfTest.java
@@ -125,7 +125,7 @@ public class GridGgfsSizeSelfTest extends GridGgfsCommonAbstractTest {
 
         dataCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
         dataCfg.setPreloadMode(SYNC);
-        dataCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+        dataCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         dataCfg.setQueryIndexEnabled(false);
         dataCfg.setAtomicityMode(TRANSACTIONAL);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
index 34a693d..e4f5145 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsStreamsSelfTest.java
@@ -129,7 +129,7 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
             cacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
 
             cacheCfg.setBackups(0);
-            cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(CFG_GRP_SIZE));
+            cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(CFG_GRP_SIZE));
         }
 
         cacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
@@ -200,7 +200,7 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
                 out.write(new byte[1024 * 1024]);
         }
 
-        GridGgfsFile info = fs.info(path);
+        IgniteFsFile info = fs.info(path);
 
         Collection<IgniteFsBlockLocation> affNodes = fs.affinity(path, 0, info.length());
 
@@ -246,7 +246,7 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
             }
 
             // After this we should have first two block colocated with grid 0 and last block colocated with grid 1.
-            GridGgfsFileImpl fileImpl = (GridGgfsFileImpl)fs.info(path);
+            IgniteFsFileImpl fileImpl = (IgniteFsFileImpl)fs.info(path);
 
             GridCache<Object, Object> metaCache = grid(0).cachex(META_CACHE_NAME);
 
@@ -364,7 +364,7 @@ public class GridGgfsStreamsSelfTest extends GridGgfsCommonAbstractTest {
 
         info("Get stored file info: " + path);
 
-        GridGgfsFile desc = fs.info(path);
+        IgniteFsFile desc = fs.info(path);
 
         info("Validate stored file info: " + desc);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
index 88adf6f..35f5c9a 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/GridGgfsTaskSelfTest.java
@@ -106,7 +106,7 @@ public class GridGgfsTaskSelfTest extends GridGgfsCommonAbstractTest {
         dataCacheCfg.setAtomicityMode(TRANSACTIONAL);
         dataCacheCfg.setDistributionMode(PARTITIONED_ONLY);
         dataCacheCfg.setWriteSynchronizationMode(FULL_SYNC);
-        dataCacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(1));
+        dataCacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(1));
         dataCacheCfg.setBackups(0);
         dataCacheCfg.setQueryIndexEnabled(false);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
index 34e5345..fcbb563 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/ggfs/split/GridGgfsAbstractRecordResolverSelfTest.java
@@ -58,7 +58,7 @@ public class GridGgfsAbstractRecordResolverSelfTest extends GridCommonAbstractTe
         dataCacheCfg.setAtomicityMode(TRANSACTIONAL);
         dataCacheCfg.setDistributionMode(NEAR_PARTITIONED);
         dataCacheCfg.setWriteSynchronizationMode(FULL_SYNC);
-        dataCacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(128));
+        dataCacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(128));
         dataCacheCfg.setBackups(0);
         dataCacheCfg.setQueryIndexEnabled(false);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
index 8459461..09fd723 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v1/GridGgfsHadoopFileSystem.java
@@ -814,12 +814,12 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
                 return arr;
             }
             else {
-                Collection<GridGgfsFile> list = rmtClient.listFiles(path);
+                Collection<IgniteFsFile> list = rmtClient.listFiles(path);
 
                 if (list == null)
                     throw new FileNotFoundException("File " + f + " does not exist.");
 
-                List<GridGgfsFile> files = new ArrayList<>(list);
+                List<IgniteFsFile> files = new ArrayList<>(list);
 
                 FileStatus[] arr = new FileStatus[files.size()];
 
@@ -952,7 +952,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
                 return toPrimary(secondaryFs.getFileStatus(toSecondary(f)));
             }
             else {
-                GridGgfsFile info = rmtClient.info(convert(f));
+                IgniteFsFile info = rmtClient.info(convert(f));
 
                 if (info == null)
                     throw new FileNotFoundException("File not found: " + f);
@@ -1185,7 +1185,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
      * @return Hadoop file status.
      */
     @SuppressWarnings("deprecation")
-    private FileStatus convert(GridGgfsFile file) {
+    private FileStatus convert(IgniteFsFile file) {
         return new FileStatus(file.length(), file.isDirectory(), getDefaultReplication(),
             file.groupBlockSize(), file.modificationTime(), file.accessTime(), permission(file),
             file.property(PROP_USER_NAME, DFLT_USER_NAME), file.property(PROP_GROUP_NAME, "users"),
@@ -1224,7 +1224,7 @@ public class GridGgfsHadoopFileSystem extends FileSystem {
      * @param file File info.
      * @return Hadoop permission.
      */
-    private FsPermission permission(GridGgfsFile file) {
+    private FsPermission permission(IgniteFsFile file) {
         String perm = file.property(PROP_PERMISSION, null);
 
         if (perm == null)

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
index 9d320b4..201adcf 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/ggfs/hadoop/v2/GridGgfsHadoopFileSystem.java
@@ -691,12 +691,12 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
                 return arr;
             }
             else {
-                Collection<GridGgfsFile> list = rmtClient.listFiles(path);
+                Collection<IgniteFsFile> list = rmtClient.listFiles(path);
 
                 if (list == null)
                     throw new FileNotFoundException("File " + f + " does not exist.");
 
-                List<GridGgfsFile> files = new ArrayList<>(list);
+                List<IgniteFsFile> files = new ArrayList<>(list);
 
                 FileStatus[] arr = new FileStatus[files.size()];
 
@@ -758,7 +758,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
             if (mode(f) == PROXY)
                 return toPrimary(secondaryFs.getFileStatus(toSecondary(f)));
             else {
-                GridGgfsFile info = rmtClient.info(convert(f));
+                IgniteFsFile info = rmtClient.info(convert(f));
 
                 if (info == null)
                     throw new FileNotFoundException("File not found: " + f);
@@ -933,7 +933,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
      * @param file GGFS file information.
      * @return Hadoop file status.
      */
-    private FileStatus convert(GridGgfsFile file) {
+    private FileStatus convert(IgniteFsFile file) {
         return new FileStatus(
             file.length(),
             file.isDirectory(),
@@ -978,7 +978,7 @@ public class GridGgfsHadoopFileSystem extends AbstractFileSystem implements Clos
      * @param file File info.
      * @return Hadoop permission.
      */
-    private FsPermission permission(GridGgfsFile file) {
+    private FsPermission permission(IgniteFsFile file) {
         String perm = file.property(PROP_PERMISSION, null);
 
         if (perm == null)

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoop.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoop.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoop.java
index 558500c..3b35a95 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoop.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoop.java
@@ -44,7 +44,7 @@ public interface GridGgfsHadoop {
      * @return Future for info operation.
      * @throws GridException If failed.
      */
-    public GridGgfsFile info(IgniteFsPath path) throws GridException, IOException;
+    public IgniteFsFile info(IgniteFsPath path) throws GridException, IOException;
 
     /**
      * Command to update file properties.
@@ -54,7 +54,7 @@ public interface GridGgfsHadoop {
      * @return Future for update operation.
      * @throws GridException If failed.
      */
-    public GridGgfsFile update(IgniteFsPath path, Map<String, String> props) throws GridException, IOException;
+    public IgniteFsFile update(IgniteFsPath path, Map<String, String> props) throws GridException, IOException;
 
     /**
      * Sets last access time and last modification time for a file.
@@ -124,7 +124,7 @@ public interface GridGgfsHadoop {
      * @return Future for listFiles operation.
      * @throws GridException If failed.
      */
-    public Collection<GridGgfsFile> listFiles(IgniteFsPath path) throws GridException, IOException;
+    public Collection<IgniteFsFile> listFiles(IgniteFsPath path) throws GridException, IOException;
 
     /**
      * Command to get directory listing.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
index f07b430..c3e0dae 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopFileSystemWrapper.java
@@ -26,9 +26,9 @@ import org.gridgain.grid.util.typedef.internal.*;
 import org.jetbrains.annotations.*;
 
 /**
- * Adapter to use any Hadoop file system {@link org.apache.hadoop.fs.FileSystem} as {@link GridGgfsFileSystem}.
+ * Adapter to use any Hadoop file system {@link org.apache.hadoop.fs.FileSystem} as {@link org.gridgain.grid.ggfs.IgniteFsFileSystem}.
  */
-public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, AutoCloseable {
+public class GridGgfsHadoopFileSystemWrapper implements IgniteFsFileSystem, AutoCloseable {
     /** Property name for path to Hadoop configuration. */
     public static final String SECONDARY_FS_CONFIG_PATH = "SECONDARY_FS_CONFIG_PATH";
 
@@ -110,7 +110,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
      */
     public static IgniteFsException cast(String msg, IOException e) {
         if (e instanceof FileNotFoundException)
-            return new GridGgfsFileNotFoundException(e);
+            return new IgniteFsFileNotFoundException(e);
         else if (e instanceof ParentNotDirectoryException)
             return new GridGgfsParentNotDirectoryException(msg, e);
         else if (e instanceof PathIsNotEmptyDirectoryException)
@@ -148,7 +148,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public GridGgfsFile update(IgniteFsPath path, Map<String, String> props) throws GridException {
+    @Nullable @Override public IgniteFsFile update(IgniteFsPath path, Map<String, String> props) throws GridException {
         GridGgfsHadoopFSProperties props0 = new GridGgfsHadoopFSProperties(props);
 
         try {
@@ -217,7 +217,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
             FileStatus[] statuses = fileSys.listStatus(convert(path));
 
             if (statuses == null)
-                throw new GridGgfsFileNotFoundException("Failed to list files (path not found): " + path);
+                throw new IgniteFsFileNotFoundException("Failed to list files (path not found): " + path);
 
             Collection<IgniteFsPath> res = new ArrayList<>(statuses.length);
 
@@ -227,7 +227,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
             return res;
         }
         catch (FileNotFoundException ignored) {
-            throw new GridGgfsFileNotFoundException("Failed to list files (path not found): " + path);
+            throw new IgniteFsFileNotFoundException("Failed to list files (path not found): " + path);
         }
         catch (IOException e) {
             throw handleSecondaryFsError(e, "Failed to list statuses due to secondary file system exception: " + path);
@@ -235,27 +235,27 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsFile> listFiles(IgniteFsPath path) throws GridException {
+    @Override public Collection<IgniteFsFile> listFiles(IgniteFsPath path) throws GridException {
         try {
             FileStatus[] statuses = fileSys.listStatus(convert(path));
 
             if (statuses == null)
-                throw new GridGgfsFileNotFoundException("Failed to list files (path not found): " + path);
+                throw new IgniteFsFileNotFoundException("Failed to list files (path not found): " + path);
 
-            Collection<GridGgfsFile> res = new ArrayList<>(statuses.length);
+            Collection<IgniteFsFile> res = new ArrayList<>(statuses.length);
 
             for (FileStatus status : statuses) {
                 GridGgfsFileInfo fsInfo = status.isDirectory() ? new GridGgfsFileInfo(true, properties(status)) :
                     new GridGgfsFileInfo((int)status.getBlockSize(), status.getLen(), null, null, false,
                     properties(status));
 
-                res.add(new GridGgfsFileImpl(new IgniteFsPath(path, status.getPath().getName()), fsInfo, 1));
+                res.add(new IgniteFsFileImpl(new IgniteFsPath(path, status.getPath().getName()), fsInfo, 1));
             }
 
             return res;
         }
         catch (FileNotFoundException ignored) {
-            throw new GridGgfsFileNotFoundException("Failed to list files (path not found): " + path);
+            throw new IgniteFsFileNotFoundException("Failed to list files (path not found): " + path);
         }
         catch (IOException e) {
             throw handleSecondaryFsError(e, "Failed to list statuses due to secondary file system exception: " + path);
@@ -306,7 +306,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile info(final IgniteFsPath path) throws GridException {
+    @Override public IgniteFsFile info(final IgniteFsPath path) throws GridException {
         try {
             final FileStatus status = fileSys.getFileStatus(convert(path));
 
@@ -315,7 +315,7 @@ public class GridGgfsHadoopFileSystemWrapper implements GridGgfsFileSystem, Auto
 
             final Map<String, String> props = properties(status);
 
-            return new GridGgfsFile() {
+            return new IgniteFsFile() {
                 @Override public IgniteFsPath path() {
                     return path;
                 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java
index b09fc5c..e14f9b9 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopInProc.java
@@ -72,7 +72,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile info(IgniteFsPath path) throws GridException {
+    @Override public IgniteFsFile info(IgniteFsPath path) throws GridException {
         try {
             return ggfs.info(path);
         }
@@ -82,7 +82,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile update(IgniteFsPath path, Map<String, String> props) throws GridException {
+    @Override public IgniteFsFile update(IgniteFsPath path, Map<String, String> props) throws GridException {
         try {
             return ggfs.update(path, props);
         }
@@ -148,7 +148,7 @@ public class GridGgfsHadoopInProc implements GridGgfsHadoopEx {
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsFile> listFiles(IgniteFsPath path) throws GridException {
+    @Override public Collection<IgniteFsFile> listFiles(IgniteFsPath path) throws GridException {
         try {
             return ggfs.listFiles(path);
         }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopOutProc.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopOutProc.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopOutProc.java
index 194a217..c32616c 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopOutProc.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopOutProc.java
@@ -34,7 +34,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     private static final GridPlainClosure<GridPlainFuture<GridGgfsMessage>, Long> LONG_RES = createClosure();
 
     /** Expected result is {@code GridGgfsFile}. */
-    private static final GridPlainClosure<GridPlainFuture<GridGgfsMessage>, GridGgfsFile> FILE_RES = createClosure();
+    private static final GridPlainClosure<GridPlainFuture<GridGgfsMessage>, IgniteFsFile> FILE_RES = createClosure();
 
     /** Expected result is {@code GridGgfsHandshakeResponse} */
     private static final GridPlainClosure<GridPlainFuture<GridGgfsMessage>,
@@ -50,7 +50,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
 
     /** Expected result is {@code GridGgfsFile}. */
     private static final GridPlainClosure<GridPlainFuture<GridGgfsMessage>,
-        Collection<GridGgfsFile>> FILE_COL_RES = createClosure();
+        Collection<IgniteFsFile>> FILE_COL_RES = createClosure();
 
     /** Expected result is {@code GridGgfsFile}. */
     private static final GridPlainClosure<GridPlainFuture<GridGgfsMessage>,
@@ -157,7 +157,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile info(IgniteFsPath path) throws GridException {
+    @Override public IgniteFsFile info(IgniteFsPath path) throws GridException {
         final GridGgfsPathControlRequest msg = new GridGgfsPathControlRequest();
 
         msg.command(INFO);
@@ -167,7 +167,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile update(IgniteFsPath path, Map<String, String> props) throws GridException {
+    @Override public IgniteFsFile update(IgniteFsPath path, Map<String, String> props) throws GridException {
         final GridGgfsPathControlRequest msg = new GridGgfsPathControlRequest();
 
         msg.command(UPDATE);
@@ -246,7 +246,7 @@ public class GridGgfsHadoopOutProc implements GridGgfsHadoopEx, GridGgfsHadoopIp
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsFile> listFiles(IgniteFsPath path) throws GridException {
+    @Override public Collection<IgniteFsFile> listFiles(IgniteFsPath path) throws GridException {
         final GridGgfsPathControlRequest msg = new GridGgfsPathControlRequest();
 
         msg.command(LIST_FILES);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java
index f54dbfb..9d52a99 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopUtils.java
@@ -102,7 +102,7 @@ public class GridGgfsHadoopUtils {
         // First check for any nested IOException; if exists - re-throw it.
         if (e.hasCause(IOException.class))
             return e.getCause(IOException.class);
-        else if (e instanceof GridGgfsFileNotFoundException)
+        else if (e instanceof IgniteFsFileNotFoundException)
             return new FileNotFoundException(path); // TODO: Or PathNotFoundException?
         else if (e instanceof GridGgfsParentNotDirectoryException)
             return new ParentNotDirectoryException(path);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopWrapper.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopWrapper.java b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopWrapper.java
index 4fff807..cd34dd2 100644
--- a/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopWrapper.java
+++ b/modules/hadoop/src/main/java/org/gridgain/grid/kernal/ggfs/hadoop/GridGgfsHadoopWrapper.java
@@ -88,9 +88,9 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile info(final IgniteFsPath path) throws IOException {
-        return withReconnectHandling(new FileSystemClosure<GridGgfsFile>() {
-            @Override public GridGgfsFile apply(GridGgfsHadoopEx hadoop, GridGgfsHandshakeResponse hndResp)
+    @Override public IgniteFsFile info(final IgniteFsPath path) throws IOException {
+        return withReconnectHandling(new FileSystemClosure<IgniteFsFile>() {
+            @Override public IgniteFsFile apply(GridGgfsHadoopEx hadoop, GridGgfsHandshakeResponse hndResp)
                 throws GridException, IOException {
                 return hadoop.info(path);
             }
@@ -98,9 +98,9 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
     }
 
     /** {@inheritDoc} */
-    @Override public GridGgfsFile update(final IgniteFsPath path, final Map<String, String> props) throws IOException {
-        return withReconnectHandling(new FileSystemClosure<GridGgfsFile>() {
-            @Override public GridGgfsFile apply(GridGgfsHadoopEx hadoop, GridGgfsHandshakeResponse hndResp)
+    @Override public IgniteFsFile update(final IgniteFsPath path, final Map<String, String> props) throws IOException {
+        return withReconnectHandling(new FileSystemClosure<IgniteFsFile>() {
+            @Override public IgniteFsFile apply(GridGgfsHadoopEx hadoop, GridGgfsHandshakeResponse hndResp)
                 throws GridException, IOException {
                 return hadoop.update(path, props);
             }
@@ -170,9 +170,9 @@ public class GridGgfsHadoopWrapper implements GridGgfsHadoop {
     }
 
     /** {@inheritDoc} */
-    @Override public Collection<GridGgfsFile> listFiles(final IgniteFsPath path) throws IOException {
-        return withReconnectHandling(new FileSystemClosure<Collection<GridGgfsFile>>() {
-            @Override public Collection<GridGgfsFile> apply(GridGgfsHadoopEx hadoop,
+    @Override public Collection<IgniteFsFile> listFiles(final IgniteFsPath path) throws IOException {
+        return withReconnectHandling(new FileSystemClosure<Collection<IgniteFsFile>>() {
+            @Override public Collection<IgniteFsFile> apply(GridGgfsHadoopEx hadoop,
                 GridGgfsHandshakeResponse hndResp) throws GridException, IOException {
                 return hadoop.listFiles(path);
             }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/test/java/org/gridgain/client/hadoop/GridHadoopClientProtocolSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/client/hadoop/GridHadoopClientProtocolSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/client/hadoop/GridHadoopClientProtocolSelfTest.java
index dda947f..49c4ad9 100644
--- a/modules/hadoop/src/test/java/org/gridgain/client/hadoop/GridHadoopClientProtocolSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/client/hadoop/GridHadoopClientProtocolSelfTest.java
@@ -393,7 +393,7 @@ public class GridHadoopClientProtocolSelfTest extends GridHadoopAbstractSelfTest
      */
     @SuppressWarnings("ConstantConditions")
     private static void dumpGgfs(IgniteFs ggfs, IgniteFsPath path) throws Exception {
-        GridGgfsFile file = ggfs.info(path);
+        IgniteFsFile file = ggfs.info(path);
 
         assert file != null;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba3dc44/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
index 06c0a07..5e70bd3 100644
--- a/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/gridgain/grid/ggfs/GridGgfsHadoop20FileSystemAbstractSelfTest.java
@@ -152,7 +152,7 @@ public abstract class GridGgfsHadoop20FileSystemAbstractSelfTest extends GridGgf
             cacheCfg.setCacheMode(PARTITIONED);
             cacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
             cacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
-            cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(GRP_SIZE));
+            cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(GRP_SIZE));
             cacheCfg.setBackups(0);
             cacheCfg.setQueryIndexEnabled(false);
             cacheCfg.setAtomicityMode(TRANSACTIONAL);
@@ -222,7 +222,7 @@ public abstract class GridGgfsHadoop20FileSystemAbstractSelfTest extends GridGgf
         cacheCfg.setCacheMode(PARTITIONED);
         cacheCfg.setDistributionMode(GridCacheDistributionMode.PARTITIONED_ONLY);
         cacheCfg.setWriteSynchronizationMode(GridCacheWriteSynchronizationMode.FULL_SYNC);
-        cacheCfg.setAffinityMapper(new GridGgfsGroupDataBlocksKeyMapper(GRP_SIZE));
+        cacheCfg.setAffinityMapper(new IgniteFsGroupDataBlocksKeyMapper(GRP_SIZE));
         cacheCfg.setBackups(0);
         cacheCfg.setQueryIndexEnabled(false);
         cacheCfg.setAtomicityMode(TRANSACTIONAL);
@@ -1295,7 +1295,7 @@ public abstract class GridGgfsHadoop20FileSystemAbstractSelfTest extends GridGgf
 
             IgniteFsPath filePath = new IgniteFsPath("/someFile");
 
-            GridGgfsFile fileInfo = igniteFs.info(filePath);
+            IgniteFsFile fileInfo = igniteFs.info(filePath);
 
             Collection<IgniteFsBlockLocation> locations = igniteFs.affinity(filePath, 0, fileInfo.length());
 


[03/38] incubator-ignite git commit: # Renaming

Posted by sb...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/task/GridTaskCommandHandler.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/task/GridTaskCommandHandler.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/task/GridTaskCommandHandler.java
index 4653e85..b599a48 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/task/GridTaskCommandHandler.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/rest/handlers/task/GridTaskCommandHandler.java
@@ -257,7 +257,7 @@ public class GridTaskCommandHandler extends GridRestCommandHandlerAdapter {
                                         res.setResponse(taskRestRes);
                                         fut.onDone(res);
                                     }
-                                    catch (GridPortableException e) {
+                                    catch (PortableException e) {
                                         fut.onDone(new GridException("Failed to marshal task result: " +
                                             desc.result(), e));
                                     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/security/GridSecurityCredentials.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/security/GridSecurityCredentials.java b/modules/core/src/main/java/org/gridgain/grid/security/GridSecurityCredentials.java
index 57c3b43..299e9f9 100644
--- a/modules/core/src/main/java/org/gridgain/grid/security/GridSecurityCredentials.java
+++ b/modules/core/src/main/java/org/gridgain/grid/security/GridSecurityCredentials.java
@@ -37,7 +37,7 @@ import java.io.*;
  * specifying {@link #setUserObject(Object) userObject} as well, which can be used
  * to pass in any additional information required for authentication.
  */
-public class GridSecurityCredentials implements Externalizable, GridPortableMarshalAware {
+public class GridSecurityCredentials implements Externalizable, PortableMarshalAware {
     /** */
     private static final long serialVersionUID = -2655741071578326256L;
 
@@ -176,14 +176,14 @@ public class GridSecurityCredentials implements Externalizable, GridPortableMars
     }
 
     /** {@inheritDoc} */
-    @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+    @Override public void writePortable(GridPortableWriter writer) throws PortableException {
         writer.rawWriter().writeObject(login);
         writer.rawWriter().writeObject(password);
         writer.rawWriter().writeObject(userObj);
     }
 
     /** {@inheritDoc} */
-    @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+    @Override public void readPortable(GridPortableReader reader) throws PortableException {
         login = reader.rawReader().readObject();
         password = reader.rawReader().readObject();
         userObj = reader.rawReader().readObject();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawReaderEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawReaderEx.java b/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawReaderEx.java
index a7ea04f..2367147 100644
--- a/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawReaderEx.java
+++ b/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawReaderEx.java
@@ -18,7 +18,7 @@ import org.jetbrains.annotations.*;
 public interface GridPortableRawReaderEx extends GridPortableRawReader {
     /**
      * @return Object.
-     * @throws org.apache.ignite.portables.GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    @Nullable public Object readObjectDetached() throws GridPortableException;
+    @Nullable public Object readObjectDetached() throws PortableException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawWriterEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawWriterEx.java b/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawWriterEx.java
index 18e761b..7e8dd85 100644
--- a/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawWriterEx.java
+++ b/modules/core/src/main/java/org/gridgain/grid/util/portable/GridPortableRawWriterEx.java
@@ -19,9 +19,9 @@ import org.jetbrains.annotations.*;
 public interface GridPortableRawWriterEx extends GridPortableRawWriter, AutoCloseable {
     /**
      * @param obj Object to write.
-     * @throws org.apache.ignite.portables.GridPortableException In case of error.
+     * @throws org.apache.ignite.portables.PortableException In case of error.
      */
-    public void writeObjectDetached(@Nullable Object obj) throws GridPortableException;
+    public void writeObjectDetached(@Nullable Object obj) throws PortableException;
 
     /**
      * @return Output stream.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/GridCacheOffHeapTieredAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/GridCacheOffHeapTieredAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/GridCacheOffHeapTieredAbstractSelfTest.java
index 0520d9a..b259529 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/GridCacheOffHeapTieredAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/GridCacheOffHeapTieredAbstractSelfTest.java
@@ -51,7 +51,7 @@ public abstract class GridCacheOffHeapTieredAbstractSelfTest extends GridCacheAb
         IgniteConfiguration cfg = super.getConfiguration(gridName);
 
         if (portableEnabled()) {
-            GridPortableConfiguration pCfg = new GridPortableConfiguration();
+            PortableConfiguration pCfg = new PortableConfiguration();
 
             pCfg.setClassNames(Arrays.asList(TestValue.class.getName()));
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/GridCacheOffHeapTieredEvictionAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/GridCacheOffHeapTieredEvictionAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/GridCacheOffHeapTieredEvictionAbstractSelfTest.java
index 9dbfbb5..aabd175 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/GridCacheOffHeapTieredEvictionAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/GridCacheOffHeapTieredEvictionAbstractSelfTest.java
@@ -55,7 +55,7 @@ public abstract class GridCacheOffHeapTieredEvictionAbstractSelfTest extends Gri
         IgniteConfiguration cfg = super.getConfiguration(gridName);
 
         if (portableEnabled()) {
-            GridPortableConfiguration pCfg = new GridPortableConfiguration();
+            PortableConfiguration pCfg = new PortableConfiguration();
 
             pCfg.setClassNames(Arrays.asList(TestValue.class.getName()));
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/query/GridCacheSwapScanQueryAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/query/GridCacheSwapScanQueryAbstractSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/query/GridCacheSwapScanQueryAbstractSelfTest.java
index 8bccf2e..299a2a3 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/query/GridCacheSwapScanQueryAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/cache/query/GridCacheSwapScanQueryAbstractSelfTest.java
@@ -62,7 +62,7 @@ public abstract class GridCacheSwapScanQueryAbstractSelfTest extends GridCommonA
             cacheConfiguration(TRANSACTIONAL_CACHE_NAME, TRANSACTIONAL));
 
         if (portableEnabled()) {
-            GridPortableConfiguration pCfg = new GridPortableConfiguration();
+            PortableConfiguration pCfg = new PortableConfiguration();
 
             pCfg.setClassNames(Arrays.asList(Key.class.getName(), Person.class.getName()));
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a228c7d6/modules/core/src/test/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderImplSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderImplSelfTest.java b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderImplSelfTest.java
index 03ae4d0..3e6b207 100644
--- a/modules/core/src/test/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderImplSelfTest.java
+++ b/modules/core/src/test/java/org/gridgain/grid/kernal/processors/dataload/GridDataLoaderImplSelfTest.java
@@ -55,7 +55,7 @@ public class GridDataLoaderImplSelfTest extends GridCommonAbstractTest {
         cfg.setDiscoverySpi(discoSpi);
 
         if (portables) {
-            GridPortableConfiguration portableCfg = new GridPortableConfiguration();
+            PortableConfiguration portableCfg = new PortableConfiguration();
 
             portableCfg.setTypeConfigurations(Arrays.asList(
                 new GridPortableTypeConfiguration(TestObject.class.getName())));
@@ -251,7 +251,7 @@ public class GridDataLoaderImplSelfTest extends GridCommonAbstractTest {
     /**
      *
      */
-    private static class TestObject implements GridPortableMarshalAware, Serializable {
+    private static class TestObject implements PortableMarshalAware, Serializable {
         /** */
         private int val;
 
@@ -283,12 +283,12 @@ public class GridDataLoaderImplSelfTest extends GridCommonAbstractTest {
         }
 
         /** {@inheritDoc} */
-        @Override public void writePortable(GridPortableWriter writer) throws GridPortableException {
+        @Override public void writePortable(GridPortableWriter writer) throws PortableException {
             writer.writeInt("val", val);
         }
 
         /** {@inheritDoc} */
-        @Override public void readPortable(GridPortableReader reader) throws GridPortableException {
+        @Override public void readPortable(GridPortableReader reader) throws PortableException {
             val = reader.readInt("val");
         }
     }