]> git-server-git.apps.pok.os.sepia.ceph.com Git - ceph.git/commitdiff
*/: Cleanup WITH_ALIENSTORE
authorMatan Breizman <mbreizma@redhat.com>
Wed, 5 Feb 2025 15:34:37 +0000 (15:34 +0000)
committerMatan Breizman <mbreizma@redhat.com>
Tue, 11 Mar 2025 12:40:42 +0000 (12:40 +0000)
Signed-off-by: Matan Breizman <mbreizma@redhat.com>
30 files changed:
src/common/Finisher.cc
src/common/RefCountedObj.h
src/common/Throttle.h
src/common/TrackedOp.h
src/common/WorkQueue.h
src/common/admin_socket.h
src/common/ceph_context.cc
src/common/ceph_context.h
src/common/ceph_mutex.h
src/common/dout.h
src/common/mempool.cc
src/common/perf_counters.cc
src/common/perf_counters.h
src/global/global_context.cc
src/include/common_fwd.h
src/include/mempool.h
src/include/utime.h
src/kv/RocksDBStore.cc
src/libcephsqlite.cc
src/mds/Server.h
src/mon/Monitor.cc
src/mon/Paxos.cc
src/msg/async/Stack.h
src/os/bluestore/BlueFS.cc
src/osd/PeeringState.cc
src/osd/PeeringState.h
src/osdc/ObjectCacher.cc
src/rgw/rgw_dmclock_scheduler_ctx.h
src/rgw/rgw_dmclock_sync_scheduler.cc
src/test/fio/fio_ceph_objectstore.cc

index 9d2792fc252fb76334bf495602b77f3bdb55dca6..b8e7f3e63420cbb5083032fa41fbec17f0944d30 100644 (file)
@@ -5,7 +5,7 @@
 #include "common/perf_counters.h"
 #include "include/types.h" // for operator<<(std::vector)
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index a266775739967fbae9ad797f1d553f7af47e2ad2..6dfdd4a592b48d2c47a887cd8acbcba89aa4cc61 100644 (file)
@@ -89,7 +89,7 @@ template<typename... Args>
   virtual ~RefCountedObjectSafe() override {}
 };
 
-#if !defined(WITH_SEASTAR)|| defined(WITH_ALIEN)
+#ifndef WITH_SEASTAR
 
 /**
  * RefCountedCond
@@ -186,7 +186,7 @@ static inline void intrusive_ptr_add_ref(RefCountedWaitObject *p) {
 static inline void intrusive_ptr_release(RefCountedWaitObject *p) {
   p->put();
 }
-#endif // !defined(WITH_SEASTAR)|| defined(WITH_ALIEN)
+#endif // ifndef WITH_SEASTAR
 
 static inline void intrusive_ptr_add_ref(const RefCountedObject *p) {
   p->get();
index fdafb07647585a92b0ef47e31841bd1fcac8aa4b..b46878994edda88aa3d0206ad2266896663dfbf8 100644 (file)
@@ -15,7 +15,7 @@
 #include "include/Context.h"
 #include "common/ThrottleInterface.h"
 #include "common/Timer.h"
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index 2cfe470488fffc12285cc0f1ddb48a4ce3512017..cbfc0b8e25ed9ba15cb58844207220b1701f2326 100644 (file)
@@ -24,7 +24,7 @@
 #include "include/spinlock.h"
 #include "msg/Message.h"
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index f30dc08e6d17c692712d3c83b3c429c8ab522a39..f51c59b9f9e3871be5efa9468a5dc73d939c42f0 100644 (file)
@@ -15,7 +15,7 @@
 #ifndef CEPH_WORKQUEUE_H
 #define CEPH_WORKQUEUE_H
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 // for ObjectStore.h
 struct ThreadPool {
   struct TPHandle {
index 9f7f83395770f4404c434c3fef85f7e215902f19..4183ad30fb3ab8f5cd2d8752c43a7f51ea9a4bb5 100644 (file)
@@ -15,7 +15,7 @@
 #ifndef CEPH_COMMON_ADMIN_SOCKET_H
 #define CEPH_COMMON_ADMIN_SOCKET_H
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include "crimson/admin/admin_socket.h"
 #else
 
index 4bf1086e31d9fdf3b3b498abe39fbfc7b2b78934..76feeb2e2afc5d2cb77438e43e6941b41a0c952f 100644 (file)
@@ -48,7 +48,7 @@
 #include "common/PluginRegistry.h"
 #include "common/valgrind.h"
 #include "include/spinlock.h"
-#if !(defined(WITH_SEASTAR) && !defined(WITH_ALIEN))
+#ifndef WITH_SEASTAR
 #include "mon/MonMap.h"
 #endif
 
@@ -64,7 +64,7 @@ using ceph::bufferlist;
 using ceph::HeartbeatMap;
 
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 namespace crimson::common {
 CephContext::CephContext()
   : _conf{crimson::common::local_conf()},
index 6a02d5c5bf1fcc93cd31295f8e7c7271423b211e..6e2d710e9f68e82da8b22a37919259360c79f3b3 100644 (file)
@@ -34,7 +34,7 @@
 #include "common/cmdparse.h"
 #include "common/code_environment.h"
 #include "msg/msg_types.h"
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include "crimson/common/config_proxy.h"
 #include "crimson/common/perf_counters_collection.h"
 #else
@@ -66,7 +66,7 @@ namespace ceph {
   }
 }
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 namespace crimson::common {
 class CephContext {
 public:
@@ -423,7 +423,7 @@ private:
 #endif
 #endif // WITH_SEASTAR
 
-#if !(defined(WITH_SEASTAR) && !defined(WITH_ALIEN)) && defined(__cplusplus)
+#if !defined(WITH_SEASTAR) && defined(__cplusplus)
 namespace ceph::common {
 inline void intrusive_ptr_add_ref(CephContext* cct)
 {
@@ -435,5 +435,5 @@ inline void intrusive_ptr_release(CephContext* cct)
   cct->put();
 }
 }
-#endif // !(defined(WITH_SEASTAR) && !defined(WITH_ALIEN)) && defined(__cplusplus)
+#endif // !defined(WITH_SEASTAR) && defined(__cplusplus)
 #endif
index 6ed8c56d5dad3b8227c3faf036462ab2cab64ca6..7430472cc952612c992658f877a67c6f78d12946 100644 (file)
@@ -14,7 +14,7 @@
 // and make_recursive_mutex() factory methods, which take a string
 // naming the mutex for the purposes of the lockdep debug variant.
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include <seastar/core/condition-variable.hh>
 
 #include "crimson/common/log.h"
@@ -87,7 +87,7 @@ namespace ceph {
   #define ceph_mutex_is_locked_by_me(m) true
 }
 
-#else  // defined (WITH_SEASTAR) && !defined(WITH_ALIEN)
+#else  // ifdef WITH_SEASTAR
 //
 // For legacy Mutex users that passed recursive=true, use
 // ceph::make_recursive_mutex.  For legacy Mutex users that passed
index 8d05b12fbe2b30ee2499ee110f2b87c48696bae8..bec46d1f6981c7d90e77038c4a65b178728daa9c 100644 (file)
@@ -20,7 +20,7 @@
 
 #include "include/ceph_assert.h"
 #include "include/common_fwd.h"
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include <seastar/util/log.hh>
 #include "crimson/common/log.h"
 #include "crimson/common/config_proxy.h"
@@ -139,7 +139,7 @@ struct is_dynamic<dynamic_marker_t<T>> : public std::true_type {};
 // generic macros
 #define dout_prefix *_dout
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #define dout_impl(cct, sub, v)                                          \
   do {                                                                  \
     if (crimson::common::local_conf()->subsys.should_gather(sub, v)) {  \
index 4ecfaf81fc662f55a7aa87ca9abed800240e87e0..9358727e148cd0ee7ffb36ddafed75fb311ab9b1 100644 (file)
@@ -15,7 +15,7 @@
 #include "include/mempool.h"
 #include "include/demangle.h"
 
-#if defined(_GNU_SOURCE) && defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#if defined(_GNU_SOURCE) && defined(WITH_SEASTAR)
 #else
 // Thread local variables should save index, not &shard[index],
 // because shard[] is defined in the class
@@ -98,7 +98,7 @@ size_t mempool::pool_t::allocated_items() const
 
 void mempool::pool_t::adjust_count(ssize_t items, ssize_t bytes)
 {
-#if defined(_GNU_SOURCE) && defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#if defined(_GNU_SOURCE) && defined(WITH_SEASTAR)
   // the expected path: we alway pick the shard for a cpu core
   // a thread is executing on.
   const size_t shard_index = pick_a_shard_int();
@@ -128,7 +128,7 @@ void mempool::pool_t::get_stats(
     for (auto &p : type_map) {
       std::string n = ceph_demangle(p.second.type_name);
       stats_t &s = (*by_type)[n];
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
       s.bytes = 0;
       s.items = 0;
       for (size_t i = 0 ; i < num_shards; ++i) {
index 17828fda8dd63c7275e16c7a5e3a88325c9c644f..14949fdcffd344e9b404e9a663c0fda0e57ec4c2 100644 (file)
@@ -531,7 +531,7 @@ PerfCounters::PerfCounters(CephContext *cct, const std::string &name,
     m_lower_bound(lower_bound),
     m_upper_bound(upper_bound),
     m_name(name)
-#if !defined(WITH_SEASTAR) || defined(WITH_ALIEN)
+#ifndef WITH_SEASTAR
     ,
     m_lock_name(std::string("PerfCounters::") + name.c_str()),
     m_lock(ceph::make_mutex(m_lock_name))
index 411f9abecdfb23691e220a3d346207923aa9fed0..80a17d10bc8875a696a122a1f22025729a41c5ab 100644 (file)
@@ -305,7 +305,7 @@ private:
 
   int prio_adjust = 0;
 
-#if !defined(WITH_SEASTAR) || defined(WITH_ALIEN)
+#ifndef WITH_SEASTAR
   const std::string m_lock_name;
   /** Protects m_data */
   ceph::mutex m_lock;
index 0fea21d558aea3da3ad1468ce71549b176de5572..e87a01685cdc6a94c037382c937eade09c1a1aee 100644 (file)
 
 #include <string.h>
 #include "common/ceph_context.h"
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include "crimson/common/config_proxy.h"
 #endif
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 namespace ceph::global {
 int __attribute__((weak)) g_conf_set_val(const std::string& key, const std::string& s) {
   return 0;
@@ -38,14 +38,14 @@ int __attribute__((weak)) g_conf_rm_val(const std::string& key) {
 namespace TOPNSPC::global {
 CephContext *g_ceph_context = NULL;
 ConfigProxy& g_conf() {
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
   return crimson::common::local_conf();
 #else
   return g_ceph_context->_conf;
 #endif
 }
 
-#ifdef WITH_ALIEN
+#ifndef WITH_SEASTAR
 int g_conf_set_val(const std::string& key, const std::string& s)
 {
   if (g_ceph_context != NULL)
index d906aadfa460314f2727508e7ea2db5348f5138f..e7ed9cae6a352021190c1787b7a8bb50c815e37e 100644 (file)
@@ -1,6 +1,6 @@
 #pragma once
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #define TOPNSPC crimson
 #else
 #define TOPNSPC ceph
index a6dca48dd6fef43d5e2f9baadc8c0cbd5f0a6b52..4535bffcde78f8e5142de76a40cb6888625a0bf3 100644 (file)
@@ -26,7 +26,7 @@
 #include <boost/container/flat_set.hpp>
 #include <boost/container/flat_map.hpp>
 
-#if defined(_GNU_SOURCE) && defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#if defined(_GNU_SOURCE) && defined(WITH_SEASTAR)
 #  include <sched.h>
 #endif
 
@@ -206,7 +206,7 @@ enum {
 };
 
 static size_t pick_a_shard_int() {
-#if defined(_GNU_SOURCE) && defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#if defined(_GNU_SOURCE) && defined(WITH_SEASTAR)
   // a thread local storage is actually just an approximation;
   // what we truly want is a _cpu local storage_.
   //
@@ -262,7 +262,7 @@ const char *get_pool_name(pool_index_t ix);
 struct type_t {
   const char *type_name;
   size_t item_size;
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
   struct type_shard_t {
     ceph::atomic<ssize_t> items = {0}; // signed
     char __padding[128 - sizeof(ceph::atomic<ssize_t>)];
@@ -366,7 +366,7 @@ public:
     shard.bytes += total;
     shard.items += n;
     if (type) {
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
       type->shards[shid].items += n;
 #else
       type->items += n;
@@ -383,7 +383,7 @@ public:
     shard.bytes -= total;
     shard.items -= n;
     if (type) {
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
       type->shards[shid].items -= n;
 #else
       type->items -= n;
@@ -399,7 +399,7 @@ public:
     shard.bytes += total;
     shard.items += n;
     if (type) {
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
       type->shards[shid].items += n;
 #else
       type->items += n;
@@ -420,7 +420,7 @@ public:
     shard.bytes -= total;
     shard.items -= n;
     if (type) {
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
       type->shards[shid].items -= n;
 #else
       type->items -= n;
index 588280a7df12b52620d279ccc03de1fef2fc66ac..86763fd5f884b4b2bb83d9b1f5b5942aabd29b48 100644 (file)
@@ -20,7 +20,7 @@
 #include <time.h>
 #include <errno.h>
 
-#if defined(WITH_SEASTAR)
+#ifdef WITH_SEASTAR
 #include <seastar/core/lowres_clock.hh>
 #endif
 
@@ -93,7 +93,7 @@ public:
     tv.tv_nsec = std::max<common_t>((std::chrono::duration_cast<std::chrono::nanoseconds>(dur) %
                                     std::chrono::seconds(1)).count(), 0);
   }
-#if defined(WITH_SEASTAR)
+#ifdef WITH_SEASTAR
   explicit utime_t(const seastar::lowres_system_clock::time_point& t) {
     tv.tv_sec = std::chrono::duration_cast<std::chrono::seconds>(
         t.time_since_epoch()).count();
index 9170b1468a1af0e76ec685d72ee54089addad8d5..72773c7c7da761e3350801563df574b647ced4fd 100644 (file)
@@ -35,7 +35,7 @@
 
 #include "common/debug.h"
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index 1d9d7e4954edfecfc08d25f3117ff0afb569341b..95280f6cc9731d6d49c537ff46c64ef30319f4af 100644 (file)
@@ -52,7 +52,7 @@ SQLITE_EXTENSION_INIT1
 #include "include/libcephsqlite.h"
 #include "SimpleRADOSStriper.h"
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index bc1a15d35a6e684689eccd4c3dda41252c4d15cc..8ac8280442735dd83a24cc8f7618ab3e78ab08a4 100644 (file)
@@ -26,7 +26,7 @@
 #include "CInode.h"
 #include "Mutation.h"
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index 9a4e11e5aeb6317f2c2886af508b636a43d3e1d2..748a83f7c7cf9e9ef59b08f692cc0dcec9264deb 100644 (file)
@@ -96,7 +96,7 @@
 
 #include "auth/none/AuthNoneClientHandler.h"
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index 5d2a12a1a1defcedb33dd99f9cf594393b0706e7..a25194260a2368217c41b40676c9a2317faae686 100644 (file)
@@ -23,7 +23,7 @@
 #include "common/Timer.h"
 #include "messages/PaxosServiceMessage.h"
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index 436e0859b0a589db31b125b759f141451f1c428e..4bef92055be18890cf1b2b44d322a0e2c82dc4bf 100644 (file)
@@ -23,7 +23,7 @@
 #include "msg/async/Event.h"
 #include "msg/msg_types.h"
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index 843415159211b6c1b2fd648c56dcdfb984bd37d2..4016ba92560c94d01ea75269fcd7466d6bb39c47 100644 (file)
@@ -13,7 +13,7 @@
 #include "include/ceph_assert.h"
 #include "common/admin_socket.h"
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index 9f111285cbc30327e1eec95c29b0bae6fa7ff6b4..4f1a30efebc6decf44084f14ff36f6d36f5469f1 100644 (file)
@@ -2775,7 +2775,7 @@ void PeeringState::activate(
 
       psdout(10) << "activate peer osd." << peer << " " << pi << dendl;
 
-      #if defined(WITH_SEASTAR)
+      #ifdef WITH_SEASTAR
       MURef<MOSDPGLog> m;
       #else
       MRef<MOSDPGLog> m;
index 518baa4d70420557be0b017335aee551c6614275..f1c552b2120e64c84aa0c5bf4bb2c059a7d15c9b 100644 (file)
@@ -79,7 +79,7 @@ struct PeeringCtx;
 
 // [primary only] content recovery state
 struct BufferedRecoveryMessages {
-#if defined(WITH_SEASTAR)
+#ifdef WITH_SEASTAR
   std::map<int, std::vector<MessageURef>> message_map;
 #else
   std::map<int, std::vector<MessageRef>> message_map;
@@ -287,7 +287,7 @@ public:
     virtual uint64_t get_snap_trimq_size() const = 0;
 
     /// Send cluster message to osd
-    #if defined(WITH_SEASTAR)
+    #ifdef WITH_SEASTAR
     virtual void send_cluster_message(
       int osd, MessageURef m, epoch_t epoch, bool share_map_update=false) = 0;
     #else
index c43dad34b1b267fae8eb62abc145c6e648e4ee6f..0a423b1b4e18064c7225c4b703dddfeb9f53ec72 100644 (file)
@@ -13,7 +13,7 @@
 
 #include <unordered_map>
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index a74c8043e8b682265c701e067372af2fb6ba7e7b..c0e986635e76e77f6c25fc6a0ae29bb7ac070c05 100644 (file)
@@ -8,7 +8,7 @@
 #include "common/config.h"
 #include "rgw_dmclock.h"
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index 918b70ffc3973c4992d9fb797e1a3dc9308c5d53..de1f064acf79cfbc3d7184d44c9dae9082a111ef 100644 (file)
@@ -5,7 +5,7 @@
 #include "rgw_dmclock_sync_scheduler.h"
 #include "rgw_dmclock_scheduler_ctx.h"
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index b320c8a72c99765b1c907b338989c9af371cfc4a..ebde1680f0aac6ed4067a5c4e69a8359b4370c3e 100644 (file)
@@ -30,7 +30,7 @@
 #include "include/ceph_assert.h" // fio.h clobbers our assert.h
 #include <algorithm>
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_SEASTAR
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"