You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by en...@apache.org on 2016/12/16 00:19:27 UTC

[1/3] hbase git commit: HBASE-17219 [C++] Reformat the code according to the style guidelines

Repository: hbase
Updated Branches:
  refs/heads/HBASE-14850 7e59ff620 -> a8b5984c5


http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/third-party/BUCK
----------------------------------------------------------------------
diff --git a/hbase-native-client/third-party/BUCK b/hbase-native-client/third-party/BUCK
index 8c0b5f9..f37eb4e 100644
--- a/hbase-native-client/third-party/BUCK
+++ b/hbase-native-client/third-party/BUCK
@@ -28,14 +28,15 @@ def add_system_libs(names=[],
         genrule(
             name=gen_rule_name,
             out=gen_rule_name,
-            bash="mkdir -p $OUT && cp {}/lib{}.a $OUT".format(lib_dir, name), )
-        prebuilt_cxx_library(name=name,
-                             lib_name=name,
-                             lib_dir='$(location :{})'.format(gen_rule_name),
-                             deps=deps,
-                             force_static=True,
-                             exported_deps=exported_deps,
-                             visibility=rule_visibility, )
+            bash="mkdir -p $OUT && cp {}/lib{}.a $OUT".format(lib_dir, name),)
+        prebuilt_cxx_library(
+            name=name,
+            lib_name=name,
+            lib_dir='$(location :{})'.format(gen_rule_name),
+            deps=deps,
+            force_static=True,
+            exported_deps=exported_deps,
+            visibility=rule_visibility,)
         rules.append(":" + name)
     return rules
 
@@ -43,16 +44,19 @@ def add_system_libs(names=[],
 def add_dynamic_libs(names=[]):
     rules = []
     for name in names:
-        prebuilt_cxx_library(name=name,
-                             header_only=True,
-                             exported_linker_flags=["-l" + name],
-                             visibility=["PUBLIC"], )
+        prebuilt_cxx_library(
+            name=name,
+            header_only=True,
+            exported_linker_flags=["-l" + name],
+            visibility=["PUBLIC"],)
         rules.append(":" + name)
     return rules
 
 
-system_libs = ["lzma",
-               "event", ]
+system_libs = [
+    "lzma",
+    "event",
+]
 local_libs = [
     "double-conversion",
     "boost_regex",
@@ -73,38 +77,39 @@ tp_dep_rules =  add_system_libs(system_libs,) \
   + dynamic_rules
 
 zookeeper = add_system_libs(["zookeeper_mt"], lib_dir="/usr/local/lib")
-folly = add_system_libs(['folly'],
-                        lib_dir='/usr/local/lib',
-                        exported_deps=tp_dep_rules, )
-folly_bench = add_system_libs(['follybenchmark'],
-                              lib_dir='/usr/local/lib',
-                              exported_deps=folly + tp_dep_rules, )
-wangle = add_system_libs(['wangle'],
-                         lib_dir='/usr/local/lib',
-                         exported_deps=folly + tp_dep_rules)
+folly = add_system_libs(
+    ['folly'],
+    lib_dir='/usr/local/lib',
+    exported_deps=tp_dep_rules,)
+folly_bench = add_system_libs(
+    ['follybenchmark'],
+    lib_dir='/usr/local/lib',
+    exported_deps=folly + tp_dep_rules,)
+wangle = add_system_libs(
+    ['wangle'], lib_dir='/usr/local/lib', exported_deps=folly + tp_dep_rules)
 
 genrule(
     name="gen_zk",
     out="gen_zk",
-    bash="mkdir -p $OUT  && wget http://www-us.apache.org/dist/zookeeper/zookeeper-3.4.8/zookeeper-3.4.8.tar.gz &&   tar zxf zookeeper-3.4.8.tar.gz &&   rm -rf zookeeper-3.4.8.tar.gz &&   cd zookeeper-3.4.8 &&   cd src/c && ./configure --prefix=$OUT &&   make &&   make install && cd $OUT && rm -rf zookeeper-3.4.8*")
-cxx_library(name='google-test',
-            srcs=[
-                'googletest/googletest/src/gtest-all.cc',
-                'googletest/googlemock/src/gmock-all.cc',
-                'googletest/googlemock/src/gmock_main.cc',
-            ],
-            header_namespace='',
-            exported_headers=subdir_glob([
-                ('googletest/googletest/include', '**/*.h'),
-                ('googletest/googlemock/include', '**/*.h'),
-            ]),
-            headers=subdir_glob([
-                ('googletest/googletest', 'src/*.h'),
-                ('googletest/googletest', 'src/*.cc'),
-                ('googletest/googlemock', 'src/*.h'),
-                ('googletest/googlemock', 'src/*.cc'),
-            ]),
-            exported_deps=dynamic_rules,
-            visibility=[
-                'PUBLIC',
-            ], )
+    bash="mkdir -p $OUT  && wget http://www-us.apache.org/dist/zookeeper/zookeeper-3.4.8/zookeeper-3.4.8.tar.gz &&   tar zxf zookeeper-3.4.8.tar.gz &&   rm -rf zookeeper-3.4.8.tar.gz &&   cd zookeeper-3.4.8 &&   cd src/c && ./configure --prefix=$OUT &&   make &&   make install && cd $OUT && rm -rf zookeeper-3.4.8*"
+)
+cxx_library(
+    name='google-test',
+    srcs=[
+        'googletest/googletest/src/gtest-all.cc',
+        'googletest/googlemock/src/gmock-all.cc',
+        'googletest/googlemock/src/gmock_main.cc',
+    ],
+    header_namespace='',
+    exported_headers=subdir_glob([
+        ('googletest/googletest/include', '**/*.h'),
+        ('googletest/googlemock/include', '**/*.h'),
+    ]),
+    headers=subdir_glob([
+        ('googletest/googletest', 'src/*.h'),
+        ('googletest/googletest', 'src/*.cc'),
+        ('googletest/googlemock', 'src/*.h'),
+        ('googletest/googlemock', 'src/*.cc'),
+    ]),
+    exported_deps=dynamic_rules,
+    visibility=['PUBLIC',],)

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/utils/BUCK
----------------------------------------------------------------------
diff --git a/hbase-native-client/utils/BUCK b/hbase-native-client/utils/BUCK
index 2ab6a89..120331a 100644
--- a/hbase-native-client/utils/BUCK
+++ b/hbase-native-client/utils/BUCK
@@ -15,27 +15,15 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-cxx_library(name="utils",
-            exported_headers=[
-                "user-util.h",
-            ],
-            srcs=[
-                "user-util.cc",
-            ],
-            deps=[
-                '//third-party:folly',
-            ],
-            tests=[
-                ":user-util-test"
-            ],
-            visibility=[
-                'PUBLIC',
-            ],
-            compiler_flags=['-Weffc++'], )
-cxx_test(name="user-util-test",
-         srcs=[
-             "user-util-test.cc",
-         ],
-         deps=[
-             ":utils",
-         ], )
+cxx_library(
+    name="utils",
+    exported_headers=["user-util.h",],
+    srcs=["user-util.cc",],
+    deps=['//third-party:folly',],
+    tests=[":user-util-test"],
+    visibility=['PUBLIC',],
+    compiler_flags=['-Weffc++'],)
+cxx_test(
+    name="user-util-test",
+    srcs=["user-util-test.cc",],
+    deps=[":utils",],)

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/utils/user-util.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/utils/user-util.h b/hbase-native-client/utils/user-util.h
index 0704bc6..6f8fce1 100644
--- a/hbase-native-client/utils/user-util.h
+++ b/hbase-native-client/utils/user-util.h
@@ -31,7 +31,7 @@ namespace hbase {
  * the user information after the first invocation.
  */
 class UserUtil {
-public:
+ public:
   /**
    * Constructor.
    */
@@ -43,7 +43,7 @@ public:
    */
   std::string user_name();
 
-private:
+ private:
   /**
    * Compute the username. This will block.
    */
@@ -51,4 +51,4 @@ private:
   std::once_flag once_flag_;
   std::string user_name_;
 };
-} // namespace hbase
+}  // namespace hbase


[3/3] hbase git commit: HBASE-17218 [C++] Use Google Style guide and cpplint - ADDENDUM to add executable bit to the script

Posted by en...@apache.org.
HBASE-17218 [C++] Use Google Style guide and cpplint - ADDENDUM to add executable bit to the script


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

Branch: refs/heads/HBASE-14850
Commit: a8b5984c54c442988885ed77df2ba6fb8b18e33b
Parents: bd6e0b9
Author: Enis Soztutar <en...@apache.org>
Authored: Thu Dec 15 16:19:09 2016 -0800
Committer: Enis Soztutar <en...@apache.org>
Committed: Thu Dec 15 16:19:09 2016 -0800

----------------------------------------------------------------------
 hbase-native-client/bin/cpplint.sh | 0
 1 file changed, 0 insertions(+), 0 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hbase/blob/a8b5984c/hbase-native-client/bin/cpplint.sh
----------------------------------------------------------------------
diff --git a/hbase-native-client/bin/cpplint.sh b/hbase-native-client/bin/cpplint.sh
old mode 100644
new mode 100755


[2/3] hbase git commit: HBASE-17219 [C++] Reformat the code according to the style guidelines

Posted by en...@apache.org.
HBASE-17219 [C++] Reformat the code according to the style guidelines


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

Branch: refs/heads/HBASE-14850
Commit: bd6e0b94c04d827aa74383b2751d0b472529c6ba
Parents: 7e59ff6
Author: Enis Soztutar <en...@apache.org>
Authored: Thu Dec 15 15:54:58 2016 -0800
Committer: Enis Soztutar <en...@apache.org>
Committed: Thu Dec 15 15:54:58 2016 -0800

----------------------------------------------------------------------
 hbase-native-client/Dockerfile                  |   2 +-
 hbase-native-client/bin/format-code.sh          |   2 +-
 hbase-native-client/connection/BUCK             |  64 +++++------
 .../connection/client-dispatcher.h              |   6 +-
 .../connection/client-handler.cc                |   3 +-
 hbase-native-client/connection/client-handler.h |   6 +-
 .../connection/connection-factory.h             |  12 +--
 .../connection/connection-pool-test.cc          |   6 +-
 .../connection/connection-pool.cc               |   6 +-
 .../connection/connection-pool.h                |   9 +-
 hbase-native-client/connection/pipeline.cc      |   4 +-
 hbase-native-client/connection/pipeline.h       |  10 +-
 hbase-native-client/connection/request.h        |   6 +-
 hbase-native-client/connection/response.h       |   6 +-
 hbase-native-client/connection/service.h        |   2 +-
 hbase-native-client/core/BUCK                   |  81 +++++++-------
 hbase-native-client/core/cell.cc                |  10 +-
 hbase-native-client/core/cell.h                 |   4 +-
 hbase-native-client/core/client.cc              |   4 +-
 hbase-native-client/core/client.h               |   6 +-
 hbase-native-client/core/configuration.cc       |  12 +--
 hbase-native-client/core/configuration.h        |   2 +-
 hbase-native-client/core/get-test.cc            |  19 ++--
 hbase-native-client/core/get.cc                 |  68 +++++-------
 hbase-native-client/core/get.h                  |  36 ++++---
 .../core/hbase_configuration-test.cc            |  15 +--
 .../core/hbase_configuration_loader.cc          |   7 +-
 .../core/hbase_configuration_loader.h           |   1 -
 hbase-native-client/core/hbase_macros.h         |   4 +-
 hbase-native-client/core/location-cache.cc      |  16 +--
 hbase-native-client/core/location-cache.h       |  10 +-
 hbase-native-client/core/meta-utils.h           |   4 +-
 hbase-native-client/core/region-location.h      |   6 +-
 hbase-native-client/core/scan-test.cc           |  17 +--
 hbase-native-client/core/scan.cc                | 106 +++++++------------
 hbase-native-client/core/scan.h                 |  91 +++++++++++-----
 hbase-native-client/core/time_range-test.cc     |   8 +-
 hbase-native-client/core/time_range.cc          |  38 +++----
 hbase-native-client/core/time_range.h           |   8 +-
 hbase-native-client/serde/BUCK                  |  97 +++++++++--------
 hbase-native-client/serde/region-info.h         |   9 +-
 hbase-native-client/serde/rpc.h                 |  16 +--
 hbase-native-client/serde/server-name.h         |   5 +-
 hbase-native-client/serde/table-name.h          |  12 ++-
 hbase-native-client/serde/zk.cc                 |   1 -
 hbase-native-client/serde/zk.h                  |   4 +-
 hbase-native-client/test-util/test-util.h       |   6 +-
 hbase-native-client/third-party/BUCK            |  95 +++++++++--------
 hbase-native-client/utils/BUCK                  |  36 +++----
 hbase-native-client/utils/user-util.h           |   6 +-
 50 files changed, 493 insertions(+), 511 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/Dockerfile
----------------------------------------------------------------------
diff --git a/hbase-native-client/Dockerfile b/hbase-native-client/Dockerfile
index 4504a8e..8b56590 100644
--- a/hbase-native-client/Dockerfile
+++ b/hbase-native-client/Dockerfile
@@ -24,7 +24,7 @@ ARG CXXFLAGS="-D_GLIBCXX_USE_CXX11_ABI=0 -fPIC -g -fno-omit-frame-pointer -O2 -p
 
 ENV JAVA_HOME="/usr/lib/jvm/java-8-openjdk-amd64/"
 
-RUN apt-get install -y vim maven inetutils-ping python-pip doxygen graphviz && \
+RUN apt-get install -y vim maven inetutils-ping python-pip doxygen graphviz clang-format && \
       pip install yapf && \
       apt-get -qq clean && \
       apt-get -y -qq autoremove && \

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/bin/format-code.sh
----------------------------------------------------------------------
diff --git a/hbase-native-client/bin/format-code.sh b/hbase-native-client/bin/format-code.sh
index 331717a..55fe69e 100755
--- a/hbase-native-client/bin/format-code.sh
+++ b/hbase-native-client/bin/format-code.sh
@@ -20,4 +20,4 @@ IFS=$'\n\t'
 
 
 find core connection serde utils test-util -name "*.h" -or -name "*.cc" | xargs -P8 clang-format -i --style=Google
-find core connection serde utils third-party -name "BUCK" | xargs -P8 yapf -i
+find core connection serde utils third-party -name "BUCK" | xargs -P8 yapf -i --style=google

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/connection/BUCK
----------------------------------------------------------------------
diff --git a/hbase-native-client/connection/BUCK b/hbase-native-client/connection/BUCK
index 39b8be5..f093d5a 100644
--- a/hbase-native-client/connection/BUCK
+++ b/hbase-native-client/connection/BUCK
@@ -17,34 +17,36 @@
 
 # This is the library dealing with a single connection
 # to a single server.
-cxx_library(name="connection",
-            exported_headers=[
-                "client-dispatcher.h",
-                "client-handler.h",
-                "connection-factory.h",
-                "connection-pool.h",
-                "pipeline.h",
-                "request.h",
-                "response.h",
-                "service.h",
-            ],
-            srcs=[
-                "client-dispatcher.cc",
-                "client-handler.cc",
-                "connection-factory.cc",
-                "connection-pool.cc",
-                "pipeline.cc",
-                "request.cc",
-            ],
-            deps=[
-                "//if:if",
-                "//utils:utils",
-                "//serde:serde",
-                "//third-party:folly",
-                "//third-party:wangle",
-            ],
-            compiler_flags=['-Weffc++'],
-            visibility=['//core/...', ], )
-cxx_test(name="connection-pool-test",
-         srcs=["connection-pool-test.cc", ],
-         deps=[":connection", ], )
+cxx_library(
+    name="connection",
+    exported_headers=[
+        "client-dispatcher.h",
+        "client-handler.h",
+        "connection-factory.h",
+        "connection-pool.h",
+        "pipeline.h",
+        "request.h",
+        "response.h",
+        "service.h",
+    ],
+    srcs=[
+        "client-dispatcher.cc",
+        "client-handler.cc",
+        "connection-factory.cc",
+        "connection-pool.cc",
+        "pipeline.cc",
+        "request.cc",
+    ],
+    deps=[
+        "//if:if",
+        "//utils:utils",
+        "//serde:serde",
+        "//third-party:folly",
+        "//third-party:wangle",
+    ],
+    compiler_flags=['-Weffc++'],
+    visibility=['//core/...',],)
+cxx_test(
+    name="connection-pool-test",
+    srcs=["connection-pool-test.cc",],
+    deps=[":connection",],)

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/connection/client-dispatcher.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/connection/client-dispatcher.h b/hbase-native-client/connection/client-dispatcher.h
index 2497cc7..5528a44 100644
--- a/hbase-native-client/connection/client-dispatcher.h
+++ b/hbase-native-client/connection/client-dispatcher.h
@@ -37,7 +37,7 @@ namespace hbase {
 class ClientDispatcher
     : public wangle::ClientDispatcherBase<SerializePipeline,
                                           std::unique_ptr<Request>, Response> {
-public:
+ public:
   /** Create a new ClientDispatcher */
   ClientDispatcher();
   /** Read a response off the pipeline. */
@@ -49,7 +49,7 @@ public:
   /** Close the dispatcher and the associated pipeline. */
   folly::Future<folly::Unit> close() override;
 
-private:
+ private:
   folly::AtomicHashMap<uint32_t, folly::Promise<Response>> requests_;
   // Start at some number way above what could
   // be there for un-initialized call id counters.
@@ -61,4 +61,4 @@ private:
   // not a big deal.
   std::atomic<uint32_t> current_call_id_;
 };
-} // namespace hbase
+}  // namespace hbase

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/connection/client-handler.cc
----------------------------------------------------------------------
diff --git a/hbase-native-client/connection/client-handler.cc b/hbase-native-client/connection/client-handler.cc
index 3409b80..e445444 100644
--- a/hbase-native-client/connection/client-handler.cc
+++ b/hbase-native-client/connection/client-handler.cc
@@ -37,7 +37,8 @@ using hbase::pb::GetResponse;
 using google::protobuf::Message;
 
 ClientHandler::ClientHandler(std::string user_name)
-    : user_name_(user_name), serde_(),
+    : user_name_(user_name),
+      serde_(),
       once_flag_(std::make_unique<std::once_flag>()),
       resp_msgs_(
           make_unique<folly::AtomicHashMap<

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/connection/client-handler.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/connection/client-handler.h b/hbase-native-client/connection/client-handler.h
index 984a947..269b737 100644
--- a/hbase-native-client/connection/client-handler.h
+++ b/hbase-native-client/connection/client-handler.h
@@ -51,7 +51,7 @@ namespace hbase {
 class ClientHandler : public wangle::Handler<std::unique_ptr<folly::IOBuf>,
                                              Response, std::unique_ptr<Request>,
                                              std::unique_ptr<folly::IOBuf>> {
-public:
+ public:
   /**
    * Create the handler
    * @param user_name the user name of the user running this process.
@@ -71,7 +71,7 @@ public:
   folly::Future<folly::Unit> write(Context *ctx,
                                    std::unique_ptr<Request> r) override;
 
-private:
+ private:
   std::unique_ptr<std::once_flag> once_flag_;
   std::string user_name_;
   RpcSerde serde_;
@@ -81,4 +81,4 @@ private:
       uint32_t, std::shared_ptr<google::protobuf::Message>>>
       resp_msgs_;
 };
-} // namespace hbase
+}  // namespace hbase

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/connection/connection-factory.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/connection/connection-factory.h b/hbase-native-client/connection/connection-factory.h
index fb5d9fe..4627952 100644
--- a/hbase-native-client/connection/connection-factory.h
+++ b/hbase-native-client/connection/connection-factory.h
@@ -34,7 +34,7 @@ namespace hbase {
  * pipeline.
  */
 class ConnectionFactory {
-public:
+ public:
   /**
    * Constructor.
    * There should only be one ConnectionFactory per client.
@@ -54,12 +54,12 @@ public:
    *
    * This is mostly visible so that mocks can override socket connections.
    */
-  virtual std::shared_ptr<HBaseService>
-  Connect(std::shared_ptr<wangle::ClientBootstrap<SerializePipeline>> client,
-          const std::string &hostname, int port);
+  virtual std::shared_ptr<HBaseService> Connect(
+      std::shared_ptr<wangle::ClientBootstrap<SerializePipeline>> client,
+      const std::string &hostname, int port);
 
-private:
+ private:
   std::shared_ptr<wangle::IOThreadPoolExecutor> io_pool_;
   std::shared_ptr<RpcPipelineFactory> pipeline_factory_;
 };
-} // namespace hbase
+}  // namespace hbase

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/connection/connection-pool-test.cc
----------------------------------------------------------------------
diff --git a/hbase-native-client/connection/connection-pool-test.cc b/hbase-native-client/connection/connection-pool-test.cc
index bd2d585..e17c16c 100644
--- a/hbase-native-client/connection/connection-pool-test.cc
+++ b/hbase-native-client/connection/connection-pool-test.cc
@@ -33,7 +33,7 @@ using ::testing::Return;
 using ::testing::_;
 
 class MockConnectionFactory : public ConnectionFactory {
-public:
+ public:
   MockConnectionFactory() : ConnectionFactory(nullptr) {}
   MOCK_METHOD0(MakeBootstrap,
                std::shared_ptr<wangle::ClientBootstrap<SerializePipeline>>());
@@ -46,7 +46,7 @@ public:
 class MockBootstrap : public wangle::ClientBootstrap<SerializePipeline> {};
 
 class MockServiceBase : public HBaseService {
-public:
+ public:
   folly::Future<Response> operator()(std::unique_ptr<Request> req) override {
     return do_operation(req.get());
   }
@@ -56,7 +56,7 @@ public:
 };
 
 class MockService : public MockServiceBase {
-public:
+ public:
   MOCK_METHOD1(do_operation, folly::Future<Response>(Request *));
 };
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/connection/connection-pool.cc
----------------------------------------------------------------------
diff --git a/hbase-native-client/connection/connection-pool.cc b/hbase-native-client/connection/connection-pool.cc
index aa3d094..2cb8e81 100644
--- a/hbase-native-client/connection/connection-pool.cc
+++ b/hbase-native-client/connection/connection-pool.cc
@@ -33,8 +33,10 @@ using folly::SocketAddress;
 
 ConnectionPool::ConnectionPool(
     std::shared_ptr<wangle::IOThreadPoolExecutor> io_executor)
-    : cf_(std::make_shared<ConnectionFactory>(io_executor)), clients_(),
-      connections_(), map_mutex_() {}
+    : cf_(std::make_shared<ConnectionFactory>(io_executor)),
+      clients_(),
+      connections_(),
+      map_mutex_() {}
 ConnectionPool::ConnectionPool(std::shared_ptr<ConnectionFactory> cf)
     : cf_(cf), clients_(), connections_(), map_mutex_() {}
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/connection/connection-pool.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/connection/connection-pool.h b/hbase-native-client/connection/connection-pool.h
index b8c950b..c89744e 100644
--- a/hbase-native-client/connection/connection-pool.h
+++ b/hbase-native-client/connection/connection-pool.h
@@ -18,8 +18,8 @@
  */
 #pragma once
 
-#include <boost/functional/hash.hpp>
 #include <folly/SharedMutex.h>
+#include <boost/functional/hash.hpp>
 #include <mutex>
 #include <unordered_map>
 
@@ -31,7 +31,6 @@ namespace hbase {
 
 /** Equals function for server name that ignores start time */
 struct ServerNameEquals {
-
   /** equals */
   bool operator()(const hbase::pb::ServerName &lhs,
                   const hbase::pb::ServerName &rhs) const {
@@ -59,7 +58,7 @@ struct ServerNameHash {
  * regionserver has on it.
  */
 class ConnectionPool {
-public:
+ public:
   /** Create connection pool wit default connection factory */
   ConnectionPool(std::shared_ptr<wangle::IOThreadPoolExecutor> io_executor);
 
@@ -87,7 +86,7 @@ public:
    */
   void Close(const hbase::pb::ServerName &sn);
 
-private:
+ private:
   std::shared_ptr<HBaseService> GetCached(const hbase::pb::ServerName &sn);
   std::shared_ptr<HBaseService> GetNew(const hbase::pb::ServerName &sn);
   std::unordered_map<hbase::pb::ServerName, std::shared_ptr<HBaseService>,
@@ -102,4 +101,4 @@ private:
   std::shared_ptr<ConnectionFactory> cf_;
 };
 
-} // namespace hbase
+}  // namespace hbase

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/connection/pipeline.cc
----------------------------------------------------------------------
diff --git a/hbase-native-client/connection/pipeline.cc b/hbase-native-client/connection/pipeline.cc
index 39cce8b..14ad73c 100644
--- a/hbase-native-client/connection/pipeline.cc
+++ b/hbase-native-client/connection/pipeline.cc
@@ -32,8 +32,8 @@ using namespace wangle;
 
 RpcPipelineFactory::RpcPipelineFactory() : user_util_() {}
 
-SerializePipeline::Ptr
-RpcPipelineFactory::newPipeline(std::shared_ptr<AsyncTransportWrapper> sock) {
+SerializePipeline::Ptr RpcPipelineFactory::newPipeline(
+    std::shared_ptr<AsyncTransportWrapper> sock) {
   auto pipeline = SerializePipeline::create();
   pipeline->addBack(AsyncSocketHandler{sock});
   pipeline->addBack(EventBaseHandler{});

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/connection/pipeline.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/connection/pipeline.h b/hbase-native-client/connection/pipeline.h
index 88d7845..b969e2b 100644
--- a/hbase-native-client/connection/pipeline.h
+++ b/hbase-native-client/connection/pipeline.h
@@ -35,7 +35,7 @@ using SerializePipeline =
  * Factory to create new pipelines for HBase RPC's.
  */
 class RpcPipelineFactory : public wangle::PipelineFactory<SerializePipeline> {
-public:
+ public:
   /**
    * Constructor. This will create user util.
    */
@@ -50,10 +50,10 @@ public:
    * - Length Field Based Frame Decoder
    * - Client Handler
    */
-  SerializePipeline::Ptr
-  newPipeline(std::shared_ptr<folly::AsyncTransportWrapper> sock) override;
+  SerializePipeline::Ptr newPipeline(
+      std::shared_ptr<folly::AsyncTransportWrapper> sock) override;
 
-private:
+ private:
   UserUtil user_util_;
 };
-} // namespace hbase
+}  // namespace hbase

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/connection/request.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/connection/request.h b/hbase-native-client/connection/request.h
index 634d1ba..91c684d 100644
--- a/hbase-native-client/connection/request.h
+++ b/hbase-native-client/connection/request.h
@@ -32,7 +32,7 @@ namespace hbase {
  * response object.
  */
 class Request {
-public:
+ public:
   /** Create a request object for a get */
   static std::unique_ptr<Request> get();
   /** Create a request object for a mutate */
@@ -62,10 +62,10 @@ public:
    * method type to decode. */
   std::string method() { return method_; }
 
-private:
+ private:
   uint32_t call_id_;
   std::shared_ptr<google::protobuf::Message> req_msg_ = nullptr;
   std::shared_ptr<google::protobuf::Message> resp_msg_ = nullptr;
   std::string method_ = "Get";
 };
-} // namespace hbase
+}  // namespace hbase

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/connection/response.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/connection/response.h b/hbase-native-client/connection/response.h
index aac57c2..6458c6b 100644
--- a/hbase-native-client/connection/response.h
+++ b/hbase-native-client/connection/response.h
@@ -35,7 +35,7 @@ namespace hbase {
  * This is the class sent to a service.
  */
 class Response {
-public:
+ public:
   /**
    * Constructor.
    * Initinalizes the call id to 0. 0 should never be a valid call id.
@@ -62,8 +62,8 @@ public:
     resp_msg_ = std::move(response);
   }
 
-private:
+ private:
   uint32_t call_id_;
   std::shared_ptr<google::protobuf::Message> resp_msg_;
 };
-} // namespace hbase
+}  // namespace hbase

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/connection/service.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/connection/service.h b/hbase-native-client/connection/service.h
index 79f087d..226f936 100644
--- a/hbase-native-client/connection/service.h
+++ b/hbase-native-client/connection/service.h
@@ -25,4 +25,4 @@
 
 namespace hbase {
 using HBaseService = wangle::Service<std::unique_ptr<Request>, Response>;
-} // namespace hbase
+}  // namespace hbase

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/BUCK
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/BUCK b/hbase-native-client/core/BUCK
index fa01eb3..20e4736 100644
--- a/hbase-native-client/core/BUCK
+++ b/hbase-native-client/core/BUCK
@@ -53,46 +53,41 @@ cxx_library(
         "//third-party:zookeeper_mt",
     ],
     compiler_flags=['-Weffc++'],
-    visibility=[
-        'PUBLIC',
-    ], )
-cxx_test(name="location-cache-test",
-         srcs=[
-             "location-cache-test.cc",
-         ],
-         deps=[":core",
-               "//test-util:test-util", ],
-         run_test_separately=True, )
-cxx_test(name="cell-test",
-         srcs=[
-             "cell-test.cc",
-         ],
-         deps=[":core", ],
-         run_test_separately=True, )
-cxx_test(name="get-test",
-         srcs=[
-             "get-test.cc",
-         ],
-         deps=[":core", ],
-         run_test_separately=True, )
-cxx_test(name="time_range-test",
-         srcs=[
-             "time_range-test.cc",
-         ],
-         deps=[":core", ],
-         run_test_separately=True, )
-cxx_test(name="hbase_configuration-test",
-         srcs=[
-             "hbase_configuration-test.cc",
-         ],
-         deps=[":core", ],
-         run_test_separately=True, )
-cxx_test(name="scan-test",
-         srcs=[
-             "scan-test.cc",
-         ],
-         deps=[":core", ],
-         run_test_separately=True, )
-cxx_binary(name="simple-client",
-           srcs=["simple-client.cc", ],
-           deps=[":core", "//connection:connection"], )
+    visibility=['PUBLIC',],)
+cxx_test(
+    name="location-cache-test",
+    srcs=["location-cache-test.cc",],
+    deps=[
+        ":core",
+        "//test-util:test-util",
+    ],
+    run_test_separately=True,)
+cxx_test(
+    name="cell-test",
+    srcs=["cell-test.cc",],
+    deps=[":core",],
+    run_test_separately=True,)
+cxx_test(
+    name="get-test",
+    srcs=["get-test.cc",],
+    deps=[":core",],
+    run_test_separately=True,)
+cxx_test(
+    name="time_range-test",
+    srcs=["time_range-test.cc",],
+    deps=[":core",],
+    run_test_separately=True,)
+cxx_test(
+    name="hbase_configuration-test",
+    srcs=["hbase_configuration-test.cc",],
+    deps=[":core",],
+    run_test_separately=True,)
+cxx_test(
+    name="scan-test",
+    srcs=["scan-test.cc",],
+    deps=[":core",],
+    run_test_separately=True,)
+cxx_binary(
+    name="simple-client",
+    srcs=["simple-client.cc",],
+    deps=[":core", "//connection:connection"],)

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/cell.cc
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/cell.cc b/hbase-native-client/core/cell.cc
index 5129bc9..37ebd13 100644
--- a/hbase-native-client/core/cell.cc
+++ b/hbase-native-client/core/cell.cc
@@ -25,9 +25,13 @@ namespace hbase {
 Cell::Cell(const std::string &row, const std::string &family,
            const std::string &qualifier, const long &timestamp,
            const std::string &value, const hbase::CellType &cell_type)
-    : row_(row), family_(family), qualifier_(qualifier), timestamp_(timestamp),
-      cell_type_(cell_type), value_(value), sequence_id_(0) {
-
+    : row_(row),
+      family_(family),
+      qualifier_(qualifier),
+      timestamp_(timestamp),
+      cell_type_(cell_type),
+      value_(value),
+      sequence_id_(0) {
   if (0 == row.size())
     throw std::runtime_error("Row size should be greater than 0");
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/cell.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/cell.h b/hbase-native-client/core/cell.h
index 2b15ad6..16ed280 100644
--- a/hbase-native-client/core/cell.h
+++ b/hbase-native-client/core/cell.h
@@ -34,7 +34,7 @@ enum CellType {
 };
 
 class Cell {
-public:
+ public:
   Cell(const std::string &row, const std::string &family,
        const std::string &qualifier, const long &timestamp,
        const std::string &value, const hbase::CellType &cell_type);
@@ -47,7 +47,7 @@ public:
   CellType Type() const;
   long SequenceId() const;
 
-private:
+ private:
   std::string row_;
   std::string family_;
   std::string qualifier_;

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/client.cc
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/client.cc b/hbase-native-client/core/client.cc
index 82ecd22..0389b24 100644
--- a/hbase-native-client/core/client.cc
+++ b/hbase-native-client/core/client.cc
@@ -21,8 +21,8 @@
 
 #include <glog/logging.h>
 
-#include <string>
 #include <unistd.h>
+#include <string>
 
 using namespace folly;
 using namespace std;
@@ -43,4 +43,4 @@ Client::~Client() {
   io_executor_->stop();
 }
 
-} // namespace hbase
+}  // namespace hbase

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/client.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/client.h b/hbase-native-client/core/client.h
index ba24bb9..296a8a0 100644
--- a/hbase-native-client/core/client.h
+++ b/hbase-native-client/core/client.h
@@ -39,7 +39,7 @@ namespace hbase {
  * have only one Client per cluster around.
  */
 class Client {
-public:
+ public:
   /**
    * Create a new client.
    * @param quorum_spec Where to connect to get Zookeeper bootstrap information.
@@ -47,10 +47,10 @@ public:
   explicit Client(std::string quorum_spec);
   ~Client();
 
-private:
+ private:
   std::shared_ptr<wangle::CPUThreadPoolExecutor> cpu_executor_;
   std::shared_ptr<wangle::IOThreadPoolExecutor> io_executor_;
   LocationCache location_cache_;
 };
 
-} // namespace hbase
+}  // namespace hbase

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/configuration.cc
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/configuration.cc b/hbase-native-client/core/configuration.cc
index 9816cff..c074cf6 100644
--- a/hbase-native-client/core/configuration.cc
+++ b/hbase-native-client/core/configuration.cc
@@ -21,8 +21,8 @@
 
 #include <stdexcept>
 
-#include <boost/lexical_cast.hpp>
 #include <glog/logging.h>
+#include <boost/lexical_cast.hpp>
 
 namespace hbase {
 
@@ -129,7 +129,6 @@ optional<std::string> Configuration::GetEnv(const std::string &key) const {
 }
 
 optional<std::string> Configuration::GetProperty(const std::string &key) const {
-
   auto found = hb_property_.find(key);
   if (found != hb_property_.end()) {
     return std::experimental::make_optional(found->second.value);
@@ -158,8 +157,7 @@ optional<int32_t> Configuration::GetInt(const std::string &key) const {
     try {
       return std::experimental::make_optional(
           boost::lexical_cast<int32_t>(*raw));
-    }
-    catch (const boost::bad_lexical_cast &blex) {
+    } catch (const boost::bad_lexical_cast &blex) {
       throw std::runtime_error(blex.what());
     }
   }
@@ -177,8 +175,7 @@ optional<int64_t> Configuration::GetLong(const std::string &key) const {
     try {
       return std::experimental::make_optional(
           boost::lexical_cast<int64_t>(*raw));
-    }
-    catch (const boost::bad_lexical_cast &blex) {
+    } catch (const boost::bad_lexical_cast &blex) {
       throw std::runtime_error(blex.what());
     }
   }
@@ -196,8 +193,7 @@ optional<double> Configuration::GetDouble(const std::string &key) const {
     try {
       return std::experimental::make_optional(
           boost::lexical_cast<double>(*raw));
-    }
-    catch (const boost::bad_lexical_cast &blex) {
+    } catch (const boost::bad_lexical_cast &blex) {
       throw std::runtime_error(blex.what());
     }
   }

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/configuration.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/configuration.h b/hbase-native-client/core/configuration.h
index 44d6cd6..d313cf6 100644
--- a/hbase-native-client/core/configuration.h
+++ b/hbase-native-client/core/configuration.h
@@ -88,7 +88,7 @@ class Configuration {
   struct ConfigData {
     std::string value;
     bool final;
-    ConfigData() : final(false) {};
+    ConfigData() : final(false){};
     ConfigData(const std::string &value) : value(value), final(false) {}
     void operator=(const std::string &new_value) {
       value = new_value;

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/get-test.cc
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/get-test.cc b/hbase-native-client/core/get-test.cc
index 9a09a23..53c14e3 100644
--- a/hbase-native-client/core/get-test.cc
+++ b/hbase-native-client/core/get-test.cc
@@ -19,8 +19,8 @@
 
 #include "core/get.h"
 
-#include <gtest/gtest.h>
 #include <glog/logging.h>
+#include <gtest/gtest.h>
 using namespace hbase;
 const int NUMBER_OF_GETS = 5;
 
@@ -135,15 +135,16 @@ void GetMethods(Get &get, const std::string &row) {
   ASSERT_THROW(get.SetTimeRange(-1000, 2000), std::runtime_error);
   ASSERT_THROW(get.SetTimeRange(1000, -2000), std::runtime_error);
   ASSERT_THROW(get.SetTimeRange(1000, 200), std::runtime_error);
-  ASSERT_THROW(get.SetTimeStamp(std::numeric_limits<long>::max()), std::runtime_error);
+  ASSERT_THROW(get.SetTimeStamp(std::numeric_limits<long>::max()),
+               std::runtime_error);
 
-  //Test some exceptions
+  // Test some exceptions
   ASSERT_THROW(get.SetMaxVersions(0), std::runtime_error);
   ASSERT_THROW(get.SetMaxVersions(std::numeric_limits<unsigned int>::max() + 1),
                std::runtime_error);
 }
 
-TEST (Get, SingleGet) {
+TEST(Get, SingleGet) {
   std::string row_str = "row-test";
   Get get(row_str);
   GetMethods(get, row_str);
@@ -156,7 +157,8 @@ TEST (Get, SingleGet) {
   geteq = get_tmp;
   GetMethods(geteq, row_str);
 
-  // Adding the below tests as there were some concerns raised that the same vector of qualifiers in FamilyMap is being shared between copied objects
+  // Adding the below tests as there were some concerns raised that the same
+  // vector of qualifiers in FamilyMap is being shared between copied objects
   // Verify the source object's family map size before using it to copy.
   EXPECT_EQ(3, get.Family().size());
 
@@ -192,11 +194,12 @@ TEST (Get, SingleGet) {
   ++it;
   EXPECT_EQ(it, get.Family().end());
 
-  //Verifying the copied object's families. It will remain unchanged and below tests should pass
+  // Verifying the copied object's families. It will remain unchanged and below
+  // tests should pass
   CheckFamiliesAfterCopy(getcp_fam);
 }
 
-TEST (Get, MultiGet) {
+TEST(Get, MultiGet) {
   std::vector<Get *> gets;
   for (int i = 0; i < NUMBER_OF_GETS; i++) {
     std::string row_str = "row-test";
@@ -214,7 +217,7 @@ TEST (Get, MultiGet) {
   gets.clear();
 }
 
-TEST (Get, Exception) {
+TEST(Get, Exception) {
   std::string row(std::numeric_limits<short>::max() + 1, 'X');
   ASSERT_THROW(Get tmp = Get(row), std::runtime_error);
   ASSERT_THROW(Get tmp = Get(""), std::runtime_error);

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/get.cc
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/get.cc b/hbase-native-client/core/get.cc
index b412a4b..a70da37 100644
--- a/hbase-native-client/core/get.cc
+++ b/hbase-native-client/core/get.cc
@@ -24,13 +24,9 @@
 
 namespace hbase {
 
-Get::~Get() {
-}
+Get::~Get() {}
 
-Get::Get(const std::string &row)
-    : row_(row) {
-  CheckRow(row_);
-}
+Get::Get(const std::string &row) : row_(row) { CheckRow(row_); }
 
 Get::Get(const Get &get) {
   row_ = get.row_;
@@ -38,27 +34,30 @@ Get::Get(const Get &get) {
   cache_blocks_ = get.cache_blocks_;
   check_existence_only_ = get.check_existence_only_;
   consistency_ = get.consistency_;
-  tr_.reset(new TimeRange(get.Timerange().MinTimeStamp(), get.Timerange().MaxTimeStamp()));
+  tr_.reset(new TimeRange(get.Timerange().MinTimeStamp(),
+                          get.Timerange().MaxTimeStamp()));
   family_map_.insert(get.family_map_.begin(), get.family_map_.end());
 }
 
-Get& Get::operator=(const Get &get) {
+Get &Get::operator=(const Get &get) {
   row_ = get.row_;
   max_versions_ = get.max_versions_;
   cache_blocks_ = get.cache_blocks_;
   check_existence_only_ = get.check_existence_only_;
   consistency_ = get.consistency_;
-  tr_.reset(new TimeRange(get.Timerange().MinTimeStamp(), get.Timerange().MaxTimeStamp()));
+  tr_.reset(new TimeRange(get.Timerange().MinTimeStamp(),
+                          get.Timerange().MaxTimeStamp()));
   family_map_.insert(get.family_map_.begin(), get.family_map_.end());
   return *this;
 }
 
-Get& Get::AddFamily(const std::string &family) {
+Get &Get::AddFamily(const std::string &family) {
   const auto &it = family_map_.find(family);
 
   /**
    * Check if any qualifiers are already present or not.
-   * Remove all existing qualifiers if the given family is already present in the map
+   * Remove all existing qualifiers if the given family is already present in
+   * the map
    */
   if (family_map_.end() != it) {
     it->second.clear();
@@ -68,8 +67,9 @@ Get& Get::AddFamily(const std::string &family) {
   return *this;
 }
 
-Get& Get::AddColumn(const std::string &family, const std::string &qualifier) {
-  const auto &it = std::find(family_map_[family].begin(), family_map_[family].end(), qualifier);
+Get &Get::AddColumn(const std::string &family, const std::string &qualifier) {
+  const auto &it = std::find(family_map_[family].begin(),
+                             family_map_[family].end(), qualifier);
 
   /**
    * Check if any qualifiers are already present or not.
@@ -81,32 +81,22 @@ Get& Get::AddColumn(const std::string &family, const std::string &qualifier) {
   return *this;
 }
 
-const std::string& Get::Row() const {
-  return row_;
-}
+const std::string &Get::Row() const { return row_; }
 
-hbase::pb::Consistency Get::Consistency() const {
-  return consistency_;
-}
+hbase::pb::Consistency Get::Consistency() const { return consistency_; }
 
 Get &Get::SetConsistency(hbase::pb::Consistency consistency) {
   consistency_ = consistency;
   return *this;
 }
 
-bool Get::HasFamilies() const {
-  return !family_map_.empty();
-}
+bool Get::HasFamilies() const { return !family_map_.empty(); }
 
-const FamilyMap &Get::Family() const {
-  return family_map_;
-}
+const FamilyMap &Get::Family() const { return family_map_; }
 
-int Get::MaxVersions() const {
-  return max_versions_;
-}
+int Get::MaxVersions() const { return max_versions_; }
 
-Get& Get::SetMaxVersions(uint32_t max_versions) {
+Get &Get::SetMaxVersions(uint32_t max_versions) {
   if (0 == max_versions)
     throw std::runtime_error("max_versions must be positive");
 
@@ -114,28 +104,24 @@ Get& Get::SetMaxVersions(uint32_t max_versions) {
   return *this;
 }
 
-bool Get::CacheBlocks() const {
-  return cache_blocks_;
-}
+bool Get::CacheBlocks() const { return cache_blocks_; }
 
-Get & Get::SetCacheBlocks(bool cache_blocks) {
+Get &Get::SetCacheBlocks(bool cache_blocks) {
   cache_blocks_ = cache_blocks;
   return *this;
 }
 
-Get& Get::SetTimeRange(long min_timestamp, long max_timestamp) {
+Get &Get::SetTimeRange(long min_timestamp, long max_timestamp) {
   tr_.reset(new TimeRange(min_timestamp, max_timestamp));
   return *this;
 }
 
-Get& Get::SetTimeStamp(long timestamp) {
+Get &Get::SetTimeStamp(long timestamp) {
   tr_.reset(new TimeRange(timestamp, timestamp + 1));
   return *this;
 }
 
-const TimeRange& Get::Timerange() const {
-  return *tr_;
-}
+const TimeRange &Get::Timerange() const { return *tr_; }
 
 void Get::CheckRow(const std::string &row) {
   const int kMaxRowLength = std::numeric_limits<short>::max();
@@ -144,9 +130,9 @@ void Get::CheckRow(const std::string &row) {
     throw std::runtime_error("Row length can't be 0");
   }
   if (row_length > kMaxRowLength) {
-    throw std::runtime_error(
-        "Length of " + row + " is greater than max row size: " + std::to_string(kMaxRowLength));
+    throw std::runtime_error("Length of " + row +
+                             " is greater than max row size: " +
+                             std::to_string(kMaxRowLength));
   }
 }
-
 }

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/get.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/get.h b/hbase-native-client/core/get.h
index 9704aa1..90c42ee 100644
--- a/hbase-native-client/core/get.h
+++ b/hbase-native-client/core/get.h
@@ -19,31 +19,30 @@
 
 #pragma once
 
+#include <cstdint>
 #include <map>
 #include <memory>
 #include <string>
 #include <vector>
-#include <cstdint>
 #include "core/time_range.h"
 #include "if/Client.pb.h"
 
 namespace hbase {
 
 /**
- * @brief Map consisting of column families and qualifiers to be used for Get operation
+ * @brief Map consisting of column families and qualifiers to be used for Get
+ * operation
  */
 using FamilyMap = std::map<std::string, std::vector<std::string>>;
 
 class Get {
-
  public:
-
   /**
    * Constructors
    */
-  Get(const std::string &row);
-  Get(const Get &cget);
-  Get& operator=(const Get &cget);
+  Get(const std::string& row);
+  Get(const Get& cget);
+  Get& operator=(const Get& cget);
 
   ~Get();
 
@@ -53,7 +52,8 @@ class Get {
   int MaxVersions() const;
 
   /**
-   * @brief Get up to the specified number of versions of each column. default is 1.
+   * @brief Get up to the specified number of versions of each column. default
+   * is 1.
    * @param max_versions max_versons to set
    */
   Get& SetMaxVersions(uint32_t max_versions = 1);
@@ -70,9 +70,10 @@ class Get {
   Get& SetCacheBlocks(bool cache_blocks);
 
   /**
-   * @brief Returns the Get family map (FamilyMap) for this Get operation. Used for constructing Scan object with an already constructed Get
+   * @brief Returns the Get family map (FamilyMap) for this Get operation. Used
+   * for constructing Scan object with an already constructed Get
    */
-  const FamilyMap &Family() const;
+  const FamilyMap& Family() const;
 
   /**
    * @brief Returns the timerange for this Get
@@ -80,7 +81,8 @@ class Get {
   const TimeRange& Timerange() const;
 
   /**
-   * @brief Get versions of columns only within the specified timestamp range, [minStamp, maxStamp).
+   * @brief Get versions of columns only within the specified timestamp range,
+   * [minStamp, maxStamp).
    * @param minStamp the minimum timestamp, inclusive
    * @param maxStamp the maximum timestamp, exclusive
    */
@@ -96,14 +98,15 @@ class Get {
    * @brief Get all columns from the specified family.
    * @param family to be retrieved
    */
-  Get& AddFamily(const std::string &family);
+  Get& AddFamily(const std::string& family);
 
   /**
-   *  @brief Get the column from the specific family with the specified qualifier.
+   *  @brief Get the column from the specific family with the specified
+   * qualifier.
    *  @param family to be retrieved
    *  @param qualifier to be retrieved
    */
-  Get& AddColumn(const std::string &family, const std::string &qualifier);
+  Get& AddColumn(const std::string& family, const std::string& qualifier);
 
   /**
    * @brief Returns the row for this Get operation
@@ -138,8 +141,9 @@ class Get {
   /**
    * @brief Checks if the row for this Get operation is proper or not
    * @param row Row to check
-   * @throws std::runtime_error if row is empty or greater than MAX_ROW_LENGTH(i.e. std::numeric_limits<short>::max())
+   * @throws std::runtime_error if row is empty or greater than
+   * MAX_ROW_LENGTH(i.e. std::numeric_limits<short>::max())
    */
-  void CheckRow(const std::string &row);
+  void CheckRow(const std::string& row);
 };
 }

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/hbase_configuration-test.cc
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/hbase_configuration-test.cc b/hbase-native-client/core/hbase_configuration-test.cc
index 167f506..eec500e 100644
--- a/hbase-native-client/core/hbase_configuration-test.cc
+++ b/hbase-native-client/core/hbase_configuration-test.cc
@@ -20,16 +20,18 @@
 #include <fstream>
 #include <iostream>
 
-#include <boost/filesystem.hpp>
-#include <gtest/gtest.h>
 #include <glog/logging.h>
-#include "core/hbase_configuration_loader.h"
+#include <gtest/gtest.h>
+#include <boost/filesystem.hpp>
 #include "core/configuration.h"
+#include "core/hbase_configuration_loader.h"
 
 using namespace hbase;
 
-const std::string kDefHBaseConfPath("./build/test-data/hbase-configuration-test/conf/");
-const std::string kHBaseConfPath("./build/test-data/hbase-configuration-test/custom-conf/");
+const std::string kDefHBaseConfPath(
+    "./build/test-data/hbase-configuration-test/conf/");
+const std::string kHBaseConfPath(
+    "./build/test-data/hbase-configuration-test/custom-conf/");
 
 const std::string kHBaseDefaultXml("hbase-default.xml");
 const std::string kHBaseSiteXml("hbase-site.xml");
@@ -131,7 +133,6 @@ void CreateHBaseConf(const std::string &dir, const std::string &file,
 }
 
 void CreateHBaseConfWithEnv() {
-
   CreateHBaseConf(kDefHBaseConfPath, kHBaseDefaultXml, kHBaseDefaultXmlData);
   CreateHBaseConf(kDefHBaseConfPath, kHBaseSiteXml, kHBaseSiteXmlData);
   setenv("HBASE_CONF", kDefHBaseConfPath.c_str(), 1);
@@ -178,7 +179,7 @@ TEST(Configuration, LoadConfFromCustomLocation) {
 
 /*
  * Config will be loaded from hbase-defualt.xml and hbase-site.xml @
- * kDefHBaseConfPath and kHBaseConfPath respectively. 
+ * kDefHBaseConfPath and kHBaseConfPath respectively.
  */
 TEST(Configuration, LoadConfFromMultipleLocatons) {
   // Remove already configured env if present.

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/hbase_configuration_loader.cc
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/hbase_configuration_loader.cc b/hbase-native-client/core/hbase_configuration_loader.cc
index 43f733a..d3aff8c 100644
--- a/hbase-native-client/core/hbase_configuration_loader.cc
+++ b/hbase-native-client/core/hbase_configuration_loader.cc
@@ -19,10 +19,10 @@
 
 #include "core/hbase_configuration_loader.h"
 
+#include <glog/logging.h>
 #include <boost/foreach.hpp>
 #include <boost/property_tree/ptree.hpp>
 #include <boost/property_tree/xml_parser.hpp>
-#include <glog/logging.h>
 
 namespace hbase {
 
@@ -172,7 +172,7 @@ bool HBaseConfigurationLoader::LoadProperties(const std::string &file,
 
     // Iterate over configuration section.
     // Store all found properties in ConfigMap
-    BOOST_FOREACH(ptree::value_type & v, pt.get_child("configuration")) {
+    BOOST_FOREACH (ptree::value_type &v, pt.get_child("configuration")) {
       if ("property" == v.first) {
         std::string name_node = v.second.get<std::string>("name");
         std::string value_node = v.second.get<std::string>("value");
@@ -183,8 +183,7 @@ bool HBaseConfigurationLoader::LoadProperties(const std::string &file,
         }
       }
     }
-  }
-  catch (std::exception &ex) {
+  } catch (std::exception &ex) {
     DLOG(WARNING) << "Exception in parsing file [" << file << "]:[" << ex.what()
                   << "]";
     return false;

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/hbase_configuration_loader.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/hbase_configuration_loader.h b/hbase-native-client/core/hbase_configuration_loader.h
index 54d90a5..49dc2b9 100644
--- a/hbase-native-client/core/hbase_configuration_loader.h
+++ b/hbase-native-client/core/hbase_configuration_loader.h
@@ -34,7 +34,6 @@ template <class T>
 using optional = std::experimental::optional<T>;
 
 class HBaseConfigurationLoader {
-
  public:
   HBaseConfigurationLoader();
   ~HBaseConfigurationLoader();

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/hbase_macros.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/hbase_macros.h b/hbase-native-client/core/hbase_macros.h
index 48304f0..d70c247 100644
--- a/hbase-native-client/core/hbase_macros.h
+++ b/hbase-native-client/core/hbase_macros.h
@@ -52,5 +52,5 @@ extern "C" {
 #endif
 
 #ifdef __cplusplus
-} // extern "C"
-#endif // __cplusplus
+}  // extern "C"
+#endif  // __cplusplus

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/location-cache.cc
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/location-cache.cc b/hbase-native-client/core/location-cache.cc
index efd2210..4359795 100644
--- a/hbase-native-client/core/location-cache.cc
+++ b/hbase-native-client/core/location-cache.cc
@@ -53,8 +53,12 @@ LocationCache::LocationCache(
     std::string quorum_spec,
     std::shared_ptr<wangle::CPUThreadPoolExecutor> cpu_executor,
     std::shared_ptr<wangle::IOThreadPoolExecutor> io_executor)
-    : quorum_spec_(quorum_spec), cpu_executor_(cpu_executor),
-      meta_promise_(nullptr), meta_lock_(), cp_(io_executor), meta_util_(),
+    : quorum_spec_(quorum_spec),
+      cpu_executor_(cpu_executor),
+      meta_promise_(nullptr),
+      meta_lock_(),
+      cp_(io_executor),
+      meta_util_(),
       zk_(nullptr) {
   zk_ = zookeeper_init(quorum_spec.c_str(), nullptr, 1000, 0, 0, 0);
 }
@@ -111,8 +115,8 @@ ServerName LocationCache::ReadMetaLocation() {
   return mrs.server();
 }
 
-Future<std::shared_ptr<RegionLocation>>
-LocationCache::LocateFromMeta(const TableName &tn, const string &row) {
+Future<std::shared_ptr<RegionLocation>> LocationCache::LocateFromMeta(
+    const TableName &tn, const string &row) {
   return this->LocateMeta()
       .via(cpu_executor_.get())
       .then([this](ServerName sn) { return this->cp_.Get(sn); })
@@ -139,8 +143,8 @@ LocationCache::LocateFromMeta(const TableName &tn, const string &row) {
       });
 }
 
-std::shared_ptr<RegionLocation>
-LocationCache::CreateLocation(const Response &resp) {
+std::shared_ptr<RegionLocation> LocationCache::CreateLocation(
+    const Response &resp) {
   auto resp_msg = static_pointer_cast<ScanResponse>(resp.resp_msg());
   auto &results = resp_msg->results().Get(0);
   auto &cells = results.cell();

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/location-cache.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/location-cache.h b/hbase-native-client/core/location-cache.h
index 830cd96..53e41ab 100644
--- a/hbase-native-client/core/location-cache.h
+++ b/hbase-native-client/core/location-cache.h
@@ -46,7 +46,7 @@ class ServerName;
  * Class that can look up and cache locations.
  */
 class LocationCache {
-public:
+ public:
   /**
    * Constructor.
    * @param quorum_spec Where to connect for Zookeeper.
@@ -79,15 +79,15 @@ public:
    * @param row of the table to look up. This object must live until after the
    * future is returned
    */
-  folly::Future<std::shared_ptr<RegionLocation>>
-  LocateFromMeta(const hbase::pb::TableName &tn, const std::string &row);
+  folly::Future<std::shared_ptr<RegionLocation>> LocateFromMeta(
+      const hbase::pb::TableName &tn, const std::string &row);
 
   /**
    * Remove the cached location of meta.
    */
   void InvalidateMeta();
 
-private:
+ private:
   void RefreshMetaLocation();
   hbase::pb::ServerName ReadMetaLocation();
   std::shared_ptr<RegionLocation> CreateLocation(const Response &resp);
@@ -103,4 +103,4 @@ private:
   // TODO: migrate this to a smart pointer with a deleter.
   zhandle_t *zk_;
 };
-} // namespace hbase
+}  // namespace hbase

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/meta-utils.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/meta-utils.h b/hbase-native-client/core/meta-utils.h
index 294e17d..303a273 100644
--- a/hbase-native-client/core/meta-utils.h
+++ b/hbase-native-client/core/meta-utils.h
@@ -30,7 +30,7 @@ namespace hbase {
  * @brief Utility for meta operations.
  */
 class MetaUtil {
-public:
+ public:
   /**
    * Given a table and a row give the row key from which to start a scan to find
    * region locations.
@@ -45,4 +45,4 @@ public:
   std::unique_ptr<Request> MetaRequest(const hbase::pb::TableName tn,
                                        const std::string &row) const;
 };
-} // namespace hbase
+}  // namespace hbase

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/region-location.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/region-location.h b/hbase-native-client/core/region-location.h
index a3d832e..b3c124d 100644
--- a/hbase-native-client/core/region-location.h
+++ b/hbase-native-client/core/region-location.h
@@ -32,7 +32,7 @@ namespace hbase {
  * region name, and a connection to the service used for connecting to it.
  */
 class RegionLocation {
-public:
+ public:
   /**
    * Constructor.
    * @param region_name The region name of this region.
@@ -79,11 +79,11 @@ public:
    */
   void set_server_name(hbase::pb::ServerName sn) { sn_ = sn; }
 
-private:
+ private:
   std::string region_name_;
   hbase::pb::RegionInfo ri_;
   hbase::pb::ServerName sn_;
   std::shared_ptr<HBaseService> service_;
 };
 
-} // namespace hbase
+}  // namespace hbase

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/scan-test.cc
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/scan-test.cc b/hbase-native-client/core/scan-test.cc
index a114502..b6a6f3e 100644
--- a/hbase-native-client/core/scan-test.cc
+++ b/hbase-native-client/core/scan-test.cc
@@ -168,15 +168,17 @@ void ScanMethods(Scan &scan) {
   ASSERT_THROW(scan.SetTimeRange(-1000, 2000), std::runtime_error);
   ASSERT_THROW(scan.SetTimeRange(1000, -2000), std::runtime_error);
   ASSERT_THROW(scan.SetTimeRange(1000, 200), std::runtime_error);
-  ASSERT_THROW(scan.SetTimeStamp(std::numeric_limits<long>::max()), std::runtime_error);
+  ASSERT_THROW(scan.SetTimeStamp(std::numeric_limits<long>::max()),
+               std::runtime_error);
 }
 
-TEST (Scan, Object) {
+TEST(Scan, Object) {
   Scan scan;
   ScanMethods(scan);
   CheckFamilies(scan);
 
-  // Resetting TimeRange values so that the copy construction and assignment operator tests pass.
+  // Resetting TimeRange values so that the copy construction and assignment
+  // operator tests pass.
   scan.SetTimeRange(0, std::numeric_limits<long>::max());
   Scan scancp(scan);
   ScanMethods(scancp);
@@ -188,22 +190,21 @@ TEST (Scan, Object) {
   CheckFamiliesAfterCopy(scaneq);
 }
 
-TEST (Scan, WithStartRow) {
+TEST(Scan, WithStartRow) {
   Scan("row-test");
   Scan scan("row-test");
   ScanMethods(scan);
   CheckFamilies(scan);
 }
 
-TEST (Scan, WithStartAndStopRow) {
+TEST(Scan, WithStartAndStopRow) {
   Scan("start-row", "stop-row");
   Scan scan("start-row", "stop-row");
   ScanMethods(scan);
   CheckFamilies(scan);
 }
 
-TEST (Scan,FromGet) {
-
+TEST(Scan, FromGet) {
   std::string row_str = "row-test";
   Get get = Get(row_str);
 
@@ -226,7 +227,7 @@ TEST (Scan,FromGet) {
   CheckFamiliesAfterCopy(scan);
 }
 
-TEST (Scan, Exception) {
+TEST(Scan, Exception) {
   std::string row(std::numeric_limits<short>::max() + 1, 'X');
   ASSERT_THROW(Scan tmp(row), std::runtime_error);
   ASSERT_THROW(Scan tmp(""), std::runtime_error);

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/scan.cc
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/scan.cc b/hbase-native-client/core/scan.cc
index 318cdb7..2dd8ef2 100644
--- a/hbase-native-client/core/scan.cc
+++ b/hbase-native-client/core/scan.cc
@@ -26,20 +26,16 @@
 
 namespace hbase {
 
-Scan::Scan() {
-}
+Scan::Scan() {}
 
-Scan::~Scan() {
-}
+Scan::~Scan() {}
 
-Scan::Scan(const std::string &start_row)
-    : start_row_(start_row) {
+Scan::Scan(const std::string &start_row) : start_row_(start_row) {
   CheckRow(start_row_);
 }
 
 Scan::Scan(const std::string &start_row, const std::string &stop_row)
-    : start_row_(start_row),
-      stop_row_(stop_row) {
+    : start_row_(start_row), stop_row_(stop_row) {
   CheckRow(start_row_);
   CheckRow(stop_row_);
 }
@@ -60,7 +56,7 @@ Scan::Scan(const Scan &scan) {
   family_map_.insert(scan.family_map_.begin(), scan.family_map_.end());
 }
 
-Scan& Scan::operator=(const Scan &scan) {
+Scan &Scan::operator=(const Scan &scan) {
   start_row_ = scan.start_row_;
   stop_row_ = scan.stop_row_;
   max_versions_ = scan.max_versions_;
@@ -80,15 +76,17 @@ Scan& Scan::operator=(const Scan &scan) {
 Scan::Scan(const Get &get) {
   cache_blocks_ = get.CacheBlocks();
   max_versions_ = get.MaxVersions();
-  tr_.reset(new TimeRange(get.Timerange().MinTimeStamp(), get.Timerange().MaxTimeStamp()));
+  tr_.reset(new TimeRange(get.Timerange().MinTimeStamp(),
+                          get.Timerange().MaxTimeStamp()));
   family_map_.insert(get.Family().begin(), get.Family().end());
 }
 
-Scan& Scan::AddFamily(const std::string &family) {
+Scan &Scan::AddFamily(const std::string &family) {
   const auto &it = family_map_.find(family);
   /**
    * Check if any qualifiers are already present or not.
-   * Remove all existing qualifiers if the given family is already present in the map
+   * Remove all existing qualifiers if the given family is already present in
+   * the map
    */
   if (family_map_.end() != it) {
     it->second.clear();
@@ -98,8 +96,9 @@ Scan& Scan::AddFamily(const std::string &family) {
   return *this;
 }
 
-Scan& Scan::AddColumn(const std::string &family, const std::string &qualifier) {
-  const auto &it = std::find(family_map_[family].begin(), family_map_[family].end(), qualifier);
+Scan &Scan::AddColumn(const std::string &family, const std::string &qualifier) {
+  const auto &it = std::find(family_map_[family].begin(),
+                             family_map_[family].end(), qualifier);
   /**
    * Check if any qualifiers are already present or not.
    * Add only if qualifiers for a given family are not present
@@ -110,72 +109,48 @@ Scan& Scan::AddColumn(const std::string &family, const std::string &qualifier) {
   return *this;
 }
 
-void Scan::SetReversed(bool reversed) {
-  reversed_ = reversed;
-}
+void Scan::SetReversed(bool reversed) { reversed_ = reversed; }
 
-bool Scan::IsReversed() const {
-  return reversed_;
-}
+bool Scan::IsReversed() const { return reversed_; }
 
 void Scan::SetStartRow(std::string &start_row) {
   CheckRow(start_row);
   start_row_ = start_row;
 }
 
-const std::string& Scan::StartRow() const {
-  return start_row_;
-}
+const std::string &Scan::StartRow() const { return start_row_; }
 
 void Scan::SetStopRow(std::string &stop_row) {
   CheckRow(stop_row);
   stop_row_ = stop_row;
 }
 
-const std::string& Scan::StopRow() const {
-  return stop_row_;
-}
+const std::string &Scan::StopRow() const { return stop_row_; }
 
-void Scan::SetSmall(bool small) {
-  small_ = small;
-}
+void Scan::SetSmall(bool small) { small_ = small; }
 
-bool Scan::IsSmall() const {
-  return small_;
-}
+bool Scan::IsSmall() const { return small_; }
 
-void Scan::SetCaching(int caching) {
-  caching_ = caching;
-}
+void Scan::SetCaching(int caching) { caching_ = caching; }
 
-int Scan::Caching() const {
-  return caching_;
-}
+int Scan::Caching() const { return caching_; }
 
-Scan& Scan::SetConsistency(const hbase::pb::Consistency consistency) {
+Scan &Scan::SetConsistency(const hbase::pb::Consistency consistency) {
   consistency_ = consistency;
   return *this;
 }
 
-hbase::pb::Consistency Scan::Consistency() const {
-  return consistency_;
-}
+hbase::pb::Consistency Scan::Consistency() const { return consistency_; }
 
-void Scan::SetCacheBlocks(bool cache_blocks) {
-  cache_blocks_ = cache_blocks;
-}
+void Scan::SetCacheBlocks(bool cache_blocks) { cache_blocks_ = cache_blocks; }
 
-bool Scan::CacheBlocks() const {
-  return cache_blocks_;
-}
+bool Scan::CacheBlocks() const { return cache_blocks_; }
 
 void Scan::SetAllowPartialResults(bool allow_partial_results) {
   allow_partial_results_ = allow_partial_results;
 }
 
-bool Scan::AllowPartialResults() const {
-  return allow_partial_results_;
-}
+bool Scan::AllowPartialResults() const { return allow_partial_results_; }
 
 void Scan::SetLoadColumnFamiliesOnDemand(bool load_column_families_on_demand) {
   load_column_families_on_demand_ = load_column_families_on_demand;
@@ -185,36 +160,30 @@ bool Scan::LoadColumnFamiliesOnDemand() const {
   return load_column_families_on_demand_;
 }
 
-Scan& Scan::SetMaxVersions(uint32_t max_versions) {
+Scan &Scan::SetMaxVersions(uint32_t max_versions) {
   max_versions_ = max_versions;
   return *this;
 }
 
-int Scan::MaxVersions() const {
-  return max_versions_;
-}
+int Scan::MaxVersions() const { return max_versions_; }
 
 void Scan::SetMaxResultSize(long max_result_size) {
   max_result_size_ = max_result_size;
 }
 
-long Scan::MaxResultSize() const {
-  return max_result_size_;
-}
+long Scan::MaxResultSize() const { return max_result_size_; }
 
 Scan &Scan::SetTimeRange(long min_stamp, long max_stamp) {
   tr_.reset(new TimeRange(min_stamp, max_stamp));
   return *this;
 }
 
-Scan& Scan::SetTimeStamp(long timestamp) {
+Scan &Scan::SetTimeStamp(long timestamp) {
   tr_.reset(new TimeRange(timestamp, timestamp + 1));
   return *this;
 }
 
-const TimeRange& Scan::Timerange() const {
-  return *tr_;
-}
+const TimeRange &Scan::Timerange() const { return *tr_; }
 
 void Scan::CheckRow(const std::string &row) {
   const int kMaxRowLength = std::numeric_limits<short>::max();
@@ -223,17 +192,14 @@ void Scan::CheckRow(const std::string &row) {
     throw std::runtime_error("Row length can't be 0");
   }
   if (row_length > kMaxRowLength) {
-    throw std::runtime_error(
-        "Length of " + row + " is greater than max row size: " + std::to_string(kMaxRowLength));
+    throw std::runtime_error("Length of " + row +
+                             " is greater than max row size: " +
+                             std::to_string(kMaxRowLength));
   }
 }
 
-bool Scan::HasFamilies() const {
-  return !family_map_.empty();
-}
+bool Scan::HasFamilies() const { return !family_map_.empty(); }
 
-const FamilyMap &Scan::Family() const {
-  return family_map_;
-}
+const FamilyMap &Scan::Family() const { return family_map_; }
 }
 /* namespace hbase */

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/scan.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/scan.h b/hbase-native-client/core/scan.h
index bd655ce..99ed26a 100644
--- a/hbase-native-client/core/scan.h
+++ b/hbase-native-client/core/scan.h
@@ -30,7 +30,8 @@
 namespace hbase {
 
 /**
- * @brief Map consisting of column families and qualifiers to be used for Get operation
+ * @brief Map consisting of column families and qualifiers to be used for Get
+ * operation
  */
 using FamilyMap = std::map<std::string, std::vector<std::string>>;
 
@@ -41,12 +42,13 @@ class Scan {
    */
   Scan();
   Scan(const Scan &scan);
-  Scan& operator=(const Scan &scan);
+  Scan &operator=(const Scan &scan);
 
   ~Scan();
 
   /**
-   * @brief Create a Scan operation starting at the specified row. If the specified row does not exist,
+   * @brief Create a Scan operation starting at the specified row. If the
+   * specified row does not exist,
    * the Scanner will start from the next closest row after the specified row.
    * @param start_row - row to start scanner at or after
    */
@@ -66,52 +68,60 @@ class Scan {
   Scan(const Get &get);
 
   /**
-   * @brief Get all columns from the specified family.Overrides previous calls to AddColumn for this family.
+   * @brief Get all columns from the specified family.Overrides previous calls
+   * to AddColumn for this family.
    * @param family - family name
    */
-  Scan& AddFamily(const std::string &family);
+  Scan &AddFamily(const std::string &family);
 
   /**
-   * @brief Get the column from the specified family with the specified qualifier.Overrides previous calls to AddFamily for this family.
+   * @brief Get the column from the specified family with the specified
+   * qualifier.Overrides previous calls to AddFamily for this family.
    * @param family - family name.
    * @param qualifier - column qualifier.
    */
-  Scan& AddColumn(const std::string &family, const std::string &qualifier);
+  Scan &AddColumn(const std::string &family, const std::string &qualifier);
 
   /**
-   * @brief Set whether this scan is a reversed one. This is false by default which means forward(normal) scan.
+   * @brief Set whether this scan is a reversed one. This is false by default
+   * which means forward(normal) scan.
    * @param reversed - if true, scan will be backward order
    */
   void SetReversed(bool reversed);
 
   /**
-   * @brief Get whether this scan is a reversed one. Returns  true if backward scan, false if forward(default) scan
+   * @brief Get whether this scan is a reversed one. Returns  true if backward
+   * scan, false if forward(default) scan
    */
   bool IsReversed() const;
 
   /**
-   * @brief Set the start row of the scan.If the specified row does not exist, the Scanner will start from the next closest row after the specified row.
+   * @brief Set the start row of the scan.If the specified row does not exist,
+   * the Scanner will start from the next closest row after the specified row.
    * @param start_row - row to start scanner at or after
-   * @throws std::runtime_error if start_row length is 0 or greater than MAX_ROW_LENGTH
+   * @throws std::runtime_error if start_row length is 0 or greater than
+   * MAX_ROW_LENGTH
    */
   void SetStartRow(std::string &start_row);
 
   /**
    * @brief returns start_row of the Scan.
    */
-  const std::string& StartRow() const;
+  const std::string &StartRow() const;
 
   /**
-   * @brief Set the stop row of the scan. The scan will include rows that are lexicographically less than the provided stop_row.
+   * @brief Set the stop row of the scan. The scan will include rows that are
+   * lexicographically less than the provided stop_row.
    * @param stop_row - row to end at (exclusive)
-   * @throws std::runtime_error if stop_row length is 0 or greater than MAX_ROW_LENGTH
+   * @throws std::runtime_error if stop_row length is 0 or greater than
+   * MAX_ROW_LENGTH
    */
   void SetStopRow(std::string &stop_row);
 
   /**
    * @brief returns stop_row of the Scan.
    */
-  const std::string& StopRow() const;
+  const std::string &StopRow() const;
 
   /**
    * @brief Set whether this scan is a small scan.
@@ -124,7 +134,8 @@ class Scan {
   bool IsSmall() const;
 
   /**
-   * @brief Set the number of rows for caching that will be passed to scanners. Higher caching values will enable faster scanners but will use more memory.
+   * @brief Set the number of rows for caching that will be passed to scanners.
+   * Higher caching values will enable faster scanners but will use more memory.
    * @param caching - the number of rows for caching.
    */
   void SetCaching(int caching);
@@ -138,7 +149,7 @@ class Scan {
    * @brief Sets the consistency level for this operation.
    * @param consistency - the consistency level
    */
-  Scan& SetConsistency(const hbase::pb::Consistency consistency);
+  Scan &SetConsistency(const hbase::pb::Consistency consistency);
 
   /**
    * @brief Returns the consistency level for this operation.
@@ -146,8 +157,12 @@ class Scan {
   hbase::pb::Consistency Consistency() const;
 
   /**
-   * @brief Set whether blocks should be cached for this Scan.This is true by default. When true, default settings of the table and family are used (this will never override caching blocks if the block cache is disabled for that family or entirely).
-   * @param cache_blocks - if false, default settings are overridden and blocks will not be cached
+   * @brief Set whether blocks should be cached for this Scan.This is true by
+   * default. When true, default settings of the table and family are used (this
+   * will never override caching blocks if the block cache is disabled for that
+   * family or entirely).
+   * @param cache_blocks - if false, default settings are overridden and blocks
+   * will not be cached
    */
   void SetCacheBlocks(bool cache_blocks);
 
@@ -157,18 +172,25 @@ class Scan {
   bool CacheBlocks() const;
 
   /**
-   * @brief Setting whether the caller wants to see the partial results that may be returned from the server. By default this value is false and the complete results will be assembled client side before being delivered to the caller.
+   * @brief Setting whether the caller wants to see the partial results that may
+   * be returned from the server. By default this value is false and the
+   * complete results will be assembled client side before being delivered to
+   * the caller.
    * @param allow_partial_results - if true partial results will be returned.
    */
   void SetAllowPartialResults(bool allow_partial_results);
 
   /**
-   * @brief true when the constructor of this scan understands that the results they will see may only represent a partial portion of a row. The entire row would be retrieved by subsequent calls to ResultScanner.next()
+   * @brief true when the constructor of this scan understands that the results
+   * they will see may only represent a partial portion of a row. The entire row
+   * would be retrieved by subsequent calls to ResultScanner.next()
    */
   bool AllowPartialResults() const;
 
   /**
-   * @brief Set the value indicating whether loading CFs on demand should be allowed (cluster default is false). On-demand CF loading doesn't load column families until necessary.
+   * @brief Set the value indicating whether loading CFs on demand should be
+   * allowed (cluster default is false). On-demand CF loading doesn't load
+   * column families until necessary.
    * @param load_column_families_on_demand
    */
   void SetLoadColumnFamiliesOnDemand(bool load_column_families_on_demand);
@@ -179,7 +201,8 @@ class Scan {
   bool LoadColumnFamiliesOnDemand() const;
 
   /**
-   * @brief Get up to the specified number of versions of each column if specified else get default i.e. one.
+   * @brief Get up to the specified number of versions of each column if
+   * specified else get default i.e. one.
    * @param max_versions - maximum versions for each column.
    */
   Scan &SetMaxVersions(uint32_t max_versions = 1);
@@ -190,7 +213,9 @@ class Scan {
   int MaxVersions() const;
 
   /**
-   * @brief Set the maximum result size. The default is -1; this means that no specific maximum result size will be set for this scan, and the global configured value will be used instead. (Defaults to unlimited).
+   * @brief Set the maximum result size. The default is -1; this means that no
+   * specific maximum result size will be set for this scan, and the global
+   * configured value will be used instead. (Defaults to unlimited).
    * @param The maximum result size in bytes.
    */
   void SetMaxResultSize(long max_result_size);
@@ -201,14 +226,20 @@ class Scan {
   long MaxResultSize() const;
 
   /**
-   * @brief Get versions of columns only within the specified timestamp range, [min_stamp, max_stamp). Note, default maximum versions to return is 1. If your time range spans more than one version and you want all versions returned, up the number of versions beyond the default.
+   * @brief Get versions of columns only within the specified timestamp range,
+   * [min_stamp, max_stamp). Note, default maximum versions to return is 1. If
+   * your time range spans more than one version and you want all versions
+   * returned, up the number of versions beyond the default.
    * @param min_stamp - minimum timestamp value, inclusive.
    * @param max_stamp - maximum timestamp value, exclusive.
    */
   Scan &SetTimeRange(long min_stamp, long max_stamp);
 
   /**
-   * @brief Get versions of columns with the specified timestamp. Note, default maximum versions to return is 1. If your time range spans more than one version and you want all versions returned, up the number of versions beyond the defaut.
+   * @brief Get versions of columns with the specified timestamp. Note, default
+   * maximum versions to return is 1. If your time range spans more than one
+   * version and you want all versions returned, up the number of versions
+   * beyond the defaut.
    * @param timestamp - version timestamp
    */
   Scan &SetTimeStamp(long timestamp);
@@ -216,7 +247,7 @@ class Scan {
   /**
    * @brief Return Timerange
    */
-  const TimeRange& Timerange() const;
+  const TimeRange &Timerange() const;
 
   /**
    * @brief Returns true if family map (FamilyMap) is non empty false otherwise
@@ -244,9 +275,11 @@ class Scan {
   FamilyMap family_map_;
 
   /**
-   * @brief Checks for row length validity, throws if length check fails, returns null otherwise.
+   * @brief Checks for row length validity, throws if length check fails,
+   * returns null otherwise.
    * @param row - row whose validity needs to be checked
-   * @throws std::runtime_error if row length equals 0 or greater than std::numeric_limits<short>::max();
+   * @throws std::runtime_error if row length equals 0 or greater than
+   * std::numeric_limits<short>::max();
    */
   void CheckRow(const std::string &row);
 };

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/time_range-test.cc
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/time_range-test.cc b/hbase-native-client/core/time_range-test.cc
index c08d52a..e066c57 100644
--- a/hbase-native-client/core/time_range-test.cc
+++ b/hbase-native-client/core/time_range-test.cc
@@ -19,13 +19,12 @@
 
 #include "core/time_range.h"
 
-#include <gtest/gtest.h>
 #include <glog/logging.h>
+#include <gtest/gtest.h>
 
 using namespace hbase;
 
-TEST (TimeRange, DefaultObject) {
-
+TEST(TimeRange, DefaultObject) {
   TimeRange *timerange_def = nullptr;
   ASSERT_NO_THROW(timerange_def = new TimeRange());
 
@@ -37,8 +36,7 @@ TEST (TimeRange, DefaultObject) {
   timerange_def = nullptr;
 }
 
-TEST (TimeRange, Exception) {
-
+TEST(TimeRange, Exception) {
   // Negative Min TS
   ASSERT_THROW(TimeRange(-1000, 2000), std::runtime_error);
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/time_range.cc
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/time_range.cc b/hbase-native-client/core/time_range.cc
index 9e6ed99..2accc9a 100644
--- a/hbase-native-client/core/time_range.cc
+++ b/hbase-native-client/core/time_range.cc
@@ -27,9 +27,7 @@ namespace hbase {
 TimeRange::TimeRange()
     : min_timestamp_(0L),
       max_timestamp_(std::numeric_limits<long>::max()),
-      all_time_(true) {
-
-}
+      all_time_(true) {}
 
 TimeRange::TimeRange(const TimeRange &tr) {
   this->all_time_ = tr.all_time_;
@@ -37,16 +35,14 @@ TimeRange::TimeRange(const TimeRange &tr) {
   this->min_timestamp_ = tr.min_timestamp_;
 }
 
-TimeRange &TimeRange::operator =(const TimeRange &tr) {
+TimeRange &TimeRange::operator=(const TimeRange &tr) {
   this->all_time_ = tr.all_time_;
   this->max_timestamp_ = tr.max_timestamp_;
   this->min_timestamp_ = tr.min_timestamp_;
   return *this;
 }
 
-TimeRange::~TimeRange() {
-
-}
+TimeRange::~TimeRange() {}
 
 TimeRange::TimeRange(long min_timestamp) {
   this->min_timestamp_ = min_timestamp;
@@ -56,16 +52,15 @@ TimeRange::TimeRange(long min_timestamp) {
 
 TimeRange::TimeRange(long min_timestamp, long max_timestamp) {
   if (min_timestamp < 0 || max_timestamp < 0) {
-    throw std::runtime_error(
-        "Timestamp cannot be negative. min_timestamp: "
-            + std::to_string(min_timestamp) + ", max_timestamp:"
-            + std::to_string(max_timestamp));
+    throw std::runtime_error("Timestamp cannot be negative. min_timestamp: " +
+                             std::to_string(min_timestamp) +
+                             ", max_timestamp:" +
+                             std::to_string(max_timestamp));
   }
   if (max_timestamp < min_timestamp) {
-    throw std::runtime_error(
-        "max_timestamp [" + std::to_string(max_timestamp)
-            + "] should be greater than min_timestamp ["
-            + std::to_string(min_timestamp) + "]");
+    throw std::runtime_error("max_timestamp [" + std::to_string(max_timestamp) +
+                             "] should be greater than min_timestamp [" +
+                             std::to_string(min_timestamp) + "]");
   }
 
   this->min_timestamp_ = min_timestamp;
@@ -73,16 +68,9 @@ TimeRange::TimeRange(long min_timestamp, long max_timestamp) {
   this->all_time_ = false;
 }
 
-long TimeRange::MinTimeStamp() const {
-  return this->min_timestamp_;
+long TimeRange::MinTimeStamp() const { return this->min_timestamp_; }
 
-}
-
-long TimeRange::MaxTimeStamp() const {
-  return this->max_timestamp_;
-}
+long TimeRange::MaxTimeStamp() const { return this->max_timestamp_; }
 
-bool TimeRange::IsAllTime() const {
-  return this->all_time_;
-}
+bool TimeRange::IsAllTime() const { return this->all_time_; }
 }

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/core/time_range.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/core/time_range.h b/hbase-native-client/core/time_range.h
index 5c07b4b..171f3ed 100644
--- a/hbase-native-client/core/time_range.h
+++ b/hbase-native-client/core/time_range.h
@@ -21,11 +21,10 @@
 
 namespace hbase {
 class TimeRange {
-
  public:
-
   /**
-   * @brief  Default constructor. Represents interval [0, Long.MAX_VALUE) (allTime)
+   * @brief  Default constructor. Represents interval [0, Long.MAX_VALUE)
+   * (allTime)
    */
   TimeRange();
   TimeRange(const TimeRange &tr);
@@ -39,7 +38,8 @@ class TimeRange {
    * @brief Represents interval [minStamp, maxStamp)
    * @param minStamp the minimum timestamp, inclusive
    * @param maxStamp the maximum timestamp, exclusive
-   * @throws std::runtime_error if min_timestamp < 0 or max_timestamp < 0 or max_timestamp < min_timestamp
+   * @throws std::runtime_error if min_timestamp < 0 or max_timestamp < 0 or
+   * max_timestamp < min_timestamp
    */
   TimeRange(long min_timestamp, long max_timestamp);
   long MinTimeStamp() const;

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/serde/BUCK
----------------------------------------------------------------------
diff --git a/hbase-native-client/serde/BUCK b/hbase-native-client/serde/BUCK
index db15026..b5aad3d 100644
--- a/hbase-native-client/serde/BUCK
+++ b/hbase-native-client/serde/BUCK
@@ -15,49 +15,54 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-cxx_library(name="serde",
-            exported_headers=[
-                "region-info.h",
-                "rpc.h",
-                "server-name.h",
-                "table-name.h",
-                "zk.h",
-            ],
-            srcs=[
-                "rpc.cc",
-                "zk.cc",
-            ],
-            deps=[
-                "//if:if",
-                "//third-party:folly",
-            ],
-            tests=[
-                ":client-deserializer-test",
-                ":client-serializer-test",
-                ":server-name-test",
-                ":table-name-test",
-                ":zk-deserializer-test",
-                ":region-info-deserializer-test",
-            ],
-            compiler_flags=['-Weffc++'],
-            visibility=[
-                'PUBLIC',
-            ], )
-cxx_test(name="table-name-test",
-         srcs=["table-name-test.cc", ],
-         deps=[":serde", ], )
-cxx_test(name="server-name-test",
-         srcs=["server-name-test.cc", ],
-         deps=[":serde", ], )
-cxx_test(name="client-serializer-test",
-         srcs=["client-serializer-test.cc", ],
-         deps=[":serde", ], )
-cxx_test(name="client-deserializer-test",
-         srcs=["client-deserializer-test.cc", ],
-         deps=[":serde", ], )
-cxx_test(name="zk-deserializer-test",
-         srcs=["zk-deserializer-test.cc", ],
-         deps=[":serde", ], )
-cxx_test(name="region-info-deserializer-test",
-         srcs=["region-info-deserializer-test.cc", ],
-         deps=[":serde", ], )
+cxx_library(
+    name="serde",
+    exported_headers=[
+        "region-info.h",
+        "rpc.h",
+        "server-name.h",
+        "table-name.h",
+        "zk.h",
+    ],
+    srcs=[
+        "rpc.cc",
+        "zk.cc",
+    ],
+    deps=[
+        "//if:if",
+        "//third-party:folly",
+    ],
+    tests=[
+        ":client-deserializer-test",
+        ":client-serializer-test",
+        ":server-name-test",
+        ":table-name-test",
+        ":zk-deserializer-test",
+        ":region-info-deserializer-test",
+    ],
+    compiler_flags=['-Weffc++'],
+    visibility=['PUBLIC',],)
+cxx_test(
+    name="table-name-test",
+    srcs=["table-name-test.cc",],
+    deps=[":serde",],)
+cxx_test(
+    name="server-name-test",
+    srcs=["server-name-test.cc",],
+    deps=[":serde",],)
+cxx_test(
+    name="client-serializer-test",
+    srcs=["client-serializer-test.cc",],
+    deps=[":serde",],)
+cxx_test(
+    name="client-deserializer-test",
+    srcs=["client-deserializer-test.cc",],
+    deps=[":serde",],)
+cxx_test(
+    name="zk-deserializer-test",
+    srcs=["zk-deserializer-test.cc",],
+    deps=[":serde",],)
+cxx_test(
+    name="region-info-deserializer-test",
+    srcs=["region-info-deserializer-test.cc",],
+    deps=[":serde",],)

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/serde/region-info.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/serde/region-info.h b/hbase-native-client/serde/region-info.h
index e2ecfc9..1b0a3fb 100644
--- a/hbase-native-client/serde/region-info.h
+++ b/hbase-native-client/serde/region-info.h
@@ -21,12 +21,13 @@
 
 #include "if/HBase.pb.h"
 
-#include <boost/algorithm/string/predicate.hpp>
 #include <folly/Conv.h>
+#include <boost/algorithm/string/predicate.hpp>
 
 namespace hbase {
 namespace pb {
-template <class String> void parseTo(String in, RegionInfo &out) {
+template <class String>
+void parseTo(String in, RegionInfo &out) {
   // TODO(eclark): there has to be something better.
   std::string s = folly::to<std::string>(in);
 
@@ -37,5 +38,5 @@ template <class String> void parseTo(String in, RegionInfo &out) {
     throw std::runtime_error("Bad protobuf for RegionInfo");
   }
 }
-} // namespace pb
-} // namespace hbase
+}  // namespace pb
+}  // namespace hbase

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/serde/rpc.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/serde/rpc.h b/hbase-native-client/serde/rpc.h
index b28b4a3..873d01c 100644
--- a/hbase-native-client/serde/rpc.h
+++ b/hbase-native-client/serde/rpc.h
@@ -40,7 +40,7 @@ namespace hbase {
  * It should throw exceptions if anything goes wrong.
  */
 class RpcSerde {
-public:
+ public:
   /**
    * Constructor assumes the default auth type.
    */
@@ -94,23 +94,23 @@ public:
    * - A protobuf var int32
    * - The message object seriailized after that.
    */
-  std::unique_ptr<folly::IOBuf>
-  SerializeDelimited(const google::protobuf::Message &msg);
+  std::unique_ptr<folly::IOBuf> SerializeDelimited(
+      const google::protobuf::Message &msg);
 
   /**
    * Serilalize a message. This does not add any length prepend.
    */
-  std::unique_ptr<folly::IOBuf>
-  SerializeMessage(const google::protobuf::Message &msg);
+  std::unique_ptr<folly::IOBuf> SerializeMessage(
+      const google::protobuf::Message &msg);
 
   /**
    * Prepend a length IOBuf to the given IOBuf chain.
    * This involves no copies or moves of the passed in data.
    */
-  std::unique_ptr<folly::IOBuf>
-  PrependLength(std::unique_ptr<folly::IOBuf> msg);
+  std::unique_ptr<folly::IOBuf> PrependLength(
+      std::unique_ptr<folly::IOBuf> msg);
 
-private:
+ private:
   /* data */
   uint8_t auth_type_;
 };

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/serde/server-name.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/serde/server-name.h b/hbase-native-client/serde/server-name.h
index 6551fdc..dda9bf2 100644
--- a/hbase-native-client/serde/server-name.h
+++ b/hbase-native-client/serde/server-name.h
@@ -19,14 +19,15 @@
 
 #pragma once
 
-#include "if/HBase.pb.h"
 #include <folly/Conv.h>
 #include <folly/String.h>
+#include "if/HBase.pb.h"
 
 namespace hbase {
 namespace pb {
 
-template <class String> void parseTo(String in, ServerName &out) {
+template <class String>
+void parseTo(String in, ServerName &out) {
   // TODO see about getting rsplit into folly.
   std::string s = folly::to<std::string>(in);
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/serde/table-name.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/serde/table-name.h b/hbase-native-client/serde/table-name.h
index c81e166..707ba44 100644
--- a/hbase-native-client/serde/table-name.h
+++ b/hbase-native-client/serde/table-name.h
@@ -21,15 +21,16 @@
 #include <memory>
 #include <string>
 
-#include "if/HBase.pb.h"
 #include <folly/Conv.h>
 #include <folly/String.h>
+#include "if/HBase.pb.h"
 
 namespace hbase {
 namespace pb {
 
 // Provide folly::to<std::string>(TableName);
-template <class String> void toAppend(const TableName &in, String *result) {
+template <class String>
+void toAppend(const TableName &in, String *result) {
   if (!in.has_namespace_() || in.namespace_() == "default") {
     folly::toAppend(in.qualifier(), result);
   } else {
@@ -37,7 +38,8 @@ template <class String> void toAppend(const TableName &in, String *result) {
   }
 }
 
-template <class String> void parseTo(String in, TableName &out) {
+template <class String>
+void parseTo(String in, TableName &out) {
   std::vector<std::string> v;
   folly::split(":", in, v);
 
@@ -50,5 +52,5 @@ template <class String> void parseTo(String in, TableName &out) {
   }
 }
 
-} // namespace pb
-} // namespace hbase
+}  // namespace pb
+}  // namespace hbase

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/serde/zk.cc
----------------------------------------------------------------------
diff --git a/hbase-native-client/serde/zk.cc b/hbase-native-client/serde/zk.cc
index 59871a5..63c96ed 100644
--- a/hbase-native-client/serde/zk.cc
+++ b/hbase-native-client/serde/zk.cc
@@ -32,7 +32,6 @@ using google::protobuf::Message;
 static const std::string MAGIC_STRING = "PBUF";
 
 bool ZkDeserializer::Parse(IOBuf *buf, Message *out) {
-
   // The format is like this
   // 1 byte of magic number. 255
   // 4 bytes of id length.

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/serde/zk.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/serde/zk.h b/hbase-native-client/serde/zk.h
index fa3de5b..5cadec2 100644
--- a/hbase-native-client/serde/zk.h
+++ b/hbase-native-client/serde/zk.h
@@ -35,7 +35,7 @@ namespace hbase {
  *
  */
 class ZkDeserializer {
-public:
+ public:
   /**
    * Merge the data from a buffer into a given message.
    *
@@ -46,4 +46,4 @@ public:
    */
   bool Parse(folly::IOBuf *buf, google::protobuf::Message *out);
 };
-} // namespace hbase
+}  // namespace hbase

http://git-wip-us.apache.org/repos/asf/hbase/blob/bd6e0b94/hbase-native-client/test-util/test-util.h
----------------------------------------------------------------------
diff --git a/hbase-native-client/test-util/test-util.h b/hbase-native-client/test-util/test-util.h
index 9050961..2fc9d69 100644
--- a/hbase-native-client/test-util/test-util.h
+++ b/hbase-native-client/test-util/test-util.h
@@ -29,7 +29,7 @@ namespace hbase {
  * @brief Class to deal with a local instance cluster for testing.
  */
 class TestUtil {
-public:
+ public:
   /**
    * Creating a TestUtil will spin up a cluster.
    */
@@ -55,7 +55,7 @@ public:
    */
   static std::string RandString(int len = 32);
 
-private:
+ private:
   folly::test::TemporaryDirectory temp_dir_;
 };
-} // namespace hbase
+}  // namespace hbase