aboutsummaryrefslogtreecommitdiffstats
path: root/library/cpp/actors/core
diff options
context:
space:
mode:
authorVlad Yaroslavlev <vladon@vladon.com>2022-02-10 16:46:25 +0300
committerDaniil Cherednik <dcherednik@yandex-team.ru>2022-02-10 16:46:25 +0300
commit344ea37b4a345701ab0e67de2266a1c1bd7baf2d (patch)
tree1a2c5ffcf89eb53ecd79dbc9bc0a195c27404d0c /library/cpp/actors/core
parent706b83ed7de5a473436620367af31fc0ceecde07 (diff)
downloadydb-344ea37b4a345701ab0e67de2266a1c1bd7baf2d.tar.gz
Restoring authorship annotation for Vlad Yaroslavlev <vladon@vladon.com>. Commit 2 of 2.
Diffstat (limited to 'library/cpp/actors/core')
-rw-r--r--library/cpp/actors/core/actorsystem.cpp4
-rw-r--r--library/cpp/actors/core/actorsystem.h8
-rw-r--r--library/cpp/actors/core/event_load.h2
-rw-r--r--library/cpp/actors/core/event_pb_ut.cpp2
-rw-r--r--library/cpp/actors/core/executor_pool_basic.cpp4
-rw-r--r--library/cpp/actors/core/executor_pool_basic.h2
-rw-r--r--library/cpp/actors/core/executor_pool_io.cpp2
-rw-r--r--library/cpp/actors/core/executor_pool_io.h2
-rw-r--r--library/cpp/actors/core/executor_pool_united.h2
-rw-r--r--library/cpp/actors/core/interconnect.h2
-rw-r--r--library/cpp/actors/core/log.cpp14
-rw-r--r--library/cpp/actors/core/log.h6
-rw-r--r--library/cpp/actors/core/log_settings.cpp2
-rw-r--r--library/cpp/actors/core/log_settings.h8
-rw-r--r--library/cpp/actors/core/mailbox.h8
-rw-r--r--library/cpp/actors/core/mon.h34
-rw-r--r--library/cpp/actors/core/mon_stats.h8
-rw-r--r--library/cpp/actors/core/process_stats.cpp2
-rw-r--r--library/cpp/actors/core/scheduler_basic.cpp10
-rw-r--r--library/cpp/actors/core/scheduler_basic.h2
-rw-r--r--library/cpp/actors/core/scheduler_queue.h4
-rw-r--r--library/cpp/actors/core/ya.make4
22 files changed, 66 insertions, 66 deletions
diff --git a/library/cpp/actors/core/actorsystem.cpp b/library/cpp/actors/core/actorsystem.cpp
index 3914a4a183..c58698a206 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 27c242ccc6..40499d7586 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 b8872738aa..0dab1dd374 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 fc8cb2d52c..a16c3092b3 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 77b4eca1d2..4dce16939a 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 7ccd3cd179..023190f7fe 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 49fe990374..fb557ae6b0 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 651217e0c9..e576d642a1 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 3d591d7ffb..a090ba2466 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 c26fe1b0b5..679a4b8cc6 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 6322677c68..5f63b5af58 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 073c233202..c11a7cf3c1 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 8f4009ae4c..f52f2fc5d2 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 bd8686cefd..7fe4504edd 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 acd6e852a3..0bd9c4d314 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 f108b370d5..c450f2338e 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 dc5c959134..d55552af0c 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 5c1b1bf08e..0e1dbd0031 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 985d411db5..fba200e16b 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 54c193c4a1..2ccde39235 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 a4905e09f1..3b8fac28f0 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 76596cdfe6..880a9d00db 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()