You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@impala.apache.org by ta...@apache.org on 2016/07/14 19:05:01 UTC

[04/18] incubator-impala git commit: IMPALA-3442: Replace '> >' with '>>' in template decls

IMPALA-3442: Replace '> >' with '>>' in template decls

Change-Id: I9b27dfbda791ec6730c329c91bed015887a5e27c
Reviewed-on: http://gerrit.cloudera.org:8080/3562
Reviewed-by: Henry Robinson <he...@cloudera.com>
Tested-by: Henry Robinson <he...@cloudera.com>


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

Branch: refs/heads/master
Commit: 55b2a639e81e295a99927d5063adaf896985b29a
Parents: df2fc08
Author: Henry Robinson <he...@cloudera.com>
Authored: Mon May 2 21:03:17 2016 -0700
Committer: Taras Bobrovytsky <ta...@apache.org>
Committed: Thu Jul 14 19:04:44 2016 +0000

----------------------------------------------------------------------
 be/src/benchmarks/string-benchmark.cc                   |  2 +-
 be/src/codegen/llvm-codegen.h                           |  2 +-
 be/src/exec/analytic-eval-node.cc                       |  4 ++--
 be/src/exec/analytic-eval-node.h                        |  4 ++--
 be/src/exec/hdfs-parquet-table-writer.cc                |  2 +-
 be/src/exec/hdfs-scan-node.cc                           |  4 ++--
 be/src/exec/hdfs-scan-node.h                            |  6 +++---
 be/src/exec/hdfs-table-sink.h                           |  2 +-
 be/src/exec/incr-stats-util.cc                          |  4 ++--
 be/src/exec/incr-stats-util.h                           |  2 +-
 be/src/exec/topn-node.cc                                |  2 +-
 be/src/exec/topn-node.h                                 |  2 +-
 be/src/exec/union-node.cc                               |  4 ++--
 be/src/exec/union-node.h                                |  4 ++--
 be/src/experiments/data-provider.cc                     |  4 ++--
 be/src/exprs/aggregate-functions-test.cc                |  2 +-
 be/src/exprs/expr-test.cc                               |  6 +++---
 be/src/resourcebroker/resource-broker.h                 |  8 ++++----
 be/src/rpc/thrift-server.h                              |  2 +-
 be/src/runtime/buffered-block-mgr-test.cc               | 10 +++++-----
 be/src/runtime/buffered-block-mgr.h                     |  2 +-
 be/src/runtime/buffered-tuple-stream.h                  |  4 ++--
 be/src/runtime/client-cache.h                           |  4 ++--
 be/src/runtime/coordinator.h                            |  2 +-
 be/src/runtime/data-stream-mgr.h                        |  4 ++--
 be/src/runtime/data-stream-recvr.cc                     |  2 +-
 be/src/runtime/disk-io-mgr.h                            |  2 +-
 be/src/runtime/free-pool-test.cc                        |  3 +--
 be/src/runtime/mem-tracker.h                            |  2 +-
 be/src/runtime/multi-precision.h                        |  2 +-
 be/src/runtime/plan-fragment-executor.h                 |  2 +-
 be/src/runtime/row-batch-serialize-test.cc              |  8 ++++----
 be/src/runtime/sorter.cc                                |  2 +-
 be/src/runtime/test-env.h                               |  2 +-
 be/src/runtime/tmp-file-mgr-test.cc                     |  2 +-
 be/src/scheduling/query-schedule.h                      |  2 +-
 be/src/scheduling/simple-scheduler.cc                   |  4 ++--
 be/src/scheduling/simple-scheduler.h                    |  2 +-
 be/src/service/fragment-mgr.h                           |  2 +-
 be/src/service/hs2-util-test.cc                         |  2 +-
 be/src/service/impala-beeswax-server.cc                 |  2 +-
 be/src/service/impala-server.cc                         |  4 ++--
 be/src/service/impala-server.h                          | 12 ++++++------
 be/src/service/query-exec-state.h                       |  2 +-
 be/src/service/session-expiry-test.cc                   |  4 ++--
 be/src/statestore/statestore.h                          |  6 +++---
 be/src/testutil/impalad-query-executor.h                |  2 +-
 be/src/transport/TSaslServerTransport.cpp               |  2 +-
 be/src/transport/TSaslServerTransport.h                 |  2 +-
 be/src/udf/uda-test-harness-impl.h                      |  4 ++--
 be/src/util/blocking-queue-test.cc                      |  2 +-
 be/src/util/collection-metrics.h                        |  4 ++--
 be/src/util/debug-util.cc                               |  2 +-
 be/src/util/internal-queue-test.cc                      |  2 +-
 be/src/util/metrics-test.cc                             |  2 +-
 be/src/util/perf-counters.h                             |  2 +-
 be/src/util/runtime-profile.h                           |  4 ++--
 be/src/util/summary-util.cc                             |  6 +++---
 be/src/util/table-printer.h                             |  2 +-
 be/src/util/thread-pool.h                               |  4 ++--
 be/src/util/url-coding.cc                               |  2 +-
 .../com/cloudera/impala/catalog/HdfsPartitionTest.java  |  2 +-
 62 files changed, 102 insertions(+), 103 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/benchmarks/string-benchmark.cc
----------------------------------------------------------------------
diff --git a/be/src/benchmarks/string-benchmark.cc b/be/src/benchmarks/string-benchmark.cc
index 170f3dc..3970609 100644
--- a/be/src/benchmarks/string-benchmark.cc
+++ b/be/src/benchmarks/string-benchmark.cc
@@ -92,7 +92,7 @@ struct CompactStringValue {
 
 struct TestData {
   vector<StringValue> normal_strings;
-  vector<CompactStringValue<8> > compact_strings;
+  vector<CompactStringValue<8>> compact_strings;
   vector<int> random_order;
   uint32_t hash_normal;
   uint32_t hash_compact;

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/codegen/llvm-codegen.h
----------------------------------------------------------------------
diff --git a/be/src/codegen/llvm-codegen.h b/be/src/codegen/llvm-codegen.h
index 332e599..e84ea74 100644
--- a/be/src/codegen/llvm-codegen.h
+++ b/be/src/codegen/llvm-codegen.h
@@ -575,7 +575,7 @@ class LlvmCodeGen {
   std::set<std::string> linked_modules_;
 
   /// The vector of functions to automatically JIT compile after FinalizeModule().
-  std::vector<std::pair<llvm::Function*, void**> > fns_to_jit_compile_;
+  std::vector<std::pair<llvm::Function*, void**>> fns_to_jit_compile_;
 
   /// Debug strings that will be outputted by jitted code.  This is a copy of all
   /// strings passed to CodegenDebugTrace.

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/exec/analytic-eval-node.cc
----------------------------------------------------------------------
diff --git a/be/src/exec/analytic-eval-node.cc b/be/src/exec/analytic-eval-node.cc
index d9fa6c3..830fd18 100644
--- a/be/src/exec/analytic-eval-node.cc
+++ b/be/src/exec/analytic-eval-node.cc
@@ -306,7 +306,7 @@ string AnalyticEvalNode::DebugStateString(bool detailed = false) const {
      << " last_result_idx=" << last_result_idx_;
   if (detailed) {
     ss << " result_tuples idx: [";
-    for (list<pair<int64_t, Tuple*> >::const_iterator it = result_tuples_.begin();
+    for (list<pair<int64_t, Tuple*>>::const_iterator it = result_tuples_.begin();
         it != result_tuples_.end(); ++it) {
       ss << it->first;
       if (*it != result_tuples_.back()) ss << ", ";
@@ -314,7 +314,7 @@ string AnalyticEvalNode::DebugStateString(bool detailed = false) const {
     ss << "]";
     if (fn_scope_ == ROWS && window_.__isset.window_start) {
       ss << " window_tuples idx: [";
-      for (list<pair<int64_t, Tuple*> >::const_iterator it = window_tuples_.begin();
+      for (list<pair<int64_t, Tuple*>>::const_iterator it = window_tuples_.begin();
           it != window_tuples_.end(); ++it) {
         ss << it->first;
         if (*it != window_tuples_.back()) ss << ", ";

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/exec/analytic-eval-node.h
----------------------------------------------------------------------
diff --git a/be/src/exec/analytic-eval-node.h b/be/src/exec/analytic-eval-node.h
index 6f17dbd..720c065 100644
--- a/be/src/exec/analytic-eval-node.h
+++ b/be/src/exec/analytic-eval-node.h
@@ -268,7 +268,7 @@ class AnalyticEvalNode : public ExecNode {
   /// output row and result_tuples_.size() may be one less than the row batch size, in
   /// which case we will process another input row batch (inserting one result tuple per
   /// input row) before returning a row batch.
-  std::list<std::pair<int64_t, Tuple*> > result_tuples_;
+  std::list<std::pair<int64_t, Tuple*>> result_tuples_;
 
   /// Index in input_stream_ of the most recently added result tuple.
   int64_t last_result_idx_;
@@ -278,7 +278,7 @@ class AnalyticEvalNode : public ExecNode {
   /// or FOLLOWING. Tuples in this list are deep copied and owned by
   /// curr_window_tuple_pool_.
   /// TODO: Remove and use BufferedTupleStream (needs support for multiple readers).
-  std::list<std::pair<int64_t, Tuple*> > window_tuples_;
+  std::list<std::pair<int64_t, Tuple*>> window_tuples_;
 
   /// The index of the last row from input_stream_ associated with output row containing
   /// resources in prev_tuple_pool_. -1 when the pool is empty. Resources from

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/exec/hdfs-parquet-table-writer.cc
----------------------------------------------------------------------
diff --git a/be/src/exec/hdfs-parquet-table-writer.cc b/be/src/exec/hdfs-parquet-table-writer.cc
index 87e42fb..ce1bbb1 100644
--- a/be/src/exec/hdfs-parquet-table-writer.cc
+++ b/be/src/exec/hdfs-parquet-table-writer.cc
@@ -298,7 +298,7 @@ class HdfsParquetTableWriter::ColumnWriter :
   static const int DICTIONARY_DATA_PAGE_SIZE_CHECK_PERIOD = 100;
 
   // Encoder for dictionary encoding for different columns. Only one is set.
-  scoped_ptr<DictEncoder<T> > dict_encoder_;
+  scoped_ptr<DictEncoder<T>> dict_encoder_;
 
   // The number of values added since we last checked the dictionary.
   int num_values_since_dict_size_check_;

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/exec/hdfs-scan-node.cc
----------------------------------------------------------------------
diff --git a/be/src/exec/hdfs-scan-node.cc b/be/src/exec/hdfs-scan-node.cc
index 8e808cd..19a071f 100644
--- a/be/src/exec/hdfs-scan-node.cc
+++ b/be/src/exec/hdfs-scan-node.cc
@@ -141,9 +141,9 @@ Status HdfsScanNode::Init(const TPlanNode& tnode, RuntimeState* state) {
   RETURN_IF_ERROR(ExecNode::Init(tnode, state));
 
   // Add collection item conjuncts
-  const map<TTupleId, vector<TExpr> >& collection_conjuncts =
+  const map<TTupleId, vector<TExpr>>& collection_conjuncts =
       tnode.hdfs_scan_node.collection_conjuncts;
-  map<TTupleId, vector<TExpr> >::const_iterator iter = collection_conjuncts.begin();
+  map<TTupleId, vector<TExpr>>::const_iterator iter = collection_conjuncts.begin();
   for (; iter != collection_conjuncts.end(); ++iter) {
     DCHECK(conjuncts_map_[iter->first].empty());
     RETURN_IF_ERROR(

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/exec/hdfs-scan-node.h
----------------------------------------------------------------------
diff --git a/be/src/exec/hdfs-scan-node.h b/be/src/exec/hdfs-scan-node.h
index f0eb8e3..c611a45 100644
--- a/be/src/exec/hdfs-scan-node.h
+++ b/be/src/exec/hdfs-scan-node.h
@@ -164,7 +164,7 @@ class HdfsScanNode : public ScanNode {
 
   DiskIoRequestContext* reader_context() { return reader_context_; }
 
-  typedef std::map<TupleId, std::vector<ExprContext*> > ConjunctsMap;
+  typedef std::map<TupleId, std::vector<ExprContext*>> ConjunctsMap;
   const ConjunctsMap& conjuncts_map() const { return conjuncts_map_; }
 
   RuntimeProfile::HighWaterMarkCounter* max_compressed_text_file_length() {
@@ -284,7 +284,7 @@ class HdfsScanNode : public ScanNode {
   }
 
   /// map from volume id to <number of split, per volume split lengths>
-  typedef boost::unordered_map<int32_t, std::pair<int, int64_t> > PerVolumnStats;
+  typedef boost::unordered_map<int32_t, std::pair<int, int64_t>> PerVolumnStats;
 
   /// Update the per volume stats with the given scan range params list
   static void UpdateHdfsSplitStats(
@@ -352,7 +352,7 @@ class HdfsScanNode : public ScanNode {
   FileDescMap file_descs_;
 
   /// File format => file descriptors.
-  typedef std::map<THdfsFileFormat::type, std::vector<HdfsFileDesc*> > FileFormatsMap;
+  typedef std::map<THdfsFileFormat::type, std::vector<HdfsFileDesc*>> FileFormatsMap;
   FileFormatsMap per_type_files_;
 
   /// Conjuncts for each materialized tuple (top-level row batch tuples and collection

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/exec/hdfs-table-sink.h
----------------------------------------------------------------------
diff --git a/be/src/exec/hdfs-table-sink.h b/be/src/exec/hdfs-table-sink.h
index 99dcc89..c5bdcc4 100644
--- a/be/src/exec/hdfs-table-sink.h
+++ b/be/src/exec/hdfs-table-sink.h
@@ -179,7 +179,7 @@ class HdfsTableSink : public DataSink {
   /// dynamic_partition_key_exprs_ generated by GetHashTblKey().
   /// Maps to an OutputPartition, which are owned by the object pool and
   /// a vector of rows to insert into this partition from the current row batch.
-  typedef std::pair<OutputPartition*, std::vector<int32_t> > PartitionPair;
+  typedef std::pair<OutputPartition*, std::vector<int32_t>> PartitionPair;
   typedef boost::unordered_map<std::string, PartitionPair> PartitionMap;
 
 

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/exec/incr-stats-util.cc
----------------------------------------------------------------------
diff --git a/be/src/exec/incr-stats-util.cc b/be/src/exec/incr-stats-util.cc
index d83144f..3f1d026 100644
--- a/be/src/exec/incr-stats-util.cc
+++ b/be/src/exec/incr-stats-util.cc
@@ -188,7 +188,7 @@ namespace impala {
 
 void FinalizePartitionedColumnStats(const TTableSchema& col_stats_schema,
     const vector<TPartitionStats>& existing_part_stats,
-    const vector<vector<string> >& expected_partitions, const TRowSet& rowset,
+    const vector<vector<string>>& expected_partitions, const TRowSet& rowset,
     int32_t num_partition_cols, TAlterTableUpdateStatsParams* params) {
   // The rowset should have the following schema: for every column in the source table,
   // five columns are produced, one row per partition.
@@ -197,7 +197,7 @@ void FinalizePartitionedColumnStats(const TTableSchema& col_stats_schema,
 
   const int num_cols =
       (col_stats_schema.columns.size() - num_partition_cols) / COLUMNS_PER_STAT;
-  unordered_set<vector<string> > seen_partitions;
+  unordered_set<vector<string>> seen_partitions;
   vector<PerColumnStats> stats(num_cols);
 
   if (rowset.rows.size() > 0) {

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/exec/incr-stats-util.h
----------------------------------------------------------------------
diff --git a/be/src/exec/incr-stats-util.h b/be/src/exec/incr-stats-util.h
index 9861e10..194f7b2 100644
--- a/be/src/exec/incr-stats-util.h
+++ b/be/src/exec/incr-stats-util.h
@@ -27,7 +27,7 @@ namespace impala {
 void FinalizePartitionedColumnStats(
     const apache::hive::service::cli::thrift::TTableSchema& col_stats_schema,
     const std::vector<TPartitionStats>& existing_part_stats,
-    const std::vector<std::vector<std::string> >& expected_partitions,
+    const std::vector<std::vector<std::string>>& expected_partitions,
     const apache::hive::service::cli::thrift::TRowSet& rowset,
     int32_t num_partition_cols, TAlterTableUpdateStatsParams* params);
 }

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/exec/topn-node.cc
----------------------------------------------------------------------
diff --git a/be/src/exec/topn-node.cc b/be/src/exec/topn-node.cc
index a2b8e06..e638e36 100644
--- a/be/src/exec/topn-node.cc
+++ b/be/src/exec/topn-node.cc
@@ -113,7 +113,7 @@ Status TopNNode::Prepare(RuntimeState* state) {
   }
   AddCodegenExecOption(codegen_enabled, codegen_status);
   priority_queue_.reset(new priority_queue<Tuple*, vector<Tuple*>,
-      ComparatorWrapper<TupleRowComparator> >(*tuple_row_less_than_));
+      ComparatorWrapper<TupleRowComparator>>(*tuple_row_less_than_));
   materialized_tuple_desc_ = row_descriptor_.tuple_descriptors()[0];
   insert_batch_timer_ = ADD_TIMER(runtime_profile(), "InsertBatchTime");
   return Status::OK();

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/exec/topn-node.h
----------------------------------------------------------------------
diff --git a/be/src/exec/topn-node.h b/be/src/exec/topn-node.h
index 29c89e0..3a521e2 100644
--- a/be/src/exec/topn-node.h
+++ b/be/src/exec/topn-node.h
@@ -113,7 +113,7 @@ class TopNNode : public ExecNode {
   /// the order of the queue is the opposite of what the ORDER BY clause specifies, such
   /// that the top of the queue is the last sorted element.
   boost::scoped_ptr<std::priority_queue<Tuple*, std::vector<Tuple*>,
-      ComparatorWrapper<TupleRowComparator> > > priority_queue_;
+      ComparatorWrapper<TupleRowComparator>>> priority_queue_;
 
   /// END: Members that must be Reset()
   /////////////////////////////////////////

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/exec/union-node.cc
----------------------------------------------------------------------
diff --git a/be/src/exec/union-node.cc b/be/src/exec/union-node.cc
index 2e4cbf5..17ae0de 100644
--- a/be/src/exec/union-node.cc
+++ b/be/src/exec/union-node.cc
@@ -42,14 +42,14 @@ Status UnionNode::Init(const TPlanNode& tnode, RuntimeState* state) {
   RETURN_IF_ERROR(ExecNode::Init(tnode, state));
   DCHECK(tnode.__isset.union_node);
   // Create const_expr_ctx_lists_ from thrift exprs.
-  const vector<vector<TExpr> >& const_texpr_lists = tnode.union_node.const_expr_lists;
+  const vector<vector<TExpr>>& const_texpr_lists = tnode.union_node.const_expr_lists;
   for (int i = 0; i < const_texpr_lists.size(); ++i) {
     vector<ExprContext*> ctxs;
     RETURN_IF_ERROR(Expr::CreateExprTrees(pool_, const_texpr_lists[i], &ctxs));
     const_result_expr_ctx_lists_.push_back(ctxs);
   }
   // Create result_expr_ctx_lists_ from thrift exprs.
-  const vector<vector<TExpr> >& result_texpr_lists = tnode.union_node.result_expr_lists;
+  const vector<vector<TExpr>>& result_texpr_lists = tnode.union_node.result_expr_lists;
   for (int i = 0; i < result_texpr_lists.size(); ++i) {
     vector<ExprContext*> ctxs;
     RETURN_IF_ERROR(Expr::CreateExprTrees(pool_, result_texpr_lists[i], &ctxs));

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/exec/union-node.h
----------------------------------------------------------------------
diff --git a/be/src/exec/union-node.h b/be/src/exec/union-node.h
index b874739..9f24d03 100644
--- a/be/src/exec/union-node.h
+++ b/be/src/exec/union-node.h
@@ -51,10 +51,10 @@ class UnionNode : public ExecNode {
   const TupleDescriptor* tuple_desc_;
 
   /// Const exprs materialized by this node. These exprs don't refer to any children.
-  std::vector<std::vector<ExprContext*> > const_result_expr_ctx_lists_;
+  std::vector<std::vector<ExprContext*>> const_result_expr_ctx_lists_;
 
   /// Exprs materialized by this node. The i-th result expr list refers to the i-th child.
-  std::vector<std::vector<ExprContext*> > result_expr_ctx_lists_;
+  std::vector<std::vector<ExprContext*>> result_expr_ctx_lists_;
 
   /////////////////////////////////////////
   /// BEGIN: Members that must be Reset()

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/experiments/data-provider.cc
----------------------------------------------------------------------
diff --git a/be/src/experiments/data-provider.cc b/be/src/experiments/data-provider.cc
index fa98b80..f50a2e1 100644
--- a/be/src/experiments/data-provider.cc
+++ b/be/src/experiments/data-provider.cc
@@ -47,7 +47,7 @@ void DataProvider::SetSeed(int seed) {
 
 void RandString(MemPool* pool, StringValue* result,
     const StringValue& min, const StringValue& max, double r,
-    variate_generator<minstd_rand&, uniform_real<> >& rand) {
+    variate_generator<minstd_rand&, uniform_real<>>& rand) {
   int min_len = min.len;
   int max_len = max.len;
   int len = r * (max_len - min_len) + min_len;
@@ -69,7 +69,7 @@ void* DataProvider::NextBatch(int* rows_returned) {
   COUNTER_ADD(bytes_generated_, num_rows * row_size_);
 
   uniform_real<> dist(0,1);
-  variate_generator<minstd_rand&, uniform_real<> > rand_double(rand_generator_, dist);
+  variate_generator<minstd_rand&, uniform_real<>> rand_double(rand_generator_, dist);
 
   char* data = data_.get();
   for (int i = 0, row_idx = rows_returned_; i < num_rows; ++i, ++row_idx) {

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/exprs/aggregate-functions-test.cc
----------------------------------------------------------------------
diff --git a/be/src/exprs/aggregate-functions-test.cc b/be/src/exprs/aggregate-functions-test.cc
index 4c1bed3..1265e01 100644
--- a/be/src/exprs/aggregate-functions-test.cc
+++ b/be/src/exprs/aggregate-functions-test.cc
@@ -50,7 +50,7 @@ bool CheckHistogramDistribution(const StringVal& actual,
   vector<string> str_vals;
   split(str_vals, result, is_any_of(","));
 
-  accumulator_set<int, stats<tag::variance> > acc;
+  accumulator_set<int, stats<tag::variance>> acc;
   int prev_val = -1;
   for (string& s: str_vals) {
     trim(s);

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/exprs/expr-test.cc
----------------------------------------------------------------------
diff --git a/be/src/exprs/expr-test.cc b/be/src/exprs/expr-test.cc
index 4147093..ce8149e 100644
--- a/be/src/exprs/expr-test.cc
+++ b/be/src/exprs/expr-test.cc
@@ -4795,7 +4795,7 @@ TEST_F(ExprTest, ConditionalFunctionIsNotFalse) {
 //   - expected_offsets: mapping of byte sizes to a set valid offsets
 //     exprs that have the same byte size can end up in a number of locations
 void ValidateLayout(const vector<Expr*>& exprs, int expected_byte_size,
-    int expected_var_begin, const map<int, set<int> >& expected_offsets) {
+    int expected_var_begin, const map<int, set<int>>& expected_offsets) {
 
   vector<int> offsets;
   set<int> offsets_found;
@@ -4809,7 +4809,7 @@ void ValidateLayout(const vector<Expr*>& exprs, int expected_byte_size,
   // Walk the computed offsets and make sure the resulting sets match expected_offsets
   for (int i = 0; i < exprs.size(); ++i) {
     int expr_byte_size = exprs[i]->type().GetByteSize();
-    map<int, set<int> >::const_iterator iter = expected_offsets.find(expr_byte_size);
+    map<int, set<int>>::const_iterator iter = expected_offsets.find(expr_byte_size);
     EXPECT_TRUE(iter != expected_offsets.end());
 
     const set<int>& possible_offsets = iter->second;
@@ -4827,7 +4827,7 @@ TEST_F(ExprTest, ResultsLayoutTest) {
   ObjectPool pool;
 
   vector<Expr*> exprs;
-  map<int, set<int> > expected_offsets;
+  map<int, set<int>> expected_offsets;
 
   // Test empty exprs
   ValidateLayout(exprs, 0, -1, expected_offsets);

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/resourcebroker/resource-broker.h
----------------------------------------------------------------------
diff --git a/be/src/resourcebroker/resource-broker.h b/be/src/resourcebroker/resource-broker.h
index 0857c1e..e4c5a25 100644
--- a/be/src/resourcebroker/resource-broker.h
+++ b/be/src/resourcebroker/resource-broker.h
@@ -262,7 +262,7 @@ class ResourceBroker {
   boost::scoped_ptr<ThriftServer> llama_callback_server_;
 
   /// Cache of Llama client connections.
-  boost::scoped_ptr<ClientCache<llama::LlamaAMServiceClient> > llama_client_cache_;
+  boost::scoped_ptr<ClientCache<llama::LlamaAMServiceClient>> llama_client_cache_;
 
   /// Lock to ensure that only a single registration with Llama is sent, e.g.,
   /// when multiple concurrent requests realize that Llama has restarted.
@@ -352,7 +352,7 @@ class ResourceBroker {
 
   /// Map from reservation IDs to pending expansion IDs. All pending request IDs have a
   /// PendingRequest in pending_requests_.
-  typedef boost::unordered_map<llama::TUniqueId, boost::unordered_set<llama::TUniqueId> >
+  typedef boost::unordered_map<llama::TUniqueId, boost::unordered_set<llama::TUniqueId>>
       PendingExpansionIdsMap;
   PendingExpansionIdsMap pending_expansion_ids_;
 
@@ -390,13 +390,13 @@ class ResourceBroker {
   /// Map from reservation ID to all satisfied requests - reservation and expansion -
   /// associated with that reservation. Used only for bookkeeping so that Impala can report
   /// on the current resource usage.
-  typedef boost::unordered_map<llama::TUniqueId, std::vector<AllocatedRequest> >
+  typedef boost::unordered_map<llama::TUniqueId, std::vector<AllocatedRequest>>
       AllocatedRequestMap;
   AllocatedRequestMap allocated_requests_;
 
   /// Protects query_resource_mgrs_
   boost::mutex query_resource_mgrs_lock_;
-  typedef boost::unordered_map<TUniqueId, std::pair<int32_t, QueryResourceMgr*> >
+  typedef boost::unordered_map<TUniqueId, std::pair<int32_t, QueryResourceMgr*>>
       QueryResourceMgrsMap;
 
   /// Map from query ID to a (ref_count, QueryResourceMgr*) pair, i.e. one QueryResourceMgr

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/rpc/thrift-server.h
----------------------------------------------------------------------
diff --git a/be/src/rpc/thrift-server.h b/be/src/rpc/thrift-server.h
index 1fd1121..bd51070 100644
--- a/be/src/rpc/thrift-server.h
+++ b/be/src/rpc/thrift-server.h
@@ -204,7 +204,7 @@ class ThriftServer {
 
   /// Map of active connection context to a shared_ptr containing that context; when an
   /// item is removed from the map, it is automatically freed.
-  typedef boost::unordered_map<ConnectionContext*, boost::shared_ptr<ConnectionContext> >
+  typedef boost::unordered_map<ConnectionContext*, boost::shared_ptr<ConnectionContext>>
       ConnectionContextSet;
   ConnectionContextSet connection_contexts_;
 

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/runtime/buffered-block-mgr-test.cc
----------------------------------------------------------------------
diff --git a/be/src/runtime/buffered-block-mgr-test.cc b/be/src/runtime/buffered-block-mgr-test.cc
index 04630fb..90a63d6 100644
--- a/be/src/runtime/buffered-block-mgr-test.cc
+++ b/be/src/runtime/buffered-block-mgr-test.cc
@@ -222,7 +222,7 @@ class BufferedBlockMgrTest : public ::testing::Test {
     }
   }
 
-  void DeleteBlocks(const vector<pair<BufferedBlockMgr::Block*, int32_t> >& blocks) {
+  void DeleteBlocks(const vector<pair<BufferedBlockMgr::Block*, int32_t>>& blocks) {
     for (int i = 0; i < blocks.size(); ++i) {
       blocks[i].first->Delete();
     }
@@ -385,9 +385,9 @@ class BufferedBlockMgrTest : public ::testing::Test {
     const int iters_before_close = num_iterations - 5000;
     bool close_called = false;
     unordered_map<BufferedBlockMgr::Block*, int> pinned_block_map;
-    vector<pair<BufferedBlockMgr::Block*, int32_t> > pinned_blocks;
+    vector<pair<BufferedBlockMgr::Block*, int32_t>> pinned_blocks;
     unordered_map<BufferedBlockMgr::Block*, int> unpinned_block_map;
-    vector<pair<BufferedBlockMgr::Block*, int32_t> > unpinned_blocks;
+    vector<pair<BufferedBlockMgr::Block*, int32_t>> unpinned_blocks;
 
     typedef enum { Pin, New, Unpin, Delete, Close } ApiFunction;
     ApiFunction api_function;
@@ -990,7 +990,7 @@ TEST_F(BufferedBlockMgrTest, DISABLED_WriteErrorBlacklist) {
       client_tracker_.get(), &block_mgrs, &clients);
 
   // Allocate files for all 2x2 combinations by unpinning blocks.
-  vector<vector<BufferedBlockMgr::Block*> > blocks;
+  vector<vector<BufferedBlockMgr::Block*>> blocks;
   vector<BufferedBlockMgr::Block*> all_blocks;
   for (int i = 0; i < NUM_BLOCK_MGRS; ++i) {
     vector<BufferedBlockMgr::Block*> mgr_blocks;
@@ -1073,7 +1073,7 @@ TEST_F(BufferedBlockMgrTest, AllocationErrorHandling) {
       false, client_tracker_.get(), &block_mgrs, &clients);
 
   // Allocate files for all 2x2 combinations by unpinning blocks.
-  vector<vector<BufferedBlockMgr::Block*> > blocks;
+  vector<vector<BufferedBlockMgr::Block*>> blocks;
   for (int i = 0; i < num_block_mgrs; ++i) {
     vector<BufferedBlockMgr::Block*> mgr_blocks;
     LOG(INFO) << "Iter " << i;

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/runtime/buffered-block-mgr.h
----------------------------------------------------------------------
diff --git a/be/src/runtime/buffered-block-mgr.h b/be/src/runtime/buffered-block-mgr.h
index 78fdb37..416751e 100644
--- a/be/src/runtime/buffered-block-mgr.h
+++ b/be/src/runtime/buffered-block-mgr.h
@@ -637,7 +637,7 @@ class BufferedBlockMgr {
   /// map contains only weak ptrs. BufferedBlockMgrs that are handed out are shared ptrs.
   /// When all the shared ptrs are no longer referenced, the BufferedBlockMgr
   /// d'tor will be called at which point the weak ptr will be removed from the map.
-  typedef boost::unordered_map<TUniqueId, boost::weak_ptr<BufferedBlockMgr> >
+  typedef boost::unordered_map<TUniqueId, boost::weak_ptr<BufferedBlockMgr>>
       BlockMgrsMap;
   static BlockMgrsMap query_to_block_mgrs_;
 

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/runtime/buffered-tuple-stream.h
----------------------------------------------------------------------
diff --git a/be/src/runtime/buffered-tuple-stream.h b/be/src/runtime/buffered-tuple-stream.h
index 23c09a9..9238b50 100644
--- a/be/src/runtime/buffered-tuple-stream.h
+++ b/be/src/runtime/buffered-tuple-stream.h
@@ -358,11 +358,11 @@ class BufferedTupleStream {
 
   /// Vectors of all the strings slots that have their varlen data stored in stream
   /// grouped by tuple_idx.
-  std::vector<std::pair<int, std::vector<SlotDescriptor*> > > inlined_string_slots_;
+  std::vector<std::pair<int, std::vector<SlotDescriptor*>>> inlined_string_slots_;
 
   /// Vectors of all the collection slots that have their varlen data stored in the
   /// stream, grouped by tuple_idx.
-  std::vector<std::pair<int, std::vector<SlotDescriptor*> > > inlined_coll_slots_;
+  std::vector<std::pair<int, std::vector<SlotDescriptor*>>> inlined_coll_slots_;
 
   /// Block manager and client used to allocate, pin and release blocks. Not owned.
   BufferedBlockMgr* block_mgr_;

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/runtime/client-cache.h
----------------------------------------------------------------------
diff --git a/be/src/runtime/client-cache.h b/be/src/runtime/client-cache.h
index ff38286..350bdd6 100644
--- a/be/src/runtime/client-cache.h
+++ b/be/src/runtime/client-cache.h
@@ -144,7 +144,7 @@ class ClientCacheHelper {
   /// client_map_ for that host. The value type is wrapped in a shared_ptr so that the copy
   /// c'tor for PerHostCache is not required.
   typedef boost::unordered_map<
-      TNetworkAddress, boost::shared_ptr<PerHostCache> > PerHostCacheMap;
+      TNetworkAddress, boost::shared_ptr<PerHostCache>> PerHostCacheMap;
   PerHostCacheMap per_host_caches_;
 
   /// Protects client_map_.
@@ -154,7 +154,7 @@ class ClientCacheHelper {
   /// all the clients are actually stored, and client instances are owned by this class and
   /// persist for exactly as long as they are present in this map.
   /// We use a map (vs. unordered_map) so we get iterator consistency across operations.
-  typedef std::map<ClientKey, boost::shared_ptr<ThriftClientImpl> > ClientMap;
+  typedef std::map<ClientKey, boost::shared_ptr<ThriftClientImpl>> ClientMap;
   ClientMap client_map_;
 
   /// Number of attempts to make to open a connection. 0 means retry indefinitely.

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/runtime/coordinator.h
----------------------------------------------------------------------
diff --git a/be/src/runtime/coordinator.h b/be/src/runtime/coordinator.h
index b4eab0e..9994e1e 100644
--- a/be/src/runtime/coordinator.h
+++ b/be/src/runtime/coordinator.h
@@ -531,7 +531,7 @@ class Coordinator {
   /// permissions of the path. The PermissionCache argument is also used to cache the
   /// output across repeated calls, to avoid repeatedly calling hdfsGetPathInfo() on the
   /// same path.
-  typedef boost::unordered_map<std::string, std::pair<bool, short> > PermissionCache;
+  typedef boost::unordered_map<std::string, std::pair<bool, short>> PermissionCache;
   void PopulatePathPermissionCache(hdfsFS fs, const std::string& path_str,
       PermissionCache* permissions_cache);
 

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/runtime/data-stream-mgr.h
----------------------------------------------------------------------
diff --git a/be/src/runtime/data-stream-mgr.h b/be/src/runtime/data-stream-mgr.h
index 21f8336..2b2b253 100644
--- a/be/src/runtime/data-stream-mgr.h
+++ b/be/src/runtime/data-stream-mgr.h
@@ -122,7 +122,7 @@ class DataStreamMgr {
   /// we don't want to create a map<pair<TUniqueId, PlanNodeId>, DataStreamRecvr*>,
   /// because that requires a bunch of copying of ids for lookup
   typedef boost::unordered_multimap<uint32_t,
-      boost::shared_ptr<DataStreamRecvr> > RecvrMap;
+      boost::shared_ptr<DataStreamRecvr>> RecvrMap;
   RecvrMap receiver_map_;
 
   /// (Fragment instance id, Plan node id) pair that uniquely identifies a stream.
@@ -182,7 +182,7 @@ class DataStreamMgr {
   inline uint32_t GetHashValue(const TUniqueId& fragment_instance_id, PlanNodeId node_id);
 
   /// The coordination primitive used to signal the arrival of a waited-for receiver
-  typedef Promise<boost::shared_ptr<DataStreamRecvr> > RendezvousPromise;
+  typedef Promise<boost::shared_ptr<DataStreamRecvr>> RendezvousPromise;
 
   /// A reference-counted promise-wrapper used to coordinate between senders and
   /// receivers. The ref_count field tracks the number of senders waiting for the arrival

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/runtime/data-stream-recvr.cc
----------------------------------------------------------------------
diff --git a/be/src/runtime/data-stream-recvr.cc b/be/src/runtime/data-stream-recvr.cc
index 83decea..f5db5c8 100644
--- a/be/src/runtime/data-stream-recvr.cc
+++ b/be/src/runtime/data-stream-recvr.cc
@@ -87,7 +87,7 @@ class DataStreamRecvr::SenderQueue {
 
   // queue of (batch length, batch) pairs.  The SenderQueue block owns memory to
   // these batches. They are handed off to the caller via GetBatch.
-  typedef list<pair<int, RowBatch*> > RowBatchQueue;
+  typedef list<pair<int, RowBatch*>> RowBatchQueue;
   RowBatchQueue batch_queue_;
 
   // The batch that was most recently returned via GetBatch(), i.e. the current batch

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/runtime/disk-io-mgr.h
----------------------------------------------------------------------
diff --git a/be/src/runtime/disk-io-mgr.h b/be/src/runtime/disk-io-mgr.h
index 79902c5..9eb663c 100644
--- a/be/src/runtime/disk-io-mgr.h
+++ b/be/src/runtime/disk-io-mgr.h
@@ -733,7 +733,7 @@ class DiskIoMgr {
   ///  free_buffers_[10] => list of free buffers with size 1 MB
   ///  free_buffers_[13] => list of free buffers with size 8 MB
   ///  free_buffers_[n]  => list of free buffers with size 2^n * 1024 B
-  std::vector<std::list<char*> > free_buffers_;
+  std::vector<std::list<char*>> free_buffers_;
 
   /// List of free buffer desc objects that can be handed out to clients
   std::list<BufferDescriptor*> free_buffer_descs_;

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/runtime/free-pool-test.cc
----------------------------------------------------------------------
diff --git a/be/src/runtime/free-pool-test.cc b/be/src/runtime/free-pool-test.cc
index c8ff93d..9e3c218 100644
--- a/be/src/runtime/free-pool-test.cc
+++ b/be/src/runtime/free-pool-test.cc
@@ -112,7 +112,7 @@ TEST(FreePoolTest, Loop) {
   MemPool mem_pool(&tracker);
   FreePool pool(&mem_pool);
 
-  map<int64_t, pair<uint8_t*, uint8_t*> > primed_allocations;
+  map<int64_t, pair<uint8_t*, uint8_t*>> primed_allocations;
   vector<int64_t> allocation_sizes;
 
   int64_t expected_pool_size = 0;
@@ -193,4 +193,3 @@ int main(int argc, char **argv) {
   ::testing::InitGoogleTest(&argc, argv);
   return RUN_ALL_TESTS();
 }
-

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/runtime/mem-tracker.h
----------------------------------------------------------------------
diff --git a/be/src/runtime/mem-tracker.h b/be/src/runtime/mem-tracker.h
index 73c9300..7700b06 100644
--- a/be/src/runtime/mem-tracker.h
+++ b/be/src/runtime/mem-tracker.h
@@ -408,7 +408,7 @@ class MemTracker {
   /// contains only weak ptrs.  MemTrackers that are handed out via GetQueryMemTracker()
   /// are shared ptrs.  When all the shared ptrs are no longer referenced, the MemTracker
   /// d'tor will be called at which point the weak ptr will be removed from the map.
-  typedef boost::unordered_map<TUniqueId, boost::weak_ptr<MemTracker> >
+  typedef boost::unordered_map<TUniqueId, boost::weak_ptr<MemTracker>>
   RequestTrackersMap;
   static RequestTrackersMap request_to_mem_trackers_;
 

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/runtime/multi-precision.h
----------------------------------------------------------------------
diff --git a/be/src/runtime/multi-precision.h b/be/src/runtime/multi-precision.h
index 0a82077..2e4b803 100644
--- a/be/src/runtime/multi-precision.h
+++ b/be/src/runtime/multi-precision.h
@@ -54,7 +54,7 @@ typedef __int128_t int128_t;
 typedef boost::multiprecision::number<
     boost::multiprecision::cpp_int_backend<256, 256,
     boost::multiprecision::signed_magnitude,
-    boost::multiprecision::unchecked, void> > int256_t;
+    boost::multiprecision::unchecked, void>> int256_t;
 
 /// There is no implicit assignment from int128_t to int256_t (or in general, the boost
 /// multi precision types and __int128_t).

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/runtime/plan-fragment-executor.h
----------------------------------------------------------------------
diff --git a/be/src/runtime/plan-fragment-executor.h b/be/src/runtime/plan-fragment-executor.h
index 082442e..9511a3e 100644
--- a/be/src/runtime/plan-fragment-executor.h
+++ b/be/src/runtime/plan-fragment-executor.h
@@ -242,7 +242,7 @@ class PlanFragmentExecutor {
   ObjectPool* obj_pool() { return runtime_state_->obj_pool(); }
 
   /// typedef for TPlanFragmentInstanceCtx.per_node_scan_ranges
-  typedef std::map<TPlanNodeId, std::vector<TScanRangeParams> > PerNodeScanRanges;
+  typedef std::map<TPlanNodeId, std::vector<TScanRangeParams>> PerNodeScanRanges;
 
   /// Main loop of profile reporting thread.
   /// Exits when notified on done_cv_.

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/runtime/row-batch-serialize-test.cc
----------------------------------------------------------------------
diff --git a/be/src/runtime/row-batch-serialize-test.cc b/be/src/runtime/row-batch-serialize-test.cc
index 1f28440..a00efa4 100644
--- a/be/src/runtime/row-batch-serialize-test.cc
+++ b/be/src/runtime/row-batch-serialize-test.cc
@@ -244,7 +244,7 @@ class RowBatchSerializeTest : public testing::Test {
   // Create a row batch from preconstructed tuples. Each tuple instance for tuple i
   // is consecutively repeated repeats[i] times. The tuple instances are used in the
   // order provided, starting at the beginning once all are used.
-  void AddTuplesToRowBatch(int num_rows, const vector<vector<Tuple*> >& tuples,
+  void AddTuplesToRowBatch(int num_rows, const vector<vector<Tuple*>>& tuples,
       const vector<int>& repeats, RowBatch* batch) {
     int tuples_per_row = batch->row_desc().tuple_descriptors().size();
     ASSERT_EQ(tuples_per_row, tuples.size());
@@ -268,7 +268,7 @@ class RowBatchSerializeTest : public testing::Test {
   // Helper to build a row batch with only one tuple per row.
   void AddTuplesToRowBatch(int num_rows, const vector<Tuple*>& tuples, int repeats,
       RowBatch* batch) {
-    vector<vector<Tuple*> > tmp_tuples(1, tuples);
+    vector<vector<Tuple*>> tmp_tuples(1, tuples);
     vector<int> tmp_repeats(1, repeats);
     AddTuplesToRowBatch(num_rows, tmp_tuples, tmp_repeats, batch);
   }
@@ -435,7 +435,7 @@ void RowBatchSerializeTest::TestDupCorrectness(bool full_dedup) {
   // All string dups are consecutive
   repeats.push_back(num_rows / distinct_string_tuples + 1);
   RowBatch* batch = pool_.Add(new RowBatch(row_desc, num_rows, tracker_.get()));
-  vector<vector<Tuple*> > distinct_tuples(2);
+  vector<vector<Tuple*>> distinct_tuples(2);
   CreateTuples(*row_desc.tuple_descriptors()[0], batch->tuple_data_pool(),
       distinct_int_tuples, 0, 10, &distinct_tuples[0]);
   CreateTuples(*row_desc.tuple_descriptors()[1], batch->tuple_data_pool(),
@@ -571,7 +571,7 @@ TEST_F(RowBatchSerializeTest, DedupPathologicalFull) {
   string huge_string;
   LOG(INFO) << "Try to resize to " << huge_string_size;
   huge_string.resize(huge_string_size, 'z');
-  vector<vector<Tuple*> > tuples(num_tuples);
+  vector<vector<Tuple*>> tuples(num_tuples);
   vector<int> repeats(num_tuples, 1); // Don't repeat tuples adjacently
   int64_t total_byte_size = 0;
   RowBatch* batch = pool_.Add(new RowBatch(row_desc, num_rows, tracker_.get()));

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/runtime/sorter.cc
----------------------------------------------------------------------
diff --git a/be/src/runtime/sorter.cc b/be/src/runtime/sorter.cc
index 627f0e1..91e9a23 100644
--- a/be/src/runtime/sorter.cc
+++ b/be/src/runtime/sorter.cc
@@ -1534,7 +1534,7 @@ Status Sorter::CreateMerger(int max_num_runs) {
   merger_.reset(
       new SortedRunMerger(compare_less_than_, output_row_desc_, profile_, true));
 
-  vector<function<Status (RowBatch**)> > merge_runs;
+  vector<function<Status (RowBatch**)>> merge_runs;
   merge_runs.reserve(max_num_runs);
   for (int i = 0; i < max_num_runs; ++i) {
     Run* run = sorted_runs_.front();

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/runtime/test-env.h
----------------------------------------------------------------------
diff --git a/be/src/runtime/test-env.h b/be/src/runtime/test-env.h
index 5950261..900bb3e 100644
--- a/be/src/runtime/test-env.h
+++ b/be/src/runtime/test-env.h
@@ -74,7 +74,7 @@ class TestEnv {
   boost::scoped_ptr<TmpFileMgr> tmp_file_mgr_;
 
   /// Per-query states with associated block managers.
-  vector<boost::shared_ptr<RuntimeState> > query_states_;
+  vector<boost::shared_ptr<RuntimeState>> query_states_;
 };
 
 }

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/runtime/tmp-file-mgr-test.cc
----------------------------------------------------------------------
diff --git a/be/src/runtime/tmp-file-mgr-test.cc b/be/src/runtime/tmp-file-mgr-test.cc
index f6f2406..7276e97 100644
--- a/be/src/runtime/tmp-file-mgr-test.cc
+++ b/be/src/runtime/tmp-file-mgr-test.cc
@@ -49,7 +49,7 @@ class TmpFileMgrTest : public ::testing::Test {
         "tmp-file-mgr.active-scratch-dirs");
     EXPECT_EQ(active.size(), active_metric->value());
     SetMetric<string>* active_set_metric =
-        metrics_->FindMetricForTesting<SetMetric<string> >(
+        metrics_->FindMetricForTesting<SetMetric<string>>(
         "tmp-file-mgr.active-scratch-dirs.list");
     set<string> active_set = active_set_metric->value();
     EXPECT_EQ(active.size(), active_set.size());

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/scheduling/query-schedule.h
----------------------------------------------------------------------
diff --git a/be/src/scheduling/query-schedule.h b/be/src/scheduling/query-schedule.h
index 20f7dfe..4c225c7 100644
--- a/be/src/scheduling/query-schedule.h
+++ b/be/src/scheduling/query-schedule.h
@@ -35,7 +35,7 @@ namespace impala {
 class Coordinator;
 
 /// map from scan node id to a list of scan ranges
-typedef std::map<TPlanNodeId, std::vector<TScanRangeParams> > PerNodeScanRanges;
+typedef std::map<TPlanNodeId, std::vector<TScanRangeParams>> PerNodeScanRanges;
 /// map from an impalad host address to the per-node assigned scan ranges;
 /// records scan range assignment for a single fragment
 typedef boost::unordered_map<TNetworkAddress, PerNodeScanRanges>

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/scheduling/simple-scheduler.cc
----------------------------------------------------------------------
diff --git a/be/src/scheduling/simple-scheduler.cc b/be/src/scheduling/simple-scheduler.cc
index a14509c..1e46c67 100644
--- a/be/src/scheduling/simple-scheduler.cc
+++ b/be/src/scheduling/simple-scheduler.cc
@@ -422,7 +422,7 @@ void SimpleScheduler::GetAllKnownBackends(BackendList* backends) {
 
 Status SimpleScheduler::ComputeScanRangeAssignment(const TQueryExecRequest& exec_request,
     QuerySchedule* schedule) {
-  map<TPlanNodeId, vector<TScanRangeLocations> >::const_iterator entry;
+  map<TPlanNodeId, vector<TScanRangeLocations>>::const_iterator entry;
   for (entry = exec_request.per_node_scan_ranges.begin();
       entry != exec_request.per_node_scan_ranges.end(); ++entry) {
     const TPlanNodeId node_id = entry->first;
@@ -815,7 +815,7 @@ void SimpleScheduler::FindNodes(const TPlan& plan,
 void SimpleScheduler::GetScanHosts(TPlanNodeId scan_id,
     const TQueryExecRequest& exec_request, const FragmentExecParams& params,
     vector<TNetworkAddress>* scan_hosts) {
-  map<TPlanNodeId, vector<TScanRangeLocations> >::const_iterator entry =
+  map<TPlanNodeId, vector<TScanRangeLocations>>::const_iterator entry =
       exec_request.per_node_scan_ranges.find(scan_id);
   if (entry == exec_request.per_node_scan_ranges.end() || entry->second.empty()) {
     // this scan node doesn't have any scan ranges; run it on the coordinator

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/scheduling/simple-scheduler.h
----------------------------------------------------------------------
diff --git a/be/src/scheduling/simple-scheduler.h b/be/src/scheduling/simple-scheduler.h
index 1d07711..5cff7a5 100644
--- a/be/src/scheduling/simple-scheduler.h
+++ b/be/src/scheduling/simple-scheduler.h
@@ -94,7 +94,7 @@ class SimpleScheduler : public Scheduler {
 
   /// Map from a datanode's IP address to a list of backend addresses running on that
   /// node.
-  typedef boost::unordered_map<std::string, std::list<TBackendDescriptor> > BackendMap;
+  typedef boost::unordered_map<std::string, std::list<TBackendDescriptor>> BackendMap;
   BackendMap backend_map_;
 
   /// Map from a datanode's hostname to its IP address to support both hostname based

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/service/fragment-mgr.h
----------------------------------------------------------------------
diff --git a/be/src/service/fragment-mgr.h b/be/src/service/fragment-mgr.h
index f63d92f..68eac15 100644
--- a/be/src/service/fragment-mgr.h
+++ b/be/src/service/fragment-mgr.h
@@ -71,7 +71,7 @@ class FragmentMgr {
 
   /// Map from fragment instance id to exec state; FragmentExecState is owned by us and
   /// referenced as a shared_ptr to allow asynchronous calls to CancelPlanFragment()
-  typedef boost::unordered_map<TUniqueId, boost::shared_ptr<FragmentExecState> >
+  typedef boost::unordered_map<TUniqueId, boost::shared_ptr<FragmentExecState>>
   FragmentExecStateMap;
   FragmentExecStateMap fragment_exec_state_map_;
 

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/service/hs2-util-test.cc
----------------------------------------------------------------------
diff --git a/be/src/service/hs2-util-test.cc b/be/src/service/hs2-util-test.cc
index c0b7b56..0d04164 100644
--- a/be/src/service/hs2-util-test.cc
+++ b/be/src/service/hs2-util-test.cc
@@ -111,7 +111,7 @@ TEST(StitchNullsTest, StitchWithOffset) {
 TEST(PrintTColumnValueTest, TestAllTypes) {
   using namespace apache::hive::service::cli::thrift;
 
-  vector<pair<apache::hive::service::cli::thrift::TColumnValue, string> > values;
+  vector<pair<apache::hive::service::cli::thrift::TColumnValue, string>> values;
   values.resize(9);
 
   values[0].first.__set_boolVal(TBoolValue());

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/service/impala-beeswax-server.cc
----------------------------------------------------------------------
diff --git a/be/src/service/impala-beeswax-server.cc b/be/src/service/impala-beeswax-server.cc
index f26ace6..988386d 100644
--- a/be/src/service/impala-beeswax-server.cc
+++ b/be/src/service/impala-beeswax-server.cc
@@ -165,7 +165,7 @@ class ImpalaServer::AsciiQueryResultSet : public ImpalaServer::QueryResultSet {
   vector<string>* result_set_;
 
   // Set to result_set_ if result_set_ is owned.
-  scoped_ptr<vector<string> > owned_result_set_;
+  scoped_ptr<vector<string>> owned_result_set_;
 };
 
 void ImpalaServer::query(QueryHandle& query_handle, const Query& query) {

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/service/impala-server.cc
----------------------------------------------------------------------
diff --git a/be/src/service/impala-server.cc b/be/src/service/impala-server.cc
index ec58ccc..e092f4b 100644
--- a/be/src/service/impala-server.cc
+++ b/be/src/service/impala-server.cc
@@ -1525,7 +1525,7 @@ void ImpalaServer::MembershipCallback(
 
     // Maps from query id (to be cancelled) to a list of failed Impalads that are
     // the cause of the cancellation.
-    map<TUniqueId, vector<TNetworkAddress> > queries_to_cancel;
+    map<TUniqueId, vector<TNetworkAddress>> queries_to_cancel;
     {
       // Build a list of queries that are running on failed hosts (as evidenced by their
       // absence from the membership list).
@@ -1562,7 +1562,7 @@ void ImpalaServer::MembershipCallback(
       // Since we are the only producer for this pool, we know that this cannot block
       // indefinitely since the queue is large enough to accept all new cancellation
       // requests.
-      map<TUniqueId, vector<TNetworkAddress> >::iterator cancellation_entry;
+      map<TUniqueId, vector<TNetworkAddress>>::iterator cancellation_entry;
       for (cancellation_entry = queries_to_cancel.begin();
           cancellation_entry != queries_to_cancel.end();
           ++cancellation_entry) {

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/service/impala-server.h
----------------------------------------------------------------------
diff --git a/be/src/service/impala-server.h b/be/src/service/impala-server.h
index 6a07ccd..9069d75 100644
--- a/be/src/service/impala-server.h
+++ b/be/src/service/impala-server.h
@@ -677,7 +677,7 @@ class ImpalaServer : public ImpalaServiceIf, public ImpalaHiveServer2ServiceIf,
 
   /// Thread pool to process cancellation requests that come from failed Impala demons to
   /// avoid blocking the statestore callback.
-  boost::scoped_ptr<ThreadPool<CancellationWork> > cancellation_thread_pool_;
+  boost::scoped_ptr<ThreadPool<CancellationWork>> cancellation_thread_pool_;
 
   /// Thread that runs ExpireSessions. It will wake up periodically to check for sessions
   /// which are idle for more their timeout values.
@@ -695,7 +695,7 @@ class ImpalaServer : public ImpalaServiceIf, public ImpalaHiveServer2ServiceIf,
 
   /// map from query id to exec state; QueryExecState is owned by us and referenced
   /// as a shared_ptr to allow asynchronous deletion
-  typedef boost::unordered_map<TUniqueId, boost::shared_ptr<QueryExecState> >
+  typedef boost::unordered_map<TUniqueId, boost::shared_ptr<QueryExecState>>
       QueryExecStateMap;
   QueryExecStateMap query_exec_state_map_;
   boost::mutex query_exec_state_map_lock_;  // protects query_exec_state_map_
@@ -827,7 +827,7 @@ class ImpalaServer : public ImpalaServiceIf, public ImpalaHiveServer2ServiceIf,
   boost::mutex session_state_map_lock_;
 
   /// A map from session identifier to a structure containing per-session information
-  typedef boost::unordered_map<TUniqueId, boost::shared_ptr<SessionState> >
+  typedef boost::unordered_map<TUniqueId, boost::shared_ptr<SessionState>>
     SessionStateMap;
   SessionStateMap session_state_map_;
 
@@ -838,7 +838,7 @@ class ImpalaServer : public ImpalaServiceIf, public ImpalaHiveServer2ServiceIf,
   /// when the connection ends. HS2 allows for multiplexing several sessions across a
   /// single connection. If a session has already been closed (only possible via HS2) it is
   /// not removed from this map to avoid the cost of looking it up.
-  typedef boost::unordered_map<TUniqueId, std::vector<TUniqueId> >
+  typedef boost::unordered_map<TUniqueId, std::vector<TUniqueId>>
     ConnectionToSessionMap;
   ConnectionToSessionMap connection_to_sessions_map_;
 
@@ -863,7 +863,7 @@ class ImpalaServer : public ImpalaServiceIf, public ImpalaHiveServer2ServiceIf,
   boost::mutex query_locations_lock_;
 
   /// A map from backend to the list of queries currently running there.
-  typedef boost::unordered_map<TNetworkAddress, boost::unordered_set<TUniqueId> >
+  typedef boost::unordered_map<TNetworkAddress, boost::unordered_set<TUniqueId>>
       QueryLocations;
   QueryLocations query_locations_;
 
@@ -918,7 +918,7 @@ class ImpalaServer : public ImpalaServiceIf, public ImpalaHiveServer2ServiceIf,
   /// Map of short usernames of authorized proxy users to the set of user(s) they are
   /// allowed to delegate to. Populated by parsing the --authorized_proxy_users_config
   /// flag.
-  typedef boost::unordered_map<std::string, boost::unordered_set<std::string> >
+  typedef boost::unordered_map<std::string, boost::unordered_set<std::string>>
       ProxyUserMap;
   ProxyUserMap authorized_proxy_user_config_;
 

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/service/query-exec-state.h
----------------------------------------------------------------------
diff --git a/be/src/service/query-exec-state.h b/be/src/service/query-exec-state.h
index 0b62a28..c2459cf 100644
--- a/be/src/service/query-exec-state.h
+++ b/be/src/service/query-exec-state.h
@@ -241,7 +241,7 @@ class ImpalaServer::QueryExecState {
 
   /// Result set used for requests that return results and are not QUERY
   /// statements. For example, EXPLAIN, LOAD, and SHOW use this.
-  boost::scoped_ptr<std::vector<TResultRow> > request_result_set_;
+  boost::scoped_ptr<std::vector<TResultRow>> request_result_set_;
 
   /// Cache of the first result_cache_max_size_ query results to allow clients to restart
   /// fetching from the beginning of the result set. This cache is appended to in

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/service/session-expiry-test.cc
----------------------------------------------------------------------
diff --git a/be/src/service/session-expiry-test.cc b/be/src/service/session-expiry-test.cc
index b76edab..48cb75e 100644
--- a/be/src/service/session-expiry-test.cc
+++ b/be/src/service/session-expiry-test.cc
@@ -56,8 +56,8 @@ TEST(SessionTest, TestExpiry) {
   EXPECT_EQ(beeswax_session_metric->value(), 0L);
 
   {
-    scoped_ptr<ThriftClient<ImpalaServiceClient> > beeswax_clients[5];
-    scoped_ptr<ThriftClient<ImpalaHiveServer2ServiceClient> > hs2_clients[5];
+    scoped_ptr<ThriftClient<ImpalaServiceClient>> beeswax_clients[5];
+    scoped_ptr<ThriftClient<ImpalaHiveServer2ServiceClient>> hs2_clients[5];
 
     // Create five Beeswax clients and five HS2 clients (each HS2 gets one session each)
     for (int i = 0; i < 5; ++i) {

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/statestore/statestore.h
----------------------------------------------------------------------
diff --git a/be/src/statestore/statestore.h b/be/src/statestore/statestore.h
index 3ca0498..2061e38 100644
--- a/be/src/statestore/statestore.h
+++ b/be/src/statestore/statestore.h
@@ -350,7 +350,7 @@ class Statestore {
   /// Subscribers are held in shared_ptrs so that RegisterSubscriber() may overwrite their
   /// entry in this map while UpdateSubscriber() tries to update an existing registration
   /// without risk of use-after-free.
-  typedef boost::unordered_map<SubscriberId, boost::shared_ptr<Subscriber> >
+  typedef boost::unordered_map<SubscriberId, boost::shared_ptr<Subscriber>>
     SubscriberMap;
   SubscriberMap subscribers_;
 
@@ -396,13 +396,13 @@ class Statestore {
 
   /// Cache of subscriber clients used for UpdateState() RPCs. Only one client per
   /// subscriber should be used, but the cache helps with the client lifecycle on failure.
-  boost::scoped_ptr<ClientCache<StatestoreSubscriberClient> > update_state_client_cache_;
+  boost::scoped_ptr<ClientCache<StatestoreSubscriberClient>> update_state_client_cache_;
 
   /// Cache of subscriber clients used for Heartbeat() RPCs. Separate from
   /// update_state_client_cache_ because we enable TCP-level timeouts for these calls,
   /// whereas they are not safe for UpdateState() RPCs which can take an unbounded amount
   /// of time.
-  boost::scoped_ptr<ClientCache<StatestoreSubscriberClient> > heartbeat_client_cache_;
+  boost::scoped_ptr<ClientCache<StatestoreSubscriberClient>> heartbeat_client_cache_;
 
   /// Thrift API implementation which proxies requests onto this Statestore
   boost::shared_ptr<StatestoreServiceIf> thrift_iface_;

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/testutil/impalad-query-executor.h
----------------------------------------------------------------------
diff --git a/be/src/testutil/impalad-query-executor.h b/be/src/testutil/impalad-query-executor.h
index 0fbaf6b..f0448f8 100644
--- a/be/src/testutil/impalad-query-executor.h
+++ b/be/src/testutil/impalad-query-executor.h
@@ -87,7 +87,7 @@ class ImpaladQueryExecutor {
 
  private:
   /// fe service-related
-  boost::scoped_ptr<ThriftClient<ImpalaServiceClient> > client_;
+  boost::scoped_ptr<ThriftClient<ImpalaServiceClient>> client_;
 
   /// Execution options
   std::vector<std::string> exec_options_;

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/transport/TSaslServerTransport.cpp
----------------------------------------------------------------------
diff --git a/be/src/transport/TSaslServerTransport.cpp b/be/src/transport/TSaslServerTransport.cpp
index 280db85..1dfa99e 100644
--- a/be/src/transport/TSaslServerTransport.cpp
+++ b/be/src/transport/TSaslServerTransport.cpp
@@ -135,7 +135,7 @@ shared_ptr<TTransport> TSaslServerTransport::Factory::getTransport(
   // ensure that when ret_transport is eventually deleted, its corresponding map entry is
   // removed. That is likely to be error prone given the locking involved; for now we go
   // with the simple solution.
-  map<shared_ptr<TTransport>, shared_ptr<TBufferedTransport> >::iterator trans_map =
+  map<shared_ptr<TTransport>, shared_ptr<TBufferedTransport>>::iterator trans_map =
       transportMap_.find(trans);
   VLOG_EVERY_N(2, 100) << "getTransport(): transportMap_ size is: "
                        << transportMap_.size();

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/transport/TSaslServerTransport.h
----------------------------------------------------------------------
diff --git a/be/src/transport/TSaslServerTransport.h b/be/src/transport/TSaslServerTransport.h
index 0db5eca..31041b3 100644
--- a/be/src/transport/TSaslServerTransport.h
+++ b/be/src/transport/TSaslServerTransport.h
@@ -174,7 +174,7 @@ class TSaslServerTransport : public TSaslTransport {
 
     /* Map from a transport to its Sasl Transport (wrapped by a TBufferedTransport). */
     std::map<boost::shared_ptr<TTransport>,
-        boost::shared_ptr<TBufferedTransport> > transportMap_;
+        boost::shared_ptr<TBufferedTransport>> transportMap_;
 
     /* Lock to synchronize the transport map. */
     boost::mutex transportMap_mutex_;

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/udf/uda-test-harness-impl.h
----------------------------------------------------------------------
diff --git a/be/src/udf/uda-test-harness-impl.h b/be/src/udf/uda-test-harness-impl.h
index e08b9b0..8be05ca 100644
--- a/be/src/udf/uda-test-harness-impl.h
+++ b/be/src/udf/uda-test-harness-impl.h
@@ -181,7 +181,7 @@ RESULT UdaTestHarnessBase<RESULT, INTERMEDIATE>::ExecuteSingleNode(
 template<typename RESULT, typename INTERMEDIATE>
 RESULT UdaTestHarnessBase<RESULT, INTERMEDIATE>::ExecuteOneLevel(int num_nodes,
     ScopedFunctionContext* result_context) {
-  std::vector<boost::shared_ptr<ScopedFunctionContext> > contexts;
+  std::vector<boost::shared_ptr<ScopedFunctionContext>> contexts;
   std::vector<INTERMEDIATE> intermediates;
   contexts.resize(num_nodes);
 
@@ -237,7 +237,7 @@ RESULT UdaTestHarnessBase<RESULT, INTERMEDIATE>::ExecuteOneLevel(int num_nodes,
 template<typename RESULT, typename INTERMEDIATE>
 RESULT UdaTestHarnessBase<RESULT, INTERMEDIATE>::ExecuteTwoLevel(
     int num1, int num2, ScopedFunctionContext* result_context) {
-  std::vector<boost::shared_ptr<ScopedFunctionContext> > level1_contexts, level2_contexts;
+  std::vector<boost::shared_ptr<ScopedFunctionContext>> level1_contexts, level2_contexts;
   std::vector<INTERMEDIATE> level1_intermediates, level2_intermediates;
   level1_contexts.resize(num1);
   level2_contexts.resize(num2);

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/util/blocking-queue-test.cc
----------------------------------------------------------------------
diff --git a/be/src/util/blocking-queue-test.cc b/be/src/util/blocking-queue-test.cc
index 1e3240b..ba6a9ad 100644
--- a/be/src/util/blocking-queue-test.cc
+++ b/be/src/util/blocking-queue-test.cc
@@ -127,7 +127,7 @@ class MultiThreadTest {
   }
 
  private:
-  typedef vector<shared_ptr<thread> > ThreadVector;
+  typedef vector<shared_ptr<thread>> ThreadVector;
 
   int iterations_;
   int nthreads_;

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/util/collection-metrics.h
----------------------------------------------------------------------
diff --git a/be/src/util/collection-metrics.h b/be/src/util/collection-metrics.h
index 276f4b9..f836765 100644
--- a/be/src/util/collection-metrics.h
+++ b/be/src/util/collection-metrics.h
@@ -96,7 +96,7 @@ class SetMetric : public Metric {
 
   virtual std::string ToHumanReadable() {
     std::stringstream out;
-    PrettyPrinter::PrintStringList<std::set<T> >(
+    PrettyPrinter::PrintStringList<std::set<T>>(
         value_, TUnit::NONE, &out);
     return out.str();
   }
@@ -273,7 +273,7 @@ class StatsMetric : public Metric {
                                     boost::accumulators::tag::count,
                                     boost::accumulators::tag::min,
                                     boost::accumulators::tag::max,
-                                    boost::accumulators::tag::variance> > Accumulator;
+                                    boost::accumulators::tag::variance>> Accumulator;
   Accumulator acc_;
 
 };

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/util/debug-util.cc
----------------------------------------------------------------------
diff --git a/be/src/util/debug-util.cc b/be/src/util/debug-util.cc
index c342965..c3f8c94 100644
--- a/be/src/util/debug-util.cc
+++ b/be/src/util/debug-util.cc
@@ -124,7 +124,7 @@ bool ParseId(const string& s, TUniqueId* id) {
   if (separator == NULL) {
     // Legacy compatibility branch
     char_separator<char> sep(" ");
-    tokenizer< char_separator<char> > tokens(s, sep);
+    tokenizer< char_separator<char>> tokens(s, sep);
     int i = 0;
     for (const string& token: tokens) {
       StringParser::ParseResult parse_result = StringParser::PARSE_SUCCESS;

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/util/internal-queue-test.cc
----------------------------------------------------------------------
diff --git a/be/src/util/internal-queue-test.cc b/be/src/util/internal-queue-test.cc
index 30bb1e8..2142de2 100644
--- a/be/src/util/internal-queue-test.cc
+++ b/be/src/util/internal-queue-test.cc
@@ -240,7 +240,7 @@ TEST(InternalQueue, TestMultiProducerMultiConsumer) {
     const int num_per_consumer = nodes.size() / NUM_CONSUMERS;
     const int num_per_producer = nodes.size() / num_producers;
 
-    vector<vector<int> > results;
+    vector<vector<int>> results;
     results.resize(NUM_CONSUMERS);
 
     int expected_delta = -1;

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/util/metrics-test.cc
----------------------------------------------------------------------
diff --git a/be/src/util/metrics-test.cc b/be/src/util/metrics-test.cc
index 7baca5f..ce80f56 100644
--- a/be/src/util/metrics-test.cc
+++ b/be/src/util/metrics-test.cc
@@ -205,7 +205,7 @@ TEST_F(MetricsTest, MemMetric) {
   // Allocate 100MB to increase the number of bytes used. TCMalloc may also give up some
   // bytes during this allocation, so this allocation is deliberately large to ensure that
   // the bytes used metric goes up net.
-  scoped_ptr<vector<uint64_t> > chunk(new vector<uint64_t>(100 * 1024 * 1024));
+  scoped_ptr<vector<uint64_t>> chunk(new vector<uint64_t>(100 * 1024 * 1024));
   EXPECT_GT(bytes_in_use->value(), cur_in_use);
 
   UIntGauge* total_bytes_reserved =

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/util/perf-counters.h
----------------------------------------------------------------------
diff --git a/be/src/util/perf-counters.h b/be/src/util/perf-counters.h
index 4597ecf..3eb0d51 100644
--- a/be/src/util/perf-counters.h
+++ b/be/src/util/perf-counters.h
@@ -129,7 +129,7 @@ class PerfCounters {
   std::vector<CounterData> counters_;
   std::vector<std::string> counter_names_;
   std::vector<std::string> snapshot_names_;
-  std::vector<std::vector<int64_t> > snapshots_;
+  std::vector<std::vector<int64_t>> snapshots_;
   /// System perf counters can be grouped together.  The OS will update all grouped counters
   /// at the same time.  This is useful to better correlate counter values.
   int group_fd_;

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/util/runtime-profile.h
----------------------------------------------------------------------
diff --git a/be/src/util/runtime-profile.h b/be/src/util/runtime-profile.h
index 98a02ed..6c90c2d 100644
--- a/be/src/util/runtime-profile.h
+++ b/be/src/util/runtime-profile.h
@@ -320,7 +320,7 @@ class RuntimeProfile {
 
   /// Map from parent counter name to a set of child counter name.
   /// All top level counters are the child of "" (root).
-  typedef std::map<std::string, std::set<std::string> > ChildCounterMap;
+  typedef std::map<std::string, std::set<std::string>> ChildCounterMap;
   ChildCounterMap child_counter_map_;
 
   /// A set of bucket counters registered in this runtime profile.
@@ -336,7 +336,7 @@ class RuntimeProfile {
   ChildMap child_map_;
 
   /// Vector of (profile, indentation flag).
-  typedef std::vector<std::pair<RuntimeProfile*, bool> > ChildVector;
+  typedef std::vector<std::pair<RuntimeProfile*, bool>> ChildVector;
   ChildVector children_;
 
   /// Protects child_map_ and children_.

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/util/summary-util.cc
----------------------------------------------------------------------
diff --git a/be/src/util/summary-util.cc b/be/src/util/summary-util.cc
index 8ba42fc..30849ca 100644
--- a/be/src/util/summary-util.cc
+++ b/be/src/util/summary-util.cc
@@ -33,7 +33,7 @@ using namespace impala;
 // for the current node and on return, will contain the id of the next node.
 void PrintExecSummary(const TExecSummary& exec_summary, int indent_level,
     int new_indent_level, int* node_idx,
-    vector<vector<string> >* result) {
+    vector<vector<string>>* result) {
   DCHECK_LT(*node_idx, exec_summary.nodes.size());
   const TPlanNodeExecSummary& node = exec_summary.nodes[*node_idx];
   const TExecStats& est_stats = node.estimated_stats;
@@ -94,7 +94,7 @@ void PrintExecSummary(const TExecSummary& exec_summary, int indent_level,
   if (node.num_children == 0) return;
 
   // Print the non-left children to the stream first.
-  vector<vector<string> > child0_result;
+  vector<vector<string>> child0_result;
   PrintExecSummary(exec_summary, indent_level, false, node_idx, &child0_result);
 
   for (int i = 1; i < node.num_children; ++i) {
@@ -121,7 +121,7 @@ string impala::PrintExecSummary(const TExecSummary& exec_summary) {
   printer.AddColumn("Est. Peak Mem", false);
   printer.AddColumn("Detail", true);
 
-  vector<vector<string> > rows;
+  vector<vector<string>> rows;
   int node_idx = 0;
   ::PrintExecSummary(exec_summary, 0, false, &node_idx, &rows);
   for (int i = 0; i < rows.size(); ++i) {

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/util/table-printer.h
----------------------------------------------------------------------
diff --git a/be/src/util/table-printer.h b/be/src/util/table-printer.h
index 69c954c..8e23dab 100644
--- a/be/src/util/table-printer.h
+++ b/be/src/util/table-printer.h
@@ -50,7 +50,7 @@ class TablePrinter {
   /// -1 to indicate unlimited.
   int max_output_width_;
 
-  std::vector<std::vector<std::string> > rows_;
+  std::vector<std::vector<std::string>> rows_;
   std::vector<int> max_col_widths_;
 
   /// Helper function to print one row to ss.

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/util/thread-pool.h
----------------------------------------------------------------------
diff --git a/be/src/util/thread-pool.h b/be/src/util/thread-pool.h
index 0f1c656..63ad41a 100644
--- a/be/src/util/thread-pool.h
+++ b/be/src/util/thread-pool.h
@@ -161,11 +161,11 @@ class ThreadPool {
 };
 
 /// Utility thread-pool that accepts callable work items, and simply invokes them.
-class CallableThreadPool : public ThreadPool<boost::function<void()> > {
+class CallableThreadPool : public ThreadPool<boost::function<void()>> {
  public:
   CallableThreadPool(const std::string& group, const std::string& thread_prefix,
       uint32_t num_threads, uint32_t queue_size) :
-      ThreadPool<boost::function<void()> >(
+      ThreadPool<boost::function<void()>>(
           group, thread_prefix, num_threads, queue_size, &CallableThreadPool::Worker) {
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/be/src/util/url-coding.cc
----------------------------------------------------------------------
diff --git a/be/src/util/url-coding.cc b/be/src/util/url-coding.cc
index b64e609..20e5783 100644
--- a/be/src/util/url-coding.cc
+++ b/be/src/util/url-coding.cc
@@ -107,7 +107,7 @@ bool UrlDecode(const string& in, string* out, bool hive_compat) {
 }
 
 static inline void Base64Encode(const char* in, int in_len, stringstream* out) {
-  typedef base64_from_binary<transform_width<const char*, 6, 8> > base64_encode;
+  typedef base64_from_binary<transform_width<const char*, 6, 8>> base64_encode;
   // Base64 encodes 8 byte chars as 6 bit values.
   stringstream::pos_type len_before = out->tellp();
   copy(base64_encode(in), base64_encode(in + in_len), std::ostream_iterator<char>(*out));

http://git-wip-us.apache.org/repos/asf/incubator-impala/blob/55b2a639/fe/src/test/java/com/cloudera/impala/catalog/HdfsPartitionTest.java
----------------------------------------------------------------------
diff --git a/fe/src/test/java/com/cloudera/impala/catalog/HdfsPartitionTest.java b/fe/src/test/java/com/cloudera/impala/catalog/HdfsPartitionTest.java
index 9959c8b..7f5054f 100644
--- a/fe/src/test/java/com/cloudera/impala/catalog/HdfsPartitionTest.java
+++ b/fe/src/test/java/com/cloudera/impala/catalog/HdfsPartitionTest.java
@@ -57,7 +57,7 @@ public class HdfsPartitionTest {
 
   @Test
   public void testCompare() {
-    List< List<LiteralExpr> > allLists = Lists.newArrayList();
+    List<List<LiteralExpr>> allLists = Lists.newArrayList();
     allLists.add(valuesNull_);
     allLists.add(valuesDecimal_);
     allLists.add(valuesDecimal1_);