You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by vo...@apache.org on 2015/09/03 12:48:59 UTC

[05/16] ignite git commit: IGNITE-1364: Moved headers to correct folders.

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/include/ignite/portable/portable_type.h
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/include/ignite/portable/portable_type.h b/modules/platform/src/main/cpp/core/include/ignite/portable/portable_type.h
new file mode 100644
index 0000000..ce5b2fa
--- /dev/null
+++ b/modules/platform/src/main/cpp/core/include/ignite/portable/portable_type.h
@@ -0,0 +1,293 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+#ifndef _IGNITE_PORTABLE_TYPE
+#define _IGNITE_PORTABLE_TYPE
+
+#include <stdint.h>
+
+#include <ignite/common/common.h>
+
+#include "ignite/grid_error.h"
+
+/**
+ * Start portable type definition.
+ */
+#define IGNITE_PORTABLE_TYPE_START(T) \
+template<> \
+struct PortableType<T> \
+{
+
+/**
+ * End portable type definition.
+ */
+#define IGNITE_PORTABLE_TYPE_END \
+};
+
+/**
+ * Implementation of GetTypeId() which returns predefined constant.
+ */
+#define IGNITE_PORTABLE_GET_TYPE_ID_AS_CONST(id) \
+int32_t GetTypeId() \
+{ \
+    return id; \
+}
+
+/**
+ * Implementation of GetTypeId() which returns hash of passed type name.
+ */
+#define IGNITE_PORTABLE_GET_TYPE_ID_AS_HASH(typeName) \
+int32_t GetTypeId() \
+{ \
+    return GetPortableStringHashCode(#typeName); \
+}
+
+/**
+ * Implementation of GetTypeName() which returns type name as is.
+ */
+#define IGNITE_PORTABLE_GET_TYPE_NAME_AS_IS(typeName) \
+std::string GetTypeName() \
+{ \
+    return #typeName; \
+}
+
+/**
+ * Default implementation of GetFieldId() function which returns Java-way hash code of the string.
+ */
+#define IGNITE_PORTABLE_GET_FIELD_ID_AS_HASH \
+int32_t GetFieldId(const char* name) \
+{ \
+    return GetPortableStringHashCode(name); \
+}
+
+/**
+ * Implementation of GetHashCode() function which always returns 0.
+ */
+#define IGNITE_PORTABLE_GET_HASH_CODE_ZERO(T) \
+int32_t GetHashCode(const T& obj) \
+{ \
+    return 0; \
+}
+
+/**
+ * Implementation of IsNull() function which always returns false.
+ */
+#define IGNITE_PORTABLE_IS_NULL_FALSE(T) \
+bool IsNull(const T& obj) \
+{ \
+    return false; \
+}
+
+/**
+ * Implementation of IsNull() function which return true if passed object is null pointer.
+ */
+#define IGNITE_PORTABLE_IS_NULL_IF_NULLPTR(T) \
+bool IsNull(const T& obj) \
+{ \
+    return obj; \
+}
+
+/**
+ * Implementation of GetNull() function which returns an instance created with defult constructor.
+ */
+#define IGNITE_PORTABLE_GET_NULL_DEFAULT_CTOR(T) \
+T GetNull() \
+{ \
+    return T(); \
+}
+
+/**
+ * Implementation of GetNull() function which returns NULL pointer.
+ */
+#define IGNITE_PORTABLE_GET_NULL_NULLPTR(T) \
+T GetNull() \
+{ \
+    return NULL; \
+}
+
+namespace ignite
+{
+    namespace portable
+    {
+        class PortableWriter;
+        class PortableReader;
+
+        /**
+         * Get portable string hash code.
+         *
+         * @param val Value.
+         * @return Hash code.
+         */
+        IGNITE_IMPORT_EXPORT int32_t GetPortableStringHashCode(const char* val);
+
+        /**
+         * Portable type structure. Defines a set of functions required for type to be serialized and deserialized.
+         */
+        template<typename T>
+        struct IGNITE_IMPORT_EXPORT PortableType
+        {
+            /**
+             * Get portable object type ID.
+             *
+             * @return Type ID.
+             */
+            int32_t GetTypeId()
+            {
+                IGNITE_ERROR_1(GridError::IGNITE_ERR_PORTABLE, "GetTypeId function is not defined for portable type.");
+            }
+
+            /**
+             * Get portable object type name.
+             *
+             * @return Type name.
+             */
+            std::string GetTypeName() 
+            {
+                IGNITE_ERROR_1(GridError::IGNITE_ERR_PORTABLE, "GetTypeName function is not defined for portable type.");
+            }
+
+            /**
+             * Get portable object field ID.
+             *
+             * @param name Field name.
+             * @return Field ID.
+             */
+            int32_t GetFieldId(const char* name)
+            {
+                return GetPortableStringHashCode(name);
+            }
+
+            /**
+             * Get portable object hash code.
+             *
+             * @param obj Portable object.
+             * @return Hash code.
+             */
+            int32_t GetHashCode(const T& obj)
+            {
+                return 0;
+            }
+
+            /**
+             * Write portable object.
+             *
+             * @param writer Writer.
+             * @param obj Object.
+             */
+            void Write(PortableWriter& writer, const T& obj)
+            {
+                IGNITE_ERROR_1(GridError::IGNITE_ERR_PORTABLE, "Write function is not defined for portable type.");
+            }
+
+            /**
+             * Read portable object.
+             *
+             * @param reader Reader.
+             * @return Object.
+             */
+            T Read(PortableReader& reader)
+            {
+                IGNITE_ERROR_1(GridError::IGNITE_ERR_PORTABLE, "Read function is not defined for portable type.");
+            }
+
+            /**
+             * Check whether passed portable object should be interpreted as NULL.
+             *
+             * @param obj Portable object to test.
+             * @return True if portable object should be interpreted as NULL.
+             */
+            bool IsNull(const T& obj)
+            {
+                return false;
+            }
+
+            /**
+             * Get NULL value for the given portable type.
+             *
+             * @return NULL value.
+             */
+            T GetNull()
+            {
+                IGNITE_ERROR_1(GridError::IGNITE_ERR_PORTABLE, "GetNull function is not defined for portable type.");
+            }
+        };
+
+        /*
+         * Templated portable type for pointers.
+         */
+        template <typename T>
+        struct IGNITE_IMPORT_EXPORT PortableType<T*>
+        {
+            /** Actual type. */
+            PortableType<T> typ;
+
+            /**
+             * Constructor.
+             */
+            PortableType()
+            {
+                typ = PortableType<T>();
+            }
+
+            int32_t GetTypeId()
+            {
+                return typ.GetTypeId();
+            }
+
+            std::string GetTypeName()
+            {
+                return typ.GetTypeName();
+            }
+
+            int32_t GetFieldId(const char* name)
+            {
+                return typ.GetFieldId(name);
+            }
+
+            int32_t GetHashCode(T* const& obj)
+            {
+                return typ.GetHashCode(*obj);
+            }
+
+            void Write(PortableWriter& writer, T* const& obj)
+            {
+                typ.Write(writer, *obj);
+            }
+
+            T* Read(PortableReader& reader)
+            {
+                T* res = new T();
+
+                *res = typ.Read(reader);
+
+                return res;
+            }
+
+            bool IsNull(T* const& obj)
+            {
+                return !obj || typ.IsNull(*obj);
+            }
+
+            T* GetNull()
+            {
+                return NULL;
+            }
+        };
+    }
+}
+
+#endif

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/include/ignite/portable/portable_writer.h
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/include/ignite/portable/portable_writer.h b/modules/platform/src/main/cpp/core/include/ignite/portable/portable_writer.h
new file mode 100644
index 0000000..5dc9494
--- /dev/null
+++ b/modules/platform/src/main/cpp/core/include/ignite/portable/portable_writer.h
@@ -0,0 +1,335 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+#ifndef _IGNITE_PORTABLE_WRITER
+#define _IGNITE_PORTABLE_WRITER
+
+#include <string>
+#include <stdint.h>
+
+#include <ignite/common/common.h>
+
+#include "ignite/portable/portable_raw_writer.h"
+
+namespace ignite
+{
+    namespace portable 
+    {
+        /**
+         * Portable writer.
+         */
+        class IGNITE_IMPORT_EXPORT PortableWriter
+        {
+        public:
+            /**
+             * Constructor.
+             *
+             * @param impl Implementation.
+             */
+            PortableWriter(ignite::impl::portable::PortableWriterImpl* impl);
+
+            /**
+             * Write 8-byte signed integer. Maps to "byte" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Value.
+             */
+            void WriteInt8(const char* fieldName, const int8_t val);
+
+            /**
+             * Write array of 8-byte signed integers. Maps to "byte[]" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Array.
+             * @param len Array length.
+             */
+            void WriteInt8Array(const char* fieldName, const int8_t* val, const int32_t len);
+
+            /**
+             * Write bool. Maps to "short" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Value.
+             */
+            void WriteBool(const char* fieldName, const bool val);
+
+            /**
+             * Write array of bools. Maps to "bool[]" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Array.
+             * @param len Array length.
+             */
+            void WriteBoolArray(const char* fieldName, const bool* val, const int32_t len);
+
+            /**
+             * Write 16-byte signed integer. Maps to "short" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Value.
+             */
+            void WriteInt16(const char* fieldName, const int16_t val);
+
+            /**
+             * Write array of 16-byte signed integers. Maps to "short[]" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Array.
+             * @param len Array length.
+             */
+            void WriteInt16Array(const char* fieldName, const int16_t* val, const int32_t len);
+
+            /**
+             * Write 16-byte unsigned integer. Maps to "char" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Value.
+             */
+            void WriteUInt16(const char* fieldName, const uint16_t val);
+
+            /**
+             * Write array of 16-byte unsigned integers. Maps to "char[]" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Array.
+             * @param len Array length.
+             */
+            void WriteUInt16Array(const char* fieldName, const uint16_t* val, const int32_t len);
+
+            /**
+             * Write 32-byte signed integer. Maps to "int" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Value.
+             */
+            void WriteInt32(const char* fieldName, const int32_t val);
+
+            /**
+             * Write array of 32-byte signed integers. Maps to "int[]" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Array.
+             * @param len Array length.
+             */
+            void WriteInt32Array(const char* fieldName, const int32_t* val, const int32_t len);
+
+            /**
+             * Write 64-byte signed integer. Maps to "long" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Value.
+             */
+            void WriteInt64(const char* fieldName, const int64_t val);
+
+            /**
+             * Write array of 64-byte signed integers. Maps to "long[]" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Array.
+             * @param len Array length.
+             */
+            void WriteInt64Array(const char* fieldName, const int64_t* val, const int32_t len);
+
+            /**
+             * Write float. Maps to "float" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Value.
+             */
+            void WriteFloat(const char* fieldName, const float val);
+
+            /**
+             * Write array of floats. Maps to "float[]" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Array.
+             * @param len Array length.
+             */
+            void WriteFloatArray(const char* fieldName, const float* val, const int32_t len);
+
+            /**
+             * Write double. Maps to "double" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Value.
+             */
+            void WriteDouble(const char* fieldName, const double val);
+
+            /**
+             * Write array of doubles. Maps to "double[]" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Array.
+             * @param len Array length.
+             */
+            void WriteDoubleArray(const char* fieldName, const double* val, const int32_t len);
+
+            /**
+             * Write Guid. Maps to "UUID" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Value.
+             */
+            void WriteGuid(const char* fieldName, const Guid val);
+
+            /**
+             * Write array of Guids. Maps to "UUID[]" type in Java.
+             *
+             * @param fieldName Field name.
+             * @param val Array.
+             * @param len Array length.
+             */
+            void WriteGuidArray(const char* fieldName, const Guid* val, const int32_t len);
+
+            /**
+             * Write string.
+             *
+             * @param fieldName Field name.
+             * @param val Null-terminated character sequence.
+             */
+            void WriteString(const char* fieldName, const char* val);
+
+            /**
+             * Write string.
+             *
+             * @param fieldName Field name.
+             * @param val String.
+             * @param len String length (characters).
+             */
+            void WriteString(const char* fieldName, const char* val, const int32_t len);
+
+            /**
+             * Write string.
+             *
+             * @param fieldName Field name.
+             * @param val String.
+             */
+            void WriteString(const char* fieldName, const std::string& val)
+            {
+                WriteString(fieldName, val.c_str());
+            }
+
+            /**
+             * Start string array write.
+             *
+             * @param fieldName Field name.
+             * @return String array writer.
+             */
+            PortableStringArrayWriter WriteStringArray(const char* fieldName);
+
+            /**
+             * Write NULL value.
+             *
+             * @param fieldName Field name.
+             */
+            void WriteNull(const char* fieldName);
+
+            /**
+             * Start array write.
+             *
+             * @param fieldName Field name.
+             * @return Array writer.
+             */
+            template<typename T>
+            PortableArrayWriter<T> WriteArray(const char* fieldName)
+            {
+                int32_t id = impl->WriteArray(fieldName);
+
+                return PortableArrayWriter<T>(impl, id);
+            }
+
+            /**
+             * Start collection write.
+             *
+             * @param fieldName Field name.
+             * @return Collection writer.
+             */
+            template<typename T>
+            PortableCollectionWriter<T> WriteCollection(const char* fieldName)
+            {
+                return WriteCollection<T>(fieldName, IGNITE_COLLECTION_UNDEFINED);
+            }
+
+            /**
+             * Start collection write.
+             *
+             * @param fieldName Field name.
+             * @param type Collection type.
+             * @return Collection writer.
+             */
+            template<typename T>
+            PortableCollectionWriter<T> WriteCollection(const char* fieldName, ignite::portable::CollectionType typ)
+            {
+                int32_t id = impl->WriteCollection(fieldName, typ);
+
+                return PortableCollectionWriter<T>(impl, id);
+            }
+
+            /**
+             * Start map write.
+             *
+             * @param fieldName Field name.
+             * @param typ Map type.
+             * @return Map writer.
+             */
+            template<typename K, typename V>
+            PortableMapWriter<K, V> WriteMap(const char* fieldName)
+            {
+                return WriteMap<K, V>(fieldName, IGNITE_MAP_UNDEFINED);
+            }
+
+            /**
+             * Start map write.
+             *
+             * @param fieldName Field name.
+             * @param typ Map type.
+             * @return Map writer.
+             */
+            template<typename K, typename V>
+            PortableMapWriter<K, V> WriteMap(const char* fieldName, ignite::portable::MapType typ)
+            {
+                int32_t id = impl->WriteMap(fieldName, typ);
+
+                return PortableMapWriter<K, V>(impl, id);
+            }
+
+            /**
+             * Write object.
+             *
+             * @param fieldName Field name.
+             * @param val Value.
+             */
+            template<typename T>
+            void WriteObject(const char* fieldName, T val)
+            {
+                impl->WriteObject<T>(fieldName, val);
+            }
+
+            /**
+             * Get raw writer for this reader.
+             *
+             * @return Raw writer.
+             */
+            PortableRawWriter RawWriter();
+        private:
+            /** Implementation delegate. */
+            ignite::impl::portable::PortableWriterImpl* impl;
+        };
+    }
+}
+
+#endif
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/os/linux/include/Makefile.am
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/os/linux/include/Makefile.am b/modules/platform/src/main/cpp/core/os/linux/include/Makefile.am
index 7402d04..2ee13eff 100644
--- a/modules/platform/src/main/cpp/core/os/linux/include/Makefile.am
+++ b/modules/platform/src/main/cpp/core/os/linux/include/Makefile.am
@@ -17,4 +17,4 @@
 
 ACLOCAL_AMFLAGS = "-Im4"
 
-nobase_include_HEADERS = gridgain/impl/utils.h
+nobase_include_HEADERS = ignite/impl/utils.h

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/os/linux/include/gridgain/impl/utils.h
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/os/linux/include/gridgain/impl/utils.h b/modules/platform/src/main/cpp/core/os/linux/include/gridgain/impl/utils.h
deleted file mode 100644
index 5cbd6cf..0000000
--- a/modules/platform/src/main/cpp/core/os/linux/include/gridgain/impl/utils.h
+++ /dev/null
@@ -1,155 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-#ifndef GRIDGAIN_UTILS
-#define GRIDGAIN_UTILS
-
-#include <cstring>
-#include <string>
-
-#include <ignite/common/common.h>
-
-#ifdef IGNITE_FRIEND
-    #define IGNITE_FRIEND_EXPORT IGNITE_EXPORT
-#else
-    #define IGNITE_FRIEND_EXPORT
-#endif
-
-namespace gridgain
-{    
-    namespace impl
-    {
-        namespace utils
-        {                
-            /**
-             * Copy characters.
-             *
-             * @param val Value.
-             * @return Result.
-             */
-            IGNITE_FRIEND_EXPORT char* CopyChars(const char* val);
-
-            /**
-             * Release characters.
-             *
-             * @param val Value.
-             */
-            IGNITE_FRIEND_EXPORT void ReleaseChars(char* val);
-            
-            /**
-             * Read system environment variable taking thread-safety in count.
-             *
-             * @param name Environment variable name.
-             * @param found Whether environment variable with such name was found.
-             * @return Environment variable value.
-             */
-            IGNITE_FRIEND_EXPORT std::string GetEnv(const std::string& name, bool* found);
-                                
-            /**
-             * Ensure that file on the given path exists in the system.
-             *
-             * @param path Path.
-             * @return True if file exists, false otherwise.
-             */
-            IGNITE_FRIEND_EXPORT bool FileExists(const std::string& path);
-
-            /**
-             * Attempts to find JVM library to load it into the process later.
-             * First search is performed using the passed path argument (is not NULL).
-             * Then JRE_HOME is evaluated. Last, JAVA_HOME is evaluated.
-             *
-             * @param Explicitly defined path (optional).
-             * @param found Whether library was found.
-             * @return Path to the file.
-             */
-            IGNITE_FRIEND_EXPORT std::string FindJvmLibrary(const std::string* path, bool* found);
-
-            /**
-             * Load JVM library into the process.
-             *
-             * @param path Optional path to the library.
-             * @return Whether load was successful.
-             */
-            IGNITE_FRIEND_EXPORT bool LoadJvmLibrary(const std::string& path);
-
-            /**
-             * Resolve GRIDGAIN_HOME directory. Resolution is performed in several
-             * steps:
-             * 1) Check for path provided as argument.
-             * 2) Check for environment variable.
-             * 3) Check for current working directory.
-             * Result of these 3 checks are evaluated based on existence of certain
-             * predefined folders inside possible GG home. If they are found, 
-             * GRIDGAIN_HOME is considered resolved.
-             *
-             * @param path Optional path to evaluate.
-             * @param found Whether GRIDGAIN_HOME home was found.
-             * @return Resolved GG home.
-             */
-            IGNITE_FRIEND_EXPORT std::string ResolveGridGainHome(const std::string* path, bool* found);
-
-            /**
-             * Create GridGain classpath based on user input and home directory.
-             *
-             * @param usrCp User's classpath.
-             * @param home GridGain home directory.
-             * @return Classpath.
-             */
-            IGNITE_FRIEND_EXPORT std::string CreateGridGainClasspath(const std::string* usrCp, const std::string* home);
-
-            /**
-             * Create GridGain classpath based on user input and home directory.
-             *
-             * @param usrCp User's classpath.
-             * @param home GridGain home directory.
-             * @param test Whether test classpath must be used.
-             * @return Classpath.
-             */
-            IGNITE_FRIEND_EXPORT std::string CreateGridGainClasspath(const std::string* usrCp, const std::string* home, bool test);
-
-            /**
-             * Safe array which automatically reclaims occupied memory when out of scope.
-             */
-            template<typename T>
-            struct IGNITE_FRIEND_EXPORT SafeArray
-            {
-                /**
-                 * Constructor.
-                 */
-                SafeArray(int cap)
-                {
-                    target = new T[cap];
-                }
-
-                /**
-                 * Destructor.
-                 */
-                ~SafeArray()
-                {
-                    delete[] target;
-                }
-
-                IGNITE_NO_COPY_ASSIGNMENT(SafeArray);
-
-                /** Target array. */
-                T* target;
-            };
-        }
-    }    
-}
-
-#endif

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/os/linux/include/ignite/impl/utils.h
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/os/linux/include/ignite/impl/utils.h b/modules/platform/src/main/cpp/core/os/linux/include/ignite/impl/utils.h
new file mode 100644
index 0000000..f2fc6e3
--- /dev/null
+++ b/modules/platform/src/main/cpp/core/os/linux/include/ignite/impl/utils.h
@@ -0,0 +1,155 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+#ifndef _IGNITE_UTILS
+#define _IGNITE_UTILS
+
+#include <cstring>
+#include <string>
+
+#include <ignite/common/common.h>
+
+#ifdef IGNITE_FRIEND
+    #define IGNITE_FRIEND_EXPORT IGNITE_EXPORT
+#else
+    #define IGNITE_FRIEND_EXPORT
+#endif
+
+namespace ignite
+{    
+    namespace impl
+    {
+        namespace utils
+        {                
+            /**
+             * Copy characters.
+             *
+             * @param val Value.
+             * @return Result.
+             */
+            IGNITE_FRIEND_EXPORT char* CopyChars(const char* val);
+
+            /**
+             * Release characters.
+             *
+             * @param val Value.
+             */
+            IGNITE_FRIEND_EXPORT void ReleaseChars(char* val);
+            
+            /**
+             * Read system environment variable taking thread-safety in count.
+             *
+             * @param name Environment variable name.
+             * @param found Whether environment variable with such name was found.
+             * @return Environment variable value.
+             */
+            IGNITE_FRIEND_EXPORT std::string GetEnv(const std::string& name, bool* found);
+                                
+            /**
+             * Ensure that file on the given path exists in the system.
+             *
+             * @param path Path.
+             * @return True if file exists, false otherwise.
+             */
+            IGNITE_FRIEND_EXPORT bool FileExists(const std::string& path);
+
+            /**
+             * Attempts to find JVM library to load it into the process later.
+             * First search is performed using the passed path argument (is not NULL).
+             * Then JRE_HOME is evaluated. Last, JAVA_HOME is evaluated.
+             *
+             * @param Explicitly defined path (optional).
+             * @param found Whether library was found.
+             * @return Path to the file.
+             */
+            IGNITE_FRIEND_EXPORT std::string FindJvmLibrary(const std::string* path, bool* found);
+
+            /**
+             * Load JVM library into the process.
+             *
+             * @param path Optional path to the library.
+             * @return Whether load was successful.
+             */
+            IGNITE_FRIEND_EXPORT bool LoadJvmLibrary(const std::string& path);
+
+            /**
+             * Resolve GRIDGAIN_HOME directory. Resolution is performed in several
+             * steps:
+             * 1) Check for path provided as argument.
+             * 2) Check for environment variable.
+             * 3) Check for current working directory.
+             * Result of these 3 checks are evaluated based on existence of certain
+             * predefined folders inside possible GG home. If they are found, 
+             * GRIDGAIN_HOME is considered resolved.
+             *
+             * @param path Optional path to evaluate.
+             * @param found Whether GRIDGAIN_HOME home was found.
+             * @return Resolved GG home.
+             */
+            IGNITE_FRIEND_EXPORT std::string ResolveGridGainHome(const std::string* path, bool* found);
+
+            /**
+             * Create GridGain classpath based on user input and home directory.
+             *
+             * @param usrCp User's classpath.
+             * @param home GridGain home directory.
+             * @return Classpath.
+             */
+            IGNITE_FRIEND_EXPORT std::string CreateGridGainClasspath(const std::string* usrCp, const std::string* home);
+
+            /**
+             * Create GridGain classpath based on user input and home directory.
+             *
+             * @param usrCp User's classpath.
+             * @param home GridGain home directory.
+             * @param test Whether test classpath must be used.
+             * @return Classpath.
+             */
+            IGNITE_FRIEND_EXPORT std::string CreateGridGainClasspath(const std::string* usrCp, const std::string* home, bool test);
+
+            /**
+             * Safe array which automatically reclaims occupied memory when out of scope.
+             */
+            template<typename T>
+            struct IGNITE_FRIEND_EXPORT SafeArray
+            {
+                /**
+                 * Constructor.
+                 */
+                SafeArray(int cap)
+                {
+                    target = new T[cap];
+                }
+
+                /**
+                 * Destructor.
+                 */
+                ~SafeArray()
+                {
+                    delete[] target;
+                }
+
+                IGNITE_NO_COPY_ASSIGNMENT(SafeArray);
+
+                /** Target array. */
+                T* target;
+            };
+        }
+    }    
+}
+
+#endif

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/os/linux/src/impl/utils.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/os/linux/src/impl/utils.cpp b/modules/platform/src/main/cpp/core/os/linux/src/impl/utils.cpp
index 64c1312..55d836a 100644
--- a/modules/platform/src/main/cpp/core/os/linux/src/impl/utils.cpp
+++ b/modules/platform/src/main/cpp/core/os/linux/src/impl/utils.cpp
@@ -18,9 +18,9 @@
 #include <dirent.h>
 #include <dlfcn.h>
 
-#include "gridgain/impl/utils.h"
+#include "ignite/impl/utils.h"
 
-namespace gridgain
+namespace ignite
 {
     namespace impl
     {
@@ -34,7 +34,7 @@ namespace gridgain
             const char* PROBE_BIN = "/bin";
             const char* PROBE_EXAMPLES = "/examples";
 
-            const char* GRIDGAIN_NATIVE_TEST_CLASSPATH = "GRIDGAIN_NATIVE_TEST_CLASSPATH";
+            const char* IGNITE_NATIVE_TEST_CLASSPATH = "IGNITE_NATIVE_TEST_CLASSPATH";
 
             /**
              * Helper method to set boolean result to reference with proper NULL-check.
@@ -410,7 +410,7 @@ namespace gridgain
                 if (home)
                 {
                     bool envFound;
-                    std::string env = GetEnv(GRIDGAIN_NATIVE_TEST_CLASSPATH, &envFound);
+                    std::string env = GetEnv(IGNITE_NATIVE_TEST_CLASSPATH, &envFound);
 
                     forceTest = envFound && env.compare("true") == 0;
                 }

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/os/win/include/gridgain/impl/utils.h
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/os/win/include/gridgain/impl/utils.h b/modules/platform/src/main/cpp/core/os/win/include/gridgain/impl/utils.h
deleted file mode 100644
index 3d72ae7..0000000
--- a/modules/platform/src/main/cpp/core/os/win/include/gridgain/impl/utils.h
+++ /dev/null
@@ -1,155 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-#ifndef _IGNITE_UTILS
-#define _IGNITE_UTILS
-
-#include <cstring>
-#include <string>
-
-#include <ignite/common/common.h>
-
-#ifdef IGNITE_FRIEND
-    #define IGNITE_FRIEND_EXPORT IGNITE_EXPORT
-#else
-    #define IGNITE_FRIEND_EXPORT
-#endif
-
-namespace ignite
-{    
-    namespace impl
-    {
-        namespace utils
-        {                
-            /**
-             * Copy characters.
-             *
-             * @param val Value.
-             * @return Result.
-             */
-            IGNITE_FRIEND_EXPORT char* CopyChars(const char* val);
-
-            /**
-             * Release characters.
-             *
-             * @param val Value.
-             */
-            IGNITE_FRIEND_EXPORT void ReleaseChars(char* val);
-            
-            /**
-             * Read system environment variable taking thread-safety in count.
-             *
-             * @param name Environment variable name.
-             * @param found Whether environment variable with such name was found.
-             * @return Environment variable value.
-             */
-            IGNITE_FRIEND_EXPORT std::string GetEnv(const std::string& name, bool* found);
-                                
-            /**
-             * Ensure that file on the given path exists in the system.
-             *
-             * @param path Path.
-             * @return True if file exists, false otherwise.
-             */
-            IGNITE_FRIEND_EXPORT bool FileExists(const std::string& path);
-
-            /**
-             * Attempts to find JVM library to load it into the process later.
-             * First search is performed using the passed path argument (is not NULL).
-             * Then JRE_HOME is evaluated. Last, JAVA_HOME is evaluated.
-             *
-             * @param Explicitly defined path (optional).
-             * @param found Whether library was found.
-             * @return Path to the file.
-             */
-            IGNITE_FRIEND_EXPORT std::string FindJvmLibrary(const std::string* path, bool* found);
-
-            /**
-             * Load JVM library into the process.
-             *
-             * @param path Optional path to the library.
-             * @return Whether load was successful.
-             */
-            IGNITE_FRIEND_EXPORT bool LoadJvmLibrary(const std::string& path);
-
-            /**
-             * Resolve GRIDGAIN_HOME directory. Resolution is performed in several 
-             * steps:
-             * 1) Check for path provided as argument.
-             * 2) Check for environment variable.
-             * 3) Check for current working directory.
-             * Result of these 3 checks are evaluated based on existence of certain
-             * predefined folders inside possible GG home. If they are found, 
-             * GRIDGAIN_HOME is considered resolved.
-             *
-             * @param path Optional path to evaluate.
-             * @param found Whether GRIDGAIN_HOME home was found.
-             * @return Resolved GG home.
-             */
-            IGNITE_FRIEND_EXPORT std::string ResolveGridGainHome(const std::string* path, bool* found);
-
-            /**
-             * Create GridGain classpath based on user input and home directory.
-             *
-             * @param usrCp User's classpath.
-             * @param home GridGain home directory.
-             * @return Classpath.
-             */
-            IGNITE_FRIEND_EXPORT std::string CreateGridGainClasspath(const std::string* usrCp, const std::string* home);
-
-            /**
-             * Create GridGain classpath based on user input and home directory.
-             *
-             * @param usrCp User's classpath.
-             * @param home GridGain home directory.
-             * @param test Whether test classpath must be used.
-             * @return Classpath.
-             */
-            IGNITE_FRIEND_EXPORT std::string CreateGridGainClasspath(const std::string* usrCp, const std::string* home, bool test);
-
-            /**
-             * Safe array which automatically reclaims occupied memory when out of scope.
-             */
-            template<typename T>
-            struct IGNITE_FRIEND_EXPORT SafeArray
-            {
-                /** Target array. */
-                T* target;
-
-                /**
-                 * Constructor.
-                 */
-                SafeArray(int cap)
-                {
-                    target = new T[cap];
-                }
-
-                /**
-                 * Destructor.
-                 */
-                ~SafeArray()
-                {
-                    delete[] target;
-                }
-
-                IGNITE_NO_COPY_ASSIGNMENT(SafeArray);
-            };
-        }
-    }    
-}
-
-#endif
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/os/win/include/ignite/impl/utils.h
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/os/win/include/ignite/impl/utils.h b/modules/platform/src/main/cpp/core/os/win/include/ignite/impl/utils.h
new file mode 100644
index 0000000..3d72ae7
--- /dev/null
+++ b/modules/platform/src/main/cpp/core/os/win/include/ignite/impl/utils.h
@@ -0,0 +1,155 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+#ifndef _IGNITE_UTILS
+#define _IGNITE_UTILS
+
+#include <cstring>
+#include <string>
+
+#include <ignite/common/common.h>
+
+#ifdef IGNITE_FRIEND
+    #define IGNITE_FRIEND_EXPORT IGNITE_EXPORT
+#else
+    #define IGNITE_FRIEND_EXPORT
+#endif
+
+namespace ignite
+{    
+    namespace impl
+    {
+        namespace utils
+        {                
+            /**
+             * Copy characters.
+             *
+             * @param val Value.
+             * @return Result.
+             */
+            IGNITE_FRIEND_EXPORT char* CopyChars(const char* val);
+
+            /**
+             * Release characters.
+             *
+             * @param val Value.
+             */
+            IGNITE_FRIEND_EXPORT void ReleaseChars(char* val);
+            
+            /**
+             * Read system environment variable taking thread-safety in count.
+             *
+             * @param name Environment variable name.
+             * @param found Whether environment variable with such name was found.
+             * @return Environment variable value.
+             */
+            IGNITE_FRIEND_EXPORT std::string GetEnv(const std::string& name, bool* found);
+                                
+            /**
+             * Ensure that file on the given path exists in the system.
+             *
+             * @param path Path.
+             * @return True if file exists, false otherwise.
+             */
+            IGNITE_FRIEND_EXPORT bool FileExists(const std::string& path);
+
+            /**
+             * Attempts to find JVM library to load it into the process later.
+             * First search is performed using the passed path argument (is not NULL).
+             * Then JRE_HOME is evaluated. Last, JAVA_HOME is evaluated.
+             *
+             * @param Explicitly defined path (optional).
+             * @param found Whether library was found.
+             * @return Path to the file.
+             */
+            IGNITE_FRIEND_EXPORT std::string FindJvmLibrary(const std::string* path, bool* found);
+
+            /**
+             * Load JVM library into the process.
+             *
+             * @param path Optional path to the library.
+             * @return Whether load was successful.
+             */
+            IGNITE_FRIEND_EXPORT bool LoadJvmLibrary(const std::string& path);
+
+            /**
+             * Resolve GRIDGAIN_HOME directory. Resolution is performed in several 
+             * steps:
+             * 1) Check for path provided as argument.
+             * 2) Check for environment variable.
+             * 3) Check for current working directory.
+             * Result of these 3 checks are evaluated based on existence of certain
+             * predefined folders inside possible GG home. If they are found, 
+             * GRIDGAIN_HOME is considered resolved.
+             *
+             * @param path Optional path to evaluate.
+             * @param found Whether GRIDGAIN_HOME home was found.
+             * @return Resolved GG home.
+             */
+            IGNITE_FRIEND_EXPORT std::string ResolveGridGainHome(const std::string* path, bool* found);
+
+            /**
+             * Create GridGain classpath based on user input and home directory.
+             *
+             * @param usrCp User's classpath.
+             * @param home GridGain home directory.
+             * @return Classpath.
+             */
+            IGNITE_FRIEND_EXPORT std::string CreateGridGainClasspath(const std::string* usrCp, const std::string* home);
+
+            /**
+             * Create GridGain classpath based on user input and home directory.
+             *
+             * @param usrCp User's classpath.
+             * @param home GridGain home directory.
+             * @param test Whether test classpath must be used.
+             * @return Classpath.
+             */
+            IGNITE_FRIEND_EXPORT std::string CreateGridGainClasspath(const std::string* usrCp, const std::string* home, bool test);
+
+            /**
+             * Safe array which automatically reclaims occupied memory when out of scope.
+             */
+            template<typename T>
+            struct IGNITE_FRIEND_EXPORT SafeArray
+            {
+                /** Target array. */
+                T* target;
+
+                /**
+                 * Constructor.
+                 */
+                SafeArray(int cap)
+                {
+                    target = new T[cap];
+                }
+
+                /**
+                 * Destructor.
+                 */
+                ~SafeArray()
+                {
+                    delete[] target;
+                }
+
+                IGNITE_NO_COPY_ASSIGNMENT(SafeArray);
+            };
+        }
+    }    
+}
+
+#endif
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/os/win/src/impl/utils.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/os/win/src/impl/utils.cpp b/modules/platform/src/main/cpp/core/os/win/src/impl/utils.cpp
index ee418ad..bd17658 100644
--- a/modules/platform/src/main/cpp/core/os/win/src/impl/utils.cpp
+++ b/modules/platform/src/main/cpp/core/os/win/src/impl/utils.cpp
@@ -17,7 +17,7 @@
 
 #include <windows.h>
 
-#include "gridgain/impl/utils.h"
+#include "ignite/impl/utils.h"
 
 namespace ignite
 {

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/project/vs/core.vcxproj
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/project/vs/core.vcxproj b/modules/platform/src/main/cpp/core/project/vs/core.vcxproj
index 78eb949..de90f65 100644
--- a/modules/platform/src/main/cpp/core/project/vs/core.vcxproj
+++ b/modules/platform/src/main/cpp/core/project/vs/core.vcxproj
@@ -68,18 +68,18 @@
   </ImportGroup>
   <PropertyGroup Label="UserMacros" />
   <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Debug|x64'">
-    <TargetName>gridgain.core</TargetName>
+    <TargetName>ignite.core</TargetName>
   </PropertyGroup>
   <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Debug|Win32'">
-    <TargetName>gridgain.core</TargetName>
+    <TargetName>ignite.core</TargetName>
     <OutDir>$(SolutionDir)$(Platform)\$(Configuration)\</OutDir>
     <IntDir>$(Platform)\$(Configuration)\</IntDir>
   </PropertyGroup>
   <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Release|x64'">
-    <TargetName>gridgain.core</TargetName>
+    <TargetName>ignite.core</TargetName>
   </PropertyGroup>
   <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Release|Win32'">
-    <TargetName>gridgain.core</TargetName>
+    <TargetName>ignite.core</TargetName>
     <OutDir>$(SolutionDir)$(Platform)\$(Configuration)\</OutDir>
     <IntDir>$(Platform)\$(Configuration)\</IntDir>
   </PropertyGroup>
@@ -188,49 +188,49 @@
     </Link>
   </ItemDefinitionGroup>
   <ItemGroup>
-    <ClInclude Include="..\..\include\gridgain\cache\cache.h" />
-    <ClInclude Include="..\..\include\gridgain\cache\cache_entry.h" />
-    <ClInclude Include="..\..\include\gridgain\cache\cache_peek_mode.h" />
-    <ClInclude Include="..\..\include\gridgain\cache\query\query.h" />
-    <ClInclude Include="..\..\include\gridgain\cache\query\query_argument.h" />
-    <ClInclude Include="..\..\include\gridgain\cache\query\query_cursor.h" />
-    <ClInclude Include="..\..\include\gridgain\cache\query\query_scan.h" />
-    <ClInclude Include="..\..\include\gridgain\cache\query\query_sql.h" />
-    <ClInclude Include="..\..\include\gridgain\cache\query\query_text.h" />
-    <ClInclude Include="..\..\include\gridgain\grid.h" />
-    <ClInclude Include="..\..\include\gridgain\grid_configuration.h" />
-    <ClInclude Include="..\..\include\gridgain\grid_error.h" />
-    <ClInclude Include="..\..\include\gridgain\grid_factory.h" />
-    <ClInclude Include="..\..\include\gridgain\guid.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\cache\cache_impl.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\cache\query\query_impl.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\grid_environment.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\grid_impl.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\handle_registry.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\interop\interop.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\interop\interop_input_stream.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\interop\interop_memory.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\interop\interop_output_stream.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\operations.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_common.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_id_resolver.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_metadata_handler.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_metadata_manager.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_metadata_snapshot.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_metadata_updater.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_metadata_updater_impl.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_reader_impl.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_utils.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_writer_impl.h" />
-    <ClInclude Include="..\..\include\gridgain\portable\portable.h" />
-    <ClInclude Include="..\..\include\gridgain\portable\portable_consts.h" />
-    <ClInclude Include="..\..\include\gridgain\portable\portable_containers.h" />
-    <ClInclude Include="..\..\include\gridgain\portable\portable_type.h" />
-    <ClInclude Include="..\..\include\gridgain\portable\portable_raw_reader.h" />
-    <ClInclude Include="..\..\include\gridgain\portable\portable_raw_writer.h" />
-    <ClInclude Include="..\..\include\gridgain\portable\portable_reader.h" />
-    <ClInclude Include="..\..\include\gridgain\portable\portable_writer.h" />
-    <ClInclude Include="..\..\os\win\include\gridgain\impl\utils.h" />
+    <ClInclude Include="..\..\include\ignite\cache\cache.h" />
+    <ClInclude Include="..\..\include\ignite\cache\cache_entry.h" />
+    <ClInclude Include="..\..\include\ignite\cache\cache_peek_mode.h" />
+    <ClInclude Include="..\..\include\ignite\cache\query\query.h" />
+    <ClInclude Include="..\..\include\ignite\cache\query\query_argument.h" />
+    <ClInclude Include="..\..\include\ignite\cache\query\query_cursor.h" />
+    <ClInclude Include="..\..\include\ignite\cache\query\query_scan.h" />
+    <ClInclude Include="..\..\include\ignite\cache\query\query_sql.h" />
+    <ClInclude Include="..\..\include\ignite\cache\query\query_text.h" />
+    <ClInclude Include="..\..\include\ignite\grid.h" />
+    <ClInclude Include="..\..\include\ignite\grid_configuration.h" />
+    <ClInclude Include="..\..\include\ignite\grid_error.h" />
+    <ClInclude Include="..\..\include\ignite\grid_factory.h" />
+    <ClInclude Include="..\..\include\ignite\guid.h" />
+    <ClInclude Include="..\..\include\ignite\impl\cache\cache_impl.h" />
+    <ClInclude Include="..\..\include\ignite\impl\cache\query\query_impl.h" />
+    <ClInclude Include="..\..\include\ignite\impl\grid_environment.h" />
+    <ClInclude Include="..\..\include\ignite\impl\grid_impl.h" />
+    <ClInclude Include="..\..\include\ignite\impl\handle_registry.h" />
+    <ClInclude Include="..\..\include\ignite\impl\interop\interop.h" />
+    <ClInclude Include="..\..\include\ignite\impl\interop\interop_input_stream.h" />
+    <ClInclude Include="..\..\include\ignite\impl\interop\interop_memory.h" />
+    <ClInclude Include="..\..\include\ignite\impl\interop\interop_output_stream.h" />
+    <ClInclude Include="..\..\include\ignite\impl\operations.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_common.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_id_resolver.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_metadata_handler.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_metadata_manager.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_metadata_snapshot.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_metadata_updater.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_metadata_updater_impl.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_reader_impl.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_utils.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_writer_impl.h" />
+    <ClInclude Include="..\..\include\ignite\portable\portable.h" />
+    <ClInclude Include="..\..\include\ignite\portable\portable_consts.h" />
+    <ClInclude Include="..\..\include\ignite\portable\portable_containers.h" />
+    <ClInclude Include="..\..\include\ignite\portable\portable_type.h" />
+    <ClInclude Include="..\..\include\ignite\portable\portable_raw_reader.h" />
+    <ClInclude Include="..\..\include\ignite\portable\portable_raw_writer.h" />
+    <ClInclude Include="..\..\include\ignite\portable\portable_reader.h" />
+    <ClInclude Include="..\..\include\ignite\portable\portable_writer.h" />
+    <ClInclude Include="..\..\os\win\include\ignite\impl\utils.h" />
   </ItemGroup>
   <ItemGroup>
     <ClCompile Include="..\..\os\win\src\impl\utils.cpp" />

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/project/vs/core.vcxproj.filters
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/project/vs/core.vcxproj.filters b/modules/platform/src/main/cpp/core/project/vs/core.vcxproj.filters
index 7640178..5747f10 100644
--- a/modules/platform/src/main/cpp/core/project/vs/core.vcxproj.filters
+++ b/modules/platform/src/main/cpp/core/project/vs/core.vcxproj.filters
@@ -84,133 +84,133 @@
     </ClCompile>
   </ItemGroup>
   <ItemGroup>
-    <ClInclude Include="..\..\include\gridgain\impl\cache\cache_impl.h">
+    <ClInclude Include="..\..\include\ignite\impl\cache\cache_impl.h">
       <Filter>Code\impl\cache</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\cache\cache.h">
+    <ClInclude Include="..\..\include\ignite\cache\cache.h">
       <Filter>Code\cache</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\cache\cache_peek_mode.h">
+    <ClInclude Include="..\..\include\ignite\cache\cache_peek_mode.h">
       <Filter>Code\cache</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\interop\interop.h">
+    <ClInclude Include="..\..\include\ignite\impl\interop\interop.h">
       <Filter>Code\impl\interop</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\interop\interop_input_stream.h">
+    <ClInclude Include="..\..\include\ignite\impl\interop\interop_input_stream.h">
       <Filter>Code\impl\interop</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\interop\interop_memory.h">
+    <ClInclude Include="..\..\include\ignite\impl\interop\interop_memory.h">
       <Filter>Code\impl\interop</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\interop\interop_output_stream.h">
+    <ClInclude Include="..\..\include\ignite\impl\interop\interop_output_stream.h">
       <Filter>Code\impl\interop</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\grid_environment.h">
+    <ClInclude Include="..\..\include\ignite\impl\grid_environment.h">
       <Filter>Code\impl</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\grid_impl.h">
+    <ClInclude Include="..\..\include\ignite\impl\grid_impl.h">
       <Filter>Code\impl</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\operations.h">
+    <ClInclude Include="..\..\include\ignite\impl\operations.h">
       <Filter>Code\impl</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_common.h">
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_common.h">
       <Filter>Code\impl\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\portable\portable_consts.h">
+    <ClInclude Include="..\..\include\ignite\portable\portable_consts.h">
       <Filter>Code\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\portable\portable.h">
+    <ClInclude Include="..\..\include\ignite\portable\portable.h">
       <Filter>Code\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\portable\portable_containers.h">
+    <ClInclude Include="..\..\include\ignite\portable\portable_containers.h">
       <Filter>Code\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_id_resolver.h">
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_id_resolver.h">
       <Filter>Code\impl\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\portable\portable_raw_reader.h">
+    <ClInclude Include="..\..\include\ignite\portable\portable_raw_reader.h">
       <Filter>Code\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\portable\portable_raw_writer.h">
+    <ClInclude Include="..\..\include\ignite\portable\portable_raw_writer.h">
       <Filter>Code\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\portable\portable_reader.h">
+    <ClInclude Include="..\..\include\ignite\portable\portable_reader.h">
       <Filter>Code\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\portable\portable_writer.h">
+    <ClInclude Include="..\..\include\ignite\portable\portable_writer.h">
       <Filter>Code\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_reader_impl.h">
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_reader_impl.h">
       <Filter>Code\impl\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_utils.h">
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_utils.h">
       <Filter>Code\impl\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_writer_impl.h">
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_writer_impl.h">
       <Filter>Code\impl\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\os\win\include\gridgain\impl\utils.h">
+    <ClInclude Include="..\..\os\win\include\ignite\impl\utils.h">
       <Filter>Code\impl</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\grid.h">
+    <ClInclude Include="..\..\include\ignite\grid.h">
       <Filter>Code</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\grid_configuration.h">
+    <ClInclude Include="..\..\include\ignite\grid_configuration.h">
       <Filter>Code</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\grid_error.h">
+    <ClInclude Include="..\..\include\ignite\grid_error.h">
       <Filter>Code</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\grid_factory.h">
+    <ClInclude Include="..\..\include\ignite\grid_factory.h">
       <Filter>Code</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\guid.h">
+    <ClInclude Include="..\..\include\ignite\guid.h">
       <Filter>Code</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\handle_registry.h">
+    <ClInclude Include="..\..\include\ignite\impl\handle_registry.h">
       <Filter>Code\impl</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\cache\cache_entry.h">
+    <ClInclude Include="..\..\include\ignite\cache\cache_entry.h">
       <Filter>Code\cache</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\cache\query\query_impl.h">
+    <ClInclude Include="..\..\include\ignite\impl\cache\query\query_impl.h">
       <Filter>Code\impl\cache\query</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_metadata_snapshot.h">
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_metadata_snapshot.h">
       <Filter>Code\impl\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_metadata_handler.h">
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_metadata_handler.h">
       <Filter>Code\impl\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_metadata_manager.h">
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_metadata_manager.h">
       <Filter>Code\impl\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\portable\portable_type.h">
+    <ClInclude Include="..\..\include\ignite\portable\portable_type.h">
       <Filter>Code\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_metadata_updater.h">
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_metadata_updater.h">
       <Filter>Code\impl\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_metadata_updater_impl.h">
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_metadata_updater_impl.h">
       <Filter>Code\impl\portable</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\cache\query\query_argument.h">
+    <ClInclude Include="..\..\include\ignite\cache\query\query_argument.h">
       <Filter>Code\cache\query</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\cache\query\query_cursor.h">
+    <ClInclude Include="..\..\include\ignite\cache\query\query_cursor.h">
       <Filter>Code\cache\query</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\cache\query\query_sql.h">
+    <ClInclude Include="..\..\include\ignite\cache\query\query_sql.h">
       <Filter>Code\cache\query</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\cache\query\query.h">
+    <ClInclude Include="..\..\include\ignite\cache\query\query.h">
       <Filter>Code\cache\query</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\cache\query\query_text.h">
+    <ClInclude Include="..\..\include\ignite\cache\query\query_text.h">
       <Filter>Code\cache\query</Filter>
     </ClInclude>
-    <ClInclude Include="..\..\include\gridgain\cache\query\query_scan.h">
+    <ClInclude Include="..\..\include\ignite\cache\query\query_scan.h">
       <Filter>Code\cache\query</Filter>
     </ClInclude>
   </ItemGroup>

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/project/vs/core.vcxprojrel
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/project/vs/core.vcxprojrel b/modules/platform/src/main/cpp/core/project/vs/core.vcxprojrel
index 78eb949..de90f65 100644
--- a/modules/platform/src/main/cpp/core/project/vs/core.vcxprojrel
+++ b/modules/platform/src/main/cpp/core/project/vs/core.vcxprojrel
@@ -68,18 +68,18 @@
   </ImportGroup>
   <PropertyGroup Label="UserMacros" />
   <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Debug|x64'">
-    <TargetName>gridgain.core</TargetName>
+    <TargetName>ignite.core</TargetName>
   </PropertyGroup>
   <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Debug|Win32'">
-    <TargetName>gridgain.core</TargetName>
+    <TargetName>ignite.core</TargetName>
     <OutDir>$(SolutionDir)$(Platform)\$(Configuration)\</OutDir>
     <IntDir>$(Platform)\$(Configuration)\</IntDir>
   </PropertyGroup>
   <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Release|x64'">
-    <TargetName>gridgain.core</TargetName>
+    <TargetName>ignite.core</TargetName>
   </PropertyGroup>
   <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Release|Win32'">
-    <TargetName>gridgain.core</TargetName>
+    <TargetName>ignite.core</TargetName>
     <OutDir>$(SolutionDir)$(Platform)\$(Configuration)\</OutDir>
     <IntDir>$(Platform)\$(Configuration)\</IntDir>
   </PropertyGroup>
@@ -188,49 +188,49 @@
     </Link>
   </ItemDefinitionGroup>
   <ItemGroup>
-    <ClInclude Include="..\..\include\gridgain\cache\cache.h" />
-    <ClInclude Include="..\..\include\gridgain\cache\cache_entry.h" />
-    <ClInclude Include="..\..\include\gridgain\cache\cache_peek_mode.h" />
-    <ClInclude Include="..\..\include\gridgain\cache\query\query.h" />
-    <ClInclude Include="..\..\include\gridgain\cache\query\query_argument.h" />
-    <ClInclude Include="..\..\include\gridgain\cache\query\query_cursor.h" />
-    <ClInclude Include="..\..\include\gridgain\cache\query\query_scan.h" />
-    <ClInclude Include="..\..\include\gridgain\cache\query\query_sql.h" />
-    <ClInclude Include="..\..\include\gridgain\cache\query\query_text.h" />
-    <ClInclude Include="..\..\include\gridgain\grid.h" />
-    <ClInclude Include="..\..\include\gridgain\grid_configuration.h" />
-    <ClInclude Include="..\..\include\gridgain\grid_error.h" />
-    <ClInclude Include="..\..\include\gridgain\grid_factory.h" />
-    <ClInclude Include="..\..\include\gridgain\guid.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\cache\cache_impl.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\cache\query\query_impl.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\grid_environment.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\grid_impl.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\handle_registry.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\interop\interop.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\interop\interop_input_stream.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\interop\interop_memory.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\interop\interop_output_stream.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\operations.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_common.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_id_resolver.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_metadata_handler.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_metadata_manager.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_metadata_snapshot.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_metadata_updater.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_metadata_updater_impl.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_reader_impl.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_utils.h" />
-    <ClInclude Include="..\..\include\gridgain\impl\portable\portable_writer_impl.h" />
-    <ClInclude Include="..\..\include\gridgain\portable\portable.h" />
-    <ClInclude Include="..\..\include\gridgain\portable\portable_consts.h" />
-    <ClInclude Include="..\..\include\gridgain\portable\portable_containers.h" />
-    <ClInclude Include="..\..\include\gridgain\portable\portable_type.h" />
-    <ClInclude Include="..\..\include\gridgain\portable\portable_raw_reader.h" />
-    <ClInclude Include="..\..\include\gridgain\portable\portable_raw_writer.h" />
-    <ClInclude Include="..\..\include\gridgain\portable\portable_reader.h" />
-    <ClInclude Include="..\..\include\gridgain\portable\portable_writer.h" />
-    <ClInclude Include="..\..\os\win\include\gridgain\impl\utils.h" />
+    <ClInclude Include="..\..\include\ignite\cache\cache.h" />
+    <ClInclude Include="..\..\include\ignite\cache\cache_entry.h" />
+    <ClInclude Include="..\..\include\ignite\cache\cache_peek_mode.h" />
+    <ClInclude Include="..\..\include\ignite\cache\query\query.h" />
+    <ClInclude Include="..\..\include\ignite\cache\query\query_argument.h" />
+    <ClInclude Include="..\..\include\ignite\cache\query\query_cursor.h" />
+    <ClInclude Include="..\..\include\ignite\cache\query\query_scan.h" />
+    <ClInclude Include="..\..\include\ignite\cache\query\query_sql.h" />
+    <ClInclude Include="..\..\include\ignite\cache\query\query_text.h" />
+    <ClInclude Include="..\..\include\ignite\grid.h" />
+    <ClInclude Include="..\..\include\ignite\grid_configuration.h" />
+    <ClInclude Include="..\..\include\ignite\grid_error.h" />
+    <ClInclude Include="..\..\include\ignite\grid_factory.h" />
+    <ClInclude Include="..\..\include\ignite\guid.h" />
+    <ClInclude Include="..\..\include\ignite\impl\cache\cache_impl.h" />
+    <ClInclude Include="..\..\include\ignite\impl\cache\query\query_impl.h" />
+    <ClInclude Include="..\..\include\ignite\impl\grid_environment.h" />
+    <ClInclude Include="..\..\include\ignite\impl\grid_impl.h" />
+    <ClInclude Include="..\..\include\ignite\impl\handle_registry.h" />
+    <ClInclude Include="..\..\include\ignite\impl\interop\interop.h" />
+    <ClInclude Include="..\..\include\ignite\impl\interop\interop_input_stream.h" />
+    <ClInclude Include="..\..\include\ignite\impl\interop\interop_memory.h" />
+    <ClInclude Include="..\..\include\ignite\impl\interop\interop_output_stream.h" />
+    <ClInclude Include="..\..\include\ignite\impl\operations.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_common.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_id_resolver.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_metadata_handler.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_metadata_manager.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_metadata_snapshot.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_metadata_updater.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_metadata_updater_impl.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_reader_impl.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_utils.h" />
+    <ClInclude Include="..\..\include\ignite\impl\portable\portable_writer_impl.h" />
+    <ClInclude Include="..\..\include\ignite\portable\portable.h" />
+    <ClInclude Include="..\..\include\ignite\portable\portable_consts.h" />
+    <ClInclude Include="..\..\include\ignite\portable\portable_containers.h" />
+    <ClInclude Include="..\..\include\ignite\portable\portable_type.h" />
+    <ClInclude Include="..\..\include\ignite\portable\portable_raw_reader.h" />
+    <ClInclude Include="..\..\include\ignite\portable\portable_raw_writer.h" />
+    <ClInclude Include="..\..\include\ignite\portable\portable_reader.h" />
+    <ClInclude Include="..\..\include\ignite\portable\portable_writer.h" />
+    <ClInclude Include="..\..\os\win\include\ignite\impl\utils.h" />
   </ItemGroup>
   <ItemGroup>
     <ClCompile Include="..\..\os\win\src\impl\utils.cpp" />

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/grid.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/grid.cpp b/modules/platform/src/main/cpp/core/src/grid.cpp
index fd25702..21bbe34 100644
--- a/modules/platform/src/main/cpp/core/src/grid.cpp
+++ b/modules/platform/src/main/cpp/core/src/grid.cpp
@@ -17,8 +17,8 @@
 
 #include <ignite/common/java.h>
 
-#include "gridgain/impl/grid_impl.h"
-#include "gridgain/grid.h"
+#include "ignite/impl/grid_impl.h"
+#include "ignite/grid.h"
 
 using namespace ignite::common::concurrent;
 using namespace ignite::impl;

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/grid_error.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/grid_error.cpp b/modules/platform/src/main/cpp/core/src/grid_error.cpp
index a909ff6..597853a 100644
--- a/modules/platform/src/main/cpp/core/src/grid_error.cpp
+++ b/modules/platform/src/main/cpp/core/src/grid_error.cpp
@@ -16,8 +16,8 @@
  */
 #include <ignite/common/java.h>
 
-#include "gridgain/impl/utils.h"
-#include "gridgain/grid_error.h"
+#include "ignite/impl/utils.h"
+#include "ignite/grid_error.h"
 
 using namespace ignite::common::java;
 using namespace ignite::impl::utils;

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/grid_factory.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/grid_factory.cpp b/modules/platform/src/main/cpp/core/src/grid_factory.cpp
index 0014320..cfdd6b7 100644
--- a/modules/platform/src/main/cpp/core/src/grid_factory.cpp
+++ b/modules/platform/src/main/cpp/core/src/grid_factory.cpp
@@ -22,10 +22,10 @@
 #include <ignite/common/exports.h>
 #include <ignite/common/java.h>
 
-#include "gridgain/impl/grid_environment.h"
-#include "gridgain/impl/grid_impl.h"
-#include "gridgain/impl/utils.h"
-#include "gridgain/grid_factory.h"
+#include "ignite/impl/grid_environment.h"
+#include "ignite/impl/grid_impl.h"
+#include "ignite/impl/utils.h"
+#include "ignite/grid_factory.h"
 
 using namespace ignite::common::concurrent;
 using namespace ignite::common::java;

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/guid.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/guid.cpp b/modules/platform/src/main/cpp/core/src/guid.cpp
index 75670e6..77997e4 100644
--- a/modules/platform/src/main/cpp/core/src/guid.cpp
+++ b/modules/platform/src/main/cpp/core/src/guid.cpp
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-#include "gridgain/guid.h"
+#include "ignite/guid.h"
 
 namespace ignite
 {

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/impl/cache/cache_impl.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/impl/cache/cache_impl.cpp b/modules/platform/src/main/cpp/core/src/impl/cache/cache_impl.cpp
index 637e7a1..176ab93 100644
--- a/modules/platform/src/main/cpp/core/src/impl/cache/cache_impl.cpp
+++ b/modules/platform/src/main/cpp/core/src/impl/cache/cache_impl.cpp
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-#include "gridgain/cache/cache_peek_mode.h"
-#include "gridgain/impl/cache/cache_impl.h"
-#include "gridgain/impl/interop/interop.h"
-#include "gridgain/impl/portable/portable_reader_impl.h"
-#include "gridgain/impl/utils.h"
-#include "gridgain/portable/portable.h"
-#include <gridgain/impl/portable/portable_metadata_updater_impl.h>
+#include "ignite/cache/cache_peek_mode.h"
+#include "ignite/impl/cache/cache_impl.h"
+#include "ignite/impl/interop/interop.h"
+#include "ignite/impl/portable/portable_reader_impl.h"
+#include "ignite/impl/utils.h"
+#include "ignite/impl/portable/portable_metadata_updater_impl.h"
+#include "ignite/portable/portable.h"
 
 using namespace ignite::common::concurrent;
 using namespace ignite::common::java;

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/impl/cache/query/query_impl.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/impl/cache/query/query_impl.cpp b/modules/platform/src/main/cpp/core/src/impl/cache/query/query_impl.cpp
index 35b7fd9..6196902 100644
--- a/modules/platform/src/main/cpp/core/src/impl/cache/query/query_impl.cpp
+++ b/modules/platform/src/main/cpp/core/src/impl/cache/query/query_impl.cpp
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-#include "gridgain/impl/cache/query/query_impl.h"
+#include "ignite/impl/cache/query/query_impl.h"
 
 using namespace ignite::common::concurrent;
 using namespace ignite::common::java;

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/impl/grid_environment.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/impl/grid_environment.cpp b/modules/platform/src/main/cpp/core/src/impl/grid_environment.cpp
index e66da91..0eaf60d 100644
--- a/modules/platform/src/main/cpp/core/src/impl/grid_environment.cpp
+++ b/modules/platform/src/main/cpp/core/src/impl/grid_environment.cpp
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-#include "gridgain/impl/portable/portable_reader_impl.h"
-#include "gridgain/impl/grid_environment.h"
-#include "gridgain/portable/portable.h"
+#include "ignite/impl/portable/portable_reader_impl.h"
+#include "ignite/impl/grid_environment.h"
+#include "ignite/portable/portable.h"
 
 using namespace ignite::common::concurrent;
 using namespace ignite::common::java;

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/impl/grid_impl.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/impl/grid_impl.cpp b/modules/platform/src/main/cpp/core/src/impl/grid_impl.cpp
index b79e548..2328239 100644
--- a/modules/platform/src/main/cpp/core/src/impl/grid_impl.cpp
+++ b/modules/platform/src/main/cpp/core/src/impl/grid_impl.cpp
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-#include "gridgain/impl/grid_impl.h"
+#include "ignite/impl/grid_impl.h"
 
 using namespace ignite::common::concurrent;
 using namespace ignite::common::java;

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/impl/handle_registry.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/impl/handle_registry.cpp b/modules/platform/src/main/cpp/core/src/impl/handle_registry.cpp
index c52833c..c447faa 100644
--- a/modules/platform/src/main/cpp/core/src/impl/handle_registry.cpp
+++ b/modules/platform/src/main/cpp/core/src/impl/handle_registry.cpp
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-#include "gridgain/impl/handle_registry.h"
+#include "ignite/impl/handle_registry.h"
 
 using namespace ignite::common::concurrent;
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/impl/interop/interop_input_stream.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/impl/interop/interop_input_stream.cpp b/modules/platform/src/main/cpp/core/src/impl/interop/interop_input_stream.cpp
index c938416..551d3a5 100644
--- a/modules/platform/src/main/cpp/core/src/impl/interop/interop_input_stream.cpp
+++ b/modules/platform/src/main/cpp/core/src/impl/interop/interop_input_stream.cpp
@@ -17,8 +17,8 @@
 
 #include <cstring>
 
-#include "gridgain/impl/interop/interop_input_stream.h"
-#include "gridgain/grid_error.h"
+#include "ignite/impl/interop/interop_input_stream.h"
+#include "ignite/grid_error.h"
 
 /**
  * Common macro to read a single value.

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/impl/interop/interop_memory.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/impl/interop/interop_memory.cpp b/modules/platform/src/main/cpp/core/src/impl/interop/interop_memory.cpp
index 52e19e7..04af510 100644
--- a/modules/platform/src/main/cpp/core/src/impl/interop/interop_memory.cpp
+++ b/modules/platform/src/main/cpp/core/src/impl/interop/interop_memory.cpp
@@ -17,8 +17,8 @@
 
 #include <ignite/common/java.h>
 
-#include "gridgain/impl/interop/interop_memory.h"
-#include "gridgain/grid_error.h"
+#include "ignite/impl/interop/interop_memory.h"
+#include "ignite/grid_error.h"
 
 using namespace ignite::common::java;
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/impl/interop/interop_output_stream.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/impl/interop/interop_output_stream.cpp b/modules/platform/src/main/cpp/core/src/impl/interop/interop_output_stream.cpp
index ebf2c67..56c428c 100644
--- a/modules/platform/src/main/cpp/core/src/impl/interop/interop_output_stream.cpp
+++ b/modules/platform/src/main/cpp/core/src/impl/interop/interop_output_stream.cpp
@@ -17,8 +17,8 @@
 
 #include <cstring>
 
-#include "gridgain/impl/interop/interop_output_stream.h"
-#include "gridgain/grid_error.h"
+#include "ignite/impl/interop/interop_output_stream.h"
+#include "ignite/grid_error.h"
 
 /**
  * Common macro to write a single value.

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_handler.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_handler.cpp b/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_handler.cpp
index 1ad40d0..5ca91dc 100644
--- a/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_handler.cpp
+++ b/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_handler.cpp
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-#include "gridgain/impl/portable/portable_metadata_handler.h"
+#include "ignite/impl/portable/portable_metadata_handler.h"
 
 using namespace ignite::common::concurrent;
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_manager.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_manager.cpp b/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_manager.cpp
index fe5b5c6..9ecf5ab 100644
--- a/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_manager.cpp
+++ b/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_manager.cpp
@@ -17,7 +17,7 @@
 
 #include <ignite/common/concurrent.h>
 
-#include "gridgain/impl/portable/portable_metadata_manager.h"
+#include "ignite/impl/portable/portable_metadata_manager.h"
 
 using namespace ignite::common::concurrent;
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_snapshot.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_snapshot.cpp b/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_snapshot.cpp
index f9a57fc..6ce5ab5 100644
--- a/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_snapshot.cpp
+++ b/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_snapshot.cpp
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-#include "gridgain/impl/portable/portable_metadata_snapshot.h"
+#include "ignite/impl/portable/portable_metadata_snapshot.h"
 
 namespace ignite
 {    

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_updater.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_updater.cpp b/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_updater.cpp
index f0f8e8e..81c96d7 100644
--- a/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_updater.cpp
+++ b/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_updater.cpp
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-#include "gridgain/impl/portable/portable_metadata_updater.h"
+#include "ignite/impl/portable/portable_metadata_updater.h"
 
 namespace ignite
 {    

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_updater_impl.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_updater_impl.cpp b/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_updater_impl.cpp
index ea89b53..472938d 100644
--- a/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_updater_impl.cpp
+++ b/modules/platform/src/main/cpp/core/src/impl/portable/portable_metadata_updater_impl.cpp
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-#include "gridgain/impl/portable/portable_metadata_updater_impl.h"
-#include <gridgain/impl/interop/interop_output_stream.h>
-#include <gridgain/impl/portable/portable_writer_impl.h>
-#include <gridgain/portable/portable_raw_writer.h>
+#include "ignite/impl/portable/portable_metadata_updater_impl.h"
+#include "ignite/impl/interop/interop_output_stream.h"
+#include "ignite/impl/portable/portable_writer_impl.h"
+#include "ignite/portable/portable_raw_writer.h"
 
 using namespace ignite::common::concurrent;
 using namespace ignite::common::java;

http://git-wip-us.apache.org/repos/asf/ignite/blob/0d70d547/modules/platform/src/main/cpp/core/src/impl/portable/portable_reader_impl.cpp
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/cpp/core/src/impl/portable/portable_reader_impl.cpp b/modules/platform/src/main/cpp/core/src/impl/portable/portable_reader_impl.cpp
index 264885c..386ccd3 100644
--- a/modules/platform/src/main/cpp/core/src/impl/portable/portable_reader_impl.cpp
+++ b/modules/platform/src/main/cpp/core/src/impl/portable/portable_reader_impl.cpp
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-#include "gridgain/impl/interop/interop.h"
-#include "gridgain/impl/portable/portable_common.h"
-#include "gridgain/impl/portable/portable_id_resolver.h"
-#include "gridgain/impl/portable/portable_reader_impl.h"
-#include "gridgain/impl/portable/portable_utils.h"
-#include "gridgain/portable/portable_type.h"
-#include "gridgain/grid_error.h"
+#include "ignite/impl/interop/interop.h"
+#include "ignite/impl/portable/portable_common.h"
+#include "ignite/impl/portable/portable_id_resolver.h"
+#include "ignite/impl/portable/portable_reader_impl.h"
+#include "ignite/impl/portable/portable_utils.h"
+#include "ignite/portable/portable_type.h"
+#include "ignite/grid_error.h"
 
 using namespace ignite::impl::interop;
 using namespace ignite::impl::portable;