]> git.apps.os.sepia.ceph.com Git - ceph-ci.git/commitdiff
src: sed -i 's/WITH_SEASTAR/WITH_CRIMSON/'
authorMatan Breizman <mbreizma@redhat.com>
Thu, 3 Apr 2025 07:53:15 +0000 (07:53 +0000)
committerMatan Breizman <mbreizma@redhat.com>
Thu, 3 Apr 2025 07:53:15 +0000 (07:53 +0000)
Signed-off-by: Matan Breizman <mbreizma@redhat.com>
87 files changed:
CMakeLists.txt
ceph.spec.in
debian/rules
do_freebsd.sh
doc/dev/crimson/crimson.rst
etc/sysctl/CMakeLists.txt
install-deps.sh
src/CMakeLists.txt
src/auth/AuthSessionHandler.cc
src/auth/cephx/CephxProtocol.cc
src/auth/cephx/CephxSessionHandler.cc
src/common/Finisher.cc
src/common/PriorityCache.cc
src/common/RefCountedObj.h
src/common/Thread.cc
src/common/Throttle.h
src/common/TrackedOp.h
src/common/WorkQueue.h
src/common/admin_socket.cc
src/common/admin_socket.h
src/common/ceph_atomic.h
src/common/ceph_context.cc
src/common/ceph_context.h
src/common/ceph_mutex.h
src/common/common_init.cc
src/common/common_init.h
src/common/config_proxy.h
src/common/config_values.cc
src/common/dout.h
src/common/options/global.yaml.in
src/common/perf_counters.cc
src/common/perf_counters.h
src/common/perf_counters_cache.h
src/common/pick_address.cc
src/common/pick_address.h
src/common/shared_cache.hpp
src/common/version.cc
src/crimson/CMakeLists.txt
src/dmclock/src/dmclock_server.h
src/global/global_context.cc
src/include/buffer.h
src/include/common_fwd.h
src/include/utime.h
src/kv/RocksDBStore.cc
src/libcephsqlite.cc
src/mds/FSMap.cc
src/mds/Server.h
src/messages/MForward.h
src/messages/MOSDOp.h
src/messages/MOSDPGNotify2.h
src/messages/MOSDPeeringOp.h
src/mon/MonMap.cc
src/mon/MonMap.h
src/mon/Monitor.cc
src/mon/Paxos.cc
src/msg/Message.cc
src/msg/Message.h
src/msg/async/Stack.h
src/os/ObjectStore.h
src/os/bluestore/BlueFS.cc
src/osd/ClassHandler.cc
src/osd/DynamicPerfStats.h
src/osd/ECCommon.cc
src/osd/ECCommon.h
src/osd/ECCommonL.cc
src/osd/ECCommonL.h
src/osd/ECListener.h
src/osd/OSDMap.h
src/osd/OpRequest.h
src/osd/PGLog.cc
src/osd/PGLog.h
src/osd/PGTransaction.h
src/osd/PeeringState.cc
src/osd/PeeringState.h
src/osd/SnapMapper.cc
src/osd/SnapMapper.h
src/osd/osd_types.h
src/osd/scheduler/mClockScheduler.cc
src/osd/scrubber/osd_scrub_sched.h
src/osdc/ObjectCacher.cc
src/rgw/rgw_dmclock_scheduler_ctx.h
src/rgw/rgw_dmclock_sync_scheduler.cc
src/script/run-make.sh
src/test/CMakeLists.txt
src/test/fio/fio_ceph_objectstore.cc
src/test/rgw/test_rgw_amqp.cc
src/test/rgw/test_rgw_lua.cc

index 4e30d65e31d2d0a9ca2c8a08212c8eee67b13fcd..dc411ddfa7d4609fbdc7ae22a984bc09d33cc81e 100644 (file)
@@ -705,8 +705,8 @@ if (WITH_SYSTEM_ROCKSDB)
   find_package(RocksDB 5.14 REQUIRED)
 endif()
 
-option(WITH_SEASTAR "Build seastar components")
-set(HAVE_SEASTAR ${WITH_SEASTAR})
+option(WITH_CRIMSON "Build seastar components")
+set(HAVE_SEASTAR ${WITH_CRIMSON})
 
 # Boost
 option(WITH_SYSTEM_BOOST "require and build with system Boost" OFF)
@@ -721,7 +721,7 @@ if(WITH_MGR)
   list(APPEND BOOST_COMPONENTS
     python${MGR_PYTHON_VERSION_MAJOR}${MGR_PYTHON_VERSION_MINOR})
 endif()
-if(WITH_SEASTAR)
+if(WITH_CRIMSON)
   list(APPEND BOOST_COMPONENTS timer)
 endif()
 
index 12dbad48d6d6bc60809d892455a41356fc2dc886..2a604e0f9deec51171fa5dfc9d3d6d6dbc841ec6 100644 (file)
@@ -1544,7 +1544,7 @@ cmake .. \
     -DWITH_SYSTEM_QATZIP:BOOL=ON \
 %endif
 %if 0%{with seastar}
-    -DWITH_SEASTAR:BOOL=ON \
+    -DWITH_CRIMSON:BOOL=ON \
     -DWITH_JAEGER:BOOL=OFF \
 %endif
     -DWITH_GRAFANA:BOOL=ON \
index 6c0ab5e12c690aa3f970a120249872bd72ad7a6c..d365416024254a0b0282c74a249e0cc19d710f58 100755 (executable)
@@ -12,7 +12,7 @@ ifneq (,$(findstring WITH_STATIC_LIBSTDCXX,$(CEPH_EXTRA_CMAKE_ARGS)))
   # see http://tracker.ceph.com/issues/25209
   export DEB_LDFLAGS_MAINT_STRIP = -Wl,-Bsymbolic-functions
 endif
-ifeq (,$(findstring WITH_SEASTAR,$(CEPH_EXTRA_CMAKE_ARGS)))
+ifeq (,$(findstring WITH_CRIMSON,$(CEPH_EXTRA_CMAKE_ARGS)))
   export CEPH_OSD_BASENAME = ceph-osd
 else
   export CEPH_OSD_BASENAME = crimson-osd
index 442fd633f46e933395e759636be4932829016546..c962458b437ef751f7efa930091a01532de3535d 100755 (executable)
@@ -49,7 +49,7 @@ mkdir ${BUILD_DIR}
        -D WITH_SYSTEM_NPM=ON \
        -D WITH_LTTNG=OFF \
        -D WITH_BABELTRACE=OFF \
-       -D WITH_SEASTAR=OFF \
+       -D WITH_CRIMSON=OFF \
        -D WITH_FUSE=ON \
        -D WITH_KRBD=OFF \
        -D WITH_XFS=OFF \
index f6d59a057ff85301bdad23a67b85497df2d88f65..21e6ab344339042095075d951f0279d255ac7d44 100644 (file)
@@ -15,8 +15,8 @@ Building Crimson
 
 Crimson is not enabled by default. Enable it at build time by running::
 
-  $ WITH_SEASTAR=true ./install-deps.sh
-  $ ./do_cmake.sh -DWITH_SEASTAR=ON
+  $ WITH_CRIMSON=true ./install-deps.sh
+  $ ./do_cmake.sh -DWITH_CRIMSON=ON
 
 Please note, `ASan`_ is enabled by default if Crimson is built from a source
 cloned using ``git``.
index a31344c6a9c49e72f0f947790a525a9bba02ab9d..7acd810f02c372a079a9b9cc7fff5a38f60e810e 100644 (file)
@@ -4,7 +4,7 @@ if(CMAKE_SIZEOF_VOID_P EQUAL 8)
   set(sysctl_pid_max "kernel.pid_max = 4194304")
 endif()
 
-if(WITH_SEASTAR)
+if(WITH_CRIMSON)
   configure_file(90-crimson-osd.conf.in
     ${CMAKE_CURRENT_SOURCE_DIR}/90-ceph-osd.conf
     @ONLY)
index 6df0b94e33ae065aaf2da3bd8546f442f230869c..54bacb6567a8a2a13a4e88421fe894e1fbcd8791 100755 (executable)
@@ -372,7 +372,7 @@ if [ x$(uname)x = xFreeBSDx ]; then
         sysutils/fusefs-libs \
     exit
 else
-    [ $WITH_SEASTAR ] && with_seastar=true || with_seastar=false
+    [ $WITH_CRIMSON ] && with_seastar=true || with_seastar=false
     [ $WITH_PMEM ] && with_pmem=true || with_pmem=false
     source /etc/os-release
     case "$ID" in
index 6f1f1d38c05f233a96c666d078b64228d37a0d83..0a142bdb462034d0e45a14326d8b8fa86dc6b552 100644 (file)
@@ -391,7 +391,7 @@ set_target_properties(Boost::MPL PROPERTIES
   INTERFACE_COMPILE_DEFINITIONS
     "BOOST_MPL_CFG_NO_PREPROCESSED_HEADERS;BOOST_MPL_LIMIT_LIST_SIZE=30")
 
-if(WITH_SEASTAR)
+if(WITH_CRIMSON)
   find_package(c-ares 1.13.0 QUIET)
   if(NOT c-ares_FOUND)
     message(STATUS "Could not find c-ares, will build it")
index d7ad21831edea3ffd9f73d1a27a932307d46149b..f0a8374005ede15beb430e5d926ea9d0d4e2efbd 100644 (file)
@@ -31,7 +31,7 @@ AuthSessionHandler *get_auth_session_handler(
 {
 
   // Should add code to only print the SHA1 hash of the key, unless in secure debugging mode
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   ldout(cct,10) << "In get_auth_session_handler for protocol " << protocol << dendl;
 #endif
   switch (protocol) {
index 9d423b1463d869efb8cb6a655205cba43045c631..93504358d32b1b1b77b6a2642ed0ddbcda760598 100644 (file)
@@ -526,7 +526,7 @@ bool cephx_verify_authorizer(CephContext *cct, const KeyStore& keys,
     // generate a connection secret
     connection_secret->resize(connection_secret_required_len);
     if (connection_secret_required_len) {
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
       std::random_device rd;
       std::generate_n(connection_secret->data(),
                      connection_secret_required_len,
index 6b27125688a338be661172a892e6091f8a11c4b5..1c0ad4e63539e74b585cf7ee159d3789924ef90d 100644 (file)
@@ -25,7 +25,7 @@
 #define dout_subsys ceph_subsys_auth
 
 namespace {
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
   crimson::common::ConfigProxy& conf(CephContext*) {
     return crimson::common::local_conf();
   }
index b8e7f3e63420cbb5083032fa41fbec17f0944d30..34eb84109375353e0c088adda237b2e58d8004ca 100644 (file)
@@ -5,7 +5,7 @@
 #include "common/perf_counters.h"
 #include "include/types.h" // for operator<<(std::vector)
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index fa845991d7f1968a85b6e856cbdded31bfbe9748..ca5165f1ae1539436995c0dd627e00b1c43cde33 100644 (file)
@@ -16,7 +16,7 @@
 #include "common/dout.h"
 #include "perfglue/heap_profiler.h"
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_CRIMSON
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index 6dfdd4a592b48d2c47a887cd8acbcba89aa4cc61..924d01eea8097415cc9313e0437d51bc4dccebca 100644 (file)
@@ -89,7 +89,7 @@ template<typename... Args>
   virtual ~RefCountedObjectSafe() override {}
 };
 
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
 
 /**
  * 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 // ifndef WITH_SEASTAR
+#endif // ifndef WITH_CRIMSON
 
 static inline void intrusive_ptr_add_ref(const RefCountedObject *p) {
   p->get();
index c714aa0aa87917f6c9dde89cacf3d31f12a40b1a..ec397d663403f446621db6146c8e10a53f8b5c3a 100644 (file)
@@ -18,7 +18,7 @@
 #include <sys/syscall.h>   /* For SYS_xxx definitions */
 #endif
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/os/alienstore/alien_store.h"
 #endif
 
index b46878994edda88aa3d0206ad2266896663dfbf8..dac441bbbf05086690470dcf65dd34fae3a8ee44 100644 (file)
@@ -15,7 +15,7 @@
 #include "include/Context.h"
 #include "common/ThrottleInterface.h"
 #include "common/Timer.h"
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index 1cc76a4b5f9346d49f9f02d2854cb05a30062ef5..c6e3ab50b8eac51ed85123d78b2d9e869a686484 100644 (file)
@@ -28,7 +28,7 @@
 #include "include/spinlock.h"
 #include "msg/Message.h"
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index f51c59b9f9e3871be5efa9468a5dc73d939c42f0..64cede55ffa985301ffad7cdce7d047fae2ce02f 100644 (file)
@@ -15,7 +15,7 @@
 #ifndef CEPH_WORKQUEUE_H
 #define CEPH_WORKQUEUE_H
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 // for ObjectStore.h
 struct ThreadPool {
   struct TPHandle {
index b345d7cfb2ca0a34ba06199fee4c726b1b6954d7..957f92ad4d3b626d3e9bd17a5e35ae0fe8db277e 100644 (file)
@@ -35,7 +35,7 @@
 #include "common/version.h"
 #include "common/ceph_mutex.h"
 
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
 #include "common/Cond.h"
 #endif
 
@@ -442,7 +442,7 @@ void AdminSocket::do_tell_queue()
        auto reply = new MCommandReply(r, err);
        reply->set_tid(m->get_tid());
        reply->set_data(outbl);
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
         // TODO: crimson: handle asok commmand from alien thread
 #else
        m->get_connection()->send_message(reply);
@@ -458,7 +458,7 @@ void AdminSocket::do_tell_queue()
        auto reply = new MMonCommandAck(m->cmd, r, err, 0);
        reply->set_tid(m->get_tid());
        reply->set_data(outbl);
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
         // TODO: crimson: handle asok commmand from alien thread
 #else
        m->get_connection()->send_message(reply);
@@ -473,7 +473,7 @@ int AdminSocket::execute_command(
   std::ostream& errss,
   bufferlist *outbl)
 {
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
    // TODO: crimson: blocking execute_command() in alien thread
   return -ENOSYS;
 #else
index 4183ad30fb3ab8f5cd2d8752c43a7f51ea9a4bb5..55f3ab15a541dd0853654b92bb914882b3ab2c72 100644 (file)
@@ -15,7 +15,7 @@
 #ifndef CEPH_COMMON_ADMIN_SOCKET_H
 #define CEPH_COMMON_ADMIN_SOCKET_H
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/admin/admin_socket.h"
 #else
 
index 4a96ed97e9c7acd54a126d6e7bf9f8316c8b3d70..76a4db3c6fcc6d7d5af88c341efaafca6ed6e20a 100644 (file)
@@ -17,7 +17,7 @@
 // like a full memory barrier stalling execution till CPU's store and
 // load buffers are drained.
 
-#if defined(WITH_SEASTAR) && !defined(WITH_BLUESTORE)
+#if defined(WITH_CRIMSON) && !defined(WITH_BLUESTORE)
 
 #include <type_traits>
 
@@ -84,10 +84,10 @@ namespace ceph {
   template <class T> using atomic = dummy_atomic<T>;
 } // namespace ceph
 
-#else  // WITH_SEASTAR
+#else  // WITH_CRIMSON
 
 namespace ceph {
   template <class T> using atomic = ::std::atomic<T>;
 } // namespace ceph
 
-#endif // WITH_SEASTAR
+#endif // WITH_CRIMSON
index cbcf8a90327847d5b0b43624e339c9cb7fa9c746..8e6cbcf39a1c26f9dfb141c5381c7d0a13ac141d 100644 (file)
@@ -48,7 +48,7 @@
 #include "common/PluginRegistry.h"
 #include "common/valgrind.h"
 #include "include/spinlock.h"
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
 #include "mon/MonMap.h"
 #endif
 
@@ -64,7 +64,7 @@ using ceph::bufferlist;
 using ceph::HeartbeatMap;
 
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 namespace crimson::common {
 CephContext::CephContext()
   : _conf{crimson::common::local_conf()},
@@ -105,7 +105,7 @@ PerfCountersCollectionImpl* CephContext::get_perfcounters_collection()
 }
 
 }
-#else  // WITH_SEASTAR
+#else  // WITH_CRIMSON
 namespace {
 
 #ifdef CEPH_DEBUG_MUTEX
@@ -1063,4 +1063,4 @@ void CephContext::set_mon_addrs(const MonMap& mm) {
   set_mon_addrs(mon_addrs);
 }
 }
-#endif // WITH_SEASTAR
+#endif // WITH_CRIMSON
index 5a2619a8f2be6795060e3dfb5df7cf2f22989d7e..cd8dd1404d57774c44d64e96e8bfe490367adc73 100644 (file)
@@ -34,7 +34,7 @@
 #include "common/cmdparse.h"
 #include "common/code_environment.h"
 #include "msg/msg_types.h"
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/config_proxy.h"
 #include "crimson/common/perf_counters_collection.h"
 #else
@@ -67,7 +67,7 @@ namespace ceph {
   }
 }
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 namespace crimson::common {
 class CephContext {
 public:
@@ -424,9 +424,9 @@ private:
 #ifdef __cplusplus
 }
 #endif
-#endif // WITH_SEASTAR
+#endif // WITH_CRIMSON
 
-#if !defined(WITH_SEASTAR) && defined(__cplusplus)
+#if !defined(WITH_CRIMSON) && defined(__cplusplus)
 namespace ceph::common {
 inline void intrusive_ptr_add_ref(CephContext* cct)
 {
@@ -438,5 +438,5 @@ inline void intrusive_ptr_release(CephContext* cct)
   cct->put();
 }
 }
-#endif // !defined(WITH_SEASTAR) && defined(__cplusplus)
+#endif // !defined(WITH_CRIMSON) && defined(__cplusplus)
 #endif
index 7430472cc952612c992658f877a67c6f78d12946..120b04f9e3b8a0334a6affc6525000e4e7dd45b7 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.
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #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  // ifdef WITH_SEASTAR
+#else  // ifdef WITH_CRIMSON
 //
 // For legacy Mutex users that passed recursive=true, use
 // ceph::make_recursive_mutex.  For legacy Mutex users that passed
@@ -197,7 +197,7 @@ namespace ceph {
 
 #endif // CEPH_DEBUG_MUTEX
 
-#endif // WITH_SEASTAR
+#endif // WITH_CRIMSON
 
 namespace ceph {
 
index 5e61c507831a502942f92397207fe8eec78ced4e..0c3d6a84ea1057a2253c909cd4e1f6366d0c33de 100644 (file)
@@ -27,7 +27,7 @@
 
 #define dout_subsys ceph_subsys_
 
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
 CephContext *common_preinit(const CephInitParameters &iparams,
                            enum code_environment_t code_env, int flags)
 {
@@ -73,7 +73,7 @@ CephContext *common_preinit(const CephInitParameters &iparams,
   }
   return cct;
 }
-#endif // #ifndef WITH_SEASTAR
+#endif // #ifndef WITH_CRIMSON
 
 void complain_about_parse_error(CephContext *cct,
                                const std::string& parse_error)
@@ -84,7 +84,7 @@ void complain_about_parse_error(CephContext *cct,
   lderr(cct) << parse_error << dendl;
 }
 
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
 
 /* Please be sure that this can safely be called multiple times by the
  * same application. */
@@ -131,4 +131,4 @@ void common_init_finish(CephContext *cct)
   }
 }
 
-#endif // #ifndef WITH_SEASTAR
+#endif // #ifndef WITH_CRIMSON
index a6940c6eb89236cb65c0f8e098d81b44bb1ba39c..c5a469bee7c4c8eae9966a9ee6bfeb18209319d9 100644 (file)
@@ -43,7 +43,7 @@ enum common_init_flags_t {
   CINIT_FLAG_NO_CCT_PERF_COUNTERS = 0x40,
 };
 
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
 class CephInitParameters;
 
 /*
@@ -65,7 +65,7 @@ class CephInitParameters;
  */
 CephContext *common_preinit(const CephInitParameters &iparams,
                            enum code_environment_t code_env, int flags);
-#endif // #ifndef WITH_SEASTAR
+#endif // #ifndef WITH_CRIMSON
 
 /* Print out some parse error. */
 void complain_about_parse_error(CephContext *cct,
index 7710eec85adbc714560a6cf5cf7c27392a6d0e5f..cdd705509f1c35edfbf1fe16e6159584d68075a8 100644 (file)
@@ -84,7 +84,7 @@ public:
     return values;
   }
   void set_config_values(const ConfigValues& val) {
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
     std::lock_guard l{lock};
 #endif
     values = val;
index f4a0a19595c5628a4c335544ccdc6a4187b1527c..2cdecbf0d83aecc7143ba5e5e0b8c40d769324b9 100644 (file)
@@ -2,7 +2,7 @@
 #include "config_values.h"
 
 #include "config.h"
-#if WITH_SEASTAR
+#if WITH_CRIMSON
 #include "crimson/common/log.h"
 #endif
 
@@ -78,7 +78,7 @@ void ConfigValues::set_logging(int which, const char* val)
     }
     subsys.set_log_level(which, log);
     subsys.set_gather_level(which, gather);
-#if WITH_SEASTAR
+#if WITH_CRIMSON
     crimson::get_logger(which).set_level(crimson::to_log_level(log));
 #endif
   }
index bec46d1f6981c7d90e77038c4a65b178728daa9c..4fed3d9178dd35765e8c00104a1b289e4b473e47 100644 (file)
@@ -20,7 +20,7 @@
 
 #include "include/ceph_assert.h"
 #include "include/common_fwd.h"
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #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
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #define dout_impl(cct, sub, v)                                          \
   do {                                                                  \
     if (crimson::common::local_conf()->subsys.should_gather(sub, v)) {  \
@@ -190,7 +190,7 @@ struct is_dynamic<dynamic_marker_t<T>> : public std::true_type {};
     _dout_cct->_log->submit_entry(std::move(_dout_e));                  \
   }                                                                     \
   } while (0)
-#endif // WITH_SEASTAR
+#endif // WITH_CRIMSON
 
 #define lsubdout(cct, sub, v)  dout_impl(cct, ceph_subsys_##sub, v) dout_prefix
 #define ldout(cct, v)  dout_impl(cct, dout_subsys, v) dout_prefix
index 99cd1b7adea0b0365b3e468eaa441dc31404d407..51200eb9dd0edb76c5f3e68db553716038da974f 100644 (file)
@@ -5174,7 +5174,7 @@ options:
     Only applied when OSD is doing ``--mkfs``.
   default: true
   verbatim: |
-    #ifdef WITH_SEASTAR
+    #ifdef WITH_CRIMSON
     // This is necessary as the Seastar's allocator imposes restrictions
     // on the number of threads that entered malloc/free/*. Unfortunately,
     // RocksDB sharding in BlueStore dramatically lifted the number of
index 9d26f579cf5f36a98005670319eb8a41057c90a0..fe9b9b1876534f0a981c163f447581e4a0397d22 100644 (file)
@@ -164,7 +164,7 @@ PerfCounters::~PerfCounters()
 
 void PerfCounters::inc(int idx, uint64_t amt)
 {
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   if (!m_cct->_conf->perf)
     return;
 #endif
@@ -185,7 +185,7 @@ void PerfCounters::inc(int idx, uint64_t amt)
 
 void PerfCounters::dec(int idx, uint64_t amt)
 {
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   if (!m_cct->_conf->perf)
     return;
 #endif
@@ -201,7 +201,7 @@ void PerfCounters::dec(int idx, uint64_t amt)
 
 void PerfCounters::set(int idx, uint64_t amt)
 {
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   if (!m_cct->_conf->perf)
     return;
 #endif
@@ -225,7 +225,7 @@ void PerfCounters::set(int idx, uint64_t amt)
 
 uint64_t PerfCounters::get(int idx) const
 {
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   if (!m_cct->_conf->perf)
     return 0;
 #endif
@@ -240,7 +240,7 @@ uint64_t PerfCounters::get(int idx) const
 
 void PerfCounters::tinc(int idx, utime_t amt)
 {
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   if (!m_cct->_conf->perf)
     return;
 #endif
@@ -261,7 +261,7 @@ void PerfCounters::tinc(int idx, utime_t amt)
 
 void PerfCounters::tinc(int idx, ceph::timespan amt)
 {
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   if (!m_cct->_conf->perf)
     return;
 #endif
@@ -282,7 +282,7 @@ void PerfCounters::tinc(int idx, ceph::timespan amt)
 
 void PerfCounters::tset(int idx, utime_t amt)
 {
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   if (!m_cct->_conf->perf)
     return;
 #endif
@@ -299,7 +299,7 @@ void PerfCounters::tset(int idx, utime_t amt)
 
 void PerfCounters::tset(int idx, ceph::timespan amt)
 {
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   if (!m_cct->_conf->perf)
     return;
 #endif
@@ -316,7 +316,7 @@ void PerfCounters::tset(int idx, ceph::timespan amt)
 
 utime_t PerfCounters::tget(int idx) const
 {
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   if (!m_cct->_conf->perf)
     return utime_t();
 #endif
@@ -332,7 +332,7 @@ utime_t PerfCounters::tget(int idx) const
 
 void PerfCounters::hinc(int idx, int64_t x, int64_t y)
 {
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   if (!m_cct->_conf->perf)
     return;
 #endif
@@ -349,7 +349,7 @@ void PerfCounters::hinc(int idx, int64_t x, int64_t y)
 
 pair<uint64_t, uint64_t> PerfCounters::get_tavg_ns(int idx) const
 {
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   if (!m_cct->_conf->perf)
     return make_pair(0, 0);
 #endif
@@ -533,7 +533,7 @@ PerfCounters::PerfCounters(CephContext *cct, const std::string &name,
     m_lower_bound(lower_bound),
     m_upper_bound(upper_bound),
     m_name(name)
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
     ,
     m_lock_name(std::string("PerfCounters::") + name.c_str()),
     m_lock(ceph::make_mutex(m_lock_name))
index 8887d9d5f809f8b3c4cf1136b0d49ae4769df0d4..23b32d5a449a4270fa2035f302e3071d7083eef6 100644 (file)
@@ -306,7 +306,7 @@ private:
 
   int prio_adjust = 0;
 
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   const std::string m_lock_name;
   /** Protects m_data */
   ceph::mutex m_lock;
index 03b21f38ba24a7dd1bfcd1f30a2dcaa6e1d8ab11..b67046eb7b9821991deb1183444875ef66363768 100644 (file)
@@ -5,7 +5,7 @@
 #include "common/intrusive_lru.h"
 #include "include/utime.h"
 
-#if defined(WITH_SEASTAR) && !defined(WITH_ALIEN)
+#ifdef WITH_CRIMSON
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index cca200b506bdee10865235d5e2980031b92a54b1..81593fd091163d391662d0e71a65962770fa11fa 100644 (file)
@@ -34,7 +34,7 @@
 #include "include/ipaddr.h"
 #include "include/str_list.h"
 #include "common/ceph_context.h"
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
 #include "common/config.h"
 #include "common/config_obs.h"
 #endif
@@ -137,7 +137,7 @@ bool matches_with_net(CephContext *cct,
 
 int grade_with_numa_node(const ifaddrs& ifa, int numa_node)
 {
-#if defined(WITH_SEASTAR) || defined(_WIN32)
+#if defined(WITH_CRIMSON) || defined(_WIN32)
   return 0;
 #else
   if (numa_node < 0) {
@@ -198,7 +198,7 @@ const struct sockaddr *find_ip_in_subnet_list(
   return best_addr;
 }
 
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
 // observe this change
 struct Observer : public md_config_obs_t {
   const std::string key;
@@ -298,7 +298,7 @@ void pick_addresses(CephContext *cct, int needs)
     }
   }
 }
-#endif // !WITH_SEASTAR
+#endif // !WITH_CRIMSON
 
 static std::optional<entity_addr_t> get_one_address(
   CephContext *cct,
index c28a6037ded797e18661288d5b4ee4087fc71d20..94eec9ee0ac7c3e78bd3f6c62193aa582a762321 100644 (file)
@@ -22,7 +22,7 @@ class entity_addrvec_t;
 #define CEPH_PICK_ADDRESS_DEFAULT_MON_PORTS  0x80
 #define CEPH_PICK_ADDRESS_PUBLIC_BIND 0x100
 
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
 /*
   Pick addresses based on subnets if needed.
 
@@ -44,7 +44,7 @@ class entity_addrvec_t;
  */
 void pick_addresses(CephContext *cct, int needs);
 
-#endif // !WITH_SEASTAR
+#endif // !WITH_CRIMSON
 
 int pick_addresses(CephContext *cct, unsigned flags, entity_addrvec_t *addrs,
                   int preferred_numa_node = -1);
index f20a930f6abb0b34c51b8e644377086a1da77cd2..d285e370ba5803e17c009f2c1d3012ce23bfe446 100644 (file)
@@ -17,7 +17,7 @@
 
 #include <map>
 #include <list>
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include <boost/smart_ptr/local_shared_ptr.hpp>
 #else
 #include <memory>
@@ -31,7 +31,7 @@
 template <class K, class V>
 class SharedLRU {
   CephContext *cct;
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
   using VPtr = boost::local_shared_ptr<V>;
   using WeakVPtr = boost::weak_ptr<V>;
 #else
index 1f25f629ef3a39bd38cee922ab99d599ecd93962..e6939541713b9094f881cea81855f3a1bdbf4f54 100644 (file)
@@ -50,7 +50,7 @@ std::string const pretty_version_to_str(void)
       << " (" << STRINGIFY(CEPH_GIT_VER) << ") "
       << ceph_release_name(CEPH_RELEASE)
       << " (" << CEPH_RELEASE_TYPE << ")"
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
       << " (crimson)"
 #endif
       ;
index b8f620c3036a2bc276d8b68432966003bfb54ff7..1823b3076a3e4fb022d1d12f31b5daeec0c00534 100644 (file)
@@ -1,5 +1,5 @@
 add_library(crimson::cflags INTERFACE IMPORTED)
-set(crimson_cflag_definitions "WITH_SEASTAR=1")
+set(crimson_cflag_definitions "WITH_CRIMSON=1")
 
 set_target_properties(crimson::cflags PROPERTIES
   INTERFACE_COMPILE_DEFINITIONS "${crimson_cflag_definitions}"
index 9d01dd62230cf3aa128cba023b77f486a7893910..f27632bf34d2dd5f6eaa145bcb05e4159464680f 100644 (file)
@@ -31,7 +31,7 @@
 #include <map>
 #include <deque>
 #include <queue>
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
 #include <atomic>
 #include <mutex>
 #include <condition_variable>
@@ -760,7 +760,7 @@ namespace crimson {
       ClientInfoFunc        client_info_f;
       static constexpr bool is_dynamic_cli_info_f = U1;
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
       static constexpr int data_mtx = 0;
       struct DataGuard { DataGuard(int) {} };
 #else
@@ -806,7 +806,7 @@ namespace crimson {
       RejectThreshold  reject_threshold = 0;
 
       double           anticipation_timeout;
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
       bool finishing;
 #else
       std::atomic_bool finishing;
@@ -1509,7 +1509,7 @@ namespace crimson {
       }
     }; // class PullPriorityQueue
 
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
     // TODO: PushPriorityQueue is not ported to seastar yet
     // PUSH version
     template<typename C, typename R, bool IsDelayed=false, bool U1=false, unsigned B=2>
@@ -1811,6 +1811,6 @@ namespace crimson {
        }
       }
     }; // class PushPriorityQueue
-#endif // !WITH_SEASTAR
+#endif // !WITH_CRIMSON
   } // namespace dmclock
 } // namespace crimson
index e87a01685cdc6a94c037382c937eade09c1a1aee..139e81d92a5a115e2ed5f794296fb279e39f639a 100644 (file)
 
 #include <string.h>
 #include "common/ceph_context.h"
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/config_proxy.h"
 #endif
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 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() {
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
   return crimson::common::local_conf();
 #else
   return g_ceph_context->_conf;
 #endif
 }
 
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
 int g_conf_set_val(const std::string& key, const std::string& s)
 {
   if (g_ceph_context != NULL)
index d8f4f306cc38df14a5cfc2e37887170dd0c3cd6b..1cbd659f2a309cee153d9d2c10971fce1290af9c 100644 (file)
 
 #define CEPH_BUFFER_API
 
-#ifdef HAVE_SEASTAR
+#ifdef WITH_CRIMSON
 namespace seastar {
 template <typename T> class temporary_buffer;
 namespace net {
 class packet;
 }
 }
-#endif // HAVE_SEASTAR
+#endif // WITH_CRIMSON
 class deleter;
 
 template<typename T> class DencDumper;
@@ -149,7 +149,7 @@ struct error_code;
   ceph::unique_leakable_ptr<raw> create_small_page_aligned(unsigned len);
   ceph::unique_leakable_ptr<raw> claim_buffer(unsigned len, char *buf, deleter del);
 
-#ifdef HAVE_SEASTAR
+#ifdef WITH_CRIMSON
   /// create a raw buffer to wrap seastar cpu-local memory, using foreign_ptr to
   /// make it safe to share between cpus
   ceph::unique_leakable_ptr<buffer::raw> create(seastar::temporary_buffer<char>&& buf);
@@ -335,12 +335,12 @@ struct error_code;
     void zero(unsigned o, unsigned l, bool crc_reset = true);
     unsigned append_zeros(unsigned l);
 
-#ifdef HAVE_SEASTAR
+#ifdef WITH_CRIMSON
     /// create a temporary_buffer, copying the ptr as its deleter
     operator seastar::temporary_buffer<char>() &;
     /// convert to temporary_buffer, stealing the ptr as its deleter
     operator seastar::temporary_buffer<char>() &&;
-#endif // HAVE_SEASTAR
+#endif // WITH_CRIMSON
 
   };
 
@@ -1105,7 +1105,7 @@ struct error_code;
       }
     }
 
-#ifdef HAVE_SEASTAR
+#ifdef WITH_CRIMSON
     /// convert the bufferlist into a network packet
     operator seastar::net::packet() &&;
 #endif
index e7ed9cae6a352021190c1787b7a8bb50c815e37e..3c449513854c10e26e8eca299f2d3cb0d55f0807 100644 (file)
@@ -1,6 +1,6 @@
 #pragma once
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #define TOPNSPC crimson
 #else
 #define TOPNSPC ceph
index 86763fd5f884b4b2bb83d9b1f5b5942aabd29b48..1b7b600c23c4ca1b6bd966d8379199337778fc5d 100644 (file)
@@ -20,7 +20,7 @@
 #include <time.h>
 #include <errno.h>
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #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);
   }
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
   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 72773c7c7da761e3350801563df574b647ced4fd..cc6b2e7ced23c94126dd01be6133eee52d7d812f 100644 (file)
@@ -35,7 +35,7 @@
 
 #include "common/debug.h"
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index 95280f6cc9731d6d49c537ff46c64ef30319f4af..fa3164d893b6faa96016a7b5f978a28ba1e613fa 100644 (file)
@@ -52,7 +52,7 @@ SQLITE_EXTENSION_INIT1
 #include "include/libcephsqlite.h"
 #include "SimpleRADOSStriper.h"
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index ea8b78bb0f6908610a4d5536ad64d60987ade742..b4d2167790d7896ed82d18d732302adcfd3eeaca 100644 (file)
@@ -20,7 +20,7 @@
 #include "common/debug.h"
 #include "common/StackStringStream.h"
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/config_proxy.h"
 #else
 #include "common/config_proxy.h"
index d4ad3aecf5d388d1b3f24cdfdeecc83c0614cb97..460618a319c70f8303016b6fea918e800b5d0359 100644 (file)
@@ -26,7 +26,7 @@
 #include "CInode.h"
 #include "Mutation.h"
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index d574a3751c53955d1df79e86b696e30d112bcf62..cf1d8d47e78e152631e4ea4ca9dab66479d07887 100644 (file)
@@ -48,7 +48,7 @@ public:
     tid(t), client_caps(caps), msg(NULL) {
     client_type = m->get_source().type();
     client_addrs = m->get_source_addrs();
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
     ceph_abort("In crimson, conn is independently maintained outside Message");
 #else
     if (auto &con = m->get_connection()) {
index 0153fdbb27231b206abd4d68001599ddeb49b57a..4b1ea979ae256a3990ca92cfacc434b68b5b35e5 100644 (file)
@@ -166,7 +166,7 @@ public:
   uint64_t get_features() const {
     if (features)
       return features;
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
     ceph_abort("In crimson, conn is independently maintained outside Message");
 #else
     return get_connection()->get_features();
index ae17edae50f23d204b98ce2890c2d6c1840e287b..17871227fd6843475a06086633352cc7663bc879 100644 (file)
@@ -33,7 +33,7 @@ public:
        spgid,
        pg_shard_t(get_source().num(), notify.from),
        notify,
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
        features
 #else
        get_connection()->get_features()
index bfb0380260c1e3a24505c6b66f32785316a34f69..7c1bf598485960395af55944ec1c2bd6a28787de 100644 (file)
@@ -26,7 +26,7 @@ public:
   virtual PGPeeringEvent *get_event() = 0;
   virtual void inner_print(std::ostream& out) const = 0;
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
   // In crimson, conn is independently maintained outside Message.
   // Instead of get features from the connection later, set features at
   // the start of the operation.
index 8d0540d71f2b15f07f3ee76840c50f038e5b1da3..128c28a3a2799517f103d892f7cfe778ea1f1327 100644 (file)
@@ -9,7 +9,7 @@
 #include <sys/stat.h>
 #include <fcntl.h>
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include <seastar/core/fstream.hh>
 #include <seastar/core/reactor.hh>
 #include <seastar/net/dns.hh>
@@ -39,7 +39,7 @@ using std::vector;
 using ceph::DNSResolver;
 using ceph::Formatter;
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 namespace {
   seastar::logger& logger()
   {
@@ -767,7 +767,7 @@ void MonMap::check_health(health_check_map_t *checks) const
   }
 }
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 
 seastar::future<> MonMap::read_monmap(const std::string& monmap)
 {
@@ -904,7 +904,7 @@ seastar::future<> MonMap::build_initial(const crimson::common::ConfigProxy& conf
   }
 }
 
-#else  // WITH_SEASTAR
+#else  // WITH_CRIMSON
 
 int MonMap::init_with_monmap(const std::string& monmap, std::ostream& errout)
 {
@@ -1030,4 +1030,4 @@ int MonMap::build_initial(CephContext *cct, bool for_mkfs, ostream& errout)
   calc_legacy_ranks();
   return 0;
 }
-#endif // WITH_SEASTAR
+#endif // WITH_CRIMSON
index dcdc2f531ab6b438f4cc4e60169e35a046674ea0..7baa9bbd7cb7fb609ea669720d2dff8125836df8 100644 (file)
@@ -15,7 +15,7 @@
 #ifndef CEPH_MONMAP_H
 #define CEPH_MONMAP_H
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include <seastar/core/future.hh>
 #endif
 
@@ -33,7 +33,7 @@
 
 class health_check_map_t;
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 namespace crimson::common {
   class ConfigProxy;
 }
@@ -459,7 +459,7 @@ public:
    * @param cct context (and associated config)
    * @param errout std::ostream to send error messages too
    */
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
   seastar::future<> build_initial(const crimson::common::ConfigProxy& conf, bool for_mkfs);
 #else
   int build_initial(CephContext *cct, bool for_mkfs, std::ostream& errout);
@@ -528,7 +528,7 @@ protected:
                      bool for_mkfs,
                      std::string_view prefix);
   int init_with_config_file(const ConfigProxy& conf, std::ostream& errout);
-#if WITH_SEASTAR
+#if WITH_CRIMSON
   seastar::future<> read_monmap(const std::string& monmap);
   /// try to build monmap with different settings, like
   /// mon_host, mon* sections, and mon_dns_srv_name
index 9c062e6651e12bc36cc98e8a1cf3ea6e4ea7206d..ba0b91527b268295b2dff9296953ba133d3001f6 100644 (file)
@@ -96,7 +96,7 @@
 
 #include "auth/none/AuthNoneClientHandler.h"
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index a25194260a2368217c41b40676c9a2317faae686..2a6167ec2e1adf40c3fdb9120ace43cda027993d 100644 (file)
@@ -23,7 +23,7 @@
 #include "common/Timer.h"
 #include "messages/PaxosServiceMessage.h"
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index e0af298231ff07c574bffe3f4cdab5f5bc3abe66..db5b1f573ff1de22a91162edcd204ba869af4b2d 100644 (file)
@@ -323,7 +323,7 @@ Message *decode_message(CephContext *cct,
                         ceph::bufferlist& data,
                         Message::ConnectionRef conn)
 {
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
   // In crimson, conn is independently maintained outside Message.
   ceph_assert(conn == nullptr);
 #endif
@@ -335,7 +335,7 @@ Message *decode_message(CephContext *cct,
     if (front_crc != footer.front_crc) {
       if (cct) {
        ldout(cct, 0) << "bad crc in front " << front_crc << " != exp " << footer.front_crc
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
                      << " from " << conn->get_peer_addr()
 #endif
                      << dendl;
@@ -348,7 +348,7 @@ Message *decode_message(CephContext *cct,
     if (middle_crc != footer.middle_crc) {
       if (cct) {
        ldout(cct, 0) << "bad crc in middle " << middle_crc << " != exp " << footer.middle_crc
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
                      << " from " << conn->get_peer_addr()
 #endif
                      << dendl;
@@ -365,7 +365,7 @@ Message *decode_message(CephContext *cct,
       if (data_crc != footer.data_crc) {
        if (cct) {
          ldout(cct, 0) << "bad crc in data " << data_crc << " != exp " << footer.data_crc
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
                        << " from " << conn->get_peer_addr()
 #endif
                        << dendl;
index 2088e2a858ec33a8de0cb6550102e4727e9cc604..5c90fb832d7982edd1a2691cc24bf389d924459f 100644 (file)
 
 class Message : public RefCountedObject {
 public:
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
   // In crimson, conn is independently maintained outside Message.
   using ConnectionRef = void*;
 #else
@@ -359,13 +359,13 @@ protected:
   }
 public:
   const ConnectionRef& get_connection() const {
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
     ceph_abort("In crimson, conn is independently maintained outside Message");
 #endif
     return connection;
   }
   void set_connection(ConnectionRef c) {
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
     // In crimson, conn is independently maintained outside Message.
     ceph_assert(c == nullptr);
 #endif
@@ -505,7 +505,7 @@ public:
     return entity_name_t(header.src);
   }
   entity_addr_t get_source_addr() const {
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
     ceph_abort("In crimson, conn is independently maintained outside Message");
 #else
     if (connection)
@@ -514,7 +514,7 @@ public:
     return entity_addr_t();
   }
   entity_addrvec_t get_source_addrs() const {
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
     ceph_abort("In crimson, conn is independently maintained outside Message");
 #else
     if (connection)
@@ -577,7 +577,7 @@ class SafeMessage : public Message {
 public:
   using Message::Message;
   bool is_a_client() const {
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
     ceph_abort("In crimson, conn is independently maintained outside Message");
 #else
     return get_connection()->get_peer_type() == CEPH_ENTITY_TYPE_CLIENT;
index 4bef92055be18890cf1b2b44d322a0e2c82dc4bf..69e5dc58a59b5c03bf95b19130e3d1fc5b092757 100644 (file)
@@ -23,7 +23,7 @@
 #include "msg/async/Event.h"
 #include "msg/msg_types.h"
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index df3ae920a2fedb89c2568bf0f63f3aa47bc33ce5..90d5ef4cd5b820ec05166f848052e50f184d2a69 100644 (file)
@@ -79,7 +79,7 @@ public:
    * @param journal path (or other descriptor) for journal (optional)
    * @param flags which filestores should check if applicable
    */
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   static std::unique_ptr<ObjectStore> create(
     CephContext *cct,
     const std::string& type,
index da6dea8931537f2e6f0e67d4c9e19093bbaec2e6..5fb54c70185b382cff1c3cf76150f7bdbea72686 100644 (file)
@@ -13,7 +13,7 @@
 #include "include/ceph_assert.h"
 #include "common/admin_socket.h"
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index d1e726408fd53c13d82fbbd30a78e4ca38618c5f..fc83391699eba5c0d7c53e1b164362efd33faa95 100644 (file)
@@ -336,7 +336,7 @@ int ClassHandler::ClassMethod::exec(cls_method_context_t ctx, bufferlist& indata
 
 ClassHandler& ClassHandler::get_instance()
 {
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
   // the context is being used solely for:
   //   1. random number generation (cls_gen_random_bytes)
   //   2. accessing the configuration
@@ -345,6 +345,6 @@ ClassHandler& ClassHandler::get_instance()
   static ClassHandler single(&cct);
 #else
   static ClassHandler single(g_ceph_context);
-#endif // WITH_SEASTAR
+#endif // WITH_CRIMSON
   return single;
 }
index c9ea7d095172c19688560cde0eae27f75bdc9323..996baabb498e3cec45e6be0f2894ec7474b5e623 100644 (file)
@@ -121,7 +121,7 @@ public:
             match_string = stringify(m->get_reqid().name);
             break;
           case OSDPerfMetricSubKeyType::CLIENT_ADDRESS:
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
            match_string = stringify(op.get_connection()->get_peer_addr());
 #else
             match_string = stringify(m->get_connection()->get_peer_addr());
index 5525906686f3cb9b746457491b8b07c06da299a8..633258c3fb004f6962f037dc7ce7fe236dcf07e5 100644 (file)
@@ -109,7 +109,7 @@ ostream &operator<<(ostream &lhs, const ECCommon::read_result_t &rhs)
 ostream &operator<<(ostream &lhs, const ECCommon::ReadOp &rhs)
 {
   lhs << "ReadOp(tid=" << rhs.tid;
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   if (rhs.op && rhs.op->get_req()) {
     lhs << ", op=";
     rhs.op->get_req()->print(lhs);
@@ -127,7 +127,7 @@ ostream &operator<<(ostream &lhs, const ECCommon::ReadOp &rhs)
 void ECCommon::ReadOp::dump(Formatter *f) const
 {
   f->dump_unsigned("tid", tid);
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   if (op && op->get_req()) {
     f->dump_stream("op") << *(op->get_req());
   }
@@ -148,7 +148,7 @@ ostream &operator<<(ostream &lhs, const ECCommon::RMWPipeline::Op &rhs)
       << " tt=" << rhs.trim_to
       << " tid=" << rhs.tid
       << " reqid=" << rhs.reqid;
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   if (rhs.client_op && rhs.client_op->get_req()) {
     lhs << " client_op=";
     rhs.client_op->get_req()->print(lhs);
@@ -416,7 +416,7 @@ void ECCommon::ReadPipeline::start_read_op(
       std::move(to_read))).first->second;
   dout(10) << __func__ << ": starting " << op << dendl;
   if (_op) {
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
     op.trace = _op->pg_trace;
 #endif
     op.trace.event("start ec read");
index 363f9890564ec9befdeabdf675260a3c9cbd8b87..8135269274d5978d3917af9880857ef9065f671e 100644 (file)
@@ -21,7 +21,7 @@
 #include "erasure-code/ErasureCodeInterface.h"
 #include "ECUtil.h"
 #include "ECTypes.h"
-#if WITH_SEASTAR
+#if WITH_CRIMSON
 #include "ExtentCache.h"
 #include "crimson/osd/object_context.h"
 #include "os/Transaction.h"
index 7bf517381ca46aadb9bb4258127fba79a7cc7015..77a0d137fb7f1c97201c41e3410ae10623acefd9 100644 (file)
@@ -108,7 +108,7 @@ ostream &operator<<(ostream &lhs, const ECCommonL::read_result_t &rhs)
 ostream &operator<<(ostream &lhs, const ECCommonL::ReadOp &rhs)
 {
   lhs << "ReadOp(tid=" << rhs.tid;
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   if (rhs.op && rhs.op->get_req()) {
     lhs << ", op=";
     rhs.op->get_req()->print(lhs);
@@ -126,7 +126,7 @@ ostream &operator<<(ostream &lhs, const ECCommonL::ReadOp &rhs)
 void ECCommonL::ReadOp::dump(Formatter *f) const
 {
   f->dump_unsigned("tid", tid);
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   if (op && op->get_req()) {
     f->dump_stream("op") << *(op->get_req());
   }
@@ -147,7 +147,7 @@ ostream &operator<<(ostream &lhs, const ECCommonL::RMWPipeline::Op &rhs)
       << " tt=" << rhs.trim_to
       << " tid=" << rhs.tid
       << " reqid=" << rhs.reqid;
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   if (rhs.client_op && rhs.client_op->get_req()) {
     lhs << " client_op=";
     rhs.client_op->get_req()->print(lhs);
@@ -415,7 +415,7 @@ void ECCommonL::ReadPipeline::start_read_op(
       std::move(to_read))).first->second;
   dout(10) << __func__ << ": starting " << op << dendl;
   if (_op) {
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
     op.trace = _op->pg_trace;
 #endif
     op.trace.event("start ec read");
index e7b3348755f234ac632b3b6c5ad52cf90a28d317..d7994d27e7a1772c6b04ab576fafad50fea4db8d 100644 (file)
@@ -22,7 +22,7 @@
 #include "erasure-code/ErasureCodeInterface.h"
 #include "ECUtilL.h"
 #include "ECTypes.h"
-#if WITH_SEASTAR
+#if WITH_CRIMSON
 #include "ECExtentCacheL.h"
 #include "crimson/osd/object_context.h"
 #include "os/Transaction.h"
index e170520dac656cfa375fbc3ccb7478fb9bd44349..79a0542661b581886c3f01374c7f26ef67f4a373 100644 (file)
@@ -35,7 +35,7 @@ struct ECListener {
   virtual void cancel_pull(
     const hobject_t &soid) = 0;
 
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   // XXX
   virtual pg_shard_t primary_shard() const = 0;
   virtual bool pgb_is_primary() const = 0;
@@ -105,7 +105,7 @@ struct ECListener {
 #endif
 
   // XXX
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   virtual GenContext<ThreadPool::TPHandle&> *bless_unlocked_gencontext(
     GenContext<ThreadPool::TPHandle&> *c) = 0;
 
index 82f706837df007ead61c4ee1cb298a1d33b04571..025420c4e63ce45dd33c4e6269465e8ff9b5f1fd 100644 (file)
@@ -40,7 +40,7 @@
 
 #include "crush/CrushWrapper.h"
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include <boost/smart_ptr/local_shared_ptr.hpp>
 #endif
 
@@ -1842,7 +1842,7 @@ public:
 WRITE_CLASS_ENCODER_FEATURES(OSDMap)
 WRITE_CLASS_ENCODER_FEATURES(OSDMap::Incremental)
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/local_shared_foreign_ptr.h"
 using LocalOSDMapRef = boost::local_shared_ptr<const OSDMap>;
 using OSDMapRef = crimson::local_shared_foreign_ptr<LocalOSDMapRef>;
index 23f3b1d932e9f38d093594e308968226b6c0be66..f477c3d1f91865b3ca383b8a4f05782dc08711da 100644 (file)
@@ -55,7 +55,7 @@ public:
   void _dump(ceph::Formatter *f) const override;
 
   bool has_feature(uint64_t f) const {
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
     ceph_abort("In crimson, conn is independently maintained outside Message");
 #else
     return request->get_connection()->has_feature(f);
index 02813e226277e72cea763e5b7158f7e5198d1ffa..9e7c0405a63e05a67e2010c33ef14698d3da12df 100644 (file)
@@ -1070,7 +1070,7 @@ void PGLog::rebuild_missing_set_with_deletes(
   set_missing_may_contain_deletes();
 }
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 
 namespace {
   struct FuturizedShardStoreLogReader {
index c7feb870268441dc3d18d58bdca7ac54b68f6f07..8c31aab2b7223fd7bbd4db58068c154993719238 100644 (file)
@@ -33,7 +33,7 @@
 #include <unordered_map>
 #include <vector>
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include <seastar/core/future.hh>
 #include "crimson/os/futurized_store.h"
 #include "crimson/os/cyanstore/cyan_collection.h"
@@ -1684,7 +1684,7 @@ public:
                       << " log.dups.size()=" << log.dups.size() << dendl;
   } // static read_log_and_missing
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
   seastar::future<> read_log_and_missing_crimson(
     crimson::os::FuturizedStore::Shard &store,
     crimson::os::CollectionRef ch,
index bb6e4efc3f47ff69bc5a44c54b4d0182942c5c97..5055b3b42e7f9f78bd41c23f9c34050fbc0c79ef 100644 (file)
@@ -19,7 +19,7 @@
 #include <optional>
 
 #include "common/hobject.h"
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
 #include "osd/osd_internal_types.h"
 #else
 #include "crimson/osd/object_context.h"
index 607c23f335b5e5da38932b2b3a13e9e5af9d7c19..7a3c911840d48d6624f85f19a85e4f663e02a0e8 100644 (file)
@@ -2779,7 +2779,7 @@ void PeeringState::activate(
 
       psdout(10) << "activate peer osd." << peer << " " << pi << dendl;
 
-      #ifdef WITH_SEASTAR
+      #ifdef WITH_CRIMSON
       MURef<MOSDPGLog> m;
       #else
       MRef<MOSDPGLog> m;
index b2cfd93c12d53224cda11abb93241311194ad932..9c3d4a8cb58addc77ddce8700a67bc6b317bdc25 100644 (file)
@@ -85,7 +85,7 @@ struct PeeringCtx;
 
 // [primary only] content recovery state
 struct BufferedRecoveryMessages {
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
   std::map<int, std::vector<MessageURef>> message_map;
 #else
   std::map<int, std::vector<MessageRef>> message_map;
@@ -293,7 +293,7 @@ public:
     virtual uint64_t get_snap_trimq_size() const = 0;
 
     /// Send cluster message to osd
-    #ifdef WITH_SEASTAR
+    #ifdef WITH_CRIMSON
     virtual void send_cluster_message(
       int osd, MessageURef m, epoch_t epoch, bool share_map_update=false) = 0;
     #else
index c484d59e58d827189424efa98a925690c8ad2522..53abac1128865332d40a95da20115ce395a312bb 100644 (file)
@@ -81,7 +81,7 @@ const char *SnapMapper::PURGED_SNAP_PREFIX = "PSN_";
 
   */
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/log.h"
 #include "crimson/osd/pg_interval_interrupt_condition.h"
   template <typename ValuesT = void>
@@ -205,7 +205,7 @@ int OSDriver::get_next_or_current(
     return -ENOENT;
   }
 }
-#endif // WITH_SEASTAR
+#endif // WITH_CRIMSON
 
   SnapMapper::SnapMapper(
     CephContext* cct,
@@ -921,7 +921,7 @@ void SnapMapper::record_purged_snaps(
 }
 
 
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
 bool SnapMapper::Scrubber::_parse_p()
 {
   if (!psit->valid()) {
@@ -1025,7 +1025,7 @@ void SnapMapper::Scrubber::run()
   psit = ObjectMap::ObjectMapIterator();
   mapit = ObjectMap::ObjectMapIterator();
 }
-#endif // !WITH_SEASTAR
+#endif // !WITH_CRIMSON
 
 
 // -------------------------------------
@@ -1051,7 +1051,7 @@ bool SnapMapper::is_legacy_mapping(const string &to_test)
     LEGACY_MAPPING_PREFIX;
 }
 
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
 /* Octopus modified the SnapMapper key format from
  *
  *  <LEGACY_MAPPING_PREFIX><snapid>_<shardid>_<hobject_t::to_str()>
@@ -1142,4 +1142,4 @@ int SnapMapper::convert_legacy(
   }
   return 0;
 }
-#endif // !WITH_SEASTAR
+#endif // !WITH_CRIMSON
index 15397e92d1ba7c0931bdea69dc4326e5d1603273..136d8a679026faaede528aca9c1c075fbc4796d2 100644 (file)
@@ -23,7 +23,7 @@
 
 #include "common/hobject.h"
 #include "common/map_cacher.hpp"
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #  include "crimson/os/futurized_store.h"
 #  include "crimson/os/futurized_collection.h"
 #endif
@@ -35,7 +35,7 @@
 #include "osd/SnapMapReaderI.h"
 
 class OSDriver : public MapCacher::StoreDriver<std::string, ceph::buffer::list> {
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
   using ObjectStoreT = crimson::os::FuturizedStore::Shard;
   using CollectionHandleT = ObjectStoreT::CollectionRef;
 #else
@@ -78,7 +78,7 @@ public:
     return OSTransaction(ch->get_cid(), hoid, t);
   }
 
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   OSDriver(ObjectStoreT *os, const coll_t& cid, const ghobject_t &hoid) :
     OSDriver(os, os->open_collection(cid), hoid) {}
 #endif
@@ -175,7 +175,7 @@ public:
   static const char *PURGED_SNAP_EPOCH_PREFIX;
   static const char *PURGED_SNAP_PREFIX;
 
-#ifndef WITH_SEASTAR
+#ifndef WITH_CRIMSON
   struct Scrubber {
     CephContext *cct;
     ObjectStore *store;
index c654cb71cd685b74e4bda3a946d8bc0f8f358266..49fd0e1939fe1de4ca01056ea312fd69521564a5 100644 (file)
@@ -29,7 +29,7 @@
 #include <string_view>
 
 #include <boost/variant.hpp>
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include <boost/smart_ptr/local_shared_ptr.hpp>
 #endif
 
@@ -3310,7 +3310,7 @@ WRITE_CLASS_ENCODER(pg_fast_info_t)
  * the might_have_unfound set
  */
 class PastIntervals {
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
   using OSDMapRef = boost::local_shared_ptr<const OSDMap>;
 #else
   using OSDMapRef = std::shared_ptr<const OSDMap>;
index 33f2d6b79067d5f5ff5df2d4e2abb793866fa44c..225873a2f6436d24eb3f3c02542d2c87412889de 100644 (file)
@@ -19,7 +19,7 @@
 #include "osd/scheduler/mClockScheduler.h"
 #include "common/debug.h"
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index c30532ce0d934151b7a006fcecf4c4ce887661a6..c3092c3e871162704c9c451fd78bdce100a0c75f 100644 (file)
@@ -224,7 +224,7 @@ class ScrubQueue {
   CephContext* cct;
   Scrub::ScrubSchedListener& osd_service;
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
   auto& conf() const { return local_conf(); }
 #else
   auto& conf() const { return cct->_conf; }
index 0a423b1b4e18064c7225c4b703dddfeb9f53ec72..42dfff2914d379fbb3de910378005b2fe2b9864a 100644 (file)
@@ -13,7 +13,7 @@
 
 #include <unordered_map>
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index c0e986635e76e77f6c25fc6a0ae29bb7ac070c05..e93b527b9fed2853ef0d57838d32656e53881e4d 100644 (file)
@@ -8,7 +8,7 @@
 #include "common/config.h"
 #include "rgw_dmclock.h"
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index de1f064acf79cfbc3d7184d44c9dae9082a111ef..942d5e98d434fab9b33083d101e35405c57b046e 100644 (file)
@@ -5,7 +5,7 @@
 #include "rgw_dmclock_sync_scheduler.h"
 #include "rgw_dmclock_scheduler_ctx.h"
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index f7868a425667d5d9750f7f3860d25fda81ae1979..e9a07ac2121631803d7c908a910924b74c2557e6 100755 (executable)
@@ -119,8 +119,8 @@ EOM
     cmake_opts+=" -DWITH_GRAFANA=ON"
     cmake_opts+=" -DWITH_SPDK=ON"
     cmake_opts+=" -DWITH_RBD_MIRROR=ON"
-    if [ $WITH_SEASTAR ]; then
-        cmake_opts+=" -DWITH_SEASTAR=ON"
+    if [ $WITH_CRIMSON ]; then
+        cmake_opts+=" -DWITH_CRIMSON=ON"
     fi
     if [ $WITH_RBD_RWL ]; then
         cmake_opts+=" -DWITH_RBD_RWL=ON"
index 76e93052df7dac3243b4c9b3e72b168484cbc8d7..449d3eb10855f92a46716a383f49ab9b0e69a47f 100644 (file)
@@ -90,7 +90,7 @@ endif(WITH_RADOSGW)
 if(WITH_RBD AND NOT WIN32)
 add_subdirectory(rbd_mirror)
 endif(WITH_RBD AND NOT WIN32)
-if(WITH_SEASTAR)
+if(WITH_CRIMSON)
   add_subdirectory(crimson)
 endif()
 add_subdirectory(system)
index ebde1680f0aac6ed4067a5c4e69a8359b4370c3e..14141392d3a9e51026694a60f505bae95c884146 100644 (file)
@@ -30,7 +30,7 @@
 #include "include/ceph_assert.h" // fio.h clobbers our assert.h
 #include <algorithm>
 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
 #include "crimson/common/perf_counters_collection.h"
 #else
 #include "common/perf_counters_collection.h"
index 7fa6f6f5444d18ee8ab7f95052442a04cb639d6c..24b80c1faff5c24eef2ac45addcdace91f18891f 100644 (file)
@@ -21,7 +21,7 @@ class CctCleaner {
 public:
   CctCleaner(CephContext* _cct) : cct(_cct) {}
   ~CctCleaner() { 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
     delete cct; 
 #else
     cct->put(); 
index d5291f8115475891a2d7aa5d072f46112c3c1ad3..8cd23b90b2f8a6d8affc60bfc8576a1aed7da85a 100644 (file)
@@ -22,7 +22,7 @@ class CctCleaner {
 public:
   CctCleaner(CephContext* _cct) : cct(_cct) {}
   ~CctCleaner() { 
-#ifdef WITH_SEASTAR
+#ifdef WITH_CRIMSON
     delete cct; 
 #else
     cct->put();