diff options
author | babenko <babenko@yandex-team.com> | 2025-01-11 23:39:24 +0300 |
---|---|---|
committer | babenko <babenko@yandex-team.com> | 2025-01-11 23:54:51 +0300 |
commit | 389054495d864432cf6d3f891e1eab1e6a7d426f (patch) | |
tree | 287370cc46d2e51cd56ccb28bb51dc527ccadbb9 | |
parent | 849c2c67c7a818b682a11f6e92f7ff4a07e1a1cf (diff) | |
download | ydb-389054495d864432cf6d3f891e1eab1e6a7d426f.tar.gz |
NB cosmetics
commit_hash:b7a2eef93e6ea33ff1d21cc269f30a5e58f9ff0f
39 files changed, 46 insertions, 46 deletions
diff --git a/yt/yt/client/api/rpc_proxy/client_impl.cpp b/yt/yt/client/api/rpc_proxy/client_impl.cpp index 6ace94bcb9..8bd34870bd 100644 --- a/yt/yt/client/api/rpc_proxy/client_impl.cpp +++ b/yt/yt/client/api/rpc_proxy/client_impl.cpp @@ -101,7 +101,7 @@ IChannelPtr TClient::CreateSequoiaAwareRetryingChannel(IChannelPtr channel, bool { const auto& config = Connection_->GetConfig(); bool retrySequoiaErrorsOnly = !config->EnableRetries; - // NB: even if client's retries are disabled Sequoia transient failures are + // NB: Even if client's retries are disabled Sequoia transient failures are // still retriable. See IsRetriableError(). return CreateRetryingChannel( config->RetryingChannel, diff --git a/yt/yt/client/chunk_client/read_limit.h b/yt/yt/client/chunk_client/read_limit.h index 07474b880b..7bd7625269 100644 --- a/yt/yt/client/chunk_client/read_limit.h +++ b/yt/yt/client/chunk_client/read_limit.h @@ -170,7 +170,7 @@ public: TReadLimit ToExactUpperCounterpart() const; //! Return inverted read limit, i.e. integer selectors remain as is and key bound is inverted. - //! NB: this method makes YT_VERIFY that read limit contains exactly one selector. Otherwise + //! NB: This method makes YT_VERIFY that read limit contains exactly one selector. Otherwise //! semantics of such method is weird. TReadLimit Invert() const; diff --git a/yt/yt/client/driver/cypress_commands.cpp b/yt/yt/client/driver/cypress_commands.cpp index b94dd9dce8..7333ead50c 100644 --- a/yt/yt/client/driver/cypress_commands.cpp +++ b/yt/yt/client/driver/cypress_commands.cpp @@ -170,7 +170,7 @@ void TListCommand::Register(TRegistrar registrar) { registrar.Parameter("path", &TThis::Path); - // NB: default value is an empty filter in contrast to GetCommand, for which it is the universal filter. + // NB: Default value is an empty filter in contrast to GetCommand, for which it is the universal filter. // Refer to YT-5543 for details. registrar.ParameterWithUniversalAccessor<TAttributeFilter>( "attributes", diff --git a/yt/yt/client/queue_client/consumer_client.cpp b/yt/yt/client/queue_client/consumer_client.cpp index 1de69d46e2..e17e2df394 100644 --- a/yt/yt/client/queue_client/consumer_client.cpp +++ b/yt/yt/client/queue_client/consumer_client.cpp @@ -445,7 +445,7 @@ private: YT_ABORT(); } - // NB: in BigRT offsets encode the last read row, while we operate with the first unread row. + // NB: In BigRT offsets encode the last read row, while we operate with the first unread row. auto partitionInfo = TPartitionInfo{ .PartitionIndex = FromUnversionedValue<i64>(partitionIndexValue), .NextRowIndex = offset, diff --git a/yt/yt/client/table_client/columnar.cpp b/yt/yt/client/table_client/columnar.cpp index b18bec8937..5cfc89f80f 100644 --- a/yt/yt/client/table_client/columnar.cpp +++ b/yt/yt/client/table_client/columnar.cpp @@ -402,7 +402,7 @@ void BuildDictionaryIndexesFromDictionaryIndexesWithZeroNull( const auto* currentInput = beginInput; auto* currentOutput = dst.Begin(); while (currentInput < endInput) { - // NB: null becomes FFFFFFFF. + // NB: Null becomes FFFFFFFF. *currentOutput++ = (*currentInput++) - 1; } } diff --git a/yt/yt/client/table_client/helpers.cpp b/yt/yt/client/table_client/helpers.cpp index a28626f202..680f5f995b 100644 --- a/yt/yt/client/table_client/helpers.cpp +++ b/yt/yt/client/table_client/helpers.cpp @@ -354,7 +354,7 @@ TVersionedOwningRow YsonToVersionedRow( const std::vector<TTimestamp>& deleteTimestamps, const std::vector<TTimestamp>& extraWriteTimestamps) { - // NB: this implementation is extra slow, it is intended only for using in tests. + // NB: This implementation is extra slow, it is intended only for using in tests. auto rowBuffer = New<TRowBuffer>(); auto row = YsonToVersionedRow(rowBuffer, keyYson, valueYson, deleteTimestamps, extraWriteTimestamps); return TVersionedOwningRow(row); diff --git a/yt/yt/client/table_client/key.h b/yt/yt/client/table_client/key.h index 9ebc581120..1f902e0c60 100644 --- a/yt/yt/client/table_client/key.h +++ b/yt/yt/client/table_client/key.h @@ -23,7 +23,7 @@ public: static TKey FromRow(TUnversionedRow row, std::optional<int> length = {}); //! Same as above, but does not check that row does not contain sentinels. - //! NB: in debug mode value type check is still performed, but results in YT_ABORT(). + //! NB: In debug mode value type check is still performed, but results in YT_ABORT(). static TKey FromRowUnchecked(TUnversionedRow row, std::optional<int> length = {}); //! Performs a deep copy of underlying values into owning row. @@ -64,7 +64,7 @@ void Serialize(const TKey& key, NYson::IYsonConsumer* consumer); //! replacing all sentinels to <null> and by padding row with nulls or shortening it so that //! row length is exactly keyLength. //! -//! NB: this method is inefficient (as it deals with owning rows), do not use it on hot path. +//! NB: This method is inefficient (as it deals with owning rows), do not use it on hot path. TUnversionedOwningRow LegacyKeyToKeyFriendlyOwningRow(TUnversionedRow row, int keyLength); //////////////////////////////////////////////////////////////////////////////// diff --git a/yt/yt/client/table_client/key_bound.h b/yt/yt/client/table_client/key_bound.h index e37c695e7e..49b0ca6f6d 100644 --- a/yt/yt/client/table_client/key_bound.h +++ b/yt/yt/client/table_client/key_bound.h @@ -33,7 +33,7 @@ public: static TKeyBound FromRow(TRow&& row, bool isInclusive, bool isUpper); //! Construct from a given row without checking presence of types Min, Max and Bottom. - //! NB: in debug mode value type check is still performed, but results in YT_ABORT(). + //! NB: In debug mode value type check is still performed, but results in YT_ABORT(). static TKeyBound FromRowUnchecked(const TRow& row, bool isInclusive, bool isUpper); //! Same as previous but for rvalue refs. @@ -150,7 +150,7 @@ bool operator ==(const TOwningKeyBound& lhs, const TOwningKeyBound& rhs); std::pair<int, bool> GetBoundPrefixAndInclusiveness(TUnversionedRow row, bool isUpper, int keyLength); //! Convert legacy key bound expressed as a row possibly containing Min/Max to owning key bound. -//! NB: key length is needed to properly distinguish if K + [min] is an inclusive K or exclusive K. +//! NB: Key length is needed to properly distinguish if K + [min] is an inclusive K or exclusive K. TOwningKeyBound KeyBoundFromLegacyRow(TUnversionedRow row, bool isUpper, int keyLength); //! Same as previous, but non-owning variant over row buffer. diff --git a/yt/yt/client/table_client/logical_type.cpp b/yt/yt/client/table_client/logical_type.cpp index 46ae7221da..5c31d97df6 100644 --- a/yt/yt/client/table_client/logical_type.cpp +++ b/yt/yt/client/table_client/logical_type.cpp @@ -394,7 +394,7 @@ i64 TOptionalLogicalType::GetMemoryUsage(i64 limit) const YT_ASSERT(limit > 0); if (Element_->GetMetatype() == ELogicalMetatype::Simple) { - // NB: see TOptionalLogicalType::GetMemoryUsage(). + // NB: See TOptionalLogicalType::GetMemoryUsage(). return 0; } else if (auto sizeOfThis = static_cast<i64>(sizeof(*this)); sizeOfThis >= limit) { return sizeof(*this); diff --git a/yt/yt/client/table_client/unversioned_row.h b/yt/yt/client/table_client/unversioned_row.h index 3dfa236502..ab2ccf01df 100644 --- a/yt/yt/client/table_client/unversioned_row.h +++ b/yt/yt/client/table_client/unversioned_row.h @@ -79,7 +79,7 @@ public: char* GetMutableString() { YT_VERIFY(IsStringLikeType(Value_.Type)); - // NB: it is correct to use `const_cast` here to modify the stored string + // NB: It is correct to use `const_cast` here to modify the stored string // because initially it's allocated as a non-const `char*`. return const_cast<char*>(Value_.Data.String); } diff --git a/yt/yt/client/table_client/unversioned_value.h b/yt/yt/client/table_client/unversioned_value.h index 7a0c64edf0..b0c651fdf2 100644 --- a/yt/yt/client/table_client/unversioned_value.h +++ b/yt/yt/client/table_client/unversioned_value.h @@ -24,7 +24,7 @@ union TUnversionedValueData //! |Boolean| value. bool Boolean; //! String value for |String| type or YSON-encoded value for |Any| type. - //! NB: string is not zero-terminated, so never use it as a TString. + //! NB: String is not zero-terminated, so never use it as a TString. //! Use #TUnversionedValue::AsStringBuf() or #TUnversionedValue::AsString() instead. const char* String; }; diff --git a/yt/yt/client/ypath/parser_detail.cpp b/yt/yt/client/ypath/parser_detail.cpp index cb11a20767..30739dde0c 100644 --- a/yt/yt/client/ypath/parser_detail.cpp +++ b/yt/yt/client/ypath/parser_detail.cpp @@ -252,7 +252,7 @@ void ParseKeyPart( tokenizer.ParseNext(); } -// NB: since our final result while parsing YPath is an attribute dictionary, we intentionally refrain +// NB: Since our final result while parsing YPath is an attribute dictionary, we intentionally refrain // from using TReadLimit (or even TLegacyReadLimit) as an intermediate structure here. YPath short // form is parsed using merely NYTree primitives and unversioned rows. diff --git a/yt/yt/client/ypath/rich.cpp b/yt/yt/client/ypath/rich.cpp index 352e4ef540..6a4bd12a2a 100644 --- a/yt/yt/client/ypath/rich.cpp +++ b/yt/yt/client/ypath/rich.cpp @@ -325,7 +325,7 @@ NChunkClient::TReadRange RangeNodeToReadRange( THROW_ERROR_EXCEPTION("Cannot use key or key bound in read limit for an unsorted object"); } - // NB: for the sake of compatibility, we support specifying both key and key bound in read limit. + // NB: For the sake of compatibility, we support specifying both key and key bound in read limit. // In this case we consider only key bound and completely ignore key. if (keyNode && !keyBoundNode) { @@ -376,7 +376,7 @@ NChunkClient::TReadRange RangeNodeToReadRange( // than interpreting it as a key bound using interop method. if (isExact && (owningKey.GetCount() > comparator.GetLength() || containsSentinels)) { - // NB: there are two tricky cases when read limit is exact: + // NB: There are two tricky cases when read limit is exact: // - (1) if specified key is longer than comparator. Recall that (in old terms) // there may be no keys between (foo, bar) and (foo, bar, <max>) in a table with single // key column. @@ -703,7 +703,7 @@ TString ConvertToString(const TRichYPath& path, EYsonFormat ysonFormat) void FormatValue(TStringBuilderBase* builder, const TRichYPath& path, TStringBuf spec) { - // NB: we intentionally use Text format since string-representation of rich ypath should be readable. + // NB: We intentionally use Text format since string-representation of rich ypath should be readable. FormatValue(builder, ConvertToString(path, EYsonFormat::Text), spec); } diff --git a/yt/yt/core/concurrency/async_stream.h b/yt/yt/core/concurrency/async_stream.h index ae5e0880ba..1885e073c7 100644 --- a/yt/yt/core/concurrency/async_stream.h +++ b/yt/yt/core/concurrency/async_stream.h @@ -31,7 +31,7 @@ DEFINE_REFCOUNTED_TYPE(IAsyncInputStream) //! Creates a synchronous adapter from a given asynchronous stream. /*! - * NB: in order to ensure memory safety with WaitFor strategy, data is read to an + * NB: In order to ensure memory safety with WaitFor strategy, data is read to an * intermediate shared buffer and then copied to the destination buffer. * Do not use this wrapper in throughput-critical code, prefer using * async or async zero-copy input stream interface instead. @@ -160,7 +160,7 @@ struct IAsyncZeroCopyOutputStream * the previous call is complete. The returned future, however, provides * means to implement backpressure. * - * NB: this shared ref should become unique ref. + * NB: This shared ref should become unique ref. */ [[nodiscard]] virtual TFuture<void> Write(const TSharedRef& data) = 0; diff --git a/yt/yt/core/concurrency/fiber.cpp b/yt/yt/core/concurrency/fiber.cpp index 62e057b650..bf10886b98 100644 --- a/yt/yt/core/concurrency/fiber.cpp +++ b/yt/yt/core/concurrency/fiber.cpp @@ -192,7 +192,7 @@ private: Fibers_.Append(std::move(toRegister)); - // NB: util intrusive list does not return + // NB: Util intrusive list does not return // nullptr in case of empty! // We have to check ourselves that // PopBack return is a valid one. diff --git a/yt/yt/core/concurrency/fiber_scheduler_thread.cpp b/yt/yt/core/concurrency/fiber_scheduler_thread.cpp index a5363db233..c0e4612e03 100644 --- a/yt/yt/core/concurrency/fiber_scheduler_thread.cpp +++ b/yt/yt/core/concurrency/fiber_scheduler_thread.cpp @@ -445,7 +445,7 @@ private: void RemoveOverdrawnIdleFibers() { - // NB: size_t to int conversion. + // NB: Size_t to int conversion. int size = IdleFibers_.size_approx(); int maxSize = TFiberManager::GetMaxIdleFibers(); if (size <= maxSize) { diff --git a/yt/yt/core/http/compression_detail.h b/yt/yt/core/http/compression_detail.h index 1110f71c4b..28180d9ddc 100644 --- a/yt/yt/core/http/compression_detail.h +++ b/yt/yt/core/http/compression_detail.h @@ -8,7 +8,7 @@ namespace NYT::NHttp::NDetail { //////////////////////////////////////////////////////////////////////////////// -// NB: some codecs (e.g. lzop) accept ui16 as buffer size. +// NB: Some codecs (e.g. lzop) accept ui16 as buffer size. constexpr size_t DefaultCompressionBufferSize = 32_KB; std::unique_ptr<IOutputStream> TryDetectOptionalCompressors( diff --git a/yt/yt/core/http/helpers.cpp b/yt/yt/core/http/helpers.cpp index 5ed8355c6d..ccdedd864e 100644 --- a/yt/yt/core/http/helpers.cpp +++ b/yt/yt/core/http/helpers.cpp @@ -401,7 +401,7 @@ bool TryParseTraceParent(const TString& traceParent, NTracing::TSpanContext& spa return false; } - // NB: we support three-part form in which version is assumed to be zero. + // NB: We support three-part form in which version is assumed to be zero. ui8 version = 0; if (parts.size() == 4) { if (parts[0].size() != 2) { diff --git a/yt/yt/core/json/config.h b/yt/yt/core/json/config.h index e9f2c52792..67ba835016 100644 --- a/yt/yt/core/json/config.h +++ b/yt/yt/core/json/config.h @@ -39,7 +39,7 @@ public: bool StringifyNanAndInfinity; // Size of buffer used read out input stream in parser. - // NB: in case of parsing long string yajl holds in memory whole string prefix and copy it on every parse call. + // NB: In case of parsing long string yajl holds in memory whole string prefix and copy it on every parse call. // Therefore parsing long strings works faster with larger buffer. int BufferSize; diff --git a/yt/yt/core/misc/consistent_hashing_ring.h b/yt/yt/core/misc/consistent_hashing_ring.h index 4b244fbf52..36754e9fdf 100644 --- a/yt/yt/core/misc/consistent_hashing_ring.h +++ b/yt/yt/core/misc/consistent_hashing_ring.h @@ -33,7 +33,7 @@ namespace NYT { h(s, i) -> ui64 h(f, i) -> ui64 where i is an int, and h, s and f are instances of H, S and F, respectively. - (NB: care should be taken to avoid serial hash collisions. That is, if + (NB: Care should be taken to avoid serial hash collisions. That is, if h(s1, 0) == h(s2, 0) it should be likely that h(s1, 1) != h(s2, 1). This is the reason why a hasher is called with both and object to hash and an additional sequence number.) diff --git a/yt/yt/core/misc/error.cpp b/yt/yt/core/misc/error.cpp index 3da51a391b..d206029e19 100644 --- a/yt/yt/core/misc/error.cpp +++ b/yt/yt/core/misc/error.cpp @@ -367,7 +367,7 @@ void Serialize( }) .DoIf(valueProducer != nullptr, [&] (auto fluent) { auto* consumer = fluent.GetConsumer(); - // NB: we are forced to deal with a bare consumer here because + // NB: We are forced to deal with a bare consumer here because // we can't use void(TFluentMap) in a function signature as it // will lead to the inclusion of fluent.h in error.h and a cyclic // inclusion error.h -> fluent.h -> callback.h -> error.h diff --git a/yt/yt/core/misc/proc.cpp b/yt/yt/core/misc/proc.cpp index 03185c40ac..8f563fc020 100644 --- a/yt/yt/core/misc/proc.cpp +++ b/yt/yt/core/misc/proc.cpp @@ -1235,7 +1235,7 @@ TNetworkInterfaceStatisticsMap GetNetworkInterfaceStatistics() XX(Tx.Carrier); XX(Tx.Compressed); #undef XX - // NB: data is racy; duplicates are possible; just deal with it. + // NB: Data is racy; duplicates are possible; just deal with it. interfaceToStatistics.emplace(interfaceName, statistics); } return interfaceToStatistics; diff --git a/yt/yt/core/misc/signal_registry.h b/yt/yt/core/misc/signal_registry.h index 23dbdeb950..dbb066f7b1 100644 --- a/yt/yt/core/misc/signal_registry.h +++ b/yt/yt/core/misc/signal_registry.h @@ -45,7 +45,7 @@ public: void PushCallback(int signal, TSignalHandler callback); //! Adds the default signal handler which is called after invoking our custom handlers. - //! NB: this handler restores default signal handler as a side-effect. Use it only + //! NB: This handler restores default signal handler as a side-effect. Use it only //! when default handler terminates the program. void PushDefaultSignalHandler(int signal); diff --git a/yt/yt/core/misc/unittests/bit_packed_integer_vector_ut.cpp b/yt/yt/core/misc/unittests/bit_packed_integer_vector_ut.cpp index ba53a942b4..a14fa10eb1 100644 --- a/yt/yt/core/misc/unittests/bit_packed_integer_vector_ut.cpp +++ b/yt/yt/core/misc/unittests/bit_packed_integer_vector_ut.cpp @@ -18,7 +18,7 @@ size_t Compress(const std::vector<T> &data, std::vector<ui64> *buffer) } auto size = CompressedUnsignedVectorSizeInWords(maxValue, data.size()); - // NB: initialize with zeros! + // NB: Initialize with zeros! buffer->resize(size, 0); return BitPackUnsignedVector(TRange(data), maxValue, buffer->data()); diff --git a/yt/yt/core/rpc/dispatcher.h b/yt/yt/core/rpc/dispatcher.h index 684f9de0a4..ae1d586a01 100644 --- a/yt/yt/core/rpc/dispatcher.h +++ b/yt/yt/core/rpc/dispatcher.h @@ -35,7 +35,7 @@ public: //! dispatch compression callbacks. This invoker is a wrapper around compression pool invoker. const IPrioritizedInvokerPtr& GetPrioritizedCompressionPoolInvoker(); //! Returns the fair-share thread pool with the similar semantics as previous two. - //! NB: this thread pool is different from the underlying thread pool beneath two previous invokers. + //! NB: This thread pool is different from the underlying thread pool beneath two previous invokers. const NConcurrency::IFairShareThreadPoolPtr& GetFairShareCompressionThreadPool(); //! Returns true if alert must be issued when a request is missing request info. diff --git a/yt/yt/core/rpc/message_format.cpp b/yt/yt/core/rpc/message_format.cpp index da4d1ee026..34b390183d 100644 --- a/yt/yt/core/rpc/message_format.cpp +++ b/yt/yt/core/rpc/message_format.cpp @@ -77,7 +77,7 @@ public: { google::protobuf::io::StringOutputStream output(&protoBuffer); auto converter = CreateProtobufWriter(&output, messageType); - // NB: formatOptionsYson is ignored, since YSON parser has no user-defined options. + // NB: FormatOptionsYson is ignored, since YSON parser has no user-defined options. ParseYsonStringBuffer(TStringBuf(message.Begin(), message.End()), EYsonType::Node, converter.get()); } return TSharedRef::FromString(FromProto<TString>(protoBuffer)); diff --git a/yt/yt/core/rpc/per_key_request_queue_provider-inl.h b/yt/yt/core/rpc/per_key_request_queue_provider-inl.h index aab3e84796..84638a9703 100644 --- a/yt/yt/core/rpc/per_key_request_queue_provider-inl.h +++ b/yt/yt/core/rpc/per_key_request_queue_provider-inl.h @@ -55,7 +55,7 @@ TRequestQueue* TPerKeyRequestQueueProvider<T>::DoGetQueue(const T& key) ? configs.BytesThrottlerConfig : nullptr); - // NB: not calling ReconfigurationCallback_ here because, for newly + // NB: Not calling ReconfigurationCallback_ here because, for newly // created queues, ConfigureQueue is supposed to be called shortly. return queue; diff --git a/yt/yt/core/rpc/response_keeper.h b/yt/yt/core/rpc/response_keeper.h index 9a4edbc262..fbbcc8f788 100644 --- a/yt/yt/core/rpc/response_keeper.h +++ b/yt/yt/core/rpc/response_keeper.h @@ -65,7 +65,7 @@ public: * to every subscriber waiting for the future previously returned by * #TryBeginRequest. Such a call must be done, or the subscribers will get * a 'promise abandoned' error. - * NB: the returned function object may be null if there weren't any + * NB: The returned function object may be null if there weren't any * requests associated with #mutationId (or if response keeper isn't started). */ [[nodiscard]] diff --git a/yt/yt/core/ya.make b/yt/yt/core/ya.make index e6f1868960..6aece93319 100644 --- a/yt/yt/core/ya.make +++ b/yt/yt/core/ya.make @@ -130,7 +130,7 @@ SRCS( misc/digest.cpp misc/error.cpp misc/fs.cpp - # NB: it is necessary to prevent linker optimization of + # NB: It is necessary to prevent linker optimization of # REGISTER_INTERMEDIATE_PROTO_INTEROP_REPRESENTATION macros for TGuid. GLOBAL misc/guid.cpp misc/hazard_ptr.cpp diff --git a/yt/yt/core/ytree/attribute_filter.cpp b/yt/yt/core/ytree/attribute_filter.cpp index c014affb30..796507ccf2 100644 --- a/yt/yt/core/ytree/attribute_filter.cpp +++ b/yt/yt/core/ytree/attribute_filter.cpp @@ -408,7 +408,7 @@ std::unique_ptr<TAttributeFilter::IAsyncFilteringConsumer> TAttributeFilter::Cre //////////////////////////////////////////////////////////////////////////////// -// NB: universal filter is represented as an absent protobuf value. +// NB: Universal filter is represented as an absent protobuf value. void ToProto(NProto::TAttributeFilter* protoFilter, const TAttributeFilter& filter) { diff --git a/yt/yt/core/ytree/ephemeral_node_factory.cpp b/yt/yt/core/ytree/ephemeral_node_factory.cpp index c3d0e87c89..f69bad4cec 100644 --- a/yt/yt/core/ytree/ephemeral_node_factory.cpp +++ b/yt/yt/core/ytree/ephemeral_node_factory.cpp @@ -250,7 +250,7 @@ public: auto it = ChildToKey_.find(child); YT_ASSERT(it != ChildToKey_.end()); - // NB: don't use const auto& here, it becomes invalid! + // NB: Don't use const auto& here, it becomes invalid! auto key = it->second; ChildToKey_.erase(it); YT_VERIFY(KeyToChild_.erase(key) == 1); @@ -267,7 +267,7 @@ public: auto it = ChildToKey_.find(oldChild); YT_ASSERT(it != ChildToKey_.end()); - // NB: don't use const auto& here, it becomes invalid! + // NB: Don't use const auto& here, it becomes invalid! auto key = it->second; oldChild->SetParent(nullptr); diff --git a/yt/yt/core/ytree/interned_attributes.h b/yt/yt/core/ytree/interned_attributes.h index 85d55e1f10..ac947226bf 100644 --- a/yt/yt/core/ytree/interned_attributes.h +++ b/yt/yt/core/ytree/interned_attributes.h @@ -28,7 +28,7 @@ public: void Load(TStreamLoadContext& context); private: - // NB: this codes are subject to change! Do not rely on their values. Do not serialize them. + // NB: This codes are subject to change! Do not rely on their values. Do not serialize them. // Use Save/Load methods instead. size_t Code_; }; diff --git a/yt/yt/core/ytree/unittests/ytree_ut.cpp b/yt/yt/core/ytree/unittests/ytree_ut.cpp index c1caf87b86..2f48f584c5 100644 --- a/yt/yt/core/ytree/unittests/ytree_ut.cpp +++ b/yt/yt/core/ytree/unittests/ytree_ut.cpp @@ -131,7 +131,7 @@ TEST(TYTreeTest, TestGetWithAttributes) auto node = ConvertToNode(yson); auto compareYsons = [] (TYsonStringBuf expectedYson, INodePtr node, const TAttributeFilter& attributeFilter) { - // NB: serialization of ephemeral nodes is always stable. + // NB: Serialization of ephemeral nodes is always stable. TYsonString actualYson = SyncYPathGet(node, "", attributeFilter); auto stableOriginal = ConvertToYsonString(node, EYsonFormat::Pretty).ToString(); auto stableExpected = ConvertToYsonString(ConvertToNode(expectedYson), EYsonFormat::Pretty).ToString(); diff --git a/yt/yt/core/ytree/virtual.cpp b/yt/yt/core/ytree/virtual.cpp index 32292e5df4..f03f16b407 100644 --- a/yt/yt/core/ytree/virtual.cpp +++ b/yt/yt/core/ytree/virtual.cpp @@ -178,7 +178,7 @@ void TVirtualMapBase::GetSelf( auto writer = New<TAsyncYsonWriter>(); - // NB: we do not want empty attributes (<>) to appear in the result in order to comply + // NB: We do not want empty attributes (<>) to appear in the result in order to comply // with current behaviour for some paths (like //sys/scheduler/orchid/scheduler/operations). if (std::ssize(keys) != size || OwningNode_) { writer->OnBeginAttributes(); @@ -607,7 +607,7 @@ void TVirtualListBase::GetSelf( auto writer = New<TAsyncYsonWriter>(); - // NB: we do not want empty attributes (<>) to appear in the result in order to comply + // NB: We do not want empty attributes (<>) to appear in the result in order to comply // with current behaviour for some paths (like //sys/scheduler/orchid/scheduler/operations). if (limit < size) { writer->OnBeginAttributes(); diff --git a/yt/yt/library/formats/skiff_writer.cpp b/yt/yt/library/formats/skiff_writer.cpp index 4ddef9da35..86315ea716 100644 --- a/yt/yt/library/formats/skiff_writer.cpp +++ b/yt/yt/library/formats/skiff_writer.cpp @@ -678,7 +678,7 @@ public: auto createComplexValueConverter = [&] (const TFieldDescription& skiffField, bool isSparse) -> TUnversionedValueToSkiffConverter { auto columnSchema = indexedSchemas.GetColumnSchema(tableIndex, skiffField.Name()); - // NB: we don't create complex value converter for simple types + // NB: We don't create complex value converter for simple types // (column is missing in schema or has simple type). // 1. Complex value converter expects unversioned values of type ANY // and simple types have other types. diff --git a/yt/yt/library/formats/yaml_parser.cpp b/yt/yt/library/formats/yaml_parser.cpp index 5e930f250e..21ac5a8901 100644 --- a/yt/yt/library/formats/yaml_parser.cpp +++ b/yt/yt/library/formats/yaml_parser.cpp @@ -128,7 +128,7 @@ public: { ForAllConsumers([] (auto* consumer) { consumer->OnEndAttributes(); }); --CurrentDepth_; - // NB: do not call MaybeFinishAnchorOrRun here, as we do not want to record only + // NB: Do not call MaybeFinishAnchorOrRun here, as we do not want to record only // attribute map part of the node. } diff --git a/yt/yt/library/formats/yaml_writer.cpp b/yt/yt/library/formats/yaml_writer.cpp index 3d2961d46a..7996675f78 100644 --- a/yt/yt/library/formats/yaml_writer.cpp +++ b/yt/yt/library/formats/yaml_writer.cpp @@ -210,7 +210,7 @@ public: virtual void OnBeginAttributes() override { - // NB: node with attributes in YAML is represented as a yt/attrnode-tagged 2-item sequence. + // NB: Node with attributes in YAML is represented as a yt/attrnode-tagged 2-item sequence. OnNodeEnter(); EmitEvent( yaml_sequence_start_event_initialize, diff --git a/yt/yt/library/process/process.cpp b/yt/yt/library/process/process.cpp index 406040419a..3895c688b7 100644 --- a/yt/yt/library/process/process.cpp +++ b/yt/yt/library/process/process.cpp @@ -615,7 +615,7 @@ private: #else pid_t DoSpawnChildVFork() { - // NB: fork() copy-on-write cause undefined behaviour when run concurrently with + // NB: Fork() copy-on-write cause undefined behaviour when run concurrently with // Disk IO on O_DIRECT file descriptor. vfork don't suffer from the same issue. // NB: vfork() blocks parent until child executes new program or exits. int pid = vfork(); diff --git a/yt/yt/library/tracing/ya.make b/yt/yt/library/tracing/ya.make index 793497e270..aae64984fe 100644 --- a/yt/yt/library/tracing/ya.make +++ b/yt/yt/library/tracing/ya.make @@ -26,7 +26,7 @@ RECURSE( ) IF (NOT OPENSOURCE) - # NB: default-linux-x86_64-relwithdebinfo-opensource build does not support python programs and modules. + # NB: Default-linux-x86_64-relwithdebinfo-opensource build does not support python programs and modules. RECURSE( integration py |