Skip to content

Commit 78cbed5

Browse files
craig[bot]arulajmani
andcommitted
Merge #153888
153888: kv: move various log lines from Dev to KvExec r=tbg a=arulajmani See individual commits. Informs #152584 `@nicktrav,` `@tbg` -- these commits migrate all the log lines that need to go into the KvExec channel from the spreadsheet `@kevin-v-ngo` shared with us and then some. Co-authored-by: Arul Ajmani <[email protected]>
2 parents 9469c4b + fd35fe3 commit 78cbed5

23 files changed

+66
-66
lines changed

pkg/kv/kvclient/kvcoord/dist_sender.go

Lines changed: 9 additions & 9 deletions
Original file line numberDiff line numberDiff line change
@@ -1049,7 +1049,7 @@ func (ds *DistSender) getRoutingInfo(
10491049
containsFn = (*roachpb.RangeDescriptor).ContainsKeyInverted
10501050
}
10511051
if !containsFn(returnToken.Desc(), descKey) {
1052-
log.Dev.Fatalf(ctx, "programming error: range resolution returning non-matching descriptor: "+
1052+
log.KvExec.Fatalf(ctx, "programming error: range resolution returning non-matching descriptor: "+
10531053
"desc: %s, key: %s, reverse: %t", returnToken.Desc(), descKey, redact.Safe(useReverseScan))
10541054
}
10551055
}
@@ -1284,7 +1284,7 @@ func (ds *DistSender) Send(
12841284
if len(parts) != 1 {
12851285
panic("EndTxn not in last chunk of batch")
12861286
} else if require1PC {
1287-
log.Dev.Fatalf(ctx, "required 1PC transaction cannot be split: %s", ba)
1287+
log.KvExec.Fatalf(ctx, "required 1PC transaction cannot be split: %s", ba)
12881288
}
12891289
parts = splitBatchAndCheckForRefreshSpans(ba, true /* split ET */)
12901290
onePart = false
@@ -2228,7 +2228,7 @@ func (ds *DistSender) sendPartialBatch(
22282228
{
22292229
var s redact.StringBuilder
22302230
slowRangeRPCWarningStr(&s, ba, dur, attempts, routingTok.Desc(), err, reply)
2231-
log.Dev.Warningf(ctx, "slow range RPC: %v", &s)
2231+
log.KvExec.Warningf(ctx, "slow range RPC: %v", &s)
22322232
}
22332233
// If the RPC wasn't successful, defer the logging of a message once the
22342234
// RPC is not retried any more.
@@ -2240,7 +2240,7 @@ func (ds *DistSender) sendPartialBatch(
22402240
ds.metrics.SlowRPCs.Dec(1)
22412241
var s redact.StringBuilder
22422242
slowRangeRPCReturnWarningStr(&s, tBegin.Elapsed(), attempts)
2243-
log.Dev.Warningf(ctx, "slow RPC response: %v", &s)
2243+
log.KvExec.Warningf(ctx, "slow RPC response: %v", &s)
22442244
}(tBegin, attempts)
22452245
}
22462246
tBegin = 0 // prevent reentering branch for this RPC
@@ -2333,7 +2333,7 @@ func (ds *DistSender) sendPartialBatch(
23332333
}
23342334

23352335
if pErr == nil {
2336-
log.Dev.Fatal(ctx, "exited retry loop without an error or early exit")
2336+
log.KvExec.Fatal(ctx, "exited retry loop without an error or early exit")
23372337
}
23382338

23392339
return response{pErr: pErr}
@@ -2563,7 +2563,7 @@ func (ds *DistSender) sendToReplicas(
25632563
case kvpb.RoutingPolicy_NEAREST:
25642564
replicaFilter = AllExtantReplicas
25652565
default:
2566-
log.Dev.Fatalf(ctx, "unknown routing policy: %s", ba.RoutingPolicy)
2566+
log.KvExec.Fatalf(ctx, "unknown routing policy: %s", ba.RoutingPolicy)
25672567
}
25682568
desc := routing.Desc()
25692569
replicas, err := NewReplicaSlice(ctx, ds.nodeDescs, desc, routing.Leaseholder(), replicaFilter)
@@ -2603,7 +2603,7 @@ func (ds *DistSender) sendToReplicas(
26032603
log.VEventf(ctx, 2, "routing to nearest replica; leaseholder not required order=%v", replicas)
26042604

26052605
default:
2606-
log.Dev.Fatalf(ctx, "unknown routing policy: %s", ba.RoutingPolicy)
2606+
log.KvExec.Fatalf(ctx, "unknown routing policy: %s", ba.RoutingPolicy)
26072607
}
26082608

26092609
// NB: upgrade the connection class to SYSTEM, for critical ranges. Set it to
@@ -2737,7 +2737,7 @@ func (ds *DistSender) sendToReplicas(
27372737
} else if routing.Leaseholder() == nil {
27382738
// NB: Normally we don't have both routeToLeaseholder and a nil
27392739
// leaseholder. This could be changed to an assertion.
2740-
log.Dev.Errorf(ctx, "attempting %v to route to leaseholder, but the leaseholder is unknown %v", ba, routing)
2740+
log.KvExec.Errorf(ctx, "attempting %v to route to leaseholder, but the leaseholder is unknown %v", ba, routing)
27412741
} else if ba.Replica.NodeID == routing.Leaseholder().NodeID {
27422742
// We are sending this request to the leaseholder, so it doesn't
27432743
// make sense to attempt to proxy it.
@@ -2780,7 +2780,7 @@ func (ds *DistSender) sendToReplicas(
27802780
if admissionpb.WorkPriority(ba.AdmissionHeader.Priority) >= admissionpb.NormalPri {
27812781
// Note that these RPC may or may not have succeeded. Errors are counted separately below.
27822782
ds.metrics.SlowReplicaRPCs.Inc(1)
2783-
log.Dev.Warningf(ctx, "slow replica RPC: %v", &s)
2783+
log.KvExec.Warningf(ctx, "slow replica RPC: %v", &s)
27842784
} else {
27852785
log.Eventf(ctx, "slow replica RPC: %v", &s)
27862786
}

pkg/kv/kvclient/kvcoord/dist_sender_mux_rangefeed.go

Lines changed: 8 additions & 8 deletions
Original file line numberDiff line numberDiff line change
@@ -66,10 +66,10 @@ func muxRangeFeed(
6666
eventCh chan<- RangeFeedMessage,
6767
) (retErr error) {
6868
if log.V(1) {
69-
log.Dev.Infof(ctx, "Establishing MuxRangeFeed (%s...; %d spans)", spans[0], len(spans))
69+
log.KvExec.Infof(ctx, "Establishing MuxRangeFeed (%s...; %d spans)", spans[0], len(spans))
7070
start := timeutil.Now()
7171
defer func() {
72-
log.Dev.Infof(ctx, "MuxRangeFeed terminating after %s with err=%v", timeutil.Since(start), retErr)
72+
log.KvExec.Infof(ctx, "MuxRangeFeed terminating after %s with err=%v", timeutil.Since(start), retErr)
7373
}()
7474
}
7575

@@ -381,10 +381,10 @@ func (m *rangefeedMuxer) startNodeMuxRangeFeed(
381381
defer restore()
382382

383383
if log.V(1) {
384-
log.Dev.Infof(ctx, "Establishing MuxRangeFeed to node %d", nodeID)
384+
log.KvExec.Infof(ctx, "Establishing MuxRangeFeed to node %d", nodeID)
385385
start := timeutil.Now()
386386
defer func() {
387-
log.Dev.Infof(ctx, "MuxRangeFeed to node %d terminating after %s with err=%v",
387+
log.KvExec.Infof(ctx, "MuxRangeFeed to node %d terminating after %s with err=%v",
388388
nodeID, timeutil.Since(start), retErr)
389389
}()
390390
}
@@ -403,7 +403,7 @@ func (m *rangefeedMuxer) startNodeMuxRangeFeed(
403403
maybeCloseClient := func() {
404404
if closer, ok := mux.(io.Closer); ok {
405405
if err := closer.Close(); err != nil {
406-
log.Dev.Warningf(ctx, "error closing mux rangefeed client: %v", err)
406+
log.KvExec.Warningf(ctx, "error closing mux rangefeed client: %v", err)
407407
}
408408
}
409409
}
@@ -442,7 +442,7 @@ func (m *rangefeedMuxer) startNodeMuxRangeFeed(
442442
}
443443

444444
if log.V(1) {
445-
log.Dev.Infof(ctx, "mux to node %d restarted %d streams", ms.nodeID, len(toRestart))
445+
log.KvExec.Infof(ctx, "mux to node %d restarted %d streams", ms.nodeID, len(toRestart))
446446
}
447447
return m.restartActiveRangeFeeds(ctx, recvErr, toRestart)
448448
}
@@ -471,7 +471,7 @@ func (m *rangefeedMuxer) receiveEventsFromNode(
471471
// additional event(s) arriving for a stream that is no longer active.
472472
if active == nil {
473473
if log.V(1) {
474-
log.Dev.Infof(ctx, "received stray event stream %d: %v", event.StreamID, event)
474+
log.KvExec.Infof(ctx, "received stray event stream %d: %v", event.StreamID, event)
475475
}
476476
continue
477477
}
@@ -566,7 +566,7 @@ func (m *rangefeedMuxer) restartActiveRangeFeed(
566566
}
567567

568568
if log.V(1) {
569-
log.Dev.Infof(ctx, "RangeFeed %s@%s (r%d, replica %s) disconnected with last checkpoint %s ago: %v (errInfo %v)",
569+
log.KvExec.Infof(ctx, "RangeFeed %s@%s (r%d, replica %s) disconnected with last checkpoint %s ago: %v (errInfo %v)",
570570
active.Span, active.StartAfter, active.RangeID, active.ReplicaDescriptor,
571571
timeutil.Since(active.Resolved.GoTime()), reason, errInfo)
572572
}

pkg/kv/kvclient/kvcoord/txn_coord_sender.go

Lines changed: 9 additions & 9 deletions
Original file line numberDiff line numberDiff line change
@@ -239,10 +239,10 @@ func newRootTxnCoordSender(
239239
txn.AssertInitialized(context.TODO())
240240

241241
if txn.Status != roachpb.PENDING {
242-
log.Dev.Fatalf(context.TODO(), "unexpected non-pending txn in RootTransactionalSender: %s", txn)
242+
log.KvExec.Fatalf(context.TODO(), "unexpected non-pending txn in RootTransactionalSender: %s", txn)
243243
}
244244
if txn.Sequence != 0 {
245-
log.Dev.Fatalf(context.TODO(), "cannot initialize root txn with seq != 0: %s", txn)
245+
log.KvExec.Fatalf(context.TODO(), "cannot initialize root txn with seq != 0: %s", txn)
246246
}
247247

248248
tcs := &TxnCoordSender{
@@ -380,7 +380,7 @@ func newLeafTxnCoordSender(
380380
txn.AssertInitialized(context.TODO())
381381

382382
if txn.Status != roachpb.PENDING {
383-
log.Dev.Fatalf(context.TODO(), "unexpected non-pending txn in LeafTransactionalSender: %s", tis)
383+
log.KvExec.Fatalf(context.TODO(), "unexpected non-pending txn in LeafTransactionalSender: %s", tis)
384384
}
385385

386386
tcs := &TxnCoordSender{
@@ -537,7 +537,7 @@ func (tc *TxnCoordSender) Send(
537537

538538
// Associate the txnID with the trace.
539539
if tc.mu.txn.ID == (uuid.UUID{}) {
540-
log.Dev.Fatalf(ctx, "cannot send transactional request through unbound TxnCoordSender")
540+
log.KvExec.Fatalf(ctx, "cannot send transactional request through unbound TxnCoordSender")
541541
}
542542
if sp.IsVerbose() {
543543
sp.SetTag("txnID", attribute.StringValue(tc.mu.txn.ID.String()))
@@ -674,7 +674,7 @@ func (tc *TxnCoordSender) Send(
674674
// docs/RFCS/20200811_non_blocking_txns.md.
675675
func (tc *TxnCoordSender) maybeCommitWait(ctx context.Context, deferred bool) error {
676676
if tc.mu.txn.Status != roachpb.PREPARED && tc.mu.txn.Status != roachpb.COMMITTED {
677-
log.Dev.Fatalf(ctx, "maybeCommitWait called when not prepared/committed")
677+
log.KvExec.Fatalf(ctx, "maybeCommitWait called when not prepared/committed")
678678
}
679679
if tc.mu.commitWaitDeferred && !deferred {
680680
// If this is an automatic commit-wait call and the user of this
@@ -787,7 +787,7 @@ func (tc *TxnCoordSender) maybeRejectClientLocked(
787787
// unexpected for it to find the transaction already in a txnFinalized
788788
// state. This may be a bug, so log a stack trace.
789789
stack := debugutil.Stack()
790-
log.Dev.Errorf(ctx, "%s. stack:\n%s", msg, stack)
790+
log.KvExec.Errorf(ctx, "%s. stack:\n%s", msg, stack)
791791
}
792792
reason := kvpb.TransactionStatusError_REASON_UNKNOWN
793793
if tc.mu.txn.Status == roachpb.COMMITTED {
@@ -1028,7 +1028,7 @@ func (tc *TxnCoordSender) updateStateLocked(
10281028
if errTxnID != txnID {
10291029
// KV should not return errors for transactions other than the one in
10301030
// the BatchRequest.
1031-
log.Dev.Fatalf(ctx, "retryable error for the wrong txn. ba.Txn: %s. pErr: %s",
1031+
log.KvExec.Fatalf(ctx, "retryable error for the wrong txn. ba.Txn: %s. pErr: %s",
10321032
ba.Txn, pErr)
10331033
}
10341034
return kvpb.NewError(tc.handleRetryableErrLocked(ctx, pErr))
@@ -1095,7 +1095,7 @@ func sanityCheckErrWithTxn(
10951095
Detail: "you have encountered a known bug in CockroachDB, please consider " +
10961096
"reporting on the Github issue or reach out via Support.",
10971097
}))
1098-
log.Dev.Warningf(ctx, "%v", err)
1098+
log.KvExec.Warningf(ctx, "%v", err)
10991099
return err
11001100
}
11011101

@@ -1479,7 +1479,7 @@ func (tc *TxnCoordSender) UpdateRootWithLeafFinalState(
14791479
defer tc.mu.Unlock()
14801480

14811481
if tc.mu.txn.ID == (uuid.UUID{}) {
1482-
log.Dev.Fatalf(ctx, "cannot UpdateRootWithLeafFinalState on unbound TxnCoordSender. input id: %s", tfs.Txn.ID)
1482+
log.KvExec.Fatalf(ctx, "cannot UpdateRootWithLeafFinalState on unbound TxnCoordSender. input id: %s", tfs.Txn.ID)
14831483
}
14841484

14851485
// Sanity check: don't combine if the tfs is for a different txn ID.

pkg/kv/kvclient/kvcoord/txn_interceptor_heartbeater.go

Lines changed: 6 additions & 6 deletions
Original file line numberDiff line numberDiff line change
@@ -317,11 +317,11 @@ func (h *txnHeartbeater) closeLocked() {
317317
// startHeartbeatLoopLocked starts a heartbeat loop in a different goroutine.
318318
func (h *txnHeartbeater) startHeartbeatLoopLocked(ctx context.Context) {
319319
if h.loopInterval < 0 {
320-
log.Dev.Infof(ctx, "coordinator heartbeat loop disabled")
320+
log.KvExec.Infof(ctx, "coordinator heartbeat loop disabled")
321321
return
322322
}
323323
if h.mu.loopStarted {
324-
log.Dev.Fatal(ctx, "attempting to start a second heartbeat loop")
324+
log.KvExec.Fatal(ctx, "attempting to start a second heartbeat loop")
325325
}
326326
log.VEventf(ctx, 2, kvbase.SpawningHeartbeatLoopMsg)
327327
h.mu.loopStarted = true
@@ -459,15 +459,15 @@ func (h *txnHeartbeater) heartbeatLocked(ctx context.Context) bool {
459459
// client needs to send a rollback.
460460
return false
461461
case roachpb.COMMITTED:
462-
log.Dev.Fatalf(ctx, "txn committed but heartbeat loop hasn't been signaled to stop: %s", h.mu.txn)
462+
log.KvExec.Fatalf(ctx, "txn committed but heartbeat loop hasn't been signaled to stop: %s", h.mu.txn)
463463
default:
464-
log.Dev.Fatalf(ctx, "unexpected txn status in heartbeat loop: %s", h.mu.txn)
464+
log.KvExec.Fatalf(ctx, "unexpected txn status in heartbeat loop: %s", h.mu.txn)
465465
}
466466

467467
// Clone the txn in order to put it in the heartbeat request.
468468
txn := h.mu.txn.Clone()
469469
if txn.Key == nil {
470-
log.Dev.Fatalf(ctx, "attempting to heartbeat txn without anchor key: %v", txn)
470+
log.KvExec.Fatalf(ctx, "attempting to heartbeat txn without anchor key: %v", txn)
471471
}
472472
ba := &kvpb.BatchRequest{}
473473
ba.Txn = txn
@@ -632,7 +632,7 @@ func (h *txnHeartbeater) abortTxnAsyncLocked(ctx context.Context) {
632632
TaskName: taskName,
633633
})
634634
if err != nil {
635-
log.Dev.Warningf(ctx, "%v", err)
635+
log.KvExec.Warningf(ctx, "%v", err)
636636
h.metrics.AsyncRollbacksFailed.Inc(1)
637637
return
638638
}

pkg/kv/kvclient/kvcoord/txn_interceptor_pipeliner.go

Lines changed: 6 additions & 6 deletions
Original file line numberDiff line numberDiff line change
@@ -490,10 +490,10 @@ func (tp *txnPipeliner) attachLocksToEndTxn(
490490

491491
if log.V(3) {
492492
for _, intent := range et.LockSpans {
493-
log.Dev.Infof(ctx, "intent: [%s,%s)", intent.Key, intent.EndKey)
493+
log.KvExec.Infof(ctx, "intent: [%s,%s)", intent.Key, intent.EndKey)
494494
}
495495
for _, write := range et.InFlightWrites {
496-
log.Dev.Infof(ctx, "in-flight: %d:%s (%s)", write.Sequence, write.Key, write.Strength)
496+
log.KvExec.Infof(ctx, "in-flight: %d:%s (%s)", write.Sequence, write.Key, write.Strength)
497497
}
498498
}
499499
return ba, nil
@@ -736,7 +736,7 @@ func (tp *txnPipeliner) updateLockTracking(
736736
// fine for now, but we add some observability to be aware of this happening.
737737
if tp.ifWrites.byteSize() > maxBytes {
738738
if tp.inflightOverBudgetEveryN.ShouldLog() || log.ExpensiveLogEnabled(ctx, 2) {
739-
log.Dev.Warningf(ctx, "a transaction's in-flight writes and locking reads have "+
739+
log.KvExec.Warningf(ctx, "a transaction's in-flight writes and locking reads have "+
740740
"exceeded the intent tracking limit (kv.transaction.max_intents_bytes). "+
741741
"in-flight writes and locking reads size: %d bytes, txn: %s, ba: %s",
742742
tp.ifWrites.byteSize(), ba.Txn, ba.Summary())
@@ -748,7 +748,7 @@ func (tp *txnPipeliner) updateLockTracking(
748748
// number of ranged locking reads before sending the request.
749749
if rejectTxnMaxCount > 0 && tp.writeCount > rejectTxnMaxCount {
750750
if tp.inflightOverBudgetEveryN.ShouldLog() || log.ExpensiveLogEnabled(ctx, 2) {
751-
log.Dev.Warningf(ctx, "a transaction has exceeded the maximum number of writes "+
751+
log.KvExec.Warningf(ctx, "a transaction has exceeded the maximum number of writes "+
752752
"allowed by kv.transaction.max_intents_and_locks: "+
753753
"count: %d, txn: %s, ba: %s", tp.writeCount, ba.Txn, ba.Summary())
754754
}
@@ -782,7 +782,7 @@ func (tp *txnPipeliner) updateLockTracking(
782782
condensed := tp.lockFootprint.maybeCondense(ctx, tp.riGen, locksBudget)
783783
if condensed && !alreadyCondensed {
784784
if tp.condensedIntentsEveryN.ShouldLog() || log.ExpensiveLogEnabled(ctx, 2) {
785-
log.Dev.Warningf(ctx,
785+
log.KvExec.Warningf(ctx,
786786
"a transaction has hit the intent tracking limit (kv.transaction.max_intents_bytes); "+
787787
"is it a bulk operation? Intent cleanup will be slower. txn: %s ba: %s",
788788
ba.Txn, ba.Summary())
@@ -878,7 +878,7 @@ func (tp *txnPipeliner) updateLockTrackingInner(
878878
// Record any writes that were performed asynchronously. We'll
879879
// need to prove that these succeeded sometime before we commit.
880880
if span.EndKey != nil {
881-
log.Dev.Fatalf(ctx, "unexpected multi-key intent pipelined")
881+
log.KvExec.Fatalf(ctx, "unexpected multi-key intent pipelined")
882882
}
883883
tp.ifWrites.insert(span.Key, seq, str)
884884
} else {

pkg/kv/kvclient/kvcoord/txn_interceptor_write_buffer.go

Lines changed: 4 additions & 4 deletions
Original file line numberDiff line numberDiff line change
@@ -601,7 +601,7 @@ func (twb *txnWriteBuffer) adjustError(
601601
// For requests that were not transformed, attributing an error to them
602602
// shouldn't confuse the client.
603603
if baIdx == pErr.Index.Index && record.transformed {
604-
log.Dev.Warningf(ctx, "error index %d is part of a transformed request", pErr.Index.Index)
604+
log.KvExec.Warningf(ctx, "error index %d is part of a transformed request", pErr.Index.Index)
605605
pErr.Index = nil
606606
return pErr
607607
} else if baIdx == pErr.Index.Index {
@@ -626,7 +626,7 @@ func (twb *txnWriteBuffer) adjustErrorUponFlush(
626626
if pErr.Index.Index < int32(numBuffered) {
627627
// If the error belongs to a request because part of the buffer flush, nil
628628
// out the index.
629-
log.Dev.Warningf(ctx, "error index %d is part of the buffer flush", pErr.Index.Index)
629+
log.KvExec.Warningf(ctx, "error index %d is part of the buffer flush", pErr.Index.Index)
630630
pErr.Index = nil
631631
} else {
632632
// Otherwise, adjust the error index to hide the impact of any flushed
@@ -1313,7 +1313,7 @@ func (twb *txnWriteBuffer) mergeResponseWithRequestRecords(
13131313
ctx context.Context, rr requestRecords, br *kvpb.BatchResponse,
13141314
) (_ *kvpb.BatchResponse, pErr *kvpb.Error) {
13151315
if rr.Empty() && br == nil {
1316-
log.Dev.Fatal(ctx, "unexpectedly found no transformations and no batch response")
1316+
log.KvExec.Fatal(ctx, "unexpectedly found no transformations and no batch response")
13171317
} else if rr.Empty() {
13181318
return br, nil
13191319
}
@@ -1325,7 +1325,7 @@ func (twb *txnWriteBuffer) mergeResponseWithRequestRecords(
13251325
brResp := kvpb.ResponseUnion{}
13261326
if !record.stripped {
13271327
if len(br.Responses) == 0 {
1328-
log.Dev.Fatal(ctx, "unexpectedly found a non-stripped request and no batch response")
1328+
log.KvExec.Fatal(ctx, "unexpectedly found a non-stripped request and no batch response")
13291329
}
13301330
// If the request wasn't stripped from the batch we sent to KV, we
13311331
// received a response for it, which then needs to be combined with

pkg/kv/kvserver/batcheval/cmd_add_sstable.go

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -475,7 +475,7 @@ func computeSSTStatsDiffWithFallback(
475475
stats, err := storage.ComputeSSTStatsDiff(
476476
ctx, sst, readWriter, nowNanos, start, end)
477477
if errors.IsAny(err, storage.ComputeSSTStatsDiffReaderHasRangeKeys, storage.ComputeStatsDiffViolation) {
478-
log.Dev.Warningf(ctx, "computing SST stats as estimates because of ComputeSSTStatsDiff error: %s", err)
478+
log.KvExec.Warningf(ctx, "computing SST stats as estimates because of ComputeSSTStatsDiff error: %s", err)
479479
sstStats, err := computeSSTStats(ctx, sst, nowNanos)
480480
if err != nil {
481481
return enginepb.MVCCStats{}, errors.Wrap(err, "error computing SST stats during fallback")

pkg/kv/kvserver/batcheval/cmd_clear_range.go

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -201,7 +201,7 @@ func computeStatsDelta(
201201
// We only want to assert the correctness of stats that do not contain
202202
// estimates.
203203
if delta.ContainsEstimates == 0 && !delta.Equal(computed) {
204-
log.Dev.Fatalf(ctx, "fast-path MVCCStats computation gave wrong result: diff(fast, computed) = %s",
204+
log.KvExec.Fatalf(ctx, "fast-path MVCCStats computation gave wrong result: diff(fast, computed) = %s",
205205
pretty.Diff(delta, computed))
206206
}
207207
}

pkg/kv/kvserver/batcheval/cmd_end_transaction.go

Lines changed: 3 additions & 3 deletions
Original file line numberDiff line numberDiff line change
@@ -833,7 +833,7 @@ func updateFinalizedTxn(
833833
opts := storage.MVCCWriteOptions{Stats: ms, Category: fs.BatchEvalReadCategory}
834834
if !evalCtx.EvalKnobs().DisableTxnAutoGC && len(externalLocks) == 0 {
835835
if log.V(2) {
836-
log.Dev.Infof(ctx, "auto-gc'ed %s (%d locks)", txn.Short(), len(args.LockSpans))
836+
log.KvExec.Infof(ctx, "auto-gc'ed %s (%d locks)", txn.Short(), len(args.LockSpans))
837837
}
838838
if !recordAlreadyExisted {
839839
// Nothing to delete, so there's no use writing a deletion tombstone. This
@@ -956,7 +956,7 @@ func RunCommitTrigger(
956956
return res, nil
957957
}
958958

959-
log.Dev.Fatalf(ctx, "unknown commit trigger: %+v", ct)
959+
log.KvExec.Fatalf(ctx, "unknown commit trigger: %+v", ct)
960960
return result.Result{}, nil
961961
}
962962

@@ -1400,7 +1400,7 @@ func splitTriggerHelper(
14001400
return enginepb.MVCCStats{}, result.Result{}, errors.Wrap(err, "unable to load lease")
14011401
}
14021402
if leftLease.Empty() {
1403-
log.Dev.Fatalf(ctx, "LHS of split has no lease")
1403+
log.KvExec.Fatalf(ctx, "LHS of split has no lease")
14041404
}
14051405

14061406
// Copy the lease from the left-hand side of the split over to the

0 commit comments

Comments
 (0)