Clang-format aos

It has drifted...  Clean it up a bit.

Change-Id: I2fe31a2187b4f690634ae6942786575db20192af
Signed-off-by: Austin Schuh <austin.linux@gmail.com>
diff --git a/aos/events/epoll_test.cc b/aos/events/epoll_test.cc
index 053a09b..b725747 100644
--- a/aos/events/epoll_test.cc
+++ b/aos/events/epoll_test.cc
@@ -129,9 +129,7 @@
   // epoll_ctl manpage, this should trigger an error).
   Pipe pipe;
   int number_errors = 0;
-  epoll_.OnError(pipe.write_fd(), [&]() {
-    ++number_errors;
-  });
+  epoll_.OnError(pipe.write_fd(), [&]() { ++number_errors; });
 
   // Sanity check that we *don't* get any errors before anything interesting has
   // happened.
diff --git a/aos/events/event_scheduler.h b/aos/events/event_scheduler.h
index b64728c..d91a75e 100644
--- a/aos/events/event_scheduler.h
+++ b/aos/events/event_scheduler.h
@@ -347,8 +347,9 @@
 inline monotonic_clock::time_point EventScheduler::monotonic_now() const {
   const logger::BootTimestamp t =
       FromDistributedClock(scheduler_scheduler_->distributed_now());
-  CHECK_EQ(t.boot, boot_count_) << ": " << " " << t << " d "
-                                << scheduler_scheduler_->distributed_now();
+  CHECK_EQ(t.boot, boot_count_)
+      << ": "
+      << " " << t << " d " << scheduler_scheduler_->distributed_now();
   return t.time;
 }
 
diff --git a/aos/events/logging/boot_timestamp.cc b/aos/events/logging/boot_timestamp.cc
index b3511f4..ef65171 100644
--- a/aos/events/logging/boot_timestamp.cc
+++ b/aos/events/logging/boot_timestamp.cc
@@ -19,8 +19,8 @@
 
 std::ostream &operator<<(std::ostream &os,
                          const struct BootQueueIndex &queue_index) {
-  return os << "{.boot=" << queue_index.boot
-            << ", .index=" << queue_index.index << "}";
+  return os << "{.boot=" << queue_index.boot << ", .index=" << queue_index.index
+            << "}";
 }
 
 }  // namespace aos::logger
diff --git a/aos/events/logging/buffer_encoder_param_test.h b/aos/events/logging/buffer_encoder_param_test.h
index fd1a00c..871e25e 100644
--- a/aos/events/logging/buffer_encoder_param_test.h
+++ b/aos/events/logging/buffer_encoder_param_test.h
@@ -6,12 +6,11 @@
 #include <random>
 #include <vector>
 
-#include "glog/logging.h"
-#include "gtest/gtest.h"
-
 #include "aos/events/logging/logfile_utils.h"
 #include "aos/events/logging/logger_generated.h"
 #include "aos/testing/random_seed.h"
+#include "glog/logging.h"
+#include "gtest/gtest.h"
 
 namespace aos::logger::testing {
 
diff --git a/aos/events/logging/buffer_encoder_test.cc b/aos/events/logging/buffer_encoder_test.cc
index 0687f83..5a9b85f 100644
--- a/aos/events/logging/buffer_encoder_test.cc
+++ b/aos/events/logging/buffer_encoder_test.cc
@@ -4,12 +4,11 @@
 #include <fstream>
 #include <string>
 
+#include "aos/events/logging/buffer_encoder_param_test.h"
 #include "glog/logging.h"
 #include "gmock/gmock.h"
 #include "gtest/gtest.h"
 
-#include "aos/events/logging/buffer_encoder_param_test.h"
-
 namespace aos::logger::testing {
 
 class DummyEncoderTest : public BufferEncoderBaseTest {};
diff --git a/aos/events/logging/log_cat.cc b/aos/events/logging/log_cat.cc
index d85b79b..3e1dd1e 100644
--- a/aos/events/logging/log_cat.cc
+++ b/aos/events/logging/log_cat.cc
@@ -315,30 +315,29 @@
         VLOG(1) << "Listening on " << name << " " << type;
 
         CHECK_NOTNULL(channel->schema());
-        event_loop_->MakeRawWatcher(
-            channel,
-            [this, channel, start_time, end_time](const aos::Context &context,
-                                                  const void * /*message*/) {
-              if (!FLAGS_print) {
-                return;
-              }
+        event_loop_->MakeRawWatcher(channel, [this, channel, start_time,
+                                              end_time](
+                                                 const aos::Context &context,
+                                                 const void * /*message*/) {
+          if (!FLAGS_print) {
+            return;
+          }
 
-              if (!FLAGS_fetch && !started_) {
-                return;
-              }
+          if (!FLAGS_fetch && !started_) {
+            return;
+          }
 
-              if (context.monotonic_event_time < start_time ||
-                  context.monotonic_event_time > end_time) {
-                return;
-              }
+          if (context.monotonic_event_time < start_time ||
+              context.monotonic_event_time > end_time) {
+            return;
+          }
 
-              PrintMessage(node_name_, node_factory_, channel, context,
-                           builder_);
-              ++(*message_print_counter_);
-              if (FLAGS_count > 0 && *message_print_counter_ >= FLAGS_count) {
-                factory_->Exit();
-              }
-            });
+          PrintMessage(node_name_, node_factory_, channel, context, builder_);
+          ++(*message_print_counter_);
+          if (FLAGS_count > 0 && *message_print_counter_ >= FLAGS_count) {
+            factory_->Exit();
+          }
+        });
       }
     }
   }
diff --git a/aos/events/logging/log_namer.h b/aos/events/logging/log_namer.h
index 4a1e74f..7947ebe 100644
--- a/aos/events/logging/log_namer.h
+++ b/aos/events/logging/log_namer.h
@@ -220,9 +220,7 @@
         UUID::FromString(header_.message().logger_node_boot_uuid());
   }
 
-  void ClearStartTimes() {
-    node_states_.clear();
-  }
+  void ClearStartTimes() { node_states_.clear(); }
 
   void SetStartTimes(size_t node_index, const UUID &boot_uuid,
                      monotonic_clock::time_point monotonic_start_time,
diff --git a/aos/events/logging/log_reader.h b/aos/events/logging/log_reader.h
index 196ac53..c1333c6 100644
--- a/aos/events/logging/log_reader.h
+++ b/aos/events/logging/log_reader.h
@@ -349,9 +349,8 @@
 
     // Sets the node event loop factory for replaying into a
     // SimulatedEventLoopFactory.  Returns the EventLoop to use.
-    void SetNodeEventLoopFactory(
-        NodeEventLoopFactory *node_event_loop_factory,
-        SimulatedEventLoopFactory *event_loop_factory);
+    void SetNodeEventLoopFactory(NodeEventLoopFactory *node_event_loop_factory,
+                                 SimulatedEventLoopFactory *event_loop_factory);
 
     // Sets and gets the event loop to use.
     void set_event_loop(EventLoop *event_loop) { event_loop_ = event_loop; }
diff --git a/aos/events/logging/log_stats.cc b/aos/events/logging/log_stats.cc
index cf11fa6..7c3511d 100644
--- a/aos/events/logging/log_stats.cc
+++ b/aos/events/logging/log_stats.cc
@@ -301,8 +301,7 @@
                     << "hz max";
         }
         std::cout << " " << channel_stats[i].avg_message_size()
-                  << " bytes avg, "
-                  << channel_stats[i].avg_message_bandwidth()
+                  << " bytes avg, " << channel_stats[i].avg_message_bandwidth()
                   << " bytes/sec avg, " << channel_stats[i].max_message_size()
                   << " bytes max / " << channel_stats[i].channel()->max_size()
                   << "bytes " << channel_stats[i].Percentile();
diff --git a/aos/events/logging/log_writer.h b/aos/events/logging/log_writer.h
index 23ab349..c364d36 100644
--- a/aos/events/logging/log_writer.h
+++ b/aos/events/logging/log_writer.h
@@ -135,8 +135,9 @@
 
   // Restart logging using a new naming scheme. Intended for log rotation.
   // Returns a unique_ptr to the prior log_namer instance.
-  std::unique_ptr<LogNamer> RestartLogging(std::unique_ptr<LogNamer> log_namer,
-                    std::optional<UUID> log_start_uuid = std::nullopt);
+  std::unique_ptr<LogNamer> RestartLogging(
+      std::unique_ptr<LogNamer> log_namer,
+      std::optional<UUID> log_start_uuid = std::nullopt);
 
   // Moves the current log location to the new name. Returns true if a change
   // was made, false otherwise.
@@ -227,7 +228,7 @@
   std::vector<int> event_loop_to_logged_channel_index_;
 
   // Start/Restart write configuration into LogNamer space.
-  std::string WriteConfiguration(LogNamer* log_namer);
+  std::string WriteConfiguration(LogNamer *log_namer);
 
   void WriteHeader(aos::monotonic_clock::time_point monotonic_start_time =
                        aos::monotonic_clock::min_time,
@@ -249,7 +250,8 @@
   void WriteMissingTimestamps();
 
   void WriteData(NewDataWriter *writer, const FetcherStruct &f);
-  void WriteTimestamps(NewDataWriter *timestamps_writer, const FetcherStruct &f);
+  void WriteTimestamps(NewDataWriter *timestamps_writer,
+                       const FetcherStruct &f);
   void WriteContent(NewDataWriter *contents_writer, const FetcherStruct &f);
 
   void WriteFetchedRecord(FetcherStruct &f);
diff --git a/aos/events/logging/logfile_utils.cc b/aos/events/logging/logfile_utils.cc
index ecdf5d6..01f3002 100644
--- a/aos/events/logging/logfile_utils.cc
+++ b/aos/events/logging/logfile_utils.cc
@@ -558,8 +558,8 @@
     }
 
     if (span_reader_.IsIncomplete()) {
-      LOG(ERROR) << "Unable to access some messages in " << filename()
-                 << " : " << span_reader_.TotalRead() << " bytes read, "
+      LOG(ERROR) << "Unable to access some messages in " << filename() << " : "
+                 << span_reader_.TotalRead() << " bytes read, "
                  << span_reader_.TotalConsumed() << " bytes usable."
                  << std::endl;
     }
@@ -570,15 +570,14 @@
 
   if (crash_on_corrupt_message_flag_) {
     CHECK(msg.Verify()) << "Corrupted message at offset "
-                        << total_verified_before_
-                        << " found within " << filename()
+                        << total_verified_before_ << " found within "
+                        << filename()
                         << "; set --nocrash_on_corrupt_message to see summary;"
                         << " also set --ignore_corrupt_messages to process"
                         << " anyway";
 
   } else if (!msg.Verify()) {
-    LOG(ERROR) << "Corrupted message at offset "
-               << total_verified_before_
+    LOG(ERROR) << "Corrupted message at offset " << total_verified_before_
                << " from " << filename() << std::endl;
 
     total_corrupted_ += msg_data.size();
@@ -922,14 +921,13 @@
       size_t monotonic_remote_boot = 0xffffff;
 
       if (m->monotonic_remote_time.has_value()) {
-        const Node *node = parts().config->nodes()->Get(
-            source_node_index_[m->channel_index]);
+        const Node *node =
+            parts().config->nodes()->Get(source_node_index_[m->channel_index]);
 
         std::optional<size_t> boot = parts_message_reader_.boot_count(
             source_node_index_[m->channel_index]);
         CHECK(boot) << ": Failed to find boot for node " << MaybeNodeName(node)
-                    << ", with index "
-                    << source_node_index_[m->channel_index];
+                    << ", with index " << source_node_index_[m->channel_index];
         monotonic_remote_boot = *boot;
       }
 
@@ -1242,16 +1240,16 @@
 }
 
 void TimestampMapper::QueueMessage(Message *m) {
-  matched_messages_.emplace_back(TimestampedMessage{
-      .channel_index = m->channel_index,
-      .queue_index = m->queue_index,
-      .monotonic_event_time = m->timestamp,
-      .realtime_event_time = m->data->realtime_sent_time,
-      .remote_queue_index = BootQueueIndex::Invalid(),
-      .monotonic_remote_time = BootTimestamp::min_time(),
-      .realtime_remote_time = realtime_clock::min_time,
-      .monotonic_timestamp_time = BootTimestamp::min_time(),
-      .data = std::move(m->data)});
+  matched_messages_.emplace_back(
+      TimestampedMessage{.channel_index = m->channel_index,
+                         .queue_index = m->queue_index,
+                         .monotonic_event_time = m->timestamp,
+                         .realtime_event_time = m->data->realtime_sent_time,
+                         .remote_queue_index = BootQueueIndex::Invalid(),
+                         .monotonic_remote_time = BootTimestamp::min_time(),
+                         .realtime_remote_time = realtime_clock::min_time,
+                         .monotonic_timestamp_time = BootTimestamp::min_time(),
+                         .data = std::move(m->data)});
 }
 
 TimestampedMessage *TimestampMapper::Front() {
@@ -1448,13 +1446,12 @@
 
   if (remote_queue_index < data_queue->front().queue_index ||
       remote_queue_index > data_queue->back().queue_index) {
-    return Message{
-        .channel_index = message.channel_index,
-        .queue_index = remote_queue_index,
-        .timestamp = monotonic_remote_time,
-        .monotonic_remote_boot = 0xffffff,
-        .monotonic_timestamp_boot = 0xffffff,
-        .data = nullptr};
+    return Message{.channel_index = message.channel_index,
+                   .queue_index = remote_queue_index,
+                   .timestamp = monotonic_remote_time,
+                   .monotonic_remote_boot = 0xffffff,
+                   .monotonic_timestamp_boot = 0xffffff,
+                   .data = nullptr};
   }
 
   // The algorithm below is constant time with some assumptions.  We need there
diff --git a/aos/events/logging/logfile_utils.h b/aos/events/logging/logfile_utils.h
index 41d4a9a..ca733d4 100644
--- a/aos/events/logging/logfile_utils.h
+++ b/aos/events/logging/logfile_utils.h
@@ -208,8 +208,9 @@
 
   size_t TotalRead() const { return total_read_; }
   size_t TotalConsumed() const { return total_consumed_; }
-  bool IsIncomplete() const { return is_finished_
-      && total_consumed_ < total_read_; }
+  bool IsIncomplete() const {
+    return is_finished_ && total_consumed_ < total_read_;
+  }
 
   // Returns a span with the data for the next message from the log file,
   // including the size.  The result is only guarenteed to be valid until
@@ -630,7 +631,8 @@
 
   realtime_clock::time_point realtime_start_time_ = realtime_clock::max_time;
   monotonic_clock::time_point monotonic_start_time_ = monotonic_clock::max_time;
-  monotonic_clock::time_point monotonic_oldest_time_ = monotonic_clock::max_time;
+  monotonic_clock::time_point monotonic_oldest_time_ =
+      monotonic_clock::max_time;
 };
 
 // Class to concatenate multiple boots worth of logs into a single per-node
diff --git a/aos/events/logging/logfile_utils_out_of_space_test_runner.cc b/aos/events/logging/logfile_utils_out_of_space_test_runner.cc
index 3010a6f..b08bebb 100644
--- a/aos/events/logging/logfile_utils_out_of_space_test_runner.cc
+++ b/aos/events/logging/logfile_utils_out_of_space_test_runner.cc
@@ -2,11 +2,10 @@
 
 #include <array>
 
-#include "gflags/gflags.h"
-#include "glog/logging.h"
-
 #include "aos/events/logging/logfile_utils.h"
 #include "aos/init.h"
+#include "gflags/gflags.h"
+#include "glog/logging.h"
 
 DECLARE_int32(flush_size);
 DEFINE_string(tmpfs, "", "tmpfs with the desired size");
diff --git a/aos/events/logging/lzma_encoder.h b/aos/events/logging/lzma_encoder.h
index 7b7010a..4edd0e8 100644
--- a/aos/events/logging/lzma_encoder.h
+++ b/aos/events/logging/lzma_encoder.h
@@ -1,9 +1,9 @@
 #ifndef AOS_EVENTS_LOGGING_LZMA_ENCODER_H_
 #define AOS_EVENTS_LOGGING_LZMA_ENCODER_H_
 
-#include <string_view>
 #include <condition_variable>
 #include <mutex>
+#include <string_view>
 #include <thread>
 
 #include "absl/types/span.h"
diff --git a/aos/events/ping_lib.h b/aos/events/ping_lib.h
index 6107494..75d06e7 100644
--- a/aos/events/ping_lib.h
+++ b/aos/events/ping_lib.h
@@ -4,8 +4,8 @@
 #include <chrono>
 
 #include "aos/events/event_loop.h"
-#include "aos/events/pong_generated.h"
 #include "aos/events/ping_generated.h"
+#include "aos/events/pong_generated.h"
 
 namespace aos {
 
diff --git a/aos/events/pong_lib.h b/aos/events/pong_lib.h
index 0b50599..7dc20d5 100644
--- a/aos/events/pong_lib.h
+++ b/aos/events/pong_lib.h
@@ -2,8 +2,8 @@
 #define AOS_EVENTS_PONG_LIB_H_
 
 #include "aos/events/event_loop.h"
-#include "aos/events/pong_generated.h"
 #include "aos/events/ping_generated.h"
+#include "aos/events/pong_generated.h"
 
 namespace aos {
 
diff --git a/aos/events/simulated_event_loop.cc b/aos/events/simulated_event_loop.cc
index 4671f12..e6bc28d 100644
--- a/aos/events/simulated_event_loop.cc
+++ b/aos/events/simulated_event_loop.cc
@@ -962,7 +962,8 @@
 }
 
 std::optional<uint32_t> SimulatedChannel::Send(
-    std::shared_ptr<SimulatedMessage> message, CheckSentTooFast check_sent_too_fast) {
+    std::shared_ptr<SimulatedMessage> message,
+    CheckSentTooFast check_sent_too_fast) {
   const auto now = scheduler_->monotonic_now();
   // Remove times that are greater than or equal to a channel_storage_duration_
   // ago
@@ -1051,8 +1052,8 @@
   CHECK_LE(length, message_->context.size);
   message_->context.size = length;
 
-  const std::optional<uint32_t> optional_queue_index =
-      simulated_channel_->Send(message_, simulated_event_loop_->options().check_sent_too_fast);
+  const std::optional<uint32_t> optional_queue_index = simulated_channel_->Send(
+      message_, simulated_event_loop_->options().check_sent_too_fast);
 
   // Check that we are not sending messages too fast
   if (!optional_queue_index) {
diff --git a/aos/events/simulated_event_loop.h b/aos/events/simulated_event_loop.h
index 234afa0..9200044 100644
--- a/aos/events/simulated_event_loop.h
+++ b/aos/events/simulated_event_loop.h
@@ -212,13 +212,13 @@
   // args for the Main class.  Returns a pointer to the class that was started
   // if it was started, or nullptr.
   template <class Main, class... Args>
-  Main *MaybeStart(std::string_view name, Args &&... args);
+  Main *MaybeStart(std::string_view name, Args &&...args);
 
   // Starts an application regardless of if the config says to or not.  name is
   // the name of the application, and args are the constructor args for the
   // application.  Returns a pointer to the class that was started.
   template <class Main, class... Args>
-  Main *AlwaysStart(std::string_view name, Args &&... args);
+  Main *AlwaysStart(std::string_view name, Args &&...args);
 
   // Returns the simulated network delay for messages forwarded between nodes.
   std::chrono::nanoseconds network_delay() const {
@@ -326,7 +326,7 @@
     // application.
     template <class... Args>
     TypedApplication(NodeEventLoopFactory *node_factory, std::string_view name,
-                     Args &&... args)
+                     Args &&...args)
         : Application(node_factory, name),
           main(event_loop.get(), std::forward<Args>(args)...) {
       VLOG(1) << node_factory->scheduler_.distributed_now() << " "
@@ -345,7 +345,7 @@
 };
 
 template <class Main, class... Args>
-Main *NodeEventLoopFactory::MaybeStart(std::string_view name, Args &&... args) {
+Main *NodeEventLoopFactory::MaybeStart(std::string_view name, Args &&...args) {
   const aos::Application *application =
       configuration::GetApplication(configuration(), node(), name);
 
@@ -356,8 +356,7 @@
 }
 
 template <class Main, class... Args>
-Main *NodeEventLoopFactory::AlwaysStart(std::string_view name,
-                                        Args &&... args) {
+Main *NodeEventLoopFactory::AlwaysStart(std::string_view name, Args &&...args) {
   std::unique_ptr<TypedApplication<Main>> app =
       std::make_unique<TypedApplication<Main>>(this, name,
                                                std::forward<Args>(args)...);
diff --git a/aos/events/simulated_event_loop_test.cc b/aos/events/simulated_event_loop_test.cc
index 4b155ce..1a35b69 100644
--- a/aos/events/simulated_event_loop_test.cc
+++ b/aos/events/simulated_event_loop_test.cc
@@ -246,7 +246,8 @@
   EXPECT_EQ(test_message_counter2.count(), 0u);
 }
 
-// Test that if we configure an event loop to be able to send too fast that we do allow it to do so.
+// Test that if we configure an event loop to be able to send too fast that we
+// do allow it to do so.
 TEST(SimulatedEventLoopTest, AllowSendTooFast) {
   SimulatedEventLoopTestFactory factory;
 
@@ -277,7 +278,8 @@
   // And now we should start being in the sending-too-fast phase.
   for (int ii = 0; ii < queue_size; ++ii) {
     ASSERT_EQ(SendTestMessage(too_fast_message_sender), RawSender::Error::kOk);
-    ASSERT_EQ(SendTestMessage(limited_message_sender), RawSender::Error::kMessagesSentTooFast);
+    ASSERT_EQ(SendTestMessage(limited_message_sender),
+              RawSender::Error::kMessagesSentTooFast);
   }
 }
 
@@ -309,7 +311,8 @@
   // This one should succeed now that the exclusive channel is removed.
   aos::Sender<TestMessage> normal_sender =
       normal_event_loop->MakeSender<TestMessage>("/test");
-  EXPECT_DEATH(exclusive_event_loop->MakeSender<TestMessage>("/test"), "TestMessage");
+  EXPECT_DEATH(exclusive_event_loop->MakeSender<TestMessage>("/test"),
+               "TestMessage");
 }
 
 void TestSentTooFastCheckEdgeCase(
diff --git a/aos/events/simulated_network_bridge.cc b/aos/events/simulated_network_bridge.cc
index c6ea811..19ca658 100644
--- a/aos/events/simulated_network_bridge.cc
+++ b/aos/events/simulated_network_bridge.cc
@@ -228,8 +228,8 @@
 
       // TODO(austin): Not cool.  We want to actually forward these.  This means
       // we need a more sophisticated concept of what is running.
-      // TODO(james): This fails if multiple messages are sent on the same channel
-      // within the same callback.
+      // TODO(james): This fails if multiple messages are sent on the same
+      // channel within the same callback.
       LOG(WARNING) << "Not forwarding message on "
                    << configuration::CleanedChannelToString(fetcher_->channel())
                    << " because we aren't running.  Set at "
diff --git a/aos/events/timing_report_dump.cc b/aos/events/timing_report_dump.cc
index 0e27b33..c71dcf5 100644
--- a/aos/events/timing_report_dump.cc
+++ b/aos/events/timing_report_dump.cc
@@ -1,9 +1,8 @@
-#include "aos/events/timing_report_dump_lib.h"
-
 #include "aos/configuration.h"
+#include "aos/events/logging/log_reader.h"
+#include "aos/events/timing_report_dump_lib.h"
 #include "aos/init.h"
 #include "aos/json_to_flatbuffer.h"
-#include "aos/events/logging/log_reader.h"
 #include "gflags/gflags.h"
 #include "glog/logging.h"
 
diff --git a/aos/events/timing_report_dump_lib.cc b/aos/events/timing_report_dump_lib.cc
index bd44ff6..b33cc73 100644
--- a/aos/events/timing_report_dump_lib.cc
+++ b/aos/events/timing_report_dump_lib.cc
@@ -21,8 +21,8 @@
   // width in the output stream).
   const auto num_width = std::setw(0);
   os << std::setfill(' ') << num_width << stats.average() << " [" << num_width
-     << stats.min() << ", " << num_width << stats.max() << "] std "
-     << num_width << stats.standard_deviation();
+     << stats.min() << ", " << num_width << stats.max() << "] std " << num_width
+     << stats.standard_deviation();
   return os;
 }
 
@@ -296,7 +296,7 @@
     }
   }
 }
-}
+}  // namespace
 
 void TimingReportDump::AccumulateReport(const timing::Report &raw_report) {
   CHECK(raw_report.has_pid());
@@ -370,7 +370,8 @@
 
 const Channel *TimingReportDump::GetChannel(int index) {
   CHECK_LT(0, index);
-  CHECK_GT(event_loop_->configuration()->channels()->size(), static_cast<size_t>(index));
+  CHECK_GT(event_loop_->configuration()->channels()->size(),
+           static_cast<size_t>(index));
   return event_loop_->configuration()->channels()->Get(index);
 }
 
diff --git a/aos/events/timing_report_dump_lib.h b/aos/events/timing_report_dump_lib.h
index a33bc3d..93163a1 100644
--- a/aos/events/timing_report_dump_lib.h
+++ b/aos/events/timing_report_dump_lib.h
@@ -1,7 +1,7 @@
 #ifndef AOS_EVENTS_TIMING_REPORT_DUMP_LIB_H_
 #define AOS_EVENTS_TIMING_REPORT_DUMP_LIB_H_
-#include <string>
 #include <map>
+#include <string>
 
 #include "aos/configuration.h"
 #include "aos/events/event_loop.h"
@@ -10,7 +10,6 @@
 #include "gflags/gflags.h"
 #include "glog/logging.h"
 
-
 namespace aos {
 // A class to handle printing timing report statistics in a useful format on the
 // command line. Main features:
@@ -32,9 +31,7 @@
 
   // Filter to use for application name. Currently requires that the provided
   // name exactly match the name of the application in question.
-  void ApplicationFilter(std::string_view name) {
-    name_filter_ = name;
-  }
+  void ApplicationFilter(std::string_view name) { name_filter_ = name; }
 
  private:
   void HandleTimingReport(const timing::Report &report);
@@ -62,7 +59,8 @@
   std::optional<std::string> name_filter_;
   // Key is pair of <process id, application name>, since neither is a unique
   // identifier across time.
-  std::map<std::pair<pid_t, std::string>, timing::ReportT> accumulated_statistics_;
+  std::map<std::pair<pid_t, std::string>, timing::ReportT>
+      accumulated_statistics_;
 };
 }  // namespace aos
 #endif  // AOS_EVENTS_TIMING_REPORT_DUMP_LIB_H_