diff options
author | Vlad Yaroslavlev <vladon@vladon.com> | 2022-02-10 16:46:23 +0300 |
---|---|---|
committer | Daniil Cherednik <dcherednik@yandex-team.ru> | 2022-02-10 16:46:23 +0300 |
commit | 706b83ed7de5a473436620367af31fc0ceecde07 (patch) | |
tree | 103305d30dec77e8f6367753367f59b3cd68f9f1 /library/cpp/actors | |
parent | 918e8a1574070d0ec733f0b76cfad8f8892ad2e5 (diff) | |
download | ydb-706b83ed7de5a473436620367af31fc0ceecde07.tar.gz |
Restoring authorship annotation for Vlad Yaroslavlev <vladon@vladon.com>. Commit 1 of 2.
Diffstat (limited to 'library/cpp/actors')
36 files changed, 122 insertions, 122 deletions
diff --git a/library/cpp/actors/core/actorsystem.cpp b/library/cpp/actors/core/actorsystem.cpp index c58698a206..3914a4a183 100644 --- a/library/cpp/actors/core/actorsystem.cpp +++ b/library/cpp/actors/core/actorsystem.cpp @@ -160,7 +160,7 @@ namespace NActors { // get high 32 bits as seconds from epoch // it could wrap every century, but we don't expect any actor-reference to live this long so such wrap will do no harm - const ui64 timeFromEpoch = TInstant::MicroSeconds(RelaxedLoad(&CurrentTimestamp)).Seconds(); + const ui64 timeFromEpoch = TInstant::MicroSeconds(RelaxedLoad(&CurrentTimestamp)).Seconds(); // get low 32 bits as counter value ui32 lowPartEnd = (ui32)(AtomicAdd(CurrentIDCounter, count)); @@ -208,7 +208,7 @@ namespace NActors { StartExecuted = true; ScheduleQueue.Reset(new NSchedulerQueue::TQueueType()); - TVector<NSchedulerQueue::TReader*> scheduleReaders; + TVector<NSchedulerQueue::TReader*> scheduleReaders; scheduleReaders.push_back(&ScheduleQueue->Reader); CpuManager->PrepareStart(scheduleReaders, this); Scheduler->Prepare(this, &CurrentTimestamp, &CurrentMonotonic); diff --git a/library/cpp/actors/core/actorsystem.h b/library/cpp/actors/core/actorsystem.h index 40499d7586..27c242ccc6 100644 --- a/library/cpp/actors/core/actorsystem.h +++ b/library/cpp/actors/core/actorsystem.h @@ -42,7 +42,7 @@ namespace NActors { namespace NSchedulerQueue { class TReader; - struct TQueueType; + struct TQueueType; } class IExecutorPool : TNonCopyable { @@ -110,7 +110,7 @@ namespace NActors { virtual void Shutdown() = 0; virtual bool Cleanup() = 0; - virtual void GetCurrentStats(TExecutorPoolStats& poolStats, TVector<TExecutorThreadStats>& statsCopy) const { + virtual void GetCurrentStats(TExecutorPoolStats& poolStats, TVector<TExecutorThreadStats>& statsCopy) const { // TODO: make pure virtual and override everywhere Y_UNUSED(poolStats); Y_UNUSED(statsCopy); @@ -173,7 +173,7 @@ namespace NActors { using TProxyWrapperFactory = std::function<TActorId(TActorSystem*, ui32)>; struct TInterconnectSetup { - TVector<TActorSetupCmd> ProxyActors; + TVector<TActorSetupCmd> ProxyActors; TProxyWrapperFactory ProxyWrapperFactory; }; @@ -229,7 +229,7 @@ namespace NActors { volatile ui64 CurrentMonotonic; volatile ui64 CurrentIDCounter; - THolder<NSchedulerQueue::TQueueType> ScheduleQueue; + THolder<NSchedulerQueue::TQueueType> ScheduleQueue; mutable TTicketLock ScheduleLock; friend class TExecutorThread; diff --git a/library/cpp/actors/core/event_load.h b/library/cpp/actors/core/event_load.h index 0dab1dd374..b8872738aa 100644 --- a/library/cpp/actors/core/event_load.h +++ b/library/cpp/actors/core/event_load.h @@ -2,7 +2,7 @@ #include <util/stream/walk.h> #include <util/system/types.h> -#include <util/generic/string.h> +#include <util/generic/string.h> #include <library/cpp/actors/util/rope.h> #include <library/cpp/actors/wilson/wilson_trace.h> diff --git a/library/cpp/actors/core/event_pb_ut.cpp b/library/cpp/actors/core/event_pb_ut.cpp index a16c3092b3..fc8cb2d52c 100644 --- a/library/cpp/actors/core/event_pb_ut.cpp +++ b/library/cpp/actors/core/event_pb_ut.cpp @@ -57,7 +57,7 @@ Y_UNIT_TEST_SUITE(TEventSerialization) { TMockEvent event; event.msg = &bm; chunker.SetSerializingEvent(&event); - char buf1[87]; + char buf1[87]; TString bmChunkedSerialized; while (!chunker.IsComplete()) { auto range = chunker.FeedBuf(&buf1[0], sizeof(buf1)); diff --git a/library/cpp/actors/core/executor_pool_basic.cpp b/library/cpp/actors/core/executor_pool_basic.cpp index 4dce16939a..77b4eca1d2 100644 --- a/library/cpp/actors/core/executor_pool_basic.cpp +++ b/library/cpp/actors/core/executor_pool_basic.cpp @@ -17,7 +17,7 @@ namespace NActors { ui32 poolId, ui32 threads, ui64 spinThreshold, - const TString& poolName, + const TString& poolName, TAffinity* affinity, TDuration timePerMailbox, ui32 eventsPerMailbox, @@ -234,7 +234,7 @@ namespace NActors { } } - void TBasicExecutorPool::GetCurrentStats(TExecutorPoolStats& poolStats, TVector<TExecutorThreadStats>& statsCopy) const { + void TBasicExecutorPool::GetCurrentStats(TExecutorPoolStats& poolStats, TVector<TExecutorThreadStats>& statsCopy) const { poolStats.MaxUtilizationTime = RelaxedLoad(&MaxUtilizationAccumulator) / (i64)(NHPTimer::GetCyclesPerSecond() / 1000); statsCopy.resize(PoolThreads + 1); diff --git a/library/cpp/actors/core/executor_pool_basic.h b/library/cpp/actors/core/executor_pool_basic.h index 023190f7fe..7ccd3cd179 100644 --- a/library/cpp/actors/core/executor_pool_basic.h +++ b/library/cpp/actors/core/executor_pool_basic.h @@ -95,7 +95,7 @@ namespace NActors { void PrepareStop() override; void Shutdown() override; - void GetCurrentStats(TExecutorPoolStats& poolStats, TVector<TExecutorThreadStats>& statsCopy) const override; + void GetCurrentStats(TExecutorPoolStats& poolStats, TVector<TExecutorThreadStats>& statsCopy) const override; TString GetName() const override { return PoolName; } diff --git a/library/cpp/actors/core/executor_pool_io.cpp b/library/cpp/actors/core/executor_pool_io.cpp index fb557ae6b0..49fe990374 100644 --- a/library/cpp/actors/core/executor_pool_io.cpp +++ b/library/cpp/actors/core/executor_pool_io.cpp @@ -106,7 +106,7 @@ namespace NActors { ActorSystem = actorSystem; - ScheduleQueue.Reset(new NSchedulerQueue::TQueueType()); + ScheduleQueue.Reset(new NSchedulerQueue::TQueueType()); for (ui32 i = 0; i != PoolThreads; ++i) { Threads[i].Thread.Reset(new TExecutorThread(i, 0, actorSystem, this, MailboxTable.Get(), PoolName)); diff --git a/library/cpp/actors/core/executor_pool_io.h b/library/cpp/actors/core/executor_pool_io.h index e576d642a1..651217e0c9 100644 --- a/library/cpp/actors/core/executor_pool_io.h +++ b/library/cpp/actors/core/executor_pool_io.h @@ -19,7 +19,7 @@ namespace NActors { TArrayHolder<TThreadCtx> Threads; TUnorderedCache<ui32, 512, 4> ThreadQueue; - THolder<NSchedulerQueue::TQueueType> ScheduleQueue; + THolder<NSchedulerQueue::TQueueType> ScheduleQueue; TTicketLock ScheduleLock; const TString PoolName; diff --git a/library/cpp/actors/core/executor_pool_united.h b/library/cpp/actors/core/executor_pool_united.h index a090ba2466..3d591d7ffb 100644 --- a/library/cpp/actors/core/executor_pool_united.h +++ b/library/cpp/actors/core/executor_pool_united.h @@ -126,7 +126,7 @@ namespace NActors { void Schedule(TMonotonic deadline, TAutoPtr<IEventHandle> ev, ISchedulerCookie* cookie, TWorkerId workerId) override; void Schedule(TDuration delta, TAutoPtr<IEventHandle> ev, ISchedulerCookie* cookie, TWorkerId workerId) override; - void GetCurrentStats(TExecutorPoolStats& poolStats, TVector<TExecutorThreadStats>& statsCopy) const override; + void GetCurrentStats(TExecutorPoolStats& poolStats, TVector<TExecutorThreadStats>& statsCopy) const override; TString GetName() const override { return PoolName; diff --git a/library/cpp/actors/core/interconnect.h b/library/cpp/actors/core/interconnect.h index 679a4b8cc6..c26fe1b0b5 100644 --- a/library/cpp/actors/core/interconnect.h +++ b/library/cpp/actors/core/interconnect.h @@ -210,7 +210,7 @@ namespace NActors { }; struct TEvNodesInfo: public TEventLocal<TEvNodesInfo, EvNodesInfo> { - TVector<TNodeInfo> Nodes; + TVector<TNodeInfo> Nodes; const TNodeInfo* GetNodeInfo(ui32 nodeId) const { for (const auto& x : Nodes) { diff --git a/library/cpp/actors/core/log.cpp b/library/cpp/actors/core/log.cpp index 5f63b5af58..6322677c68 100644 --- a/library/cpp/actors/core/log.cpp +++ b/library/cpp/actors/core/log.cpp @@ -214,7 +214,7 @@ namespace NActors { if (Settings && Settings->Satisfies(priority, component, 0ull)) { va_list params; va_start(params, c); - TString formatted; + TString formatted; vsprintf(formatted, c, params); auto ok = OutputRecord(time, NLog::EPrio(priority), component, formatted); @@ -229,7 +229,7 @@ namespace NActors { } void TLoggerActor::LogIgnoredCount(TInstant now) { - TString message = Sprintf("Ignored IgnoredCount# %" PRIu64 " log records due to logger overflow!", IgnoredCount); + TString message = Sprintf("Ignored IgnoredCount# %" PRIu64 " log records due to logger overflow!", IgnoredCount); if (!OutputRecord(now, NActors::NLog::EPrio::Error, Settings->LoggerComponent, message)) { BecomeDefunct(); } @@ -304,7 +304,7 @@ namespace NActors { void TLoggerActor::HandleLogComponentLevelRequest(TLogComponentLevelRequest::TPtr& ev, const NActors::TActorContext& ctx) { Metrics->IncLevelRequests(); - TString explanation; + TString explanation; int code = Settings->SetLevel(ev->Get()->Priority, ev->Get()->Component, explanation); ctx.Send(ev->Sender, new TLogComponentLevelResponse(code, explanation)); } @@ -475,7 +475,7 @@ namespace NActors { } } else { - TString explanation; + TString explanation; if (hasComponent && hasPriority) { Settings->SetLevel(priority, component, explanation); } @@ -675,7 +675,7 @@ namespace NActors { void WriteData(const TLogRecord& rec) override { #ifdef _MSC_VER if (IsDebuggerPresent()) { - TString x; + TString x; x.reserve(rec.Len + 2); x.append(rec.Data, rec.Len); x.append('\n'); @@ -699,7 +699,7 @@ namespace NActors { } private: - const TString Indent; + const TString Indent; }; class TLineFileLogBackend: public TFileLogBackend { @@ -739,7 +739,7 @@ namespace NActors { return new TStderrBackend(); } - TAutoPtr<TLogBackend> CreateFileBackend(const TString& fileName) { + TAutoPtr<TLogBackend> CreateFileBackend(const TString& fileName) { return new TLineFileLogBackend(fileName); } diff --git a/library/cpp/actors/core/log.h b/library/cpp/actors/core/log.h index c11a7cf3c1..073c233202 100644 --- a/library/cpp/actors/core/log.h +++ b/library/cpp/actors/core/log.h @@ -163,7 +163,7 @@ namespace NActors { protected: int Code; - TString Explanation; + TString Explanation; }; class TLogIgnored: public TEventLocal<TLogIgnored, int(NLog::EEv::Ignored)> { @@ -297,7 +297,7 @@ namespace NActors { TAutoPtr<TLogBackend> CreateSysLogBackend(const TString& ident, bool logPError, bool logCons); TAutoPtr<TLogBackend> CreateStderrBackend(); - TAutoPtr<TLogBackend> CreateFileBackend(const TString& fileName); + TAutoPtr<TLogBackend> CreateFileBackend(const TString& fileName); TAutoPtr<TLogBackend> CreateNullBackend(); TAutoPtr<TLogBackend> CreateCompositeLogBackend(TVector<TAutoPtr<TLogBackend>>&& underlyingBackends); @@ -332,7 +332,7 @@ namespace NActors { NLog::EPriority mPriority, NLog::EComponent mComponent, const char* format, TArgs&&... params) { - TString Formatted; + TString Formatted; if constexpr (sizeof... (params) > 0) { diff --git a/library/cpp/actors/core/log_settings.cpp b/library/cpp/actors/core/log_settings.cpp index f52f2fc5d2..8f4009ae4c 100644 --- a/library/cpp/actors/core/log_settings.cpp +++ b/library/cpp/actors/core/log_settings.cpp @@ -90,7 +90,7 @@ namespace NActors { int TSettings::SetLevelImpl( const TString& name, bool isSampling, EPriority priority, EComponent component, TString& explanation) { - TString titleName(name); + TString titleName(name); titleName.to_title(); // check priority diff --git a/library/cpp/actors/core/log_settings.h b/library/cpp/actors/core/log_settings.h index 7fe4504edd..bd8686cefd 100644 --- a/library/cpp/actors/core/log_settings.h +++ b/library/cpp/actors/core/log_settings.h @@ -75,7 +75,7 @@ namespace NActors { bool AllowDrop; TDuration ThrottleDelay; TArrayHolder<TAtomic> ComponentInfo; - TVector<TString> ComponentNames; + TVector<TString> ComponentNames; EComponent MinVal; EComponent MaxVal; EComponent Mask; @@ -90,8 +90,8 @@ namespace NActors { JSON_FORMAT }; ELogFormat Format; - TString ShortHostName; - TString ClusterName; + TString ShortHostName; + TString ClusterName; TString MessagePrefix; // The best way to provide minVal, maxVal and func is to have @@ -167,7 +167,7 @@ namespace NActors { private: int SetLevelImpl( - const TString& name, bool isSampling, + const TString& name, bool isSampling, EPriority priority, EComponent component, TString& explanation); }; diff --git a/library/cpp/actors/core/mailbox.h b/library/cpp/actors/core/mailbox.h index 0bd9c4d314..acd6e852a3 100644 --- a/library/cpp/actors/core/mailbox.h +++ b/library/cpp/actors/core/mailbox.h @@ -399,7 +399,7 @@ namespace NActors { struct THTSwapMailbox: public TMailboxHeader { using TQueueType = NThreading::THTSwapQueue<IEventHandle*>; - TQueueType Queue; + TQueueType Queue; NHPTimer::STime ScheduleMoment; char Padding_[16]; @@ -449,7 +449,7 @@ namespace NActors { struct TReadAsFilledMailbox: public TMailboxHeader { using TQueueType = NThreading::TReadAsFilledQueue<IEventHandle>; - TQueueType Queue; + TQueueType Queue; NHPTimer::STime ScheduleMoment; char Padding_[8]; @@ -498,11 +498,11 @@ namespace NActors { "expect sizeof(TReadAsFilledMailbox) == 192"); struct TTinyReadAsFilledMailbox: public TMailboxHeader { - using TQueueType = NThreading::TReadAsFilledQueue< + using TQueueType = NThreading::TReadAsFilledQueue< IEventHandle, NThreading::TRaFQueueBunchSize<4>>; - TQueueType Queue; + TQueueType Queue; NHPTimer::STime ScheduleMoment; char Padding_[8]; diff --git a/library/cpp/actors/core/mon.h b/library/cpp/actors/core/mon.h index c450f2338e..f108b370d5 100644 --- a/library/cpp/actors/core/mon.h +++ b/library/cpp/actors/core/mon.h @@ -57,7 +57,7 @@ namespace NActors { virtual EContentType GetContentType() const = 0; }; - // Ready to output HTML in TString + // Ready to output HTML in TString struct TEvHttpInfoRes: public IEvHttpInfoRes { TEvHttpInfoRes(const TString& answer, int subReqId = 0, EContentType contentType = Html) : Answer(answer) @@ -74,7 +74,7 @@ namespace NActors { return ContentType; } - const TString Answer; + const TString Answer; const int SubRequestId; const EContentType ContentType; }; @@ -83,7 +83,7 @@ namespace NActors { TEvRemoteHttpInfo() { } - TEvRemoteHttpInfo(const TString& query) + TEvRemoteHttpInfo(const TString& query) : Query(query) { } @@ -94,20 +94,20 @@ namespace NActors { { } - TString Query; + TString Query; HTTP_METHOD Method; - TString PathInfo() const { + TString PathInfo() const { const size_t pos = Query.find('?'); - return (pos == TString::npos) ? TString() : Query.substr(0, pos); + return (pos == TString::npos) ? TString() : Query.substr(0, pos); } TCgiParameters Cgi() const { const size_t pos = Query.find('?'); - return TCgiParameters((pos == TString::npos) ? TString() : Query.substr(pos + 1)); + return TCgiParameters((pos == TString::npos) ? TString() : Query.substr(pos + 1)); } - TString ToStringHeader() const override { + TString ToStringHeader() const override { return "TEvRemoteHttpInfo"; } @@ -137,14 +137,14 @@ namespace NActors { TEvRemoteHttpInfoRes() { } - TEvRemoteHttpInfoRes(const TString& html) + TEvRemoteHttpInfoRes(const TString& html) : Html(html) { } - TString Html; + TString Html; - TString ToStringHeader() const override { + TString ToStringHeader() const override { return "TEvRemoteHttpInfoRes"; } @@ -169,14 +169,14 @@ namespace NActors { TEvRemoteJsonInfoRes() { } - TEvRemoteJsonInfoRes(const TString& json) + TEvRemoteJsonInfoRes(const TString& json) : Json(json) { } - TString Json; + TString Json; - TString ToStringHeader() const override { + TString ToStringHeader() const override { return "TEvRemoteJsonInfoRes"; } @@ -201,14 +201,14 @@ namespace NActors { TEvRemoteBinaryInfoRes() { } - TEvRemoteBinaryInfoRes(const TString& blob) + TEvRemoteBinaryInfoRes(const TString& blob) : Blob(blob) { } - TString Blob; + TString Blob; - TString ToStringHeader() const override { + TString ToStringHeader() const override { return "TEvRemoteBinaryInfoRes"; } diff --git a/library/cpp/actors/core/mon_stats.h b/library/cpp/actors/core/mon_stats.h index d55552af0c..dc5c959134 100644 --- a/library/cpp/actors/core/mon_stats.h +++ b/library/cpp/actors/core/mon_stats.h @@ -76,9 +76,9 @@ namespace NActors { TLogHistogram EventDeliveryTimeHistogram; TLogHistogram EventProcessingCountHistogram; TLogHistogram EventProcessingTimeHistogram; - TVector<NHPTimer::STime> ElapsedTicksByActivity; - TVector<ui64> ReceivedEventsByActivity; - TVector<i64> ActorsAliveByActivity; // the sum should be positive, but per-thread might be negative + TVector<NHPTimer::STime> ElapsedTicksByActivity; + TVector<ui64> ReceivedEventsByActivity; + TVector<i64> ActorsAliveByActivity; // the sum should be positive, but per-thread might be negative TVector<ui64> ScheduledEventsByActivity; ui64 PoolActorRegistrations = 0; ui64 PoolDestroyedActors = 0; @@ -95,7 +95,7 @@ namespace NActors { {} template <typename T> - static void AggregateOne(TVector<T>& self, const TVector<T>& other) { + static void AggregateOne(TVector<T>& self, const TVector<T>& other) { const size_t selfSize = self.size(); const size_t otherSize = other.size(); if (selfSize < otherSize) diff --git a/library/cpp/actors/core/process_stats.cpp b/library/cpp/actors/core/process_stats.cpp index 0e1dbd0031..5c1b1bf08e 100644 --- a/library/cpp/actors/core/process_stats.cpp +++ b/library/cpp/actors/core/process_stats.cpp @@ -80,7 +80,7 @@ namespace NActors { TFileInput statm("/proc/" + strPid + "/statm"); statm.ReadLine(str); - TVector<TString> fields; + TVector<TString> fields; StringSplitter(str).Split(' ').SkipEmpty().Collect(&fields); if (fields.size() >= 7) { ui64 resident = FromString<ui64>(fields[1]); diff --git a/library/cpp/actors/core/scheduler_basic.cpp b/library/cpp/actors/core/scheduler_basic.cpp index fba200e16b..985d411db5 100644 --- a/library/cpp/actors/core/scheduler_basic.cpp +++ b/library/cpp/actors/core/scheduler_basic.cpp @@ -94,7 +94,7 @@ namespace NActors { while (!!activeSec && !activeSec->empty()) { TMomentMap::iterator it = activeSec->begin(); if (it->first <= throttledMonotonic) { - if (NSchedulerQueue::TQueueType* q = it->second.Get()) { + if (NSchedulerQueue::TQueueType* q = it->second.Get()) { while (NSchedulerQueue::TEntry* x = q->Reader.Pop()) { somethingDone = true; Y_VERIFY_DEBUG(x->InstantMicroseconds <= activeTick); @@ -151,18 +151,18 @@ namespace NActors { if (instant <= activeTick) { if (!activeSec) activeSec.Reset(new TMomentMap()); - TAutoPtr<NSchedulerQueue::TQueueType>& queue = (*activeSec)[instant]; + TAutoPtr<NSchedulerQueue::TQueueType>& queue = (*activeSec)[instant]; if (!queue) - queue.Reset(new NSchedulerQueue::TQueueType()); + queue.Reset(new NSchedulerQueue::TQueueType()); queue->Writer.Push(instant, ev, cookie); } else { const ui64 intrasecond = AlignUp<ui64>(instant, IntrasecondThreshold); TAutoPtr<TMomentMap>& msec = ScheduleMap[intrasecond]; if (!msec) msec.Reset(new TMomentMap()); - TAutoPtr<NSchedulerQueue::TQueueType>& queue = (*msec)[instant]; + TAutoPtr<NSchedulerQueue::TQueueType>& queue = (*msec)[instant]; if (!queue) - queue.Reset(new NSchedulerQueue::TQueueType()); + queue.Reset(new NSchedulerQueue::TQueueType()); queue->Writer.Push(instant, ev, cookie); } diff --git a/library/cpp/actors/core/scheduler_basic.h b/library/cpp/actors/core/scheduler_basic.h index 2ccde39235..54c193c4a1 100644 --- a/library/cpp/actors/core/scheduler_basic.h +++ b/library/cpp/actors/core/scheduler_basic.h @@ -26,7 +26,7 @@ namespace NActors { volatile bool StopFlag; - typedef TMap<ui64, TAutoPtr<NSchedulerQueue::TQueueType>> TMomentMap; // intrasecond queues + typedef TMap<ui64, TAutoPtr<NSchedulerQueue::TQueueType>> TMomentMap; // intrasecond queues typedef THashMap<ui64, TAutoPtr<TMomentMap>> TScheduleMap; // over-second schedule TScheduleMap ScheduleMap; diff --git a/library/cpp/actors/core/scheduler_queue.h b/library/cpp/actors/core/scheduler_queue.h index 3b8fac28f0..a4905e09f1 100644 --- a/library/cpp/actors/core/scheduler_queue.h +++ b/library/cpp/actors/core/scheduler_queue.h @@ -108,11 +108,11 @@ namespace NActors { } }; - struct TQueueType { + struct TQueueType { TReader Reader; TWriter Writer; - TQueueType() { + TQueueType() { Writer.Init(Reader); } }; diff --git a/library/cpp/actors/core/ya.make b/library/cpp/actors/core/ya.make index 880a9d00db..76596cdfe6 100644 --- a/library/cpp/actors/core/ya.make +++ b/library/cpp/actors/core/ya.make @@ -5,8 +5,8 @@ OWNER( g:kikimr ) -NO_WSHADOW() - +NO_WSHADOW() + IF (PROFILE_MEMORY_ALLOCATIONS) CFLAGS(-DPROFILE_MEMORY_ALLOCATIONS) ENDIF() diff --git a/library/cpp/actors/dnscachelib/dnscache.h b/library/cpp/actors/dnscachelib/dnscache.h index 3313a251a1..b7e199c3b5 100644 --- a/library/cpp/actors/dnscachelib/dnscache.h +++ b/library/cpp/actors/dnscachelib/dnscache.h @@ -21,7 +21,7 @@ public: TDnsCache(bool allowIpv4 = true, bool allowIpv6 = true, time_t entry_lifetime = 1800, time_t neg_lifetime = 1, ui32 request_timeout = 500000); ~TDnsCache(); - TString GetHostByAddr(const NAddr::IRemoteAddr&); + TString GetHostByAddr(const NAddr::IRemoteAddr&); // ip in network byte order TIpHost Get(const TString& host); @@ -43,7 +43,7 @@ protected: private: struct TGHBNContext { TDnsCache* Owner; - TString Hostname; + TString Hostname; int Family; }; @@ -56,23 +56,23 @@ private: THost() noexcept { } - TVector<TIpHost> AddrsV4; + TVector<TIpHost> AddrsV4; time_t ResolvedV4 = 0; time_t NotFoundV4 = 0; TAtomic InProgressV4 = 0; - TVector<in6_addr> AddrsV6; + TVector<in6_addr> AddrsV6; time_t ResolvedV6 = 0; time_t NotFoundV6 = 0; TAtomic InProgressV6 = 0; - TString AddrsV4ToString() const; - TString AddrsV6ToString() const; + TString AddrsV4ToString() const; + TString AddrsV6ToString() const; bool IsStale(int family, const TDnsCache* ctx) const noexcept; }; - typedef TMap<TString, THost> THostCache; + typedef TMap<TString, THost> THostCache; struct TAddr { TString Hostname; @@ -96,7 +96,7 @@ private: return false; } }; - typedef TMap<in6_addr, TAddr, TAddrCmp> TAddrCache; + typedef TMap<in6_addr, TAddr, TAddrCmp> TAddrCache; const THost& Resolve(const TString&, int family, bool cacheOnly = false); diff --git a/library/cpp/actors/dnscachelib/timekeeper.h b/library/cpp/actors/dnscachelib/timekeeper.h index 0528d8549c..73b5c20c35 100644 --- a/library/cpp/actors/dnscachelib/timekeeper.h +++ b/library/cpp/actors/dnscachelib/timekeeper.h @@ -14,7 +14,7 @@ class TTimeKeeper { public: static TInstant GetNow(void) { - return TInstant::MicroSeconds(GetTime()); + return TInstant::MicroSeconds(GetTime()); } static time_t GetTime(void) { diff --git a/library/cpp/actors/interconnect/load.cpp b/library/cpp/actors/interconnect/load.cpp index 2a8443da71..6ed6776e91 100644 --- a/library/cpp/actors/interconnect/load.cpp +++ b/library/cpp/actors/interconnect/load.cpp @@ -217,7 +217,7 @@ namespace NInterconnect { // put item into timeout queue PutTimeoutQueueItem(ctx, id); - const TDuration duration = TDuration::MicroSeconds(Params.IntervalMin.GetValue() + + const TDuration duration = TDuration::MicroSeconds(Params.IntervalMin.GetValue() + RandomNumber(Params.IntervalMax.GetValue() - Params.IntervalMin.GetValue() + 1)); if (Params.SoftLoad) { NextMessageTimestamp += duration; diff --git a/library/cpp/actors/interconnect/ya.make b/library/cpp/actors/interconnect/ya.make index 60d29b0fc0..f75cb720f0 100644 --- a/library/cpp/actors/interconnect/ya.make +++ b/library/cpp/actors/interconnect/ya.make @@ -6,8 +6,8 @@ OWNER( g:kikimr ) -NO_WSHADOW() - +NO_WSHADOW() + IF (PROFILE_MEMORY_ALLOCATIONS) CFLAGS(-DPROFILE_MEMORY_ALLOCATIONS) ENDIF() diff --git a/library/cpp/actors/memory_log/memlog.h b/library/cpp/actors/memory_log/memlog.h index 2aa27272a6..469b7aed5e 100644 --- a/library/cpp/actors/memory_log/memlog.h +++ b/library/cpp/actors/memory_log/memlog.h @@ -1,7 +1,7 @@ #pragma once #include <library/cpp/threading/queue/mpmc_unordered_ring.h> -#include <util/generic/string.h> +#include <util/generic/string.h> #include <util/string/printf.h> #include <util/system/datetime.h> #include <util/system/thread.h> diff --git a/library/cpp/actors/prof/tag.cpp b/library/cpp/actors/prof/tag.cpp index 9ccf03e1a9..9c4f31f09e 100644 --- a/library/cpp/actors/prof/tag.cpp +++ b/library/cpp/actors/prof/tag.cpp @@ -64,7 +64,7 @@ namespace NProfiling { return TStringAtoms::Instance().MakeTag(s); } - ui32 MakeTags(const TVector<const char*>& ss) { + ui32 MakeTags(const TVector<const char*>& ss) { return TStringAtoms::Instance().MakeTags(ss); } diff --git a/library/cpp/actors/prof/tag.h b/library/cpp/actors/prof/tag.h index 357e264a22..9ca3dcc3a5 100644 --- a/library/cpp/actors/prof/tag.h +++ b/library/cpp/actors/prof/tag.h @@ -12,7 +12,7 @@ namespace NProfiling { ui32 MakeTag(const char* s); // Make only unique tags. Y_VERIFY inside. - ui32 MakeTags(const TVector<const char*>& ss); + ui32 MakeTags(const TVector<const char*>& ss); const char* GetTag(ui32 tag); size_t GetTagsCount(); diff --git a/library/cpp/actors/prof/ut/tag_ut.cpp b/library/cpp/actors/prof/ut/tag_ut.cpp index accf3921ab..6687959752 100644 --- a/library/cpp/actors/prof/ut/tag_ut.cpp +++ b/library/cpp/actors/prof/ut/tag_ut.cpp @@ -54,7 +54,7 @@ void TAtomTagsTest::Test_MakeAndGetTag() { } void TAtomTagsTest::Test_MakeVector() { - TVector<const char*> strs = { + TVector<const char*> strs = { "vector tag 0", "vector tag 1", "vector tag 3", diff --git a/library/cpp/actors/testlib/test_runtime.cpp b/library/cpp/actors/testlib/test_runtime.cpp index 6fa25b9965..132b252cda 100644 --- a/library/cpp/actors/testlib/test_runtime.cpp +++ b/library/cpp/actors/testlib/test_runtime.cpp @@ -38,7 +38,7 @@ namespace NActors { void PrintEvent(TAutoPtr<IEventHandle>& ev, const TTestActorRuntimeBase* runtime) { Cerr << "mailbox: " << ev->GetRecipientRewrite().Hint() << ", type: " << Sprintf("%08x", ev->GetTypeRewrite()) << ", from " << ev->Sender.LocalId(); - TString name = runtime->GetActorName(ev->Sender); + TString name = runtime->GetActorName(ev->Sender); if (!name.empty()) Cerr << " \"" << name << "\""; Cerr << ", to " << ev->GetRecipientRewrite().LocalId(); @@ -473,7 +473,7 @@ namespace NActors { , ShouldContinue() , CurrentTimestamp(0) , DispatchTimeout(DEFAULT_DISPATCH_TIMEOUT) - , ReschedulingDelay(TDuration::MicroSeconds(0)) + , ReschedulingDelay(TDuration::MicroSeconds(0)) , ObserverFunc(&TTestActorRuntimeBase::DefaultObserverFunc) , ScheduledEventsSelectorFunc(&CollapsedTimeScheduledEventsSelector) , EventFilterFunc(&TTestActorRuntimeBase::DefaultFilterFunc) @@ -588,16 +588,16 @@ namespace NActors { class TScheduledTreeItem { public: - TString Name; + TString Name; ui64 Count; - TVector<TScheduledTreeItem> Children; + TVector<TScheduledTreeItem> Children; - TScheduledTreeItem(const TString& name) + TScheduledTreeItem(const TString& name) : Name(name) , Count(0) {} - TScheduledTreeItem* GetItem(const TString& name) { + TScheduledTreeItem* GetItem(const TString& name) { TScheduledTreeItem* item = nullptr; for (TScheduledTreeItem& i : Children) { if (i.Name == name) { @@ -621,8 +621,8 @@ namespace NActors { void Print(IOutputStream& stream, const TString& prefix) { for (auto it = Children.begin(); it != Children.end(); ++it) { bool lastChild = (std::next(it) == Children.end()); - TString connectionPrefix = lastChild ? "└─ " : "├─ "; - TString subChildPrefix = lastChild ? " " : "│ "; + TString connectionPrefix = lastChild ? "└─ " : "├─ "; + TString subChildPrefix = lastChild ? " " : "│ "; stream << prefix << connectionPrefix << it->Name << " (" << it->Count << ")\n"; it->Print(stream, prefix + subChildPrefix); } @@ -630,7 +630,7 @@ namespace NActors { void Print(IOutputStream& stream) { stream << Name << " (" << Count << ")\n"; - Print(stream, TString()); + Print(stream, TString()); } }; @@ -647,7 +647,7 @@ namespace NActors { runtime.ScheduledCount++; if (runtime.ScheduledCount > runtime.ScheduledLimit) { // TScheduledTreeItem root("Root"); -// TVector<TString> path; +// TVector<TString> path; // for (const auto& pr : eventTypes) { // path.clear(); // path.push_back(runtime.GetActorName(pr.first.first)); @@ -658,7 +658,7 @@ namespace NActors { // ui64 count = pr.second; // TScheduledTreeItem* item = &root; // item->Count += count; -// for (TString name : path) { +// for (TString name : path) { // item = item->GetItem(name); // item->Count += count; // } @@ -783,7 +783,7 @@ namespace NActors { TGuard<TMutex> guard(Mutex); for (ui32 nodeIndex = 0; nodeIndex < NodeCount; ++nodeIndex) { TNodeDataBase* node = Nodes[FirstNodeId + nodeIndex].Get(); - TString explanation; + TString explanation; auto status = node->LogSettings->SetLevel(priority, component, explanation); if (status) { Y_FAIL("SetLogPriority failed: %s", explanation.c_str()); @@ -1063,7 +1063,7 @@ namespace NActors { TTestActorRuntimeBase& Runtime; } DispatchContextSetter(*this, localContext); - TInstant dispatchTime = TInstant::MicroSeconds(0); + TInstant dispatchTime = TInstant::MicroSeconds(0); TInstant deadline = dispatchTime + DispatchTimeout; const TDuration scheduledEventsInspectInterval = TDuration::MilliSeconds(10); TInstant inspectScheduledEventsAt = dispatchTime + scheduledEventsInspectInterval; @@ -1152,7 +1152,7 @@ namespace NActors { isEmpty = true; auto mboxIt = startWithMboxIt; - TDeque<TEventMailboxId> suspectedBoxes; + TDeque<TEventMailboxId> suspectedBoxes; while (true) { auto& mbox = *mboxIt; bool isIgnored = true; @@ -1741,12 +1741,12 @@ namespace NActors { struct TStrandingActorDecoratorContext : public TThrRefBase { TStrandingActorDecoratorContext() - : Queue(new TQueueType) + : Queue(new TQueueType) { } - typedef TOneOneQueueInplace<IEventHandle*, 32> TQueueType; - TAutoPtr<TQueueType, TQueueType::TPtrCleanDestructor> Queue; + typedef TOneOneQueueInplace<IEventHandle*, 32> TQueueType; + TAutoPtr<TQueueType, TQueueType::TPtrCleanDestructor> Queue; }; class TStrandingActorDecorator : public TActorBootstrapped<TStrandingActorDecorator> { diff --git a/library/cpp/actors/testlib/test_runtime.h b/library/cpp/actors/testlib/test_runtime.h index 26e3b45c98..178837abf9 100644 --- a/library/cpp/actors/testlib/test_runtime.h +++ b/library/cpp/actors/testlib/test_runtime.h @@ -90,9 +90,9 @@ namespace NActors { } }; - TVector<TFinalEventCondition> FinalEvents; - TVector<TEventMailboxId> NonEmptyMailboxes; - TVector<TEventMailboxId> OnlyMailboxes; + TVector<TFinalEventCondition> FinalEvents; + TVector<TEventMailboxId> NonEmptyMailboxes; + TVector<TEventMailboxId> OnlyMailboxes; std::function<bool()> CustomFinalCondition; bool Quiet = false; }; @@ -123,13 +123,13 @@ namespace NActors { static ui64 NextUniqueId; }; - typedef TDeque<TAutoPtr<IEventHandle>> TEventsList; - typedef TSet<TScheduledEventQueueItem> TScheduledEventsList; + typedef TDeque<TAutoPtr<IEventHandle>> TEventsList; + typedef TSet<TScheduledEventQueueItem> TScheduledEventsList; class TEventMailBox : public TThrRefBase { public: TEventMailBox() - : InactiveUntil(TInstant::MicroSeconds(0)) + : InactiveUntil(TInstant::MicroSeconds(0)) #ifdef DEBUG_ORDER_EVENTS , ExpectedReceive(0) , NextToSend(0) @@ -158,7 +158,7 @@ namespace NActors { TInstant InactiveUntil; TEventsList Sent; #ifdef DEBUG_ORDER_EVENTS - TMap<IEventHandle*, ui64> TrackSent; + TMap<IEventHandle*, ui64> TrackSent; ui64 ExpectedReceive; ui64 NextToSend; #endif @@ -238,7 +238,7 @@ namespace NActors { ui32 GetNodeCount() const; ui64 AllocateLocalId(); ui32 InterconnectPoolId() const; - TString GetTempDir(); + TString GetTempDir(); TActorId Register(IActor* actor, ui32 nodeIndex = 0, ui32 poolId = 0, TMailboxType::EType mailboxType = TMailboxType::Simple, ui64 revolvingCounter = 0, const TActorId& parentid = TActorId()); @@ -427,10 +427,10 @@ namespace NActors { } template <typename... TEvents> - static TString TypeNames() { - static TString names[] = { TypeName<TEvents>()... }; - TString result; - for (const TString& s : names) { + static TString TypeNames() { + static TString names[] = { TypeName<TEvents>()... }; + TString result; + for (const TString& s : names) { if (result.empty()) { result += '<'; } else { @@ -464,8 +464,8 @@ namespace NActors { void SetDispatcherRandomSeed(TInstant time, ui64 iteration); TString GetActorName(const TActorId& actorId) const; - const TVector<ui64>& GetTxAllocatorTabletIds() const { return TxAllocatorTabletIds; } - void SetTxAllocatorTabletIds(const TVector<ui64>& ids) { TxAllocatorTabletIds = ids; } + const TVector<ui64>& GetTxAllocatorTabletIds() const { return TxAllocatorTabletIds; } + void SetTxAllocatorTabletIds(const TVector<ui64>& ids) { TxAllocatorTabletIds = ids; } void SetUseRealInterconnect() { UseRealInterconnect = true; @@ -522,7 +522,7 @@ namespace NActors { TMutex Mutex; TCondVar MailboxesHasEvents; TEventMailBoxList Mailboxes; - TMap<ui32, ui64> EvCounters; + TMap<ui32, ui64> EvCounters; ui64 DispatchCyclesCount; ui64 DispatchedEventsCount; ui64 DispatchedEventsLimit = 2'500'000; @@ -566,7 +566,7 @@ namespace NActors { std::shared_ptr<void> AppData0; THolder<TActorSystem> ActorSystem; THolder<IExecutorPool> SchedulerPool; - TVector<IExecutorPool*> ExecutorPools; + TVector<IExecutorPool*> ExecutorPools; THolder<TExecutorThread> ExecutorThread; }; @@ -605,8 +605,8 @@ namespace NActors { const TDispatchOptions* Options; TDispatchContext* PrevContext; - TMap<const TDispatchOptions::TFinalEventCondition*, ui32> FinalEventFrequency; - TSet<TEventMailboxId> FoundNonEmptyMailboxes; + TMap<const TDispatchOptions::TFinalEventCondition*, ui32> FinalEventFrequency; + TSet<TEventMailboxId> FoundNonEmptyMailboxes; bool FinalEventFound = false; }; @@ -627,7 +627,7 @@ namespace NActors { THashMap<TActorId, TActorId> ScheduleWhiteListParent; THashMap<TActorId, TString> ActorNames; TDispatchContext* CurrentDispatchContext; - TVector<ui64> TxAllocatorTabletIds; + TVector<ui64> TxAllocatorTabletIds; static ui32 NextNodeId; }; diff --git a/library/cpp/actors/util/funnel_queue.h b/library/cpp/actors/util/funnel_queue.h index 0e21e2617c..0ed5d9b966 100644 --- a/library/cpp/actors/util/funnel_queue.h +++ b/library/cpp/actors/util/funnel_queue.h @@ -224,7 +224,7 @@ public: } private: - typedef TQueueType<ElementType> TBase; + typedef TQueueType<ElementType> TBase; virtual typename TBase::TEntry* NewEntry(ElementType&& element) noexcept override { AtomicAdd(Count, 1); diff --git a/library/cpp/actors/util/recentwnd.h b/library/cpp/actors/util/recentwnd.h index ba1ede6f29..5a784640cd 100644 --- a/library/cpp/actors/util/recentwnd.h +++ b/library/cpp/actors/util/recentwnd.h @@ -3,7 +3,7 @@ #include <util/generic/deque.h> template <typename TElem, - template <typename, typename...> class TContainer = TDeque> + template <typename, typename...> class TContainer = TDeque> class TRecentWnd { public: TRecentWnd(ui32 wndSize) diff --git a/library/cpp/actors/util/thread.h b/library/cpp/actors/util/thread.h index d742c8c585..c5b0dcc736 100644 --- a/library/cpp/actors/util/thread.h +++ b/library/cpp/actors/util/thread.h @@ -7,7 +7,7 @@ #include <util/system/thread.h> #include <time.h> -inline void SetCurrentThreadName(const TString& name, +inline void SetCurrentThreadName(const TString& name, const ui32 maxCharsFromProcessName = 8) { #if defined(_linux_) // linux limits threadname by 15 + \0 diff --git a/library/cpp/actors/wilson/wilson_trace.h b/library/cpp/actors/wilson/wilson_trace.h index 3d1ca50562..d893cb6e41 100644 --- a/library/cpp/actors/wilson/wilson_trace.h +++ b/library/cpp/actors/wilson/wilson_trace.h @@ -143,7 +143,7 @@ namespace NWilson { return x.TraceId == y.TraceId && x.SpanId == y.SpanId; } - TString ToString() const { + TString ToString() const { return Sprintf("%" PRIu64 ":%" PRIu64, TraceId, SpanId); } |