Skip to content
Merged
Show file tree
Hide file tree
Changes from all commits
Commits
File filter

Filter by extension

Filter by extension

Conversations
Failed to load comments.
Loading
Jump to
Jump to file
Failed to load files.
Loading
Diff view
Diff view
4 changes: 0 additions & 4 deletions pkg/crosscluster/logical/lww_row_processor.go
Original file line number Diff line number Diff line change
Expand Up @@ -407,10 +407,6 @@ var (
// Use generic query plans since our queries are extremely simple and
// won't benefit from custom plans.
PlanCacheMode: &forceGenericPlan,
// We've observed in the CPU profiles that the default goroutine stack
// of the connExecutor goroutine is insufficient for evaluation of the
// ingestion queries, so we grow the stack right away to 32KiB.
GrowStackSize: true,
// We don't get any benefits from generating plan gists for internal
// queries, so we disable them.
DisablePlanGists: true,
Expand Down
1 change: 0 additions & 1 deletion pkg/sql/BUILD.bazel
Original file line number Diff line number Diff line change
Expand Up @@ -575,7 +575,6 @@ go_library(
"//pkg/util/errorutil",
"//pkg/util/errorutil/unimplemented",
"//pkg/util/fsm",
"//pkg/util/growstack",
"//pkg/util/grpcutil",
"//pkg/util/grunning",
"//pkg/util/hlc",
Expand Down
10 changes: 1 addition & 9 deletions pkg/sql/internal.go
Original file line number Diff line number Diff line change
Expand Up @@ -39,7 +39,6 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/sqltelemetry"
"github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/fsm"
"github.com/cockroachdb/cockroach/pkg/util/growstack"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/mon"
"github.com/cockroachdb/cockroach/pkg/util/retry"
Expand Down Expand Up @@ -223,7 +222,6 @@ func (ie *InternalExecutor) runWithEx(
syncCallback func([]*streamingCommandResult),
errCallback func(error),
attributeToUser bool,
growStackSize bool,
) error {
ex, err := ie.initConnEx(ctx, txn, w, mode, sd, stmtBuf, syncCallback, attributeToUser)
if err != nil {
Expand Down Expand Up @@ -251,11 +249,6 @@ func (ie *InternalExecutor) runWithEx(
go func() {
defer hdl.Activate(ctx).Release(ctx)
defer cleanup(ctx)
// TODO(yuzefovich): benchmark whether we should be growing the
// stack size unconditionally.
if growStackSize {
growstack.Grow()
}
if err := ex.run(
ctx,
ie.mon,
Expand Down Expand Up @@ -1196,7 +1189,6 @@ func (ie *InternalExecutor) execInternal(
txn.SetBufferedWritesEnabled(false)
}
attributeToUser := sessionDataOverride.AttributeToUser && attributeToUserEnabled.Get(&ie.s.cfg.Settings.SV)
growStackSize := sessionDataOverride.GrowStackSize
if !rw.async() && (txn != nil && txn.Type() == kv.RootTxn) {
// If the "outer" query uses the RootTxn and the sync result channel is
// requested, then we must disable both DistSQL and Streamer to ensure
Expand Down Expand Up @@ -1308,7 +1300,7 @@ func (ie *InternalExecutor) execInternal(
errCallback := func(err error) {
_ = rw.addResult(ctx, ieIteratorResult{err: err})
}
err = ie.runWithEx(ctx, opName, txn, rw, mode, sd, stmtBuf, &wg, syncCallback, errCallback, attributeToUser, growStackSize)
err = ie.runWithEx(ctx, opName, txn, rw, mode, sd, stmtBuf, &wg, syncCallback, errCallback, attributeToUser)
if err != nil {
return nil, err
}
Expand Down
3 changes: 0 additions & 3 deletions pkg/sql/sessiondata/internal.go
Original file line number Diff line number Diff line change
Expand Up @@ -79,9 +79,6 @@ type InternalExecutorOverride struct {
OriginTimestampForLogicalDataReplication hlc.Timestamp
// PlanCacheMode, if set, overrides the plan_cache_mode session variable.
PlanCacheMode *sessiondatapb.PlanCacheMode
// GrowStackSize, if true, indicates that the connExecutor goroutine stack
// should be grown to 32KiB right away.
GrowStackSize bool
// DisablePlanGists, if true, overrides the disable_plan_gists session var.
DisablePlanGists bool
// BufferedWritesEnabled, if set, controls whether the buffered writes KV transaction
Expand Down