aboutsummaryrefslogtreecommitdiffstats
diff options
context:
space:
mode:
authorbabenko <babenko@yandex-team.com>2023-10-23 16:27:36 +0300
committerbabenko <babenko@yandex-team.com>2023-10-23 17:27:27 +0300
commit08405a23b9b6caeabe8d8e19f9d850b0fe4fe52e (patch)
treeb1e4e50d0c02d384f1d20be04c7235731504e257
parent646fa535280052a90a7bfee7769e93a53daa7bd0 (diff)
downloadydb-08405a23b9b6caeabe8d8e19f9d850b0fe4fe52e.tar.gz
YT-18571: Fix myriads of typos
-rw-r--r--yt/cpp/mapreduce/client/structured_table_formats.cpp2
-rw-r--r--yt/cpp/mapreduce/interface/client_method_options.h6
-rw-r--r--yt/cpp/mapreduce/interface/common.h2
-rw-r--r--yt/cpp/mapreduce/interface/config.h2
-rw-r--r--yt/cpp/mapreduce/interface/io.h2
-rw-r--r--yt/cpp/mapreduce/interface/operation.h12
-rw-r--r--yt/cpp/mapreduce/interface/protobuf_table_schema_ut.proto2
-rw-r--r--yt/cpp/mapreduce/interface/tvm.h2
-rw-r--r--yt/cpp/mapreduce/raw_client/raw_requests.cpp2
-rw-r--r--yt/yt/client/chunk_client/config.h4
-rw-r--r--yt/yt/core/logging/file_log_writer.cpp4
-rw-r--r--yt/yt/library/numeric/binary_search.h2
-rw-r--r--yt/yt/library/numeric/unittests/piecewise_linear_function_ut.cpp2
-rw-r--r--yt/yt/library/tracing/jaeger/tracer.cpp4
-rw-r--r--yt/yt/library/tracing/jaeger/tracer.h2
-rw-r--r--yt/yt/library/ytprof/heap_profiler.cpp2
-rw-r--r--yt/yt/library/ytprof/proto/profile.proto2
-rw-r--r--yt/yt/library/ytprof/signal_safe_profiler.cpp2
-rw-r--r--yt/yt_proto/yt/client/api/rpc_proxy/proto/api_service.proto2
-rw-r--r--yt/yt_proto/yt/client/hedging/proto/config.proto4
20 files changed, 31 insertions, 31 deletions
diff --git a/yt/cpp/mapreduce/client/structured_table_formats.cpp b/yt/cpp/mapreduce/client/structured_table_formats.cpp
index f277a8dabe4..b0038f7386c 100644
--- a/yt/cpp/mapreduce/client/structured_table_formats.cpp
+++ b/yt/cpp/mapreduce/client/structured_table_formats.cpp
@@ -466,7 +466,7 @@ std::pair<TFormat, TMaybe<TSmallJobFile>> TFormatBuilder::CreateNodeFormat(
ythrow TApiUsageError()
<< "Cannot derive exact " << type << " type for intermediate " << direction << " table for job "
<< TJobFactory::Get()->GetJobName(&job)
- << "; use one of TMapReduceOperationSpec::Hint* methods to specifiy intermediate table structure";
+ << "; use one of TMapReduceOperationSpec::Hint* methods to specify intermediate table structure";
}
[[noreturn]] static void ThrowUnexpectedDifferentDescriptors(
diff --git a/yt/cpp/mapreduce/interface/client_method_options.h b/yt/cpp/mapreduce/interface/client_method_options.h
index f6e9e5791ee..71b7332ecae 100644
--- a/yt/cpp/mapreduce/interface/client_method_options.h
+++ b/yt/cpp/mapreduce/interface/client_method_options.h
@@ -449,7 +449,7 @@ struct TIOOptions
/// This is advanced option.
///
/// If `CreateTransaction` is set to `false` reader/writer doesn't create internal transaction
- /// and doesn't lock table. This option is overriden (effectively `false`) for writers by
+ /// and doesn't lock table. This option is overridden (effectively `false`) for writers by
/// @ref NYT::TTableWriterOptions::SingleHttpRequest
///
/// WARNING: if `CreateTransaction` is `false`, read/write might become non-atomic.
@@ -509,7 +509,7 @@ struct TWriterOptions
/// Data is accumulated in memory buffer so in case error occurs data could be resended.
///
/// If `RetryBlockSize` is not set buffer size is set to `DesiredChunkSize`.
- /// If niether `RetryBlockSize` nor `DesiredChunkSize` is set size of buffer is 64MB.
+ /// If neither `RetryBlockSize` nor `DesiredChunkSize` is set size of buffer is 64MB.
///
/// @note Written chunks cannot be larger than size of this memory buffer.
///
@@ -799,7 +799,7 @@ struct TLockOptions
///
/// If `Waitable' is set to true Lock method will create
/// waitable lock, that will be taken once other transactions
- /// that hold lock to that node are commited / aborted.
+ /// that hold lock to that node are committed / aborted.
///
/// @note Lock method DOES NOT wait until lock is actually acquired.
/// Waiting should be done using corresponding methods of ILock.
diff --git a/yt/cpp/mapreduce/interface/common.h b/yt/cpp/mapreduce/interface/common.h
index 6d0543b7183..8358325a8d7 100644
--- a/yt/cpp/mapreduce/interface/common.h
+++ b/yt/cpp/mapreduce/interface/common.h
@@ -1163,7 +1163,7 @@ TRichYPath MaybeWithSchema(const TRichYPath& path, const TSortColumns& sortBy =
/// - If path has associated range list and the list is not empty, function returns this list.
/// - If path has associated range list and this list is empty, exception is thrown.
///
-/// Before YT-17683 RichYPath didn't support empty range list and empty range actualy meant universal range.
+/// Before YT-17683 RichYPath didn't support empty range list and empty range actually meant universal range.
/// This function emulates this old behavior.
///
/// @see https://st.yandex-team.ru/YT-17683
diff --git a/yt/cpp/mapreduce/interface/config.h b/yt/cpp/mapreduce/interface/config.h
index f3f4cf2fe43..e0868b60b48 100644
--- a/yt/cpp/mapreduce/interface/config.h
+++ b/yt/cpp/mapreduce/interface/config.h
@@ -114,7 +114,7 @@ struct TConfig
//
// Infer schemas for nonexstent tables from typed rows (e.g. protobuf)
// when writing from operation or client writer.
- // This options can be overriden in TOperationOptions and TTableWriterOptions.
+ // This options can be overridden in TOperationOptions and TTableWriterOptions.
bool InferTableSchema;
bool UseClientProtobuf;
diff --git a/yt/cpp/mapreduce/interface/io.h b/yt/cpp/mapreduce/interface/io.h
index dbd3a2cb707..b601cf9a332 100644
--- a/yt/cpp/mapreduce/interface/io.h
+++ b/yt/cpp/mapreduce/interface/io.h
@@ -532,7 +532,7 @@ TTableReaderPtr<typename NDetail::TProtoOneOfUnique<Ts...>::TType> CreateProtoMu
const TTableReaderOptions& options = {});
///
-/// @brief Create a homogenous protobuf multi table reader from a stream.
+/// @brief Create a homogeneous protobuf multi table reader from a stream.
///
/// @tparam T Protobuf message type to read (must be inherited from `Message`).
///
diff --git a/yt/cpp/mapreduce/interface/operation.h b/yt/cpp/mapreduce/interface/operation.h
index 97d036180bb..9220bbc692d 100644
--- a/yt/cpp/mapreduce/interface/operation.h
+++ b/yt/cpp/mapreduce/interface/operation.h
@@ -322,7 +322,7 @@ struct TSimpleRawOperationIoSpec
/// @brief Describes format for both input and output.
///
- /// @note `Format' is overriden by `InputFormat' and `OutputFormat'.
+ /// @note `Format' is overridden by `InputFormat' and `OutputFormat'.
FLUENT_FIELD_OPTION(TFormat, Format);
/// Describes input format.
@@ -344,7 +344,7 @@ public:
/// @brief Describes format for both input and output of mapper.
///
- /// @note `MapperFormat' is overriden by `MapperInputFormat' and `MapperOutputFormat'.
+ /// @note `MapperFormat' is overridden by `MapperInputFormat' and `MapperOutputFormat'.
FLUENT_FIELD_OPTION(TFormat, MapperFormat);
/// Describes mapper input format.
@@ -355,7 +355,7 @@ public:
/// @brief Describes format for both input and output of reduce combiner.
///
- /// @note `ReduceCombinerFormat' is overriden by `ReduceCombinerInputFormat' and `ReduceCombinerOutputFormat'.
+ /// @note `ReduceCombinerFormat' is overridden by `ReduceCombinerInputFormat' and `ReduceCombinerOutputFormat'.
FLUENT_FIELD_OPTION(TFormat, ReduceCombinerFormat);
/// Describes reduce combiner input format.
@@ -366,7 +366,7 @@ public:
/// @brief Describes format for both input and output of reducer.
///
- /// @note `ReducerFormat' is overriden by `ReducerInputFormat' and `ReducerOutputFormat'.
+ /// @note `ReducerFormat' is overridden by `ReducerInputFormat' and `ReducerOutputFormat'.
FLUENT_FIELD_OPTION(TFormat, ReducerFormat);
/// Describes reducer input format.
@@ -703,7 +703,7 @@ struct TJobProfilerSpec
/// @brief Type of the profiler.
FLUENT_FIELD_OPTION(EProfilerType, ProfilerType);
- /// @brief Probabiliy of the job being selected for profiling.
+ /// @brief Probability of the job being selected for profiling.
FLUENT_FIELD_OPTION(double, ProfilingProbability);
/// @brief For sampling profilers, sets the number of samples per second.
@@ -2001,7 +2001,7 @@ public:
///
/// @brief This methods are called when creating table reader and writer for the job.
///
- /// Override them if you want to implement custom input logic. (e.g. addtitional bufferization)
+ /// Override them if you want to implement custom input logic. (e.g. additional bufferization)
virtual TRawTableReaderPtr CreateCustomRawJobReader(int fd) const;
virtual THolder<IProxyOutput> CreateCustomRawJobWriter(size_t outputTableCount) const;
diff --git a/yt/cpp/mapreduce/interface/protobuf_table_schema_ut.proto b/yt/cpp/mapreduce/interface/protobuf_table_schema_ut.proto
index 60bad6e650c..da1e48f691b 100644
--- a/yt/cpp/mapreduce/interface/protobuf_table_schema_ut.proto
+++ b/yt/cpp/mapreduce/interface/protobuf_table_schema_ut.proto
@@ -390,7 +390,7 @@ message TEmbedded1Message {
string str_variant = 101;
uint64 uint_variant = 102;
}
- optional uint64 embedded_num = 10; // make intensional field_num collision!
+ optional uint64 embedded_num = 10; // make intentional field_num collision!
optional string embedded_extra_field = 11;
}
diff --git a/yt/cpp/mapreduce/interface/tvm.h b/yt/cpp/mapreduce/interface/tvm.h
index d8d16d841b2..e1134e3c6e1 100644
--- a/yt/cpp/mapreduce/interface/tvm.h
+++ b/yt/cpp/mapreduce/interface/tvm.h
@@ -10,7 +10,7 @@ namespace NYT::NAuth {
/// This wrapper is required because NYT::NAuth::IServiceTicketAuthPtr is NYT::TIntrusivePtr,
/// and, if we used this pointer in interfaces of `mapreduce/yt` client, a lot of users of this library
-/// could get unexpected build errors that `TIntrusivePtr` is ambigious
+/// could get unexpected build errors that `TIntrusivePtr` is ambiguous
/// (from `::` namespace and from `::NYT::` namespace).
/// So we use this wrapper in our interfaces to avoid such problems for users.
struct IServiceTicketAuthPtrWrapper
diff --git a/yt/cpp/mapreduce/raw_client/raw_requests.cpp b/yt/cpp/mapreduce/raw_client/raw_requests.cpp
index 4a7304572b7..a1bcf5989b3 100644
--- a/yt/cpp/mapreduce/raw_client/raw_requests.cpp
+++ b/yt/cpp/mapreduce/raw_client/raw_requests.cpp
@@ -306,7 +306,7 @@ TOperationAttributes ParseOperationAttributes(const TNode& node)
if (auto typeNode = mapNode.FindPtr("type")) {
result.Type = FromString<EOperationType>(typeNode->AsString());
} else if (auto operationTypeNode = mapNode.FindPtr("operation_type")) {
- // COMPAT(levysotsky): "operation_type" is a deprecated synonim for "type".
+ // COMPAT(levysotsky): "operation_type" is a deprecated synonym for "type".
// This branch should be removed when all clusters are updated.
result.Type = FromString<EOperationType>(operationTypeNode->AsString());
}
diff --git a/yt/yt/client/chunk_client/config.h b/yt/yt/client/chunk_client/config.h
index 24726928600..5a28cb0750c 100644
--- a/yt/yt/client/chunk_client/config.h
+++ b/yt/yt/client/chunk_client/config.h
@@ -481,10 +481,10 @@ public:
//! will stop being accessed within periodic updates and then will be evicted via expiring cache logic.
TDuration ChunkInfoCacheExpirationTimeout;
- //! Upper bound on length of simultaneously requested fragments withing a reading session.
+ //! Upper bound on length of simultaneously requested fragments within a reading session.
i64 MaxInflightFragmentLength;
- //! Upper bound on count of simultaneously requested fragments withing a reading session.
+ //! Upper bound on count of simultaneously requested fragments within a reading session.
i64 MaxInflightFragmentCount;
REGISTER_YSON_STRUCT(TChunkFragmentReaderConfig);
diff --git a/yt/yt/core/logging/file_log_writer.cpp b/yt/yt/core/logging/file_log_writer.cpp
index 191d39b7f9d..d94293fd185 100644
--- a/yt/yt/core/logging/file_log_writer.cpp
+++ b/yt/yt/core/logging/file_log_writer.cpp
@@ -230,7 +230,7 @@ private:
auto count = GetFileCountToKeep(fileNames);
for (int index = count; index < ssize(fileNames); ++index) {
auto filePath = NFS::CombinePaths(DirectoryName_, fileNames[index]);
- YT_LOG_DEBUG("Remove log segement (FilePath: %v)", filePath);
+ YT_LOG_DEBUG("Remove log segment (FilePath: %v)", filePath);
NFS::Remove(filePath);
}
fileNames.resize(count);
@@ -289,7 +289,7 @@ private:
auto newFileName = Format(formatString, FileNamePrefix_, index);
auto oldPath = NFS::CombinePaths(DirectoryName_, fileNames[index - 1]);
auto newPath = NFS::CombinePaths(DirectoryName_, newFileName);
- YT_LOG_DEBUG("Rename log segement (OldFilePath: %v, NewFilePath: %v)", oldPath, newPath);
+ YT_LOG_DEBUG("Rename log segment (OldFilePath: %v, NewFilePath: %v)", oldPath, newPath);
NFS::Rename(oldPath, newPath);
}
}
diff --git a/yt/yt/library/numeric/binary_search.h b/yt/yt/library/numeric/binary_search.h
index d8a695a08b8..c0376602ad5 100644
--- a/yt/yt/library/numeric/binary_search.h
+++ b/yt/yt/library/numeric/binary_search.h
@@ -28,7 +28,7 @@ constexpr TInt IntegerLowerBound(TInt lo, TInt hi, TPredicate&& predicate);
// Return the highest integer value in [|lo|, |hi|] satisfying the predicate.
// |lo| must not be greater than |hi|.
-// |predicate| must be monotonous and determenistic, and |predicate(lo)| must be satisfied.
+// |predicate| must be monotonous and deterministic, and |predicate(lo)| must be satisfied.
// |predicate(IntegerInverseLowerBound(lo, hi, predicate))| is guaranteed to be satisfied.
// Note that if |predicate(hi)| is satisfied, |hi| is returned.
// The behaviour is undefined if |predicate| is not monotonous or not deterministic.
diff --git a/yt/yt/library/numeric/unittests/piecewise_linear_function_ut.cpp b/yt/yt/library/numeric/unittests/piecewise_linear_function_ut.cpp
index a77a3f7600e..2fb87e43176 100644
--- a/yt/yt/library/numeric/unittests/piecewise_linear_function_ut.cpp
+++ b/yt/yt/library/numeric/unittests/piecewise_linear_function_ut.cpp
@@ -1031,7 +1031,7 @@ TEST_F(TPiecewiseLinearFunctionTest, TestTransformations)
/* ExpectedTransposedFunction */ TPiecewiseLinearFunction<double>::Linear(42, 0.1, 42, 1.2),
},
{
- /* Name */ "discontinous",
+ /* Name */ "discontinuous",
/* Function */ BuildFunctionFromPoints<double>({{0, 0}, {1, 1}, {1, 2}, {2, 3}}),
/* ExpectedTransposedFunction */ BuildFunctionFromPoints<double>({{0, 0}, {1, 1}, {2, 1}, {3, 2}}),
},
diff --git a/yt/yt/library/tracing/jaeger/tracer.cpp b/yt/yt/library/tracing/jaeger/tracer.cpp
index 54a00e50054..25dc484e1f8 100644
--- a/yt/yt/library/tracing/jaeger/tracer.cpp
+++ b/yt/yt/library/tracing/jaeger/tracer.cpp
@@ -529,7 +529,7 @@ void TJaegerTracer::Flush()
DequeueAll(config);
- if (TInstant::Now() - LastSuccessfullFlushTime_ > config->QueueStallTimeout) {
+ if (TInstant::Now() - LastSuccessfulFlushTime_ > config->QueueStallTimeout) {
DropFullQueue();
}
@@ -575,7 +575,7 @@ void TJaegerTracer::Flush()
if (channel.Push(batches, spanCount)) {
DropQueue(batchCount, endpoint);
YT_LOG_DEBUG("Spans sent (Endpoint: %v)", endpoint);
- LastSuccessfullFlushTime_ = flushStartTime;
+ LastSuccessfulFlushTime_ = flushStartTime;
}
}
diff --git a/yt/yt/library/tracing/jaeger/tracer.h b/yt/yt/library/tracing/jaeger/tracer.h
index adf32c11d24..fadc9a1703d 100644
--- a/yt/yt/library/tracing/jaeger/tracer.h
+++ b/yt/yt/library/tracing/jaeger/tracer.h
@@ -164,7 +164,7 @@ private:
TMpscStack<TTraceContextPtr> TraceQueue_;
- TInstant LastSuccessfullFlushTime_ = TInstant::Now();
+ TInstant LastSuccessfulFlushTime_ = TInstant::Now();
THashMap<TString, TBatchInfo> BatchInfo_;
i64 TotalMemory_ = 0;
diff --git a/yt/yt/library/ytprof/heap_profiler.cpp b/yt/yt/library/ytprof/heap_profiler.cpp
index 70f5d9ece6e..666491a0f65 100644
--- a/yt/yt/library/ytprof/heap_profiler.cpp
+++ b/yt/yt/library/ytprof/heap_profiler.cpp
@@ -236,7 +236,7 @@ int AbslStackUnwinder(
return count;
}
- // IP point's to return address. Substract 1 to get accurate line information for profiler.
+ // IP point's to return address. Subtract 1 to get accurate line information for profiler.
frames[i] = reinterpret_cast<void*>(reinterpret_cast<uintptr_t>(cursor.GetCurrentIP()) - 1);
count++;
diff --git a/yt/yt/library/ytprof/proto/profile.proto b/yt/yt/library/ytprof/proto/profile.proto
index 18eaba3e56a..89f7ffe5bc4 100644
--- a/yt/yt/library/ytprof/proto/profile.proto
+++ b/yt/yt/library/ytprof/proto/profile.proto
@@ -76,7 +76,7 @@ message Profile {
int64 time_nanos = 9;
// Duration of the profile, if a duration makes sense.
int64 duration_nanos = 10;
- // The kind of events between sampled ocurrences.
+ // The kind of events between sampled occurrences.
// e.g [ "cpu","cycles" ] or [ "heap","bytes" ]
ValueType period_type = 11;
// The number of events between sampled occurrences.
diff --git a/yt/yt/library/ytprof/signal_safe_profiler.cpp b/yt/yt/library/ytprof/signal_safe_profiler.cpp
index 4312e7527a2..754ceb26c3d 100644
--- a/yt/yt/library/ytprof/signal_safe_profiler.cpp
+++ b/yt/yt/library/ytprof/signal_safe_profiler.cpp
@@ -195,7 +195,7 @@ void TSignalSafeProfiler::RecordSample(NBacktrace::TFramePointerCursor* cursor,
if (count != 0) {
// First IP points to next executing instruction.
// All other IP's are return addresses.
- // Substract 1 to get accurate line information for profiler.
+ // Subtract 1 to get accurate line information for profiler.
ip = reinterpret_cast<const void*>(reinterpret_cast<uintptr_t>(ip) - 1);
}
diff --git a/yt/yt_proto/yt/client/api/rpc_proxy/proto/api_service.proto b/yt/yt_proto/yt/client/api/rpc_proxy/proto/api_service.proto
index 4341707185d..9cad3e691a3 100644
--- a/yt/yt_proto/yt/client/api/rpc_proxy/proto/api_service.proto
+++ b/yt/yt_proto/yt/client/api/rpc_proxy/proto/api_service.proto
@@ -319,7 +319,7 @@ message TRowsetDescriptor
optional TTableSchema schema = 5;
}
-// Could be embedded into response attachement block sequence along with the actual data
+// Could be embedded into response attachment block sequence along with the actual data
// to indidate the progress of table reader/writer.
message TRowsetStatistics
{
diff --git a/yt/yt_proto/yt/client/hedging/proto/config.proto b/yt/yt_proto/yt/client/hedging/proto/config.proto
index b836276b49f..4f088c37cb1 100644
--- a/yt/yt_proto/yt/client/hedging/proto/config.proto
+++ b/yt/yt_proto/yt/client/hedging/proto/config.proto
@@ -28,7 +28,7 @@ message TReplicationLagPenaltyProviderConfig
optional string TablePath = 2; // Table that needs checks for replication lag.
optional uint32 LagPenalty = 3 [default = 10]; // penalty in milliseconds, same as BanPenalty in THedgingClientConfig.
optional uint32 MaxTabletLag = 4 [default = 300]; // Tablet is considered "lagged" if CurrentTimestamp - TabletLastReplicationTimestamp >= MaxTabletLag (in seconds).
- optional float MaxTabletsWithLagFraction = 5 [default = 0.05]; // Real value from 0.0 to 1.0. Replica cluster recieves LagPenalty if NumberOfTabletsWithLag >= MaxTabletsWithLagFraction * TotalNumberOfTablets.
+ optional float MaxTabletsWithLagFraction = 5 [default = 0.05]; // Real value from 0.0 to 1.0. Replica cluster receives LagPenalty if NumberOfTabletsWithLag >= MaxTabletsWithLagFraction * TotalNumberOfTablets.
optional uint32 CheckPeriod = 6 [default = 60]; // Replication lag check period (in seconds).
- optional bool ClearPenaltiesOnErrors = 7 [default = false]; // In case of any erros from master client - clear all penalties.
+ optional bool ClearPenaltiesOnErrors = 7 [default = false]; // In case of any errors from master client - clear all penalties.
}